A B C D E F G H I J K L M N O P Q R S T U V W X Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- ABORT_RATE - org.infinispan.stats.container.ExtendedStatistic
- AbstractApplicationPublisherBridge - Class in org.infinispan.spring.session
-
A bridge for passing events between Infinispan (both embedded and remote) and Spring.
- AbstractApplicationPublisherBridge(SpringCache) - Constructor for class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- AbstractCacheEventFilterConverter<K,V,C> - Class in org.infinispan.notifications.cachelistener.filter
-
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
- AbstractCacheIgnoreAware - Class in org.infinispan.server.core
-
Abstract class providing stock implementations for
CacheIgnoreAware
so all that is required is to extend this class. - AbstractCacheIgnoreAware() - Constructor for class org.infinispan.server.core.AbstractCacheIgnoreAware
- AbstractClusteringDependentLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- AbstractComponentFactory - Class in org.infinispan.factories
-
Factory that creates components used internally within Infinispan, and also wires dependencies into the components.
- AbstractComponentFactory() - Constructor for class org.infinispan.factories.AbstractComponentFactory
- AbstractComponentRegistry - Class in org.infinispan.factories
-
Deprecated.Since 9.4, please use
BasicComponentRegistry
instead. - AbstractComponentRegistry(ComponentMetadataRepo, ClassLoader, Scopes, BasicComponentRegistry) - Constructor for class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- AbstractComponentRegistry.Component - Class in org.infinispan.factories
-
Deprecated.A wrapper representing a component in the registry
- AbstractControlledLocalTopologyManager - Class in org.infinispan.util
-
Class to be extended to allow some control over the local topology manager when testing Infinispan.
- AbstractControlledLocalTopologyManager(LocalTopologyManager) - Constructor for class org.infinispan.util.AbstractControlledLocalTopologyManager
- AbstractCounterConfiguration - Class in org.infinispan.counter.configuration
-
Base counter configuration with its name, initial value and
Storage
mode. - AbstractCustomFailurePolicy<K,V> - Class in org.infinispan.xsite
-
Support class for
CustomFailurePolicy
. - AbstractCustomFailurePolicy() - Constructor for class org.infinispan.xsite.AbstractCustomFailurePolicy
- AbstractCustomInterceptorsConfigurationChildBuilder - Class in org.infinispan.configuration.cache
- AbstractCustomInterceptorsConfigurationChildBuilder(CustomInterceptorsConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
- AbstractDelegatingAdvancedCache<K,V> - Class in org.infinispan
-
Deprecated.Extend from
AbstractDelegatingAdvancedCache
instead. This class will be removed in the future. - AbstractDelegatingAdvancedCache(AdvancedCache<K, V>) - Constructor for class org.infinispan.AbstractDelegatingAdvancedCache
-
Deprecated.
- AbstractDelegatingAdvancedCache(AdvancedCache<K, V>, AbstractDelegatingAdvancedCache.AdvancedCacheWrapper<K, V>) - Constructor for class org.infinispan.AbstractDelegatingAdvancedCache
-
Deprecated.
- AbstractDelegatingCache<K,V> - Class in org.infinispan
-
Deprecated.Extend from
AbstractDelegatingCache
instead. This class will be removed in the future. - AbstractDelegatingCache(Cache<K, V>) - Constructor for class org.infinispan.AbstractDelegatingCache
-
Deprecated.
- AbstractDelegatingCacheCollection<E> - Class in org.infinispan.util
- AbstractDelegatingCacheCollection() - Constructor for class org.infinispan.util.AbstractDelegatingCacheCollection
- AbstractDelegatingCacheSet<E> - Class in org.infinispan.util
-
Same as
AbstractDelegatingCacheCollection
except this method implements Set as well. - AbstractDelegatingCacheSet() - Constructor for class org.infinispan.util.AbstractDelegatingCacheSet
- AbstractDelegatingCacheStream<R> - Class in org.infinispan.util
-
Delegate that forwards all the of the method calls to the underlying cache stream.
- AbstractDelegatingCacheStream(CacheStream<R>) - Constructor for class org.infinispan.util.AbstractDelegatingCacheStream
- AbstractDelegatingCloseableIteratorCollection<E> - Class in org.infinispan.util
-
Delegating collection that produces closeable iterators and spliterators from the collection returned from
AbstractDelegatingCloseableIteratorCollection.delegate()
method. - AbstractDelegatingCloseableIteratorCollection() - Constructor for class org.infinispan.util.AbstractDelegatingCloseableIteratorCollection
- AbstractDelegatingCloseableIteratorSet<E> - Class in org.infinispan.util
- AbstractDelegatingCloseableIteratorSet() - Constructor for class org.infinispan.util.AbstractDelegatingCloseableIteratorSet
- AbstractDelegatingCollection<E> - Class in org.infinispan.commons.util
-
Delegating collection that delegates all calls to the collection returned from
AbstractDelegatingCollection.delegate()
- AbstractDelegatingCollection() - Constructor for class org.infinispan.commons.util.AbstractDelegatingCollection
- AbstractDelegatingConcurrentMap<K,V> - Class in org.infinispan.commons.util
- AbstractDelegatingConcurrentMap() - Constructor for class org.infinispan.commons.util.AbstractDelegatingConcurrentMap
- AbstractDelegatingEmbeddedCacheManager - Class in org.infinispan.manager
-
Deprecated.Extend from
AbstractDelegatingEmbeddedCacheManager
instead. This class will be removed in the future. - AbstractDelegatingEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.manager.AbstractDelegatingEmbeddedCacheManager
-
Deprecated.
- AbstractDelegatingHandler - Class in org.infinispan.remoting.inboundhandler
-
Class to be extended to allow some control over the
PerCacheInboundInvocationHandler
in tests. - AbstractDelegatingHandler(PerCacheInboundInvocationHandler) - Constructor for class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
- AbstractDelegatingMap<K,V> - Class in org.infinispan.commons.util
- AbstractDelegatingMap() - Constructor for class org.infinispan.commons.util.AbstractDelegatingMap
- AbstractDelegatingMarshaller - Class in org.infinispan.commons.marshall
-
With the introduction of global and cache marshallers, there's a need to separate marshallers but still rely on the same marshalling backend as previously.
- AbstractDelegatingMarshaller() - Constructor for class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- AbstractDelegatingSet<E> - Class in org.infinispan.commons.util
- AbstractDelegatingSet() - Constructor for class org.infinispan.commons.util.AbstractDelegatingSet
- AbstractDelegatingTransport - Class in org.infinispan.remoting.transport
-
Designed to be overwrite.
- AbstractDelegatingTransport(Transport) - Constructor for class org.infinispan.remoting.transport.AbstractDelegatingTransport
- AbstractEmbeddedCacheManagerFactory - Class in org.infinispan.spring
-
An abstract base class for factories creating cache managers that are backed by an EmbeddedCacheManager.
- AbstractEmbeddedCacheManagerFactory() - Constructor for class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
- AbstractEncoder1x - Class in org.infinispan.server.hotrod
-
Hot Rod encoder for protocol version 1.1
- AbstractEncoder1x() - Constructor for class org.infinispan.server.hotrod.AbstractEncoder1x
- AbstractEntrySizeCalculatorHelper<K,V> - Class in org.infinispan.commons.util
-
Abstract class that provides a method to round up to the nearest value of 8 which is important for most jvm when doing size calculations.
- AbstractEntrySizeCalculatorHelper() - Constructor for class org.infinispan.commons.util.AbstractEntrySizeCalculatorHelper
- AbstractExternalizer<T> - Class in org.infinispan.commons.marshall
-
Base class for
AdvancedExternalizer
implementations that offers default implementations for some of its methods. - AbstractExternalizer() - Constructor for class org.infinispan.commons.marshall.AbstractExternalizer
- AbstractFileLookup - Class in org.infinispan.commons.util
- AbstractFileLookup() - Constructor for class org.infinispan.commons.util.AbstractFileLookup
- AbstractGlobalModuleConfigurationBuilder - Class in org.infinispan.configuration.global
- AbstractGlobalModuleConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.configuration.global.AbstractGlobalModuleConfigurationBuilder
- AbstractGlobalTxExternalizer() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
- AbstractHotRodServerChildConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
-
AbstractHotRodServerChildConfigurationBuilder.
- AbstractHotRodServerChildConfigurationBuilder(HotRodServerChildConfigurationBuilder) - Constructor for class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
- AbstractInfinispanSessionRepository - Class in org.infinispan.spring.session
-
Infinispan implementation for Spring Session with basic functionality.
- AbstractInfinispanSessionRepository(SpringCache, AbstractApplicationPublisherBridge) - Constructor for class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- AbstractInternalCacheEntry - Class in org.infinispan.container.entries
-
An abstract internal cache entry that is typically stored in the data container
- AbstractInternalCacheEntry() - Constructor for class org.infinispan.container.entries.AbstractInternalCacheEntry
- AbstractInternalCacheEntry(Object) - Constructor for class org.infinispan.container.entries.AbstractInternalCacheEntry
- AbstractInvocationContextFactory - Class in org.infinispan.context
-
Deprecated.Since 9.0, this class is going to be moved to an internal package.
- AbstractInvocationContextFactory() - Constructor for class org.infinispan.context.AbstractInvocationContextFactory
-
Deprecated.
- AbstractIterator<E> - Class in org.infinispan.commons.util
-
Abstract iterator that allows overriding just the
AbstractIterator.getNext()
method to implement it. - AbstractIterator() - Constructor for class org.infinispan.commons.util.AbstractIterator
- AbstractJBossMarshaller - Class in org.infinispan.commons.marshall.jboss
-
Common parent for both embedded and standalone JBoss Marshalling-based marshallers.
- AbstractJBossMarshaller() - Constructor for class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- AbstractJBossMarshaller.DebuggingExceptionListener - Class in org.infinispan.commons.marshall.jboss
- AbstractJdbcStoreConfiguration - Class in org.infinispan.persistence.jdbc.configuration
- AbstractJdbcStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration, ConnectionFactoryConfiguration) - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- AbstractJdbcStoreConfigurationBuilder<T extends AbstractJdbcStoreConfiguration,S extends AbstractJdbcStoreConfigurationBuilder<T,S>> - Class in org.infinispan.persistence.jdbc.configuration
- AbstractJdbcStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- AbstractJdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Class in org.infinispan.persistence.jdbc.configuration
-
AbstractJdbcStoreConfigurationChildBuilder.
- AbstractJdbcStoreConfigurationChildBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
- AbstractJdbcStoreConfigurationSerializer - Class in org.infinispan.persistence.jdbc.configuration
-
AbstractJdbcStoreConfigurationSerializer.
- AbstractJdbcStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationSerializer
- AbstractJmxRegistration - Class in org.infinispan.jmx
-
Parent class for top level JMX component registration.
- AbstractJmxRegistration() - Constructor for class org.infinispan.jmx.AbstractJmxRegistration
- AbstractKeyValueFilterConverter<K,V,C> - Class in org.infinispan.filter
-
This is a base class that should be used when implementing a KeyValueFilterConverter that provides default implementations for the
KeyValueFilter.accept(Object, Object, org.infinispan.metadata.Metadata)
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
- AbstractLockingInterceptor - Class in org.infinispan.interceptors.locking
-
Base class for various locking interceptors in this package.
- AbstractLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- AbstractMap<K,V> - Class in org.infinispan.commons.util
-
Similar to the JDK's AbstractMap, this provides common functionality for custom map implementations.
- AbstractMap() - Constructor for class org.infinispan.commons.util.AbstractMap
- AbstractMap.SimpleEntry<K,V> - Class in org.infinispan.commons.util
- AbstractMarshaller - Class in org.infinispan.commons.marshall
-
Abstract Marshaller implementation containing shared implementations.
- AbstractMarshaller() - Constructor for class org.infinispan.commons.marshall.AbstractMarshaller
- AbstractMixedSiteStatus<E> - Class in org.infinispan.xsite.status
-
Abstract class to create mixed
SiteStatus
. - AbstractMixedSiteStatus(Collection<E>, Collection<E>) - Constructor for class org.infinispan.xsite.status.AbstractMixedSiteStatus
- AbstractModuleConfigurationBuilder - Class in org.infinispan.configuration.cache
-
AbstractModuleConfigurationBuilder.
- AbstractModuleConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractModuleConfigurationBuilder
- AbstractModuleLifecycle - Class in org.infinispan.lifecycle
-
Deprecated.since 9.1. Just implement
ModuleLifecycle
instead. - AbstractModuleLifecycle() - Constructor for class org.infinispan.lifecycle.AbstractModuleLifecycle
-
Deprecated.
- AbstractNamedCacheComponentFactory - Class in org.infinispan.factories
-
A component factory for creating components scoped per-cache.
- AbstractNamedCacheComponentFactory() - Constructor for class org.infinispan.factories.AbstractNamedCacheComponentFactory
- AbstractParserContext - Class in org.infinispan.configuration.parsing
- AbstractParserContext() - Constructor for class org.infinispan.configuration.parsing.AbstractParserContext
- AbstractPersistenceConfigurationChildBuilder - Class in org.infinispan.configuration.cache
-
AbstractPersistenceConfigurationChildBuilder.
- AbstractPersistenceConfigurationChildBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractPersistenceConfigurationChildBuilder
- AbstractProtocolServer<A extends ProtocolServerConfiguration> - Class in org.infinispan.server.core
-
A common protocol server dealing with common property parameter validation and assignment and transport lifecycle.
- AbstractProtocolServer(String) - Constructor for class org.infinispan.server.core.AbstractProtocolServer
- AbstractProtocolServerConfigurationChildBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>> - Class in org.infinispan.server.core.configuration
-
Helper
- AbstractProtocolServerConfigurationChildBuilder(ProtocolServerConfigurationChildBuilder<T, S>) - Constructor for class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- AbstractRemoteCacheManagerFactory - Class in org.infinispan.spring
-
An abstract base class for factories creating cache manager that are backed by an Infinispan RemoteCacheManager.
- AbstractRemoteCacheManagerFactory() - Constructor for class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- AbstractRemoteStoreConfigurationChildBuilder<S> - Class in org.infinispan.persistence.remote.configuration
-
AbstractRemoteStoreConfigurationChildBuilder.
- AbstractRemoteStoreConfigurationChildBuilder(RemoteStoreConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- AbstractRequest<T> - Class in org.infinispan.remoting.transport
-
A remote invocation request.
- AbstractRequest(long, ResponseCollector<T>, RequestRepository) - Constructor for class org.infinispan.remoting.transport.AbstractRequest
- AbstractRestStoreConfigurationChildBuilder<S> - Class in org.infinispan.persistence.rest.configuration
-
AbstractRestStoreConfigurationChildBuilder.
- AbstractRestStoreConfigurationChildBuilder(RestStoreConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- AbstractSecurityConfigurationChildBuilder - Class in org.infinispan.persistence.remote.configuration
-
AbstractSecurityConfigurationChildBuilder.
- AbstractSegmentedAdvancedLoadWriteStore<K,V> - Class in org.infinispan.persistence.support
-
Abstract segment loader writer that implements all the single key non segmented methods by invoking the segmented equivalent by passing in the segment returned from invoking
AbstractSegmentedAdvancedLoadWriteStore.getKeyMapper()
. - AbstractSegmentedAdvancedLoadWriteStore() - Constructor for class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
- AbstractSegmentedStoreConfiguration<T extends AbstractStoreConfiguration> - Class in org.infinispan.configuration.cache
-
Abstract store configuration that should be extended when the store configuration supports being segmented.
- AbstractSegmentedStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
- AbstractSiteStatusBuilder<E> - Class in org.infinispan.xsite.status
-
A
SiteStatus
builder based on its online and offline members. - AbstractSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.AbstractSiteStatusBuilder
- AbstractStoreConfiguration - Class in org.infinispan.configuration.cache
- AbstractStoreConfiguration(boolean, boolean, boolean, AsyncStoreConfiguration, SingletonStoreConfiguration, boolean, boolean, Properties) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfiguration
-
Deprecated.Use
instead
- AbstractStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfiguration
- AbstractStoreConfigurationBuilder<T extends StoreConfiguration,S extends AbstractStoreConfigurationBuilder<T,S>> - Class in org.infinispan.configuration.cache
- AbstractStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Deprecated.
- AbstractStoreConfigurationBuilder(PersistenceConfigurationBuilder, AttributeSet) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- AbstractStoreConfigurationChildBuilder<S> - Class in org.infinispan.configuration.cache
- AbstractStoreConfigurationChildBuilder(StoreConfigurationBuilder<? extends AbstractStoreConfiguration, ? extends StoreConfigurationBuilder<?, ?>>) - Constructor for class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- AbstractStoreSerializer - Class in org.infinispan.configuration.serializing
-
AbstractStoreSerializer.
- AbstractStoreSerializer() - Constructor for class org.infinispan.configuration.serializing.AbstractStoreSerializer
- AbstractTopologyAwareEncoder1x - Class in org.infinispan.server.hotrod
-
Hot Rod encoder for protocol version 1.1
- AbstractTopologyAwareEncoder1x() - Constructor for class org.infinispan.server.hotrod.AbstractTopologyAwareEncoder1x
- AbstractTransport - Class in org.infinispan.remoting.transport
-
Deprecated.Since 9.1, please implement
Transport
directly. - AbstractTransport() - Constructor for class org.infinispan.remoting.transport.AbstractTransport
-
Deprecated.
- AbstractTransportConfigurationChildBuilder - Class in org.infinispan.configuration.cache
- AbstractTransportConfigurationChildBuilder(TransactionConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AbstractTransportConfigurationChildBuilder
- AbstractTxLockingInterceptor - Class in org.infinispan.interceptors.locking
-
Base class for transaction based locking interceptors.
- AbstractTxLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
- AbstractTypedPropertiesConfiguration - Class in org.infinispan.commons.configuration
- AbstractTypedPropertiesConfiguration(Properties) - Constructor for class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
-
Deprecated.
- AbstractTypedPropertiesConfiguration(AttributeSet) - Constructor for class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
- AbstractUpdateCommand - Class in org.infinispan.query.indexmanager
-
Base class for index commands.
- AbstractUpdateCommand(ByteString) - Constructor for class org.infinispan.query.indexmanager.AbstractUpdateCommand
- accept(Object, Object, Metadata) - Method in class org.infinispan.filter.AcceptAllKeyValueFilter
- accept(Object, Object, Metadata, Object, Metadata, EventType) - Method in class org.infinispan.persistence.remote.upgrade.RemovedFilter
- accept(Object, Throwable) - Method in interface org.infinispan.scattered.BiasManager.Revocation
- accept(Supplier<PrimitiveIterator.OfInt>) - Method in interface org.infinispan.BaseCacheStream.SegmentCompletionListener
-
Invoked each time a given number of segments have completed and the terminal operation has consumed all entries in the given segment
- accept(K) - Method in class org.infinispan.filter.CollectionKeyFilter
- accept(K) - Method in class org.infinispan.filter.CompositeKeyFilter
- accept(K) - Method in interface org.infinispan.filter.KeyFilter
-
Deprecated.
- accept(K) - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter
- accept(K) - Method in class org.infinispan.persistence.PrimaryOwnerFilter
- accept(K, Object, Metadata, Object, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter
- accept(K, V, Metadata) - Method in class org.infinispan.filter.AbstractKeyValueFilterConverter
- accept(K, V, Metadata) - Method in class org.infinispan.filter.CompositeKeyValueFilter
- accept(K, V, Metadata) - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter
- accept(K, V, Metadata) - Method in interface org.infinispan.filter.KeyValueFilter
- accept(K, V, Metadata) - Method in class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter
- accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.AbstractCacheEventFilterConverter
- accept(K, V, Metadata, V, Metadata, EventType) - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventFilter
-
Whether or not this event should be raised to the listener it is attached to.
- accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.CompositeCacheEventFilter
- accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter
- accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
- accept(K, V, Metadata, V, Metadata, EventType) - Method in class org.infinispan.notifications.cachelistener.filter.PostCacheEventFilter
- accept(InvocationContext, VisitableCommand, Object) - Method in interface org.infinispan.interceptors.InvocationSuccessAction
-
Process the result from a successful invocation stage and possibly throw an exception.
- accept(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationFinallyAction
-
Process the result or the exception from an invocation stage and possibly throw an exception.
- accept(ScopedState) - Method in class org.infinispan.globalstate.ScopeFilter
- accept(KeyVisitor) - Method in class org.infinispan.lucene.ChunkCacheKey
- accept(KeyVisitor) - Method in class org.infinispan.lucene.FileCacheKey
- accept(KeyVisitor) - Method in class org.infinispan.lucene.FileListCacheKey
- accept(KeyVisitor) - Method in class org.infinispan.lucene.FileReadLockKey
- accept(KeyVisitor<T>) - Method in interface org.infinispan.lucene.IndexScopedKey
- accept(T, U, V) - Method in interface org.infinispan.util.function.TriConsumer
-
Performs this operation on the given arguments.
- ACCEPT_ALL_FILTER - Static variable in interface org.infinispan.filter.KeyFilter
-
Deprecated.
- ACCEPT_ALL_KEY_VALUE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- AcceptAllKeyValueFilter - Class in org.infinispan.filter
-
A key value filter that accepts all entries found.
- AcceptAllKeyValueFilter.Externalizer - Class in org.infinispan.filter
- ACCESS - org.infinispan.persistence.jdbc.DatabaseType
- ACCESS_ORDER - org.infinispan.commons.equivalence.EquivalentLinkedHashMap.IterationOrder
-
Deprecated.
- accessLogging() - Method in class org.infinispan.server.hotrod.HotRodServer
- AccessLoggingHeader - Class in org.infinispan.server.hotrod
- AccessLoggingHeader(HotRodHeader, Subject, Object, int, Temporal) - Constructor for class org.infinispan.server.hotrod.AccessLoggingHeader
- accumulator() - Method in class org.infinispan.commons.util.ArrayCollector
- ACQUIRE_TIMEOUT - org.infinispan.configuration.parsing.Attribute
- acquireAllLocks(List<Object>, boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
-
Acquires locks on keys passed in.
- ACQUIRED - org.infinispan.util.concurrent.locks.LockState
-
The lock owner left the queue and it is available to acquire the lock.
- acquireExclusiveTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
- acquireExclusiveTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- acquireGlobalLock(boolean, long) - Method in class org.infinispan.util.concurrent.locks.StripedLock
-
Acquires RL on all locks aggregated by this StripedLock, in the given timeout.
- acquireLock(Object, boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
-
Blocks until a lock is acquired.
- acquireLock(Object, boolean, long) - Method in class org.infinispan.util.concurrent.locks.StripedLock
- acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
-
Acquires a readlock on all chunks for this file, to make sure chunks are not deleted while iterating on the group.
- acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
-
Acquires a readlock, in order to prevent other invocations to
SegmentReadLocker.deleteOrReleaseReadLock(String)
from deleting the file. - acquireReadLock(String) - Method in class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
-
doesn't do anything and returns true
- acquireReadLock(String) - Method in interface org.infinispan.lucene.readlocks.SegmentReadLocker
-
Acquires a readlock, in order to prevent other invocations to
SegmentReadLocker.deleteOrReleaseReadLock(String)
from deleting the file. - acquireSharedTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
- acquireSharedTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- Action - Interface in org.infinispan.remoting.inboundhandler.action
-
An action represents a step in
PerCacheInboundInvocationHandler
. - ActionListener - Interface in org.infinispan.remoting.inboundhandler.action
-
A listener that is invoked when an
Action
is completed. - ActionSequencer - Class in org.infinispan.util.concurrent
-
Orders multiple actions/tasks based on a key.
- ActionSequencer(ExecutorService, boolean, TimeService) - Constructor for class org.infinispan.util.concurrent.ActionSequencer
- ActionState - Class in org.infinispan.remoting.inboundhandler.action
-
The state used by an
Action
. - ActionState(ReplicableCommand, int, long) - Constructor for class org.infinispan.remoting.inboundhandler.action.ActionState
- ActionStatus - Enum in org.infinispan.remoting.inboundhandler.action
-
The status for an
Action
. - ActivationManager - Interface in org.infinispan.eviction
-
Controls activation of cache entries that have been passivated.
- active - Variable in class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.Whether the the current cache is the coordinator and therefore SingletonStore is active.
- ACTIVE - org.infinispan.server.hotrod.tx.table.Status
-
The client transaction is being replayed.
- activeIterations() - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
- activeIterations() - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
- activePublisherInvocations() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
-
Returns how many publisher invocations are currently active.
- activeStatusChanged(boolean) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.Method called when the cache either becomes the coordinator or stops being the coordinator.
- actual - Variable in class org.infinispan.persistence.support.DelegatingCacheLoader
- actual - Variable in class org.infinispan.persistence.support.DelegatingCacheWriter
- actual - Variable in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- AdaptiveBufferSizePredictor - Class in org.infinispan.commons.marshall
-
The
BufferSizePredictor
that automatically increases and decreases the predicted buffer size on feed back. - AdaptiveBufferSizePredictor() - Constructor for class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
-
Creates a new predictor with the default parameters.
- AdaptiveBufferSizePredictor(int, int, int) - Constructor for class org.infinispan.commons.marshall.AdaptiveBufferSizePredictor
-
Creates a new predictor with the specified parameters.
- add(int) - Method in interface org.infinispan.commons.util.IntSet
-
Adds the given int to this set and returns
true
if it was set 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(E) - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Adds the specified element to this set if it is not already present.
- add(E) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- add(E) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- add(E) - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- add(E) - Method in class org.infinispan.commons.util.ForwardingList
- add(E) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- add(E) - Method in class org.infinispan.commons.util.ImmutableListCopy
- add(Integer) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- add(Integer) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- add(Object) - Method in class org.infinispan.commons.util.ArrayCollector
- add(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- add(Permission) - Method in class org.infinispan.security.CachePermissionCollection
- add(AtomicLongFieldUpdater<T>, T, long) - Method in class org.infinispan.commons.util.concurrent.StripedCounters
- add(List<Xid>) - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
- add(Listeners.ReadWriteListeners.ReadWriteListener<K, V>) - Method in interface org.infinispan.functional.Listeners.ReadWriteListeners
-
Add a read-write listener, and return an
AutoCloseable
instance that can be used to remove the listener registration. - add(Listeners.WriteListeners.WriteListener<K, V>) - Method in interface org.infinispan.functional.Listeners.WriteListeners
-
Add a write-only listener, and return an
AutoCloseable
instance that can be used to remove the listener registration. - add(ExtendedStatistic, double, boolean) - Method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- add(ExtendedStatistic, double, GlobalTransaction, boolean) - Method in class org.infinispan.stats.CacheStatisticManager
-
Adds a value to a statistic.
- add(R) - Method in class org.infinispan.util.CollectionMapper
- add(R) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- add(T) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- ADD_CLIENT_LISTENER - org.infinispan.server.hotrod.HotRodOperation
- ADD_CLIENT_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- addAdvancedExternalizer(int, AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
-
Helper method that allows for quick registration of an
AdvancedExternalizer
implementation alongside its corresponding identifier. - addAdvancedExternalizer(AdvancedExternalizer<T>) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
-
Helper method that allows for quick registration of an
AdvancedExternalizer
implementation alongside its corresponding identifier. - addAdvancedExternalizer(AdvancedExternalizer<T>...) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
-
Helper method that allows for quick registration of
AdvancedExternalizer
implementations. - addAll(int, Collection<? extends E>) - Method in class org.infinispan.commons.util.ForwardingList
- addAll(int, Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy
- addAll(int, Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
- addAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ForwardingList
- addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy
- addAll(Collection<? extends E>) - Method in class org.infinispan.commons.util.ImmutableListCopy.ImmutableSubList
- addAll(Collection<? extends Integer>) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- addAll(Collection<? extends Integer>) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- addAll(Collection<? extends R>) - Method in class org.infinispan.util.CollectionMapper
- addAll(Collection<? extends R>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- addAll(Collection<? extends T>) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- addAll(List<CorsConfig>) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- addAll(IntSet) - Method in class org.infinispan.commons.util.ImmutableIntSet
-
Deprecated.
- addAll(IntSet) - Method in interface org.infinispan.commons.util.IntSet
-
Adds all ints from the provided set into this one
- addAll(IntSet) - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- addAll(IntSet) - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- addAllowedMech(String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- addAndGet(long) - Method in interface org.infinispan.counter.api.StrongCounter
-
Atomically adds the given value and return the new value.
- addAndGet(long) - Method in interface org.infinispan.counter.api.SyncStrongCounter
- addBackup() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
- addBackupLockForKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- addCache(ByteString, Status) - Method in class org.infinispan.server.hotrod.tx.operation.CommitTransactionOperation
- addCache(ByteString, Status) - Method in class org.infinispan.server.hotrod.tx.operation.RollbackTransactionOperation
- addCache(ByteString, Status) - Method in interface org.infinispan.server.hotrod.tx.table.CacheNameCollector
-
Adds the cache name and the
SetDecisionFunction
return value. - addCacheDependency(String, String) - Method in class org.infinispan.manager.DefaultCacheManager
- addCacheDependency(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Add a dependency between two caches.
- AddCacheDependencyAction - Class in org.infinispan.security.actions
-
AddCacheDependencyAction.
- AddCacheDependencyAction(EmbeddedCacheManager, String, String) - Constructor for class org.infinispan.security.actions.AddCacheDependencyAction
- addCacheEventConverterFactory(String, CacheEventConverterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
- addCacheEventFilterConverterFactory(String, CacheEventFilterConverterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
- addCacheEventFilterFactory(String, CacheEventFilterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
- AddCacheManagerListenerAction - Class in org.infinispan.security.actions
-
CacheManagerAddListenerAction.
- AddCacheManagerListenerAction(EmbeddedCacheManager, Object) - Constructor for class org.infinispan.security.actions.AddCacheManagerListenerAction
- addCacheName(String, SiteStatus) - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
-
Adds the cache with the
SiteStatus
connection to the site. - addCacheStoreFactory(CacheStoreFactory) - Method in class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
-
Adds a new factory for processing.
- addCallback(InvocationContext, VisitableCommand, InvocationCallback) - Method in class org.infinispan.interceptors.InvocationStage
- addCallback(InvocationContext, VisitableCommand, InvocationCallback) - Method in class org.infinispan.interceptors.SyncInvocationStage
- addClasses(Class<?>...) - Method in class org.infinispan.commons.configuration.ClassWhiteList
- addClusteredLock() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
- addClusterLoader() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
-
Adds a cluster cache loader.
- addCoinToss(DldGlobalTransaction) - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- addContinuousQueryListener(String, Map<String, Object>, ContinuousQueryListener<K, C>) - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
-
Add a listener for a continuous query.
- addContinuousQueryListener(String, ContinuousQueryListener<K, C>) - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
-
Add a listener for a continuous query.
- addContinuousQueryListener(Query, ContinuousQueryListener<K, C>) - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
-
Add a listener for a continuous query.
- addCounterListener(byte[], byte, String, Channel, VersionedEncoder) - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
- addCustomCacheConfiguration(ConfigurationBuilder) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
-
Sets the
ConfigurationBuilder
to use when creating anEmbeddedCacheManager
. - addCustomConfiguration(ConfigurationBuilder) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
-
API to introduce a customised
ConfigurationBuilder
that will override the default configurations which are already available on this class. - addCustomGlobalConfiguration(GlobalConfigurationBuilder) - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
-
Sets the
GlobalConfigurationBuilder
to use when creating anEmbeddedCacheManager
. - addDependency(T, T) - Method in class org.infinispan.util.DependencyGraph
-
Add a dependency between two elements
- addErroneousAttribute(String) - Method in exception org.infinispan.commons.CacheConfigurationException
-
Deprecated.
- addEvents(Address, UUID, Collection<ClusterEvent<K, V>>, boolean) - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterEventManager
-
Adds additional cluster events that need to be sent remotely for an event originating locally.
- addException(Address, Exception) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
-
Process an exception from a target.
- addExecutorProperty(String, String) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
-
Add key/value property pair to this executor factory configuration
- addFailure(String, Throwable) - Method in exception org.infinispan.xsite.BackupFailureException
- addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.FilteringListenable
-
Registers a listener limiting the cache-entry specific events only to annotations that are passed in as parameter.
- addFilteredListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addFilteredListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
- addGet(Object, boolean) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
-
Adds the key to the read top-key.
- addGrouper(Grouper<?>) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
-
Add a grouper
- addHexByte(StringBuilder, byte) - Static method in class org.infinispan.commons.util.Util
- addIndexedEntity(Class<?>) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- addInterceptor() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
-
Adds a new custom interceptor definition, to be added to the cache when the cache is started.
- addInterceptor(AsyncInterceptor, int) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Inserts the given interceptor at the specified position in the chain (0 based indexing).
- addInterceptor(AsyncInterceptor, int) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- addInterceptor(CommandInterceptor, int) - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 9.0, use
AdvancedCache.getAsyncInterceptorChain()
instead. - addInterceptor(CommandInterceptor, int) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Inserts the given interceptor at the specified position in the chain (o based indexing).
- addInterceptorAfter(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Adds a new interceptor in list after an interceptor of a given type.
- addInterceptorAfter(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 9.0, use
AdvancedCache.getAsyncInterceptorChain()
instead. - addInterceptorAfter(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Adds a new interceptor in list after an interceptor of a given type.
- addInterceptorBefore(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Adds a new interceptor in list before an interceptor of a given type.
- addInterceptorBefore(AsyncInterceptor, Class<? extends AsyncInterceptor>) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 9.0, use
AdvancedCache.getAsyncInterceptorChain()
instead. - addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Adds a new interceptor in list after an interceptor of a given type.
- addInterceptorBefore(CommandInterceptor, Class<? extends CommandInterceptor>, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.
- addInUseBackupSite(String) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
-
Defines the site names, from the list of sites names defined within 'backups' element, to which this cache backups its data.
- addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in class org.infinispan.server.hotrod.HotRodServer
- addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
- addKeyValueFilterConverterFactory(String, KeyValueFilterConverterFactory) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
- addListener() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- addListener(Object) - Method in class org.infinispan.manager.DefaultCacheManager
- addListener(Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addListener(Object) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- addListener(Object) - Method in interface org.infinispan.notifications.Listenable
-
Adds a listener to the component.
- addListener(Object, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addListener(Object, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareListenable
-
Adds a listener along with a class loader to use for the invocation
- addListener(Object, KeyFilter<? super K>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addListener(Object, KeyFilter<? super K>) - Method in interface org.infinispan.notifications.FilteringListenable
-
Adds a listener to the component.
- addListener(Object, KeyFilter<? super K>, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addListener(Object, KeyFilter<? super K>, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
-
Adds a listener to the component.
- addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in interface org.infinispan.notifications.FilteringListenable
-
Registers a listener that will be notified on events that pass the filter condition.
- addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
-
Adds the listener using the provided filter converter and class loader.
- addListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.ClassLoaderAwareFilteringListenable
-
Adds a listener with the provided filter and converter and using a given classloader when invoked.
- addListener(AttributeListener<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- addListener(ListenerHolder, KeyFilter<? super K>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addListener(ListenerHolder, KeyFilter<? super K>) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
- addListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addListener(ListenerHolder, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, ClassLoader) - Method in interface org.infinispan.notifications.DataConversionAwareListenable
- addListener(ActionListener) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
-
Adds a listener to be invoked when this action is ready or canceled.
- addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.CompositeAction
- addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.LockAction
- addListener(ActionListener) - Method in class org.infinispan.remoting.inboundhandler.action.PendingTxAction
- addListener(ActionListener) - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
-
It adds a listener that is invoked when this action is ready.
- addListener(CacheTransaction.TransactionCompletedListener) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- addListener(KeyAwareLockListener) - Method in interface org.infinispan.util.concurrent.locks.KeyAwareLockPromise
-
It adds the listener to this
LockPromise
. - addListener(LockListener) - Method in interface org.infinispan.util.concurrent.locks.LockPromise
-
Adds a
LockListener
to be invoked when the lock is available. - addListener(PendingLockListener) - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
-
Adds a listener to this promise.
- addListener(T) - Method in interface org.infinispan.counter.api.StrongCounter
-
Registers a
CounterListener
to this counter. - addListener(T) - Method in interface org.infinispan.counter.api.WeakCounter
-
Adds a
CounterListener
to this counter. - addLocalBias(Object, int) - Method in interface org.infinispan.scattered.BiasManager
-
Allow reading local data if the topology is still actual.
- addLocalValue(ExtendedStatistic, double) - Method in class org.infinispan.stats.CacheStatisticCollector
-
Adds a value to a local statistic.
- addLockedKey(Object) - Method in interface org.infinispan.context.InvocationContext
-
Tracks the given key as locked by this invocation context.
- addLockedKey(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- addLockInformation(Object, boolean, boolean) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
-
Adds the lock information about the key, namely if the key suffer some contention and if the keys was locked or not.
- addMarshalledEntry(Object, MarshalledEntry) - Method in class org.infinispan.persistence.support.BatchModification
- addMechProperty(String, String) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- addMember(Principal) - Method in class org.infinispan.server.core.security.simple.SimpleGroupPrincipal
- addMember(Address, boolean) - Method in class org.infinispan.xsite.status.CacheSiteStatusBuilder
-
Adds a member with an online/offline connection to the server based on the
online
parameter. - addMergePolicyFactory(EntryMergePolicyFactory) - Method in class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
- addModule(Class<T>) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- addModule(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- addOwner(Address) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- addParameter(String, Object) - Method in class org.infinispan.tasks.TaskContext
-
Adds a named parameter to the task context
- addParsingCompleteListener(ParserContextListener) - Method in class org.infinispan.configuration.parsing.AbstractParserContext
- addParsingCompleteListener(ParserContextListener) - Method in interface org.infinispan.configuration.parsing.ParserContext
- addPendingAcks(boolean, Address[]) - Method in interface org.infinispan.interceptors.distribution.BiasedCollector
- addPersistentAddressMapping(Address, PersistentUUID) - Method in interface org.infinispan.topology.PersistentUUIDManager
-
Adds a mapping between an
Address
and aPersistentUUID
- addPersistentAddressMapping(Address, PersistentUUID) - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
- addProperty(String, String) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Defines a single property.
- addProperty(String, String) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- addProperty(String, String) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.Add key/value property pair to this data container configuration
- addProperty(String, String) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
Defines a single property.
- addProperty(String, String) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
- addProperty(String, String) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
Defines a single property.
- addProperty(String, String) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
-
Add key/value property pair to this executor factory configuration
- addProperty(String, String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
- addProperty(String, String) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
-
Add key/value property pair to this executor factory configuration
- addProperty(String, String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- addPut(Object, boolean) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
-
Adds the key to the put top-key.
- addr - Variable in class org.infinispan.transaction.xa.GlobalTransaction
- addReadKey(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.since 9.1 Use
MVCCEntry.setRead()
instead - addRegexps(String...) - Method in class org.infinispan.commons.configuration.ClassWhiteList
- addRemoteValue(ExtendedStatistic, double) - Method in class org.infinispan.stats.CacheStatisticCollector
-
Adds a value to a remote statistic.
- addRemovalListener(Consumer<Iterable<InternalCacheEntry<WrappedBytes, WrappedBytes>>>) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- addRequestor(Object, Address) - Method in interface org.infinispan.distribution.L1Manager
-
Records a request that will be cached in another nodes L1
- addResponse(Address, Response) - Method in interface org.infinispan.interceptors.distribution.BiasedCollector
- addResponse(Address, Response) - Method in class org.infinispan.interceptors.distribution.RemoteGetSingleKeyCollector
- addResponse(Address, Response) - Method in interface org.infinispan.remoting.transport.ResponseCollector
-
Called when a response is received, or when a target node becomes unavailable.
- addResponse(Address, Response) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
- addResponse(Address, Response) - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
- address - Variable in class org.infinispan.query.clustered.NodeTopDocs
- address - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
- address - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- Address - Interface in org.infinispan.remoting.transport
-
A destination for an Infinispan command or operation.
- ADDRESS_COUNT - org.infinispan.configuration.parsing.Attribute
- ADDRESS_COUNT - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
- addressCount() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
-
The address pointer count
- addressCount() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
How many address pointers are configured for the off heap storage.
- addressCount(int) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
Configuration setting when using off-heap that defines how many address pointers there are.
- addressToPersistentUUID() - Method in interface org.infinispan.topology.PersistentUUIDManager
-
Provides a remapping operator which translates addresses to persistentuuids
- addressToPersistentUUID() - Method in class org.infinispan.topology.PersistentUUIDManagerImpl
- addScript(String, String) - Method in interface org.infinispan.scripting.ScriptingManager
-
Adds a new named script.
- addSegments(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- addSegments(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- addSegments(IntSet) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Notifies any underlying segmented stores that the segments provided are owned by this cache and to start/configure any underlying resources required to handle requests for entries on the given segments.
- addSegments(IntSet) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- addSegments(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Invoked when a node becomes an owner of the given segments.
- addSegments(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- addServer() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- addServer() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- addServer() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Adds a new remote server
- addShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- addShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
- addSingleFileStore() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
-
Adds a single file cache store.
- addSpecificHeaders(FullHttpResponse) - Method in class org.infinispan.rest.InfinispanCacheResponse
- addSpecificHeaders(FullHttpResponse) - Method in class org.infinispan.rest.InfinispanResponse
- addStatus(Set<Integer>) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- addStorageFormatFilteredListener(Object, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>, Set<Class<? extends Annotation>>) - Method in interface org.infinispan.notifications.FilteringListenable
-
Same as
FilteringListenable.addFilteredListener(Object, CacheEventFilter, CacheEventConverter, Set)
, but assumes the filter and/or the converter will be done in the same data format as it's stored in the cache. - addStore(Class<T>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
-
Adds a cache loader that uses the specified builder class to build its configuration.
- addStore(StoreConfigurationBuilder<?, ?>) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
-
Adds a cache loader that uses the specified builder instance to build its configuration.
- addStrongCounter() - Method in interface org.infinispan.counter.configuration.CounterConfigurationBuilder
- addStrongCounter() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
- addTargetNotFound(Address) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
-
Process a target leaving the cluster or stopping the cache.
- addToWhiteList(String) - Static method in class org.infinispan.marshall.core.ExternallyMarshallable
-
Adds package or class name to the externally marshallable white list.
- addTransfer(InboundTransferTask, IntSet) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- addTransfer(OutboundTransferTask) - Method in class org.infinispan.statetransfer.StateProviderImpl
- addUser(String, String, char[], String...) - Method in class org.infinispan.server.core.security.simple.SimpleServerAuthenticationProvider
-
Add a user to the authentication table.
- addValidResponse(Address, ValidResponse) - Method in class org.infinispan.remoting.transport.ValidResponseCollector
-
Process a valid response from a target.
- addValue(ExtendedStatistic, double) - Method in class org.infinispan.stats.container.BaseExtendedStatisticsContainer
- addValue(ExtendedStatistic, double) - Method in interface org.infinispan.stats.container.ExtendedStatisticsContainer
-
it adds the value to the statistic.
- addValue(ExtendedStatistic, double) - Method in class org.infinispan.stats.TransactionStatistics
-
Adds a value to a statistic collected for this transaction.
- addVersionRead(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Sets the version read for this key.
- addWeakCounter() - Method in interface org.infinispan.counter.configuration.CounterConfigurationBuilder
- addWeakCounter() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
- addWriteSkewFailed(Object) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
-
Adds the key to the write skew failed top-key.
- ADMIN - org.infinispan.security.AuthorizationPermission
-
Allows performing "administrative" operations on a cache
- ADMIN_FLAG - Static variable in interface org.infinispan.commons.marshall.Ids
- ADMIN_OPERATION_HANDLER - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- AdminFlagExternalizer - Class in org.infinispan.commons.marshall
- AdminFlagExternalizer() - Constructor for class org.infinispan.commons.marshall.AdminFlagExternalizer
- administration() - Method in interface org.infinispan.manager.CacheContainer
-
Provides access to administrative methods which affect the underlying cache container, such as cache creation and removal.
- administration() - Method in class org.infinispan.manager.DefaultCacheManager
- administration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Provides an
EmbeddedCacheManagerAdmin
whose methods affect the entire cluster as opposed to a single node. - AdminOperation - Enum in org.infinispan.server.core.admin
-
AdminOperations
- AdminOperationParameter - Enum in org.infinispan.server.core.admin
-
AdminOperationParameters
- adminOperationsHandler() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- adminOperationsHandler(AdminOperationsHandler) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- adminOperationsHandler(AdminOperationsHandler) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- adminOperationsHandler(AdminOperationsHandler) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Indicates the
AdminOperationsHandler
which will be used to handle admin operations - adminOperationsHandler(AdminOperationsHandler) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
- AdminOperationsHandler - Class in org.infinispan.server.core.admin
-
AdminOperationsHandler is a special
TaskEngine
which can handle admin tasks - AdminOperationsHandler(Class<? extends AdminServerTask>...) - Constructor for class org.infinispan.server.core.admin.AdminOperationsHandler
- AdminServerTask<T> - Class in org.infinispan.server.core.admin
-
Common base for admin server tasks
- AdminServerTask() - Constructor for class org.infinispan.server.core.admin.AdminServerTask
- ADVANCED_EXTERNALIZER - org.infinispan.configuration.parsing.Element
- AdvancedAsyncCacheLoader<K,V> - Class in org.infinispan.persistence.async
- AdvancedAsyncCacheLoader(CacheLoader, AtomicReference<State>) - Constructor for class org.infinispan.persistence.async.AdvancedAsyncCacheLoader
- AdvancedAsyncCacheWriter - Class in org.infinispan.persistence.async
- AdvancedAsyncCacheWriter(CacheWriter) - Constructor for class org.infinispan.persistence.async.AdvancedAsyncCacheWriter
- AdvancedCache<K,V> - Interface in org.infinispan
-
An advanced interface that exposes additional methods not available on
Cache
. - AdvancedCacheExpirationWriter<K,V> - Interface in org.infinispan.persistence.spi
-
Defines functionality for advanced expiration techniques.
- AdvancedCacheExpirationWriter.ExpirationPurgeListener<K,V> - Interface in org.infinispan.persistence.spi
-
Callback to be notified when an entry is removed by the
AdvancedCacheExpirationWriter.purge(Executor, ExpirationPurgeListener)
method. - AdvancedCacheLoader<K,V> - Interface in org.infinispan.persistence.spi
-
A specialised extension of the
CacheLoader
interface that allows processing parallel iteration over the existing entries. - AdvancedCacheLoader.CacheLoaderTask<K,V> - Interface in org.infinispan.persistence.spi
-
Deprecated.since 9.3 The process method is deprecated and thus this class shouldn't be in use any more
- AdvancedCacheLoader.TaskContext - Interface in org.infinispan.persistence.spi
-
Deprecated.since 9.3 The process method is no longer suggested and thus this class shouldn't be in use any more
- AdvancedCacheWriter<K,V> - Interface in org.infinispan.persistence.spi
-
Defines advanced functionality for persisting data to an external storage.
- AdvancedCacheWriter.PurgeListener<K> - Interface in org.infinispan.persistence.spi
-
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
-
AdvancedExternalizer
provides an alternative way to provide externalizers for marshalling/unmarshalling user defined classes that overcome the deficiencies of the more user-friendly externalizer definition model explained inExternalizer
. - advancedExternalizers() - Method in class org.infinispan.configuration.global.SerializationConfiguration
- AdvancedLoadWriteStore<K,V> - Interface in org.infinispan.persistence.spi
-
Advanced interface for interacting with an external store in a read-write mode.
- AdvancedSingletonCacheWriter - Class in org.infinispan.persistence.support
-
Deprecated.this writer will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
- AdvancedSingletonCacheWriter(CacheWriter, SingletonStoreConfiguration) - Constructor for class org.infinispan.persistence.support.AdvancedSingletonCacheWriter
-
Deprecated.
- AffectedKeysVisitor - Class in org.infinispan.statetransfer
-
Deprecated.since 9.1
- AffectedKeysVisitor() - Constructor for class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- AffinityErrorHandler - Class in org.infinispan.query.affinity
-
Handles errors occurred in the
AffinityIndexManager
. - AffinityErrorHandler(ErrorHandler) - Constructor for class org.infinispan.query.affinity.AffinityErrorHandler
- AffinityIndexManager - Class in org.infinispan.query.affinity
-
IndexManager
that splits the index into shards. - AffinityIndexManager() - Constructor for class org.infinispan.query.affinity.AffinityIndexManager
- affinityLocationIntoSegment(int) - Method in interface org.infinispan.lucene.directory.BuildContext
-
When set to a positive integer, this will force a specific data distribution: the hashing function will resolve all keys used to store the various entries for the resulting index to be owned by the specified segment id.
- affinitySegmentId() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
-
When Index Affinity is enabled, this returns the segment id to which the current index is bound to.
- affinitySegmentId(int) - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
-
When the index is stored on a per-segment affinity base, set the affinity id for this index instance.
- AffinityShardIdentifierProvider - Class in org.infinispan.query.affinity
-
Dynamic sharding based on the segment associated with the key
- AffinityShardIdentifierProvider() - Constructor for class org.infinispan.query.affinity.AffinityShardIdentifierProvider
- AffinityTaggedKey - Interface in org.infinispan.distribution.ch
- AffinityUpdateCommand - Class in org.infinispan.query.affinity
-
Handle index updates forwarded by the
AffinityIndexManager
, in exceptional cases where an index work ceases to be local to a node due to transient ownership changes. - AffinityUpdateCommand(ByteString) - Constructor for class org.infinispan.query.affinity.AffinityUpdateCommand
- after() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- after(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Dictates that the custom interceptor appears immediately after the specified interceptor.
- AFTER - org.infinispan.configuration.parsing.Attribute
- AFTER - org.infinispan.container.versioning.InequalVersionComparisonResult
-
Denotes a version that was created temporally after another version.
- AFTER - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
- AFTER_FAILURES - Static variable in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- afterBackupRemotely(ReplicableCommand, BackupResponse) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
-
method invoked after a successful backup remote invocation.
- afterCompletion(int) - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
- afterFailures() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- afterFailures(int) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
-
The number of failed request operations after which this site should be taken offline.
- afterHandle(CacheRpcCommand, DeliverOrder, boolean) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
-
Invoked after the command is handled.
- afterInvoke() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- afterInvokeRemotely(ReplicableCommand, Map<Address, Response>) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
-
method invoked after a successful remote invocation.
- afterPropertiesSet() - Method in class org.infinispan.spring.InfinispanDefaultCacheFactoryBean
- afterPropertiesSet() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
- afterPropertiesSet() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
- afterPropertiesSet() - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- afterPropertiesSet() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
- afterPropertiesSet() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
- afterPropertiesSet() - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
- afterPropertiesSet() - Method in class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
- AggregateBackupResponse - Class in org.infinispan.remoting.transport
- AggregateBackupResponse(BackupResponse, BackupResponse) - Constructor for class org.infinispan.remoting.transport.AggregateBackupResponse
- aggregateCompletionStage() - Static method in class org.infinispan.util.concurrent.CompletionStages
-
Returns a CompletionStage that also can be composed of many other CompletionStages.
- aggregateCompletionStage(R) - Static method in class org.infinispan.util.concurrent.CompletionStages
-
Same as
CompletionStages.aggregateCompletionStage()
except that when this stage completes normally it will return the value provided. - AggregateCompletionStage<R> - Interface in org.infinispan.util.concurrent
-
Aggregation of multiple
CompletionStage
instances where their count is not known or when a large amount of stages are required, as it uses less memory foot print per stage. - AggregatedClassLoader - Class in org.infinispan.commons.util
-
A ClassLoader that delegates loading of classes and resources to a list of delegate ClassLoaders.
- AggregatedClassLoader(Collection<ClassLoader>) - Constructor for class org.infinispan.commons.util.AggregatedClassLoader
-
Create an aggregated ClassLoader from a Collection of ClassLoaders
- ALIASES - org.infinispan.configuration.parsing.Attribute
- all() - Method in class org.infinispan.transaction.xa.recovery.PreparedTxIterator
- all() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.RecoveryIterator
-
Exhaust the iterator.
- ALL - org.infinispan.configuration.cache.Index
-
All cluster nodes will add the entry to the index.
- ALL - org.infinispan.distexec.DistributedTaskExecutionPolicy
- ALL - org.infinispan.functional.Param.ExecutionMode
-
Command is executed on its owners, in transactional mode in the context, too, but there it is not persisted.
- ALL - org.infinispan.manager.ClusterExecutionPolicy
-
The command can be executed on any node in the cluster
- ALL - org.infinispan.security.AuthorizationPermission
-
Aggregate permission which implies all of the others
- ALL_GET_EXECUTION - org.infinispan.stats.container.ExtendedStatistic
- ALL_KNOWN_COMPONENT_NAMES - Static variable in class org.infinispan.factories.KnownComponentNames
- ALL_NODES - org.infinispan.tasks.TaskExecutionMode
- ALL_READ - org.infinispan.security.AuthorizationPermission
-
Aggregate permission which implies all read permissions
- ALL_WRITE - org.infinispan.security.AuthorizationPermission
-
Aggregate permission which implies all write permissions
- allBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
-
Returns the list of all sites where this cache might back up its data.
- allMatch(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- allMatch(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that returns whether all elements of this traversable match the provided predicate.
- allMatch(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleStream.allMatch(DoublePredicate)
except that the DoublePredicate must also 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
- allOf(CompletionStage<?>...) - Static method in class org.infinispan.util.concurrent.CompletionStages
-
Returns a CompletionStage that completes when all of the provided stages complete, either normally or via exception.
- allOf(CompletionStage<Void>, CompletionStage<Void>) - Static method in class org.infinispan.util.concurrent.CompletionStages
-
Returns a CompletableStage that completes when both of the provides CompletionStages complete.
- ALLOW - org.infinispan.security.AuditResponse
- ALLOW_DUPLICATE_DOMAINS - org.infinispan.configuration.parsing.Attribute
- ALLOW_DUPLICATE_DOMAINS - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- ALLOW_READ_WRITES - org.infinispan.partitionhandling.PartitionHandling
-
Allow entries on each partition to diverge, with conflicts resolved during merge.
- ALLOW_READS - org.infinispan.partitionhandling.PartitionHandling
-
Allows reads for a given key if it exists in this partition, but only allows writes if this partition contains all owners of a segment.
- allowDuplicateDomains() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- allowDuplicateDomains(Boolean) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
-
If true, multiple cache manager instances could be configured under the same configured JMX domain.
- allowedMechs() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- allowedSegments - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
- allowedSegments - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- allowedSegments - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- allowInvocations() - Method in enum org.infinispan.lifecycle.ComponentStatus
- AllOwnersLostException - Exception in org.infinispan.statetransfer
-
Signals that all owners of a key have been lost.
- ALREADY_OFFLINE - org.infinispan.xsite.BackupSender.TakeSiteOfflineResponse
- ALREADY_ONLINE - org.infinispan.xsite.BackupSender.BringSiteOnlineResponse
- alwaysTruePredicate() - Static method in class org.infinispan.stream.StreamMarshalling
-
Predicate taht always returns true irrespective of the value provided
- amend(Integer, Long) - Method in class org.infinispan.xsite.OfflineStatus
- amend(TakeOfflineConfiguration) - Method in class org.infinispan.xsite.OfflineStatus
-
Configures the site to use the supplied configuration for determining when to take a site offline.
- AMEND_TAKE_OFFLINE - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
- amendTakeOffline(String, int, long) - Method in class org.infinispan.xsite.XSiteAdminOperations
- and() - Method in interface org.infinispan.query.dsl.FilterConditionContext
-
Creates a new context and connects it with the current one using boolean AND.
- and(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionContext
-
Connects a given context with the current one using boolean AND.
- andExceptionally(InvocationContext, VisitableCommand, InvocationExceptionFunction) - Method in class org.infinispan.interceptors.InvocationStage
- andFinally(InvocationContext, VisitableCommand, InvocationFinallyAction) - Method in class org.infinispan.interceptors.InvocationStage
- andHandle(InvocationContext, VisitableCommand, InvocationFinallyFunction) - Method in class org.infinispan.interceptors.InvocationStage
- annotation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- AnyEquivalence<T> - Class in org.infinispan.commons.equivalence
-
Deprecated.
- anyMatch(Predicate<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- anyMatch(Predicate<? super T>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that returns whether any elements of this traversable match the provided predicate.
- anyMatch(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleStream.anyMatch(DoublePredicate)
except that the DoublePredicate must also 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
- AnyServerEquivalence - Class in org.infinispan.commons.equivalence
-
Deprecated.
- AnyServerEquivalence() - Constructor for class org.infinispan.commons.equivalence.AnyServerEquivalence
-
Deprecated.
- APPEND_CACHE_NAME_TO_PATH - org.infinispan.persistence.rest.configuration.Attribute
- APPEND_CACHE_NAME_TO_PATH - Static variable in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- appendCacheNameToPath() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- appendCacheNameToPath(boolean) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- appendCacheNameToPath(boolean) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- appendCacheNameToPath(boolean) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
Determines whether to append the cache name to the path URI.
- appendInterceptor(AsyncInterceptor, boolean) - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
-
Appends at the end.
- appendInterceptor(AsyncInterceptor, boolean) - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- appendInterceptor(CommandInterceptor, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Appends at the end.
- AppendRequest - org.infinispan.server.memcached.MemcachedOperation
- APPLICATION_INFINISPAN_BINARY - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_INFINISPAN_BINARY_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_INFINISPAN_MARSHALLED - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_INFINISPAN_MARSHALLING - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_INFINISPAN_MARSHALLING_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_JBOSS_MARSHALLING - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_JBOSS_MARSHALLING_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_JSON - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_JSON_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_KRYO - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_KRYO_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_OBJECT - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_OBJECT_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_OCTET_STREAM - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_OCTET_STREAM_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_PDF - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_PDF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_PROTOSTREAM - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_PROTOSTREAM_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_PROTOSTUFF - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_PROTOSTUFF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_RTF - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_RTF_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_SERIALIZED_OBJECT - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_SERIALIZED_OBJECT_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_TEXT_STRING - Static variable in class org.infinispan.scripting.utils.ScriptConversions
- APPLICATION_UNKNOWN - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_UNKNOWN_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_WWW_FORM_URLENCODED - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_XML - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_XML_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_ZIP - Static variable in class org.infinispan.commons.dataconversion.MediaType
- APPLICATION_ZIP_TYPE - Static variable in class org.infinispan.commons.dataconversion.MediaType
- applicationEventPublisher - Variable in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- apply(Object) - Method in class org.infinispan.compat.FunctionMapper
- apply(Object) - Method in class org.infinispan.remoting.LocalInvocation
- apply(Object, Object) - Method in class org.infinispan.compat.BiFunctionMapper
- apply(CacheMode) - Method in enum org.infinispan.configuration.parsing.Parser.Mode
- apply(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
- apply(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- apply(InvocationContext, VisitableCommand, Object) - Method in interface org.infinispan.interceptors.InvocationSuccessFunction
-
Process the result from a successful invocation stage and either return a simple value, return a new
InvocationStage
, or throw an exception. - apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationCallback
-
Process the result or the exception from an invocation stage and either return a simple value, return a new
InvocationStage
, or throw an exception. - apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationExceptionFunction
- apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationFinallyAction
- apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationSuccessAction
- apply(InvocationContext, VisitableCommand, Object, Throwable) - Method in interface org.infinispan.interceptors.InvocationSuccessFunction
- apply(InvocationContext, VisitableCommand, Throwable) - Method in interface org.infinispan.interceptors.InvocationExceptionFunction
-
Process the result from a successful invocation stage and either return a simple value, return a new
InvocationStage
, or throw an exception. - apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.ConditionalMarkAsRollbackFunction
- apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.CreateStateFunction
- apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.PreparingDecisionFunction
- apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.SetCompletedTransactionFunction
- apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.SetDecisionFunction
- apply(EntryView.ReadWriteEntryView<CacheXid, TxState>) - Method in class org.infinispan.server.hotrod.tx.table.functions.SetPreparedFunction
- APPLY_DELTA - Static variable in interface org.infinispan.commons.marshall.Ids
- applyAsInt(Object) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
- applyDelta(K, Delta, Object...) - Method in interface org.infinispan.AdvancedCache
-
Deprecated.since 9.1
- applyLocalResult(MergingCompletableFuture, Object) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
- applyLocalResult(MergingCompletableFuture, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
- applyModificationsSync(List<Modification>) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- applyState(Address, int, boolean, Collection<StateChunk>) - Method in interface org.infinispan.statetransfer.StateConsumer
- applyState(Address, int, boolean, Collection<StateChunk>) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- applyState(XSiteState[]) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateConsumer
-
It applies state from other site.
- applyState(XSiteState[]) - Method in class org.infinispan.xsite.statetransfer.XSiteStateConsumerImpl
- applyStreamWork(LuceneWork, IndexingMonitor, IndexManager) - Method in class org.infinispan.query.indexmanager.LazyInitializingBackend
- applyStreamWork(LuceneWork, IndexingMonitor, IndexManager) - Method in class org.infinispan.query.indexmanager.LockAcquiringBackend
- applyVersion(Metadata, Metadata) - Static method in class org.infinispan.metadata.Metadatas
-
Applies version in source metadata to target metadata, if no version in target metadata.
- applyWork(List<LuceneWork>, IndexingMonitor, IndexManager) - Method in class org.infinispan.query.indexmanager.LazyInitializingBackend
- applyWork(List<LuceneWork>, IndexingMonitor, IndexManager) - Method in class org.infinispan.query.indexmanager.LockAcquiringBackend
- areLocksReleased() - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.
- array(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- ArrayCollector - Class in org.infinispan.commons.util
- ArrayCollector(Object[]) - Constructor for class org.infinispan.commons.util.ArrayCollector
- arrayConcat(T[], T[]...) - Static method in class org.infinispan.commons.util.Util
-
Concatenates an arbitrary number of arrays returning a new array containing all elements
- ArrayMap<K,V> - Class in org.infinispan.commons.util
-
Base for classes that implement hash map by storing keys in one array and values in another.
- ArrayMap() - Constructor for class org.infinispan.commons.util.ArrayMap
- ARRAYS - Static variable in interface org.infinispan.commons.marshall.Ids
- ARRIVAL_RATE - org.infinispan.stats.container.ExtendedStatistic
- asBytes() - Method in class org.infinispan.query.remote.json.JsonQueryResponse
- ASC - org.infinispan.query.dsl.SortOrder
- asCompletionException(Throwable) - Static method in class org.infinispan.util.concurrent.CompletableFutures
- asCounterManager(EmbeddedCacheManager) - Static method in class org.infinispan.counter.EmbeddedCounterManagerFactory
- asDoubleStream() - Method in interface org.infinispan.IntCacheStream
- asDoubleStream() - Method in interface org.infinispan.LongCacheStream
- asError(InfinispanRequest, HttpResponseStatus, String) - Static method in class org.infinispan.rest.InfinispanErrorResponse
- asList() - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Returns an unmofiable list with all the interceptors in sequence.
- asLongStream() - Method in interface org.infinispan.IntCacheStream
- asObject() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- assertBatchingSupported(Configuration) - Static method in class org.infinispan.batch.AutoBatchSupport
- assertCorrectlyConfigured() - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- assertKeyNotNull(Object) - Static method in class org.infinispan.commons.util.AbstractMap
- assertNotNullEntries(Collection<?>, String) - Static method in class org.infinispan.commons.util.InfinispanCollections
- assertNotNullEntries(Map<?, ?>, String) - Static method in class org.infinispan.commons.util.InfinispanCollections
- assertTypeConstructable(Class<?>, Class<?>...) - Method in class org.infinispan.factories.AbstractComponentFactory
- asSet(T...) - Static method in class org.infinispan.commons.util.Util
- asString(Object) - Method in interface org.infinispan.rest.operations.mediatypes.OutputPrinter
- async - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
-
Configuration for the async cache loader.
- async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Configuration for the async cache store.
- async() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- async() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
-
Configuration for the async cache loader.
- async() - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
Configuration for the async cache store.
- ASYNC - org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
- ASYNC - org.infinispan.configuration.parsing.Element
- ASYNC - org.infinispan.configuration.parsing.Parser.Mode
- ASYNC - org.infinispan.functional.Param.ReplicationMode
-
Invoking node does not know when the owners are updated nor if the command fails.
- ASYNC - org.infinispan.persistence.manager.PersistenceManager.AccessMode
-
The operation is performed only in a
CacheWriter
orCacheLoader
that has async write behind. - ASYNC_COMPLETE_NOTIFY_TIME - org.infinispan.stats.container.ExtendedStatistic
- ASYNC_EXECUTOR - org.infinispan.configuration.parsing.Attribute
- ASYNC_EXECUTOR - org.infinispan.persistence.remote.configuration.Attribute
- ASYNC_MARSHALLING - org.infinispan.configuration.parsing.Attribute
-
Deprecated.
- ASYNC_NOTIFICATION_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
- ASYNC_OPERATIONS_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
- ASYNC_REPLICATION_QUEUE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
-
Deprecated.Since 9.0, no longer used.
- ASYNC_TRANSPORT_EXECUTOR - org.infinispan.persistence.remote.configuration.Element
- ASYNC_TRANSPORT_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
- AsyncCache<K,V> - Interface in org.infinispan.commons.api
-
AsyncCache.
- AsyncCacheLoader<K,V> - Class in org.infinispan.persistence.async
- AsyncCacheLoader(CacheLoader, AtomicReference<State>) - Constructor for class org.infinispan.persistence.async.AsyncCacheLoader
- AsyncCacheWriter - Class in org.infinispan.persistence.async
-
The AsyncCacheWriter is a delegating CacheStore that buffers changes and writes them asynchronously to the underlying CacheStore.
- AsyncCacheWriter(CacheWriter) - Constructor for class org.infinispan.persistence.async.AsyncCacheWriter
- asyncConfiguration - Variable in class org.infinispan.persistence.async.AsyncCacheWriter
- asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- asyncExecutorFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- asyncExecutorFactory() - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Configuration for the executor service used for asynchronous work on the Transport, including asynchronous marshalling and Cache 'async operations' such as Cache.putAsync().
- ASYNCHRONOUS - org.infinispan.remoting.rpc.ResponseMode
- asyncInterceptor() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- AsyncInterceptor - Interface in org.infinispan.interceptors
-
Interface for sequential interceptors.
- AsyncInterceptorChain - Interface in org.infinispan.interceptors
-
Interceptor chain using
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. - asyncListenerExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated.This method always returns null now. Look for a thread pool named as
GlobalConfiguration.listenerThreadPool()
instead. - AsyncStoreConfiguration - Class in org.infinispan.configuration.cache
-
Configuration for the async cache store.
- AsyncStoreConfigurationBuilder<S> - Class in org.infinispan.configuration.cache
-
Configuration for the async cache store.
- asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- asyncThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- asyncThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Configuration for the asynchronous operations thread pool
- asyncTransportExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated.This method always returns null now. Look for a thread pool named as
TransportConfiguration.transportThreadPool()
instead. - asyncValue(CompletionStage<?>) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
-
Suspend the invocation until
valueFuture
completes, then return its result without running the remaining interceptors. - ATOMIC_FINE_GRAINED_MAP_FUNCTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
- ATOMIC_KEY_SET - Static variable in interface org.infinispan.commons.marshall.Ids
- ATOMIC_MAP_FUNCTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
- AtomicMap<K,V> - Interface in org.infinispan.atomic
-
This is a special type of Map geared for use in Infinispan.
- AtomicMapLookup - Class in org.infinispan.atomic
-
A helper that locates or safely constructs and registers atomic maps with a given cache.
- AtomicMapLookup() - Constructor for class org.infinispan.atomic.AtomicMapLookup
- attribute(String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Returns the named attribute
- attribute(AttributeDefinition<T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Returns the attribute identified by the supplied
AttributeDefinition
- Attribute<T> - Class in org.infinispan.commons.configuration.attributes
-
Attribute.
- Attribute - Enum in org.infinispan.configuration.parsing
-
Enumerates the attributes used in Infinispan
- Attribute - Enum in org.infinispan.counter.configuration
- Attribute - Enum in org.infinispan.lock.configuration
- Attribute - Enum in org.infinispan.persistence.jdbc.configuration
-
Enumerates the attributes used by the JDBC cache stores configuration
- Attribute - Enum in org.infinispan.persistence.jpa.configuration
-
Enumerates the attributes used by the JPA cache stores configuration
- Attribute - Enum in org.infinispan.persistence.leveldb.configuration
-
Enumerates the attributes used by the LevelDB cache stores configuration
- Attribute - Enum in org.infinispan.persistence.remote.configuration
-
Enumerates the attributes used by the Remote cache store configuration
- Attribute - Enum in org.infinispan.persistence.rest.configuration
-
Enumerates the attributes used by the Remote cache store configuration
- attributeChanged(Attribute<Object>, Object) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- attributeChanged(Attribute<T>, T) - Method in interface org.infinispan.commons.configuration.attributes.AttributeListener
- AttributeCopier<T> - Interface in org.infinispan.commons.configuration.attributes
-
AttributeCopier.
- AttributeDefinition<T> - Class in org.infinispan.commons.configuration.attributes
-
AttributeDefinition.
- AttributeDefinition.Builder<T> - Class in org.infinispan.commons.configuration.attributes
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.Configuration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.CustomStoreConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.DataContainerConfiguration
-
Deprecated.
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.InterceptorConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.MemoryConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
-
Deprecated.
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.GlobalStateConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.counter.configuration.StrongCounterConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.counter.configuration.WeakCounterConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfiguration
-
Deprecated.
- attributeDefinitionSet() - Static method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.rest.configuration.RestServerConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- attributeDefinitionSet() - Static method in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
- AttributeInitializer<T> - Interface in org.infinispan.commons.configuration.attributes
-
AttributeInitializer.
- AttributeListener<T> - Interface in org.infinispan.commons.configuration.attributes
-
An AttributeListener will be invoked whenever an attribute has been modified.
- attributes - Variable in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
- attributes - Variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- attributes - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- attributes - Variable in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- attributes - Variable in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- attributes - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- attributes - Variable in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- attributes() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- attributes() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.AuthorizationConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.Configuration
- attributes() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
-
Deprecated.
- attributes() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
-
Deprecated.
- attributes() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- attributes() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.HashConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.L1Configuration
- attributes() - Method in class org.infinispan.configuration.cache.LockingConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
-
Deprecated.
- attributes() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.
- attributes() - Method in class org.infinispan.configuration.cache.SyncConfiguration
-
Deprecated.
- attributes() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
- attributes() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
-
Deprecated.
- attributes() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- attributes() - Method in class org.infinispan.configuration.global.ExecutorFactoryConfiguration
- attributes() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- attributes() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- attributes() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
- attributes() - Method in class org.infinispan.configuration.global.SerializationConfiguration
- attributes() - Method in class org.infinispan.configuration.global.TransportConfiguration
- attributes() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
- attributes() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- attributes() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- attributeSet() - Static method in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
- AttributeSet - Class in org.infinispan.commons.configuration.attributes
-
AttributeSet is a container for
Attribute
s. - AttributeSet(Class<?>, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
- AttributeSet(Class<?>, AttributeSet, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
- AttributeSet(String, AttributeDefinition<?>...) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
- AttributeSet(String, AttributeSet, AttributeDefinition<?>[]) - Constructor for class org.infinispan.commons.configuration.attributes.AttributeSet
- AttributeValidator<T> - Interface in org.infinispan.commons.configuration.attributes
-
AttributeValidator.
- audit(Subject, AuditContext, String, AuthorizationPermission, AuditResponse) - Method in interface org.infinispan.security.AuditLogger
- AUDIT_LOGGER - org.infinispan.configuration.parsing.Attribute
- AUDIT_LOGGER - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- AuditContext - Enum in org.infinispan.security
-
AuditContext.
- auditLogger() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- auditLogger(AuditLogger) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
-
The instance of an
AuditLogger
to be used to track operations performed on caches and cachemanagers. - AuditLogger - Interface in org.infinispan.security
-
AuditLogger.
- AuditResponse - Enum in org.infinispan.security
- auth(HotRodHeader, String, byte[]) - Method in class org.infinispan.server.hotrod.Authentication
- AUTH - org.infinispan.server.hotrod.HotRodOperation
- AUTH_DIGEST - org.infinispan.persistence.remote.configuration.Element
- AUTH_EXTERNAL - org.infinispan.persistence.remote.configuration.Element
- AUTH_MECH_LIST - org.infinispan.server.hotrod.HotRodOperation
- AUTH_MECH_LIST_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- AUTH_PLAIN - org.infinispan.persistence.remote.configuration.Element
- AUTH_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- authenticate(String) - Method in class org.infinispan.rest.InfinispanResponse
-
Adds
www-authenticate
header. - authenticate(String, String) - Method in interface org.infinispan.rest.authentication.SecurityDomain
-
Returns
Subject
based on user/password combination. - authenticateHeader() - Method in class org.infinispan.rest.InfinispanResponse
- authentication() - Method in class org.infinispan.persistence.remote.configuration.AbstractSecurityConfigurationChildBuilder
- authentication() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfiguration
- authentication() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
- authentication() - Method in class org.infinispan.server.hotrod.configuration.AbstractHotRodServerChildConfigurationBuilder
- authentication() - Method in interface org.infinispan.server.hotrod.configuration.HotRodServerChildConfigurationBuilder
-
Configures authentication for this endpoint
- authentication() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- authentication() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- Authentication - Class in org.infinispan.server.hotrod
-
Handler that when added will make sure authentication is applied to requests.
- Authentication(Channel, Executor, HotRodServer) - Constructor for class org.infinispan.server.hotrod.Authentication
- AUTHENTICATION - org.infinispan.persistence.remote.configuration.Element
- AuthenticationConfiguration - Class in org.infinispan.persistence.remote.configuration
-
AuthenticationConfiguration.
- AuthenticationConfiguration - Class in org.infinispan.server.hotrod.configuration
-
AuthenticationConfiguration.
- AuthenticationConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- AuthenticationConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
-
AuthenticationConfigurationBuilder.
- AuthenticationConfigurationBuilder - Class in org.infinispan.server.hotrod.configuration
-
AuthenticationConfigurationBuilder.
- AuthenticationConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
- AuthenticationException - Exception in org.infinispan.rest.authentication
-
Exception thrown then authentication fails.
- AuthenticationException(Optional<String>) - Constructor for exception org.infinispan.rest.authentication.AuthenticationException
-
Creates new
AuthenticationException
. - Authenticator - Interface in org.infinispan.rest.authentication
-
Authentication mechanism.
- authMechList(HotRodHeader) - Method in class org.infinispan.server.hotrod.Authentication
- authMechListResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Set<String>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- authMechListResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Set<String>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- authorization() - Method in class org.infinispan.configuration.cache.SecurityConfiguration
- authorization() - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
- authorization() - Method in interface org.infinispan.configuration.cache.SecurityConfigurationChildBuilder
- authorization() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
- authorization() - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
- authorization() - Method in interface org.infinispan.configuration.global.GlobalSecurityConfigurationChildBuilder
-
Defines global roles as groups of permissions
- AUTHORIZATION - org.infinispan.configuration.parsing.Element
- AuthorizationConfiguration - Class in org.infinispan.configuration.cache
-
AuthorizationConfiguration.
- AuthorizationConfigurationBuilder - Class in org.infinispan.configuration.cache
-
AuthorizationConfigurationBuilder.
- AuthorizationConfigurationBuilder(SecurityConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
- AuthorizationManager - Interface in org.infinispan.security
-
The AuthorizationManager is a cache-scoped component which verifies that the
Subject
associated with the currentAccessControlContext
, or explicitly specified, has the requested permissions. - AuthorizationManagerFactory - Class in org.infinispan.factories
- AuthorizationManagerFactory() - Constructor for class org.infinispan.factories.AuthorizationManagerFactory
- AuthorizationPermission - Enum in org.infinispan.security
-
AuthorizationPermission.
- AuthorizingCallbackHandler - Interface in org.infinispan.server.core.security
-
AuthorizingCallbackHandler.
- authResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[]) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- authResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[]) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- AUTO - org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfiguration.ImplementationType
-
Deprecated.
- AUTO_COMMIT - org.infinispan.configuration.parsing.Attribute
- AUTO_COMMIT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- AUTO_CONFIG - org.infinispan.configuration.parsing.Attribute
- AUTO_CONFIG - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
- AutoBatchSupport - Class in org.infinispan.batch
-
Enables for automatic batching.
- AutoBatchSupport() - Constructor for class org.infinispan.batch.AutoBatchSupport
- autoChunkSize() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
-
When the segment size is larger than this number of bytes, separate segments will be created of this particular size.
- autoChunkSize(int) - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
-
When segment files are larger than this amount of bytes, the segment will be split into multiple chunks of this size.
- autoCommit() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
If the cache is transactional (i.e.
- autoCommit(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
If the cache is transactional (i.e.
- autoConfig() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
Determines if autoconfig is enabled for this IndexingConfiguration
- autoConfig() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- autoConfig(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
When enabled, applies to properties default configurations based on the cache type
- AutoInstantiableFactory - Interface in org.infinispan.factories
-
Component factories that implement this interface can be instantiated automatically by component registries when looking up components.
- autoPersist(boolean) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- AVAILABILITY_INTERVAL - org.infinispan.configuration.parsing.Attribute
- AVAILABILITY_INTERVAL - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
- AVAILABILITY_MODE - Static variable in interface org.infinispan.commons.marshall.Ids
- AVAILABILITY_MODE_CHANGE - org.infinispan.topology.CacheTopologyControlCommand.Type
- AvailabilityException - Exception in org.infinispan.partitionhandling
-
Thrown when a partition happened and the key that an operation tries to access is not available.
- AvailabilityException() - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
- AvailabilityException(String) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
- AvailabilityException(String, Throwable) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
- AvailabilityException(Throwable) - Constructor for exception org.infinispan.partitionhandling.AvailabilityException
- availabilityInterval() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- availabilityInterval(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- AvailabilityMode - Enum in org.infinispan.partitionhandling
- AvailabilityMode.Externalizer - Class in org.infinispan.partitionhandling
- available() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- available() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
-
If set to false, statistics gathering cannot be enabled during runtime.
- available() - Method in class org.infinispan.io.GridInputStream
- available() - Method in class org.infinispan.io.UnclosableObjectInputStream
- available(boolean) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
-
If set to false, statistics gathering cannot be enabled during runtime.
- AVAILABLE - org.infinispan.counter.configuration.Reliability
-
If the cluster splits in multiple partition, all of them are allowed to continue read/update the counter.
- AVAILABLE - org.infinispan.lock.configuration.Reliability
- AVAILABLE - org.infinispan.partitionhandling.AvailabilityMode
-
Regular operation mode
- AVAILABLE - Static variable in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
- availableProcessors() - Static method in class org.infinispan.commons.util.ProcessorInfo
-
Returns the number of processors available to this process.
- avg(String) - Static method in interface org.infinispan.query.dsl.Expression
- await() - Method in class org.infinispan.util.concurrent.ReclosableLatch
- await(long, TimeUnit) - Method in class org.infinispan.util.concurrent.ReclosableLatch
- await(CompletableFuture<?>, long, TimeUnit) - Static method in class org.infinispan.util.concurrent.CompletableFutures
-
It waits until the
CompletableFuture
is completed. - await(CompletableFuture<T>) - Static method in class org.infinispan.util.concurrent.CompletableFutures
-
Wait for a long time until the
CompletableFuture
is completed. - AWAIT_INITIAL_TRANSFER - org.infinispan.configuration.parsing.Attribute
- AWAIT_INITIAL_TRANSFER - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
- awaitForPushToFinish(Future<?>, long, TimeUnit) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.Method that waits for the in-memory to cache loader state to finish.
- awaitInitialTransfer() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
-
If
true
, this will cause the first call to 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.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). - awaitPendingTransactionsForAllKeys(TxInvocationContext<?>, Collection<Object>, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
-
It waits for any transaction with older topology id to complete that may have the lock for any key in
keys
acquired. - awaitPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
-
It waits for any transaction with older topology id to complete that may have the lock for
key
acquired. - awaitTermination(long, TimeUnit) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- awaitTermination(long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- awaitTermination(long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingExecutorService
- awaitTermination(long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- awaitTermination(long, TimeUnit) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
- awaitUntilUnBlock() - Method in interface org.infinispan.transaction.totalorder.TotalOrderLatch
-
It waits for this synchronization block to be unblocked.
- awaitUntilUnBlock() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
B
- backArrayOffset() - Method in class org.infinispan.commons.marshall.WrappedByteArray
- backArrayOffset() - Method in interface org.infinispan.commons.marshall.WrappedBytes
-
The offset of where data starts in the backed array.
- backgroundTaskFinished(Callable<T>) - Method in class org.infinispan.executors.SemaphoreCompletionService
-
Signal that a task that called
SemaphoreCompletionService.continueTaskInBackground()
has finished and optionally execute another task on the just-freed thread. - BackingKeySet(Cache<K, V>, CacheSet<K>, FlagAffectedCommand) - Constructor for class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
- backup() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
- backup() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- BACKUP - org.infinispan.configuration.parsing.Element
- BACKUP - org.infinispan.distribution.Ownership
-
this node is the backup owner.
- BACKUP_FAILURE_POLICY - org.infinispan.configuration.parsing.Attribute
- BACKUP_FOR - org.infinispan.configuration.parsing.Element
- backupAck(long, Address, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
-
Acknowledges a write operation completion in the backup owner.
- backupCommit(CommitCommand) - Method in interface org.infinispan.xsite.BackupSender
- backupCommit(CommitCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
- BackupConfiguration - Class in org.infinispan.configuration.cache
- BackupConfiguration(AttributeSet, TakeOfflineConfiguration, XSiteStateTransferConfiguration) - Constructor for class org.infinispan.configuration.cache.BackupConfiguration
- BackupConfiguration.BackupStrategy - Enum in org.infinispan.configuration.cache
- BackupConfigurationBuilder - Class in org.infinispan.configuration.cache
- BackupConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.BackupConfigurationBuilder
- BackupFailureException - Exception in org.infinispan.xsite
-
Exception to be used to signal failures to backup to remote sites.
- BackupFailureException() - Constructor for exception org.infinispan.xsite.BackupFailureException
- BackupFailureException(String) - Constructor for exception org.infinispan.xsite.BackupFailureException
- backupFailurePolicy() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- backupFailurePolicy(BackupFailurePolicy) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
-
Configures how the system behaves when the backup call fails.
- BackupFailurePolicy - Enum in org.infinispan.configuration.cache
-
Defines the possible behaviour in case of failure during x-site.
- backupFor() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- backupFor() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
- BackupForBuilder - Class in org.infinispan.configuration.cache
- BackupForBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.BackupForBuilder
- BackupForConfiguration - Class in org.infinispan.configuration.cache
-
Defines the remote caches for which this cache acts as a backup.
- BackupForConfiguration(AttributeSet) - Constructor for class org.infinispan.configuration.cache.BackupForConfiguration
- backupFrom(CommandsFactory, ReadWriteKeyCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, ReadWriteKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, ReadWriteManyCommand<K, V, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, ReadWriteManyEntriesCommand<K, V, T, R>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, WriteOnlyKeyCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, WriteOnlyKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, WriteOnlyManyCommand<K, V>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, WriteOnlyManyEntriesCommand<K, V, T>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, ComputeCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, ComputeIfAbsentCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, PutKeyValueCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, PutMapCommand, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, RemoveCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupFrom(CommandsFactory, ReplaceCommand) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- backupPrepare(PrepareCommand, AbstractCacheTransaction) - Method in interface org.infinispan.xsite.BackupSender
-
Prepares a transaction on the remote site.
- backupPrepare(PrepareCommand, AbstractCacheTransaction) - Method in class org.infinispan.xsite.BackupSenderImpl
- BackupReceiver - Interface in org.infinispan.xsite
-
Component present on a backup site that manages the backup information and logic.
- BackupReceiverRepository - Interface in org.infinispan.xsite
-
Global component that holds all the
BackupReceiver
s within this CacheManager. - BackupReceiverRepositoryImpl - Class in org.infinispan.xsite
- BackupReceiverRepositoryImpl() - Constructor for class org.infinispan.xsite.BackupReceiverRepositoryImpl
- backupRemotely(Collection<XSiteBackup>, XSiteReplicateCommand) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- backupRemotely(Collection<XSiteBackup>, XSiteReplicateCommand) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- backupRemotely(Collection<XSiteBackup>, XSiteReplicateCommand) - Method in interface org.infinispan.remoting.transport.Transport
- BackupResponse - Interface in org.infinispan.remoting.transport
-
Represents a response from a backup replication call.
- backupRollback(RollbackCommand) - Method in interface org.infinispan.xsite.BackupSender
- backupRollback(RollbackCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
- backups() - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
- BACKUPS - org.infinispan.configuration.parsing.Element
- backupSender - Variable in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- BackupSender - Interface in org.infinispan.xsite
-
Component responsible with sending backup data to remote sites.
- BackupSender.BringSiteOnlineResponse - Enum in org.infinispan.xsite
- BackupSender.TakeSiteOfflineResponse - Enum in org.infinispan.xsite
- BackupSenderImpl - Class in org.infinispan.xsite
- BackupSenderImpl(String) - Constructor for class org.infinispan.xsite.BackupSenderImpl
- backupSequencer - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- backupWrite(WriteCommand) - Method in interface org.infinispan.xsite.BackupSender
- backupWrite(WriteCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
- badRequest(InfinispanSearchRequest, String, String) - Static method in class org.infinispan.rest.search.InfinispanSearchResponse
- BALANCING_STRATEGY - org.infinispan.persistence.remote.configuration.Attribute
- balancingStrategy() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- balancingStrategy(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- balancingStrategy(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- balancingStrategy(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
For replicated (vs distributed) Hot Rod server clusters, the client balances requests to the servers according to this strategy.
- Base64 - Class in org.infinispan.commons.util
-
Deprecated.Not currently used internally by Infinispan; will be removed in ver. 10. Other users are advised to replace it with
Base64
. - Base64.InputStream - Class in org.infinispan.commons.util
-
Deprecated.A
Base64.InputStream
will read data from another java.io.InputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly. - Base64.OutputStream - Class in org.infinispan.commons.util
-
Deprecated.A
Base64.OutputStream
will write data to another java.io.OutputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly. - BaseAsyncInterceptor - Class in org.infinispan.interceptors
-
Base class for an interceptor in the new asynchronous invocation chain.
- BaseAsyncInterceptor() - Constructor for class org.infinispan.interceptors.BaseAsyncInterceptor
- BaseBackupInterceptor - Class in org.infinispan.interceptors.xsite
- BaseBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- BaseBackupReceiver - Class in org.infinispan.xsite
-
Common implementation logic for
BackupReceiver
- BaseBlockingRunnable - Class in org.infinispan.remoting.inboundhandler
-
Common logic to handle
CacheRpcCommand
. - BaseBlockingRunnable(BasePerCacheInboundInvocationHandler, CacheRpcCommand, Reply, boolean) - Constructor for class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- BaseCacheEntryListenerInvocation(ListenerInvocation<Event<K, V>>, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, ?>, Class<? extends Annotation>, boolean, boolean, UUID, boolean, Listener.Observation, Set<Class<? extends Annotation>>, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- BaseCacheStream<T,S extends BaseStream<T,S>> - Interface in org.infinispan
-
Interface that defines the base methods of all streams returned from a
Cache
. - BaseCacheStream.SegmentCompletionListener - Interface in org.infinispan
-
Functional interface that is used as a callback when segments are completed.
- baseCfg - Variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- BaseCustomAsyncInterceptor - Class in org.infinispan.interceptors
-
Anyone using the
AsyncInterceptorChain.addInterceptor(AsyncInterceptor, int)
method (or any of its overloaded forms) or registering custom interceptors via XML should extend this base class when creating their own custom interceptors. - BaseCustomAsyncInterceptor() - Constructor for class org.infinispan.interceptors.BaseCustomAsyncInterceptor
- BaseCustomInterceptor - Class in org.infinispan.interceptors.base
-
Deprecated.Since 9.0, use
BaseCustomAsyncInterceptor
instead. - BaseCustomInterceptor() - Constructor for class org.infinispan.interceptors.base.BaseCustomInterceptor
-
Deprecated.
- BaseDistributionInterceptor - Class in org.infinispan.interceptors.distribution
-
Base class for distribution of entries across a cluster.
- BaseDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- BaseDistributionInterceptor.ReadManyCommandHelper<C> - Interface in org.infinispan.interceptors.distribution
- BaseDistributionInterceptor.ReadOnlyManyHelper - Class in org.infinispan.interceptors.distribution
- BaseExtendedStatisticsContainer - Class in org.infinispan.stats.container
-
Common logic for the
ExtendedStatisticsContainer
- BaseExtendedStatisticsContainer(int) - Constructor for class org.infinispan.stats.container.BaseExtendedStatisticsContainer
- BaseLockingAction - Class in org.infinispan.remoting.inboundhandler.action
-
A base
Action
implementation for locking. - BaseLockingAction(DistributionManager) - Constructor for class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
- BaseLockingAction.InternalState - Enum in org.infinispan.remoting.inboundhandler.action
- BasePerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
-
Implementation with the default handling methods and utilities methods.
- BasePerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- BaseProtoStreamMarshaller - Class in org.infinispan.query.remote.client
-
Provides the starting point for implementing a
Marshaller
that uses Protobuf encoding. - BaseProtoStreamMarshaller() - Constructor for class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
- BaseQueryResponse - Interface in org.infinispan.query.remote.client
- BaseRequestProcessor - Class in org.infinispan.server.hotrod
- BasicCache<K,V> - Interface in org.infinispan.commons.api
-
BasicCache provides the common building block for the two different types of caches that Infinispan provides: embedded and remote.
- BasicCacheContainer - Interface in org.infinispan.commons.api
-
BasicCacheContainer defines the methods used to obtain a
BasicCache
. - basicComponentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
- BasicConfiguration - Interface in org.infinispan.commons.configuration
-
BasicConfiguration provides the basis for concrete configurations.
- BasicMultimapCache<K,V> - Interface in org.infinispan.multimap.api
-
BasicMultimapCache
provides the common API for the two different types of multimap caches that Infinispan provides: embedded and remote. - BATCH - org.infinispan.configuration.parsing.Parser.TransactionMode
- BATCH_SIZE - org.infinispan.persistence.jdbc.configuration.Attribute
- BATCH_SIZE - org.infinispan.persistence.jpa.configuration.Attribute
-
Deprecated.
- BATCH_SIZE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- batchContainer - Variable in class org.infinispan.batch.AutoBatchSupport
- BatchContainer - Class in org.infinispan.batch
-
A container for holding thread locals for batching, to be used with the
BatchingCache.startBatch()
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
- BatchModeTransactionManager - Class in org.infinispan.transaction.tm
-
Not really a transaction manager in the truest sense of the word.
- BatchModification - Class in org.infinispan.persistence.support
-
A simple wrapper class, necessary for Transactional stores, which allows MarshalledEntries and Object keys to be passed to a store implementation in order.
- BatchModification(Set<Object>) - Constructor for class org.infinispan.persistence.support.BatchModification
- batchSize() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
-
Deprecated.please use
AbstractStoreConfiguration.maxBatchSize()
instead. - batchSize() - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfiguration
- batchSize(int) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
Deprecated.Please use
AbstractStoreConfigurationBuilder.maxBatchSize(int)
instead. - batchSize(long) - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationBuilder
-
Deprecated.
- BeanUtils - Class in org.infinispan.commons.util
-
Simple JavaBean manipulation helper methods
- BeanUtils() - Constructor for class org.infinispan.commons.util.BeanUtils
- becomeCoordinator(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
Makes this node the coordinator for the state transfer to the site name.
- becomeCoordinator(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- before() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- before(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Dictates that the custom interceptor appears immediately before the specified interceptor.
- BEFORE - org.infinispan.configuration.parsing.Attribute
- BEFORE - org.infinispan.container.versioning.InequalVersionComparisonResult
-
Denotes a version that was created temporally before another version.
- BEFORE - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
- beforeBackupRemotely(XSiteReplicateCommand) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
-
method invoked before a backup remote invocation.
- beforeCompletion() - Method in class org.infinispan.transaction.synchronization.SynchronizationAdapter
- beforeConfirmRebalancePhase(String, int, Throwable) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- beforeHandle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
-
Invoked before the command is handled by the real
PerCacheInboundInvocationHandler
. - beforeHandleRebalance(String, CacheTopology, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- beforeHandleTopologyUpdate(String, CacheTopology, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- beforeInvalidation(IntSet, IntSet) - Method in interface org.infinispan.statetransfer.StateConsumerImpl.KeyInvalidationListener
- beforeInvoke() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- beforeInvoke() - Method in class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
- beforeInvokeRemotely(ReplicableCommand) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
-
method invoked before a remote invocation.
- beforeTopologyInstalled(int, boolean, ConsistentHash, ConsistentHash) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- begin() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- begin() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.Starts a new transaction, and associate it with the calling thread.
- begin() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
-
Deprecated.Starts a new transaction, and associate it with the calling thread.
- begin() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
- beginTransaction(GlobalTransaction, boolean) - Method in class org.infinispan.stats.CacheStatisticManager
-
Signals the start of a transaction.
- between(Object, Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Checks that the left argument is between the given range limits.
- BI_FUNCTION_MAPPER - Static variable in interface org.infinispan.commons.marshall.Ids
- BIAS_ACQUISITION - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
- BIAS_LIFESPAN - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
- BIAS_REVOCATION_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- biasAcquisition() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
For scattered cache, specifies if the nodes is allowed to cache the entry, serving reads locally.
- biasAcquisition(BiasAcquisition) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
-
Used in scattered cache.
- BiasAcquisition - Enum in org.infinispan.configuration.cache
-
Specifies when is a node allowed to acquire a bias on an entry, serving further reads to the same key locally (despite not being an owner).
- biased() - Method in interface org.infinispan.scattered.BiasManager.Revocation
- BiasedCollector - Interface in org.infinispan.interceptors.distribution
- BiasedScatteredDistributionInterceptor - Class in org.infinispan.interceptors.distribution
- BiasedScatteredDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- biasLifespan() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
For scattered cache, specifies how long is the node allowed to read the cached entry locally.
- biasLifespan(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
-
Used in scattered cache.
- BiasManager - Interface in org.infinispan.scattered
-
This component tracks if this node can read the data stored locally despite not being an owner and which nodes will read the local data that is primary-owned by this node.
- BiasManager.Revocation - Interface in org.infinispan.scattered
- BiasRevocationResponse - Class in org.infinispan.remoting.responses
- BiasRevocationResponse(Object, Address[]) - Constructor for class org.infinispan.remoting.responses.BiasRevocationResponse
- BiasRevocationResponse.Externalizer - Class in org.infinispan.remoting.responses
- BiFunctionMapper - Class in org.infinispan.compat
- BiFunctionMapper(BiFunction, DataConversion, DataConversion) - Constructor for class org.infinispan.compat.BiFunctionMapper
- BiFunctionMapper.Externalizer - Class in org.infinispan.compat
- BINARY - org.infinispan.configuration.cache.StorageType
-
Entries are stored in Java heap but as byte[] instances.
- BINARY - org.infinispan.configuration.parsing.Element
- BINARY - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- BINARY_CONVERTER - Static variable in class org.infinispan.server.core.ExternalizerIds
- BINARY_FILTER - Static variable in class org.infinispan.server.core.ExternalizerIds
- BINARY_FILTER_CONVERTER - Static variable in class org.infinispan.server.core.ExternalizerIds
- BINARY_KEYED_JDBC_STORE - org.infinispan.persistence.jdbc.configuration.Element
- BinaryEncoder - Class in org.infinispan.commons.dataconversion
-
Encoder for StoreType.BINARY.
- BinaryEncoder(StreamingMarshaller) - Constructor for class org.infinispan.commons.dataconversion.BinaryEncoder
- binaryParam() - Method in interface org.infinispan.filter.ParamKeyValueFilterConverterFactory
- bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
- bit() - Method in enum org.infinispan.server.hotrod.tx.ControlByte
- Bits - Class in org.infinispan.container.offheap
-
Utility method for inserting and retrieving values from to/from a byte[]
- Bits() - Constructor for class org.infinispan.container.offheap.Bits
- bitSetOf(Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
- bitSetOf(Enum<?>[]) - Static method in class org.infinispan.commons.util.EnumUtil
- bitSetOf(Enum<?>, Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
- bitSetOf(Enum<?>, Enum<?>, Enum<?>...) - Static method in class org.infinispan.commons.util.EnumUtil
- bitSetOf(Collection<E>) - Static method in class org.infinispan.commons.util.EnumUtil
- bitSetSize(long) - Static method in class org.infinispan.commons.util.EnumUtil
- BitShift - Class in org.infinispan.server.hotrod
- BitShift() - Constructor for class org.infinispan.server.hotrod.BitShift
- BLOCK_SIZE - org.infinispan.persistence.leveldb.configuration.Attribute
- BLOCKED - org.infinispan.scattered.ScatteredVersionManager.SegmentState
- blocking(CompletionStage<T>) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Block on a request and return its result.
- blocking(CompletionStage<T>) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- blocking(CompletionStage<T>) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- BLOCKING_BOUNDED_QUEUE_THREAD_POOL - org.infinispan.configuration.parsing.Element
- BlockingRunnable - Interface in org.infinispan.util.concurrent
-
A special Runnable (for the particular case of Total Order) that is only sent to a thread when it is ready to be executed without blocking the thread
- BlockingTaskAwareExecutorService - Interface in org.infinispan.util.concurrent
-
Executor service that is aware of
BlockingRunnable
and only dispatch the runnable to a thread when it has low (or no) probability of blocking the thread. - BlockingTaskAwareExecutorServiceImpl - Class in org.infinispan.util.concurrent
-
A special executor service that accepts a
BlockingRunnable
. - BlockingTaskAwareExecutorServiceImpl(String, ExecutorService, TimeService) - Constructor for class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- BlockingThreadPoolExecutorFactory - Class in org.infinispan.commons.executors
- BlockingThreadPoolExecutorFactory(int, int, int, long) - Constructor for class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
- blockSize(int) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- BlueprintGenerator - Class in org.infinispan.commons.util
- BlueprintGenerator() - Constructor for class org.infinispan.commons.util.BlueprintGenerator
- bool(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- Boolean(boolean) - Constructor for class org.infinispan.commons.util.ByRef.Boolean
- BOOLEAN - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- booleanResponse(HotRodHeader, HotRodServer, ByteBufAllocator, boolean) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- booleanResponse(HotRodHeader, HotRodServer, ByteBufAllocator, boolean) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- bootstrapComponents() - Method in class org.infinispan.factories.ComponentRegistry
-
Invoked before any
ModuleCommandInitializer
. - BORLAND_SUN - org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- BOTH - org.infinispan.notifications.Listener.Observation
-
Observation level used to be notified of an operation before and after it occurs
- BOTH - org.infinispan.persistence.manager.PersistenceManager.AccessMode
-
The operation is performed in all
CacheWriter
orCacheLoader
- BOUNDED_STRONG - org.infinispan.counter.api.CounterType
-
A strong consistent and bounded counter.
- BoundedExecutors - Class in org.infinispan.util.concurrent
-
Similar to JDK
Executors
except that the factory methods here allow you to specify the size of the blocking queue that backs the executor. - BoundedExecutors() - Constructor for class org.infinispan.util.concurrent.BoundedExecutors
- BoundedOffHeapDataContainer - Class in org.infinispan.container.offheap
- BoundedOffHeapDataContainer(int, long, EvictionType) - Constructor for class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- boxed() - Method in interface org.infinispan.DoubleCacheStream
- boxed() - Method in interface org.infinispan.IntCacheStream
- boxed() - Method in interface org.infinispan.LongCacheStream
- branchQualifierLength() - Method in class org.infinispan.commons.tx.XidImpl
- branchQualifierOffset() - Method in class org.infinispan.commons.tx.XidImpl
- BRING_ONLINE - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
- bringOnline() - Method in class org.infinispan.xsite.OfflineStatus
- bringSiteOnline(String) - Method in interface org.infinispan.xsite.BackupSender
-
Brings a site with the given name back online.
- bringSiteOnline(String) - Method in class org.infinispan.xsite.BackupSenderImpl
- bringSiteOnline(String) - Method in class org.infinispan.xsite.GlobalXSiteAdminOperations
- bringSiteOnline(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
- BROADCAST - org.infinispan.query.dsl.IndexedQueryMode
-
Query is sent to all nodes, and results are combined before returning to the caller.
- broadcastRebalanceStart(String, CacheTopology, boolean, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
- broadcastRebalanceStart(String, CacheTopology, boolean, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- broadcastShutdownCache(String, CacheTopology, boolean, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
- broadcastShutdownCache(String, CacheTopology, boolean, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- broadcastStableTopologyUpdate(String, CacheTopology, boolean, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
- broadcastStableTopologyUpdate(String, CacheTopology, boolean, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- broadcastTopologyUpdate(String, CacheTopology, AvailabilityMode, boolean, boolean) - Method in interface org.infinispan.topology.ClusterTopologyManager
- broadcastTopologyUpdate(String, CacheTopology, AvailabilityMode, boolean, boolean) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- BROUGHT_ONLINE - org.infinispan.xsite.BackupSender.BringSiteOnlineResponse
- buffer(int) - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- buffer(int) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- BUFFER_SIZE - org.infinispan.persistence.rest.configuration.Attribute
- BUFFER_SIZE - Static variable in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- bufferSize() - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- bufferSize(int) - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfigurationBuilder
- BufferSizePredictor - Interface in org.infinispan.commons.marshall
-
Buffer size predictor
- build() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- build() - Method in interface org.infinispan.commons.marshall.MarshallUtil.UnboundedCollectionBuilder
- build() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- build() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- build() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- build() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Builds a
GlobalConfiguration
object using the settings applied to this builder - build() - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
- build() - Method in interface org.infinispan.distexec.DistributedTaskBuilder
-
Completes creation of DistributedTask with the currently provided attributes of this DistributedTaskBuilder
- build() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- build() - Method in interface org.infinispan.metadata.Metadata.Builder
-
Build a metadata instance.
- build() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- build() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.DelegatingCacheInvocationBuilder
- build() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl.DefaultBuilder
- build() - Method in interface org.infinispan.query.dsl.QueryBuilder
-
Builds the query object.
- build() - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
-
Deprecated.
- build() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- build() - Method in class org.infinispan.rest.operations.mime.MimeMetadataBuilder
- build() - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- build() - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Builds a configuration object
- build() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- build() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
- build() - Method in class org.infinispan.xsite.status.AbstractSiteStatusBuilder
- build(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- build(boolean) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- build(boolean) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- build(boolean) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
- build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.ArrayBuilder
- build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.CollectionBuilder
- build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.EnumBuilder
- build(int) - Method in interface org.infinispan.commons.marshall.MarshallUtil.MapBuilder
- build(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- BuildContext - Interface in org.infinispan.lucene.directory
-
Building context to set construction parameters of Infinispan Directory instances
- builder - Variable in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- builder - Variable in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- builder() - Method in class org.infinispan.container.entries.RemoteMetadata
- builder() - Method in class org.infinispan.metadata.EmbeddedMetadata
- builder() - Method in interface org.infinispan.metadata.Metadata
-
Returns an instance of
Metadata.Builder
which can be used to build new instances ofMetadata
instance which are full copies of thisMetadata
. - builder() - Method in class org.infinispan.rest.operations.mime.MimeMetadata
- builder() - Method in class org.infinispan.server.memcached.MemcachedMetadata
- builder(String, T) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- builder(String, T, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- builder(CounterType) - Static method in class org.infinispan.counter.api.CounterConfiguration
- Builder<T> - Interface in org.infinispan.commons.configuration
-
Builder.
- Builder() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Builder
- builderFor(B) - Static method in class org.infinispan.commons.configuration.ConfigurationUtils
-
Returns the builder that was used to build this class.
- builderForNonStrict(B) - Static method in class org.infinispan.commons.configuration.ConfigurationUtils
-
The same as
ConfigurationUtils.builderFor(Object)
except that it won't throw an exception if no builder class is found. - buildInjectionFieldsList() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
-
Deprecated.
- buildInjectionMethodsList() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
-
Deprecated.
- buildInterceptorChain() - Method in class org.infinispan.factories.InterceptorChainFactory
- buildJmxDomain(String, MBeanServer, String) - Static method in class org.infinispan.commons.jmx.JmxUtil
-
Build the JMX domain name.
- buildMetadata() - Method in class org.infinispan.server.memcached.MemcachedDecoder
- buildMetadata(String, long, TimeUnit, long, TimeUnit) - Method in class org.infinispan.persistence.rest.metadata.EmbeddedMetadataHelper
- buildMetadata(String, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.persistence.rest.metadata.MetadataHelper
- buildMetadata(HotRodHeader, long, TimeUnitValue, long, TimeUnitValue) - Method in class org.infinispan.server.hotrod.HotRodServer
- buildQueryBuilderForClass(Class<?>) - Method in interface org.infinispan.query.SearchManager
-
Provides the Hibernate Search DSL entrypoint to build full text queries.
- buildRegistrar() - Method in class org.infinispan.jmx.AbstractJmxRegistration
- buildRegistrar() - Method in class org.infinispan.jmx.CacheJmxRegistration
- buildRegistrar() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
- BuiltBy - Annotation Type in org.infinispan.commons.configuration
-
BuiltBy.
- BULK_GET - org.infinispan.server.hotrod.HotRodOperation
- BULK_GET_KEYS - org.infinispan.server.hotrod.HotRodOperation
- BULK_GET_KEYS_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- BULK_GET_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- BULK_READ - org.infinispan.security.AuthorizationPermission
-
Allows bulk-read operations (e.g.
- BULK_WRITE - org.infinispan.security.AuthorizationPermission
-
Allows bulk-write operations (e.g.
- bulkGetKeysResponse(HotRodHeader, HotRodServer, ByteBufAllocator, CloseableIterator<byte[]>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- bulkGetKeysResponse(HotRodHeader, HotRodServer, ByteBufAllocator, CloseableIterator<byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- bulkGetResponse(HotRodHeader, HotRodServer, ByteBufAllocator, int, CacheSet<Map.Entry<byte[], byte[]>>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- bulkGetResponse(HotRodHeader, HotRodServer, ByteBufAllocator, int, CacheSet<Map.Entry<byte[], byte[]>>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- ByRef<T> - Class in org.infinispan.commons.util
-
This class can be used to pass an argument by reference.
- ByRef(T) - Constructor for class org.infinispan.commons.util.ByRef
- ByRef.Boolean - Class in org.infinispan.commons.util
-
Implementation for primitive type
- ByRef.Integer - Class in org.infinispan.commons.util
- BYTE - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- byte_(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- BYTE_ARRAY_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
- BYTE_BUFFER - Static variable in interface org.infinispan.commons.marshall.Ids
- ByteArrayEquivalence - Class in org.infinispan.commons.equivalence
-
Deprecated.
- ByteArrayEquivalence() - Constructor for class org.infinispan.commons.equivalence.ByteArrayEquivalence
-
Deprecated.
- ByteArrayWrapper - Class in org.infinispan.commons.dataconversion
-
Wraps byte[] on a
WrappedByteArray
to provide equality and hashCode support, leaving other objects unchanged. - ByteArrayWrapper() - Constructor for class org.infinispan.commons.dataconversion.ByteArrayWrapper
- ByteBuffer - Interface in org.infinispan.commons.io
-
A byte buffer that exposes the internal byte array with minimal copying.
- ByteBufferFactory - Interface in org.infinispan.commons.io
-
Used for building instances of
ByteBuffer
. - ByteBufferFactoryImpl - Class in org.infinispan.commons.io
- ByteBufferFactoryImpl() - Constructor for class org.infinispan.commons.io.ByteBufferFactoryImpl
- ByteBufferImpl - Class in org.infinispan.commons.io
-
A byte buffer that exposes the internal byte array with minimal copying
- ByteBufferImpl - Class in org.infinispan.io
-
Deprecated.
- ByteBufferImpl(byte[]) - Constructor for class org.infinispan.commons.io.ByteBufferImpl
- ByteBufferImpl(byte[], int, int) - Constructor for class org.infinispan.commons.io.ByteBufferImpl
- ByteBufferImpl(byte[], int, int) - Constructor for class org.infinispan.io.ByteBufferImpl
-
Deprecated.
- ByteBufferImpl.Externalizer - Class in org.infinispan.commons.io
- BYTES - org.infinispan.commons.util.MemoryUnit
- bytesToHex(byte[]) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
- ByteString - Class in org.infinispan.util
-
A simple class which encapsulates a byte[] representation of a String using a predefined encoding (currently UTF-8).
C
- C3P0ConnectionPool - Class in org.infinispan.persistence.jdbc.connectionfactory
-
Deprecated.Support for the C3P0 connection pool will be removed in 10.0
- C3P0ConnectionPool(ClassLoader, PooledConnectionFactoryConfiguration) - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.C3P0ConnectionPool
-
Deprecated.
- cache - Variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- cache - Variable in class org.infinispan.interceptors.base.BaseCustomInterceptor
-
Deprecated.
- cache - Variable in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
- cache - Variable in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- cache - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- cache - Variable in class org.infinispan.xsite.AbstractCustomFailurePolicy
- cache - Variable in class org.infinispan.xsite.BaseBackupReceiver
- cache(String) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
-
Deprecated.
- cache(Cache<?, ?>) - Method in class org.infinispan.tasks.TaskContext
-
The cache against which this task will be executed.
- cache(HotRodHeader, Subject) - Method in class org.infinispan.server.hotrod.HotRodServer
- cache(HotRodHeader, Subject, String) - Method in class org.infinispan.server.hotrod.HotRodServer
- Cache<K,V> - Interface in org.infinispan
-
The central interface of Infinispan.
- CACHE - org.infinispan.configuration.parsing.ParserScope
-
The cache scope
- CACHE - org.infinispan.persistence.remote.configuration.Element
- CACHE - org.infinispan.security.AuditContext
- CACHE_CONTAINER - org.infinispan.configuration.parsing.Element
- CACHE_CONTAINER - org.infinispan.configuration.parsing.ParserScope
-
The cache-container scope
- CACHE_CREATE - org.infinispan.server.core.admin.AdminOperation
- CACHE_DELIMITER - Static variable in class org.infinispan.xsite.GlobalXSiteAdminOperations
- CACHE_DEPENDENCY_GRAPH - Static variable in class org.infinispan.factories.KnownComponentNames
- CACHE_ENTRY_ACTIVATED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_ENTRY_CREATED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_ENTRY_CREATED_EVENT - org.infinispan.server.hotrod.HotRodOperation
- CACHE_ENTRY_EVICTED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_ENTRY_EXPIRED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_ENTRY_EXPIRED_EVENT - org.infinispan.server.hotrod.HotRodOperation
- CACHE_ENTRY_INVALIDATED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_ENTRY_LOADED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_ENTRY_MODIFIED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_ENTRY_MODIFIED_EVENT - org.infinispan.server.hotrod.HotRodOperation
- CACHE_ENTRY_PASSIVATED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_ENTRY_REMOVED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_ENTRY_REMOVED_EVENT - org.infinispan.server.hotrod.HotRodOperation
- CACHE_ENTRY_VISITED - org.infinispan.notifications.cachelistener.event.Event.Type
- CACHE_EVENT_CONVERTER_AS_CONVERTER - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_EVENT_FILTER_AS_KEY_VALUE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_EVENT_FILTER_CONVERTER_AS_KEY_VALUE_FILTER_CONVERTER - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_FILTERS - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheJmxRegistration
- CACHE_JOIN_INFO - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_MANAGER_JMX_GROUP - Static variable in class org.infinispan.jmx.CacheManagerJmxRegistration
- CACHE_MANAGER_NAME - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- CACHE_MODE - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
- CACHE_MODE_LOCAL - org.infinispan.context.Flag
-
Forces LOCAL mode operation, even if the cache is configured to use a clustered mode like replication, invalidation or distribution.
- CACHE_NAME - org.infinispan.server.core.admin.AdminOperationParameter
- CACHE_NAME - Static variable in class org.infinispan.factories.KnownComponentNames
- CACHE_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- CACHE_NOT_FOUND_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_REMOVE - org.infinispan.server.core.admin.AdminOperation
- CACHE_RPC_COMMAND - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_SIZE - org.infinispan.persistence.leveldb.configuration.Attribute
- CACHE_STARTED - org.infinispan.notifications.cachemanagerlistener.event.Event.Type
- CACHE_STATE - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_STATUS_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_STOP_TIMEOUT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- CACHE_STOPPED - org.infinispan.notifications.cachemanagerlistener.event.Event.Type
- CACHE_TEMPLATE - org.infinispan.configuration.parsing.ParserScope
-
The cache template scope
- CACHE_TEMPLATE - org.infinispan.server.core.admin.AdminOperationParameter
- CACHE_TOPOLOGY - Static variable in interface org.infinispan.commons.marshall.Ids
- CACHE_XID - Static variable in class org.infinispan.server.core.ExternalizerIds
- CacheAware<K,V> - Interface in org.infinispan.stream
-
Interface that describes how a cache can be injected into another object.
- CacheCollection<E> - Interface in org.infinispan
-
A collection type that returns special Cache based streams that have additional options to tweak behavior.
- CacheCollectionMapper<E,R> - Class in org.infinispan.util
-
Deprecated.since 9.2.1 It is recommended to use
WriteableCacheCollectionMapper
instead as it allows for constant time contains and other operations - CacheCollectionMapper(CacheCollection<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.CacheCollectionMapper
-
Deprecated.CacheCollection that maps entries to new type that takes a key filter that is
Function.identity()
- CacheCollectionMapper(CacheCollection<E>, Function<? super E, ? extends R>, InjectiveFunction<Object, ?>) - Constructor for class org.infinispan.util.CacheCollectionMapper
-
Deprecated.CacheCollection that maps entries to new type that takes a provided key filter.
- CacheCollectors - Class in org.infinispan.stream
-
Helper class designed to be used to create a serializable Collector for use with
CacheStream.collect(Collector)
from a supplier of a collector. - cacheComponents() - Method in class org.infinispan.factories.ComponentRegistry
-
Invoked last after all services are wired
- cacheConfiguration - Variable in class org.infinispan.interceptors.base.CommandInterceptor
-
Deprecated.
- cacheConfiguration - Variable in class org.infinispan.interceptors.BaseAsyncInterceptor
- cacheConfiguration - Variable in class org.infinispan.server.memcached.MemcachedDecoder
- CacheConfigurationException - Exception in org.infinispan.commons
-
An exception that represents an error in the configuration.
- CacheConfigurationException(Exception) - Constructor for exception org.infinispan.commons.CacheConfigurationException
- CacheConfigurationException(String) - Constructor for exception org.infinispan.commons.CacheConfigurationException
- CacheConfigurationException(String, String) - Constructor for exception org.infinispan.commons.CacheConfigurationException
-
Deprecated.
- CacheConfigurationException(String, Throwable) - Constructor for exception org.infinispan.commons.CacheConfigurationException
- CacheContainer - Interface in org.infinispan.manager
- CacheContainerAdmin<C extends CacheContainerAdmin,A extends BasicConfiguration> - Interface in org.infinispan.commons.api
-
Administrative cache container operations.
- CacheContainerAdmin.AdminFlag - Enum in org.infinispan.commons.api
-
Flags which affect only administrative operations
- CacheContainerStats - Interface in org.infinispan.stats
-
Similar to
Stats
but in the scope of a single per node CacheContainer - cacheControl(CacheControl) - Method in class org.infinispan.rest.InfinispanCacheResponse
-
Adds Cache Control headers.
- CacheControl - Class in org.infinispan.rest
-
A helper class for controlling Cache Control headers.
- CacheCreateTask - Class in org.infinispan.server.core.admin.embeddedserver
-
Admin operation to create a cache Parameters: name the name of the cache to create flags any flags, e.g.
- CacheCreateTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
- CACHED_THREAD_POOL - org.infinispan.configuration.parsing.Element
- CACHED_VALUES - Static variable in enum org.infinispan.functional.Param.ReplicationMode
- CachedThreadPoolExecutorFactory - Enum in org.infinispan.commons.executors
- CacheEntriesEvicted - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when cache entries are evicted.
- CacheEntriesEvictedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
This event subtype is passed in to any method annotated with
CacheEntriesEvicted
. - CacheEntry<K,V> - Interface in org.infinispan.container.entries
-
An entry that is stored in the data container
- CacheEntryActivated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when a cache entry is activated.
- CacheEntryActivatedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
This event subtype is passed in to any method annotated with
CacheEntryActivated
. - CacheEntryCreated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when a cache entry is created.
- CacheEntryCreatedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
This event subtype is passed in to any method annotated with
CacheEntryCreated
. - CacheEntryEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
A transactional event subtype that additionally expose a key as such events pertain to a specific cache entry.
- CacheEntryExpired - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when a cache entry is expired
- CacheEntryExpiredEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
This event subtype is passed in to any method annotated with
CacheEntryExpired
. - CacheEntryInvalidated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when a cache entry is invalidated.
- CacheEntryInvalidatedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
Notifies a listener of an invalidation event.
- CacheEntryListenerInvocation<K,V> - Interface in org.infinispan.notifications.cachelistener
-
Additional listener methods specific to caches.
- CacheEntryLoaded - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when a cache entry is loaded from a
CacheLoader
. - CacheEntryLoadedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
This event subtype is passed in to any method annotated with
CacheEntryLoaded
. - CacheEntryModified - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when a cache entry has been modified.
- CacheEntryModifiedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
This event subtype is passed in to any method annotated with
CacheEntryModified
- CacheEntryPassivated - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when cache entries are passivated.
- CacheEntryPassivatedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
This event subtype is passed in to any method annotated with
CacheEntryPassivated
. - CacheEntryRemoved - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when a cache entry is removed from the cache.
- CacheEntryRemovedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
This event subtype is passed in to any method annotated with
CacheEntryRemoved
. - cacheEntrySet() - Method in interface org.infinispan.AdvancedCache
-
Identical to
Cache.entrySet()
but is typed to return CacheEntries instead of Entries. - CacheEntrySizeCalculator<K,V> - Class in org.infinispan.container.entries
-
Implementation of a size calculator that calcultes only the size of the value assuming it is an InternalCacheEntry.
- CacheEntrySizeCalculator(EntrySizeCalculator<? super K, ? super V>) - Constructor for class org.infinispan.container.entries.CacheEntrySizeCalculator
- CacheEntryVisited - Annotation Type in org.infinispan.notifications.cachelistener.annotation
-
This annotation should be used on methods that need to be notified when a cache entry is visited.
- CacheEntryVisitedEvent<K,V> - Interface in org.infinispan.notifications.cachelistener.event
-
This event subtype is passed in to any method annotated with
CacheEntryVisited
. - CacheEventConverter<K,V,C> - Interface in org.infinispan.notifications.cachelistener.filter
-
A converter that can be used to convert the value given for an event.
- CacheEventConverterAsConverter<K,V,C> - Class in org.infinispan.notifications.cachelistener.filter
-
Converter that is implemented by using the provided CacheEventConverter.
- CacheEventConverterAsConverter(CacheEventConverter<K, V, C>) - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventConverterAsConverter
- CacheEventConverterAsConverter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
- CacheEventConverterFactory - Interface in org.infinispan.notifications.cachelistener.filter
-
Factory that can produce CacheEventConverters
- CacheEventFilter<K,V> - Interface in org.infinispan.notifications.cachelistener.filter
-
A filter that can be used to tell if an event should be raised or not.
- CacheEventFilterAsKeyValueFilter<K,V> - Class in org.infinispan.notifications.cachelistener.filter
-
KeyValueFilter that is implemented by using the provided CacheEventFilter.
- CacheEventFilterAsKeyValueFilter(CacheEventFilter<K, V>) - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterAsKeyValueFilter
- CacheEventFilterAsKeyValueFilter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
- CacheEventFilterConverter<K,V,C> - Interface in org.infinispan.notifications.cachelistener.filter
-
This interface is an optimization that can be used when an event filter and converter are most efficiently used as the same object composing the filtering and conversion in the same method invocation.
- CacheEventFilterConverterAsKeyValueFilterConverter<K,V,C> - Class in org.infinispan.notifications.cachelistener.filter
- CacheEventFilterConverterAsKeyValueFilterConverter(CacheEventFilterConverter<K, V, C>) - Constructor for class org.infinispan.notifications.cachelistener.filter.CacheEventFilterConverterAsKeyValueFilterConverter
- CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
- CacheEventFilterConverterFactory - Interface in org.infinispan.notifications.cachelistener.filter
-
Factory that can produce
CacheEventFilterConverter
instances. - CacheEventFilterFactory - Interface in org.infinispan.notifications.cachelistener.filter
-
Factory that can produce CacheEventFilters
- CacheException - Exception in org.infinispan.commons
-
Thrown when operations fail unexpectedly.
- CacheException() - Constructor for exception org.infinispan.commons.CacheException
- CacheException(String) - Constructor for exception org.infinispan.commons.CacheException
- CacheException(String, Throwable) - Constructor for exception org.infinispan.commons.CacheException
- CacheException(String, Throwable, boolean, boolean) - Constructor for exception org.infinispan.commons.CacheException
- CacheException(Throwable) - Constructor for exception org.infinispan.commons.CacheException
- cacheExists(String) - Method in class org.infinispan.manager.DefaultCacheManager
- cacheExists(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
A cache is considered to exist if it has been created and started via one of the
CacheContainer.getCache()
methods and has not yet been removed viaEmbeddedCacheManager.removeCache(String)
. - CacheFilters - Class in org.infinispan.filter
-
Static factory class that contains utility methods that can be used for performing proper transformations from
KeyValueFilter
,Converter
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.
- CacheIgnoreAware - Interface in org.infinispan.server.core
-
Defines an interface to be used when a cache is to be ignored by a server implementation.
- CacheInvocationBuilder() - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- CacheJmxRegistration - Class in org.infinispan.jmx
-
If
Configuration.jmxStatistics()
is enabled, then class will register all the MBeans from cache local's ConfigurationRegistry to the MBean server. - CacheJmxRegistration() - Constructor for class org.infinispan.jmx.CacheJmxRegistration
- CacheJoinException - Exception in org.infinispan.topology
-
Thrown when a cache fails to join a cluster
- CacheJoinException() - Constructor for exception org.infinispan.topology.CacheJoinException
- CacheJoinException(String) - Constructor for exception org.infinispan.topology.CacheJoinException
- CacheJoinException(String, Throwable) - Constructor for exception org.infinispan.topology.CacheJoinException
- CacheJoinException(Throwable) - Constructor for exception org.infinispan.topology.CacheJoinException
- CacheJoinInfo - Class in org.infinispan.topology
-
This class contains the information that a cache needs to supply to the coordinator when starting up.
- CacheJoinInfo(ConsistentHashFactory, Hash, int, int, long, boolean, CacheMode, float, PersistentUUID, Optional<Integer>) - Constructor for class org.infinispan.topology.CacheJoinInfo
- CacheJoinInfo.Externalizer - Class in org.infinispan.topology
- CacheListenerException - Exception in org.infinispan.commons
-
Wraps exceptions produced by listener implementations.
- CacheListenerException() - Constructor for exception org.infinispan.commons.CacheListenerException
- CacheListenerException(String) - Constructor for exception org.infinispan.commons.CacheListenerException
- CacheListenerException(String, Throwable) - Constructor for exception org.infinispan.commons.CacheListenerException
- CacheListenerException(Throwable) - Constructor for exception org.infinispan.commons.CacheListenerException
- CacheLoader<K,V> - Interface in org.infinispan.persistence.spi
-
Defines the logic for loading data from an external storage.
- cacheManager - Variable in class org.infinispan.query.remote.CompatibilityProtoStreamMarshaller
- cacheManager - Variable in class org.infinispan.server.core.AbstractProtocolServer
- cacheManager(EmbeddedCacheManager) - Method in class org.infinispan.tasks.TaskContext
-
The cache manager with which this task should be executed
- CACHEMANAGER - org.infinispan.security.AuditContext
- CacheManagerJmxRegistration - Class in org.infinispan.jmx
-
Registers all the components from global component registry to the mbean server.
- CacheManagerJmxRegistration() - Constructor for class org.infinispan.jmx.CacheManagerJmxRegistration
- cacheManagerName() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- cacheManagerName(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
-
If JMX statistics are enabled, this property represents the name of this cache manager.
- CacheManagerNotifier - Interface in org.infinispan.notifications.cachemanagerlistener
-
Notifications for the cache manager
- CacheManagerNotifierImpl - Class in org.infinispan.notifications.cachemanagerlistener
-
Global, shared notifications on the cache manager.
- CacheManagerNotifierImpl() - Constructor for class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- CacheManagerNotifierImpl.DefaultBuilder - Class in org.infinispan.notifications.cachemanagerlistener
- cacheManagerStarted(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
-
Deprecated.
- cacheManagerStarted(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
- cacheManagerStarted(GlobalComponentRegistry) - Method in class org.infinispan.server.hotrod.LifecycleCallbacks
- cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
-
Deprecated.
- cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
- cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.lucene.LifecycleCallbacks
- cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.persistence.remote.LifecycleCallbacks
- cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.rest.LifecycleCallbacks
- cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.server.core.LifecycleCallbacks
- cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.server.hotrod.LifecycleCallbacks
- cacheManagerStarting(GlobalComponentRegistry, GlobalConfiguration) - Method in class org.infinispan.server.memcached.LifecycleCallbacks
- cacheManagerStopped(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
-
Deprecated.
- cacheManagerStopped(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
- cacheManagerStopping(GlobalComponentRegistry) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
-
Deprecated.
- cacheManagerStopping(GlobalComponentRegistry) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
- CacheMixedSiteStatus - Class in org.infinispan.xsite.status
-
A mixed
SiteStatus
. - CacheMixedSiteStatus(List<Address>, List<Address>) - Constructor for class org.infinispan.xsite.status.CacheMixedSiteStatus
- cacheMode() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
Cache mode.
- cacheMode() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
- cacheMode(CacheMode) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
-
Cache mode.
- CacheMode - Enum in org.infinispan.configuration.cache
-
Cache replication mode.
- cacheModeString() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
- cacheName - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- cacheName - Variable in class org.infinispan.statetransfer.StateProviderImpl
- cacheName - Variable in class org.infinispan.statetransfer.StateTransferManagerImpl
- cacheName - Variable in class org.infinispan.transaction.xa.XaTransactionTable
- cacheName - Variable in class org.infinispan.xsite.BaseBackupReceiver
- cacheName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- cacheName() - Method in annotation type org.infinispan.spring.session.configuration.EnableInfinispanEmbeddedHttpSession
-
Cache name used for storing session data.
- cacheName() - Method in annotation type org.infinispan.spring.session.configuration.EnableInfinispanRemoteHttpSession
-
Cache name used for storing session data.
- CacheNameCollector - Interface in org.infinispan.server.hotrod.tx.table
-
Used by
GlobalTxTable
, it collects all the involved cache name when setting a decision for a transaction. - CacheNamesTask - Class in org.infinispan.server.core.admin.embeddedserver
-
Admin operation to obtain a list of caches
- CacheNamesTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheNamesTask
- CacheNotFoundException - Exception in org.infinispan.rest.cachemanager.exceptions
- CacheNotFoundException(String) - Constructor for exception org.infinispan.rest.cachemanager.exceptions.CacheNotFoundException
- CacheNotFoundResponse - Class in org.infinispan.remoting.responses
-
A response that signals the named cache is not running on the target node.
- CacheNotFoundResponse.Externalizer - Class in org.infinispan.remoting.responses
- cacheNotifier - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- cacheNotifier - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- CacheNotifier<K,V> - Interface in org.infinispan.notifications.cachelistener
-
Public interface with all allowed notifications.
- CacheNotifierImpl<K,V> - Class in org.infinispan.notifications.cachelistener
-
Helper class that handles all notifications to registered listeners.
- CacheNotifierImpl() - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- CacheNotifierImpl.BaseCacheEntryListenerInvocation<K,V> - Class in org.infinispan.notifications.cachelistener
- CacheNotifierImpl.CacheInvocationBuilder - Class in org.infinispan.notifications.cachelistener
- CacheNotifierImpl.ClusteredListenerInvocation<K,V> - Class in org.infinispan.notifications.cachelistener
-
This class is to be used with cluster listener invocations only when they have included current state.
- CacheNotifierImpl.DelegatingCacheInvocationBuilder - Class in org.infinispan.notifications.cachelistener
- CacheOperations - Class in org.infinispan.rest.operations
-
REST Operations implementation.
- CacheOperations(RestServerConfiguration, RestCacheManager<Object>) - Constructor for class org.infinispan.rest.operations.CacheOperations
-
Creates new instance of
CacheOperations
. - CacheOperationsHelper - Class in org.infinispan.rest.operations
- CachePermission - Class in org.infinispan.security
-
CachePermission.
- CachePermission(String) - Constructor for class org.infinispan.security.CachePermission
- CachePermission(AuthorizationPermission) - Constructor for class org.infinispan.security.CachePermission
- CachePermissionCollection - Class in org.infinispan.security
-
CachePermissionCollection.
- CachePermissionCollection() - Constructor for class org.infinispan.security.CachePermissionCollection
- CacheQuery<E> - Interface in org.infinispan.query
-
A cache-query is what will be returned when the getQuery() method is run on
SearchManagerImpl
. - CacheReindexTask - Class in org.infinispan.server.core.admin.embeddedserver
-
Admin operation to reindex a cache Parameters: name the name of the cache to reindex flags unused
- CacheReindexTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheReindexTask
- CacheRemoveTask - Class in org.infinispan.server.core.admin.embeddedserver
-
Admin operation to remove a cache Parameters: name the name of the cache to remove flags
- CacheRemoveTask() - Constructor for class org.infinispan.server.core.admin.embeddedserver.CacheRemoveTask
- CacheRpcCommandExternalizer - Class in org.infinispan.marshall.exts
-
Externalizer in charge of marshalling cache specific commands.
- CacheRpcCommandExternalizer(GlobalComponentRegistry, ReplicableCommandExternalizer) - Constructor for class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
- CacheSet<E> - Interface in org.infinispan
-
A set that also must implement the various
CacheCollection
methods for streams. - CacheSetMapper<E,R> - Class in org.infinispan.util
-
A
CacheSet
that allows for a different set to be mapped as a different instance wtih values replaced on request. - CacheSetMapper(CacheSet<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.CacheSetMapper
- cacheShutdown(String) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Initiates a cluster-wide cache shutdown for the specified cache
- cacheShutdown(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- cacheShutdown(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- CacheSiteStatusBuilder - Class in org.infinispan.xsite.status
-
A per-cache
SiteStatus
builder. - CacheSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.CacheSiteStatusBuilder
- cacheSize(long) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- cacheStarted(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
-
Deprecated.
- cacheStarted(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
- cacheStarted(Event) - Method in class org.infinispan.persistence.support.SingletonCacheWriter.SingletonStoreListener
-
Deprecated.Cache started, check whether the cache is the coordinator and set the singleton store's active status.
- CacheStarted - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
-
This annotation should be used on methods that need to be notified when a cache is started.
- CacheStartedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
-
This event is passed in to any method annotated with
CacheStarted
. - cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
-
Deprecated.
- cacheStarting(ComponentRegistry, Configuration, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
- cacheStarting(ComponentRegistry, Configuration, String) - Method in class org.infinispan.server.hotrod.LifecycleCallbacks
- CacheStatisticCollector - Class in org.infinispan.stats
-
Collects and maintains all the statistics for a cache.
- CacheStatisticCollector(TimeService) - Constructor for class org.infinispan.stats.CacheStatisticCollector
- CacheStatisticManager - Class in org.infinispan.stats
-
Manages all the statistics for a single cache.
- CacheStatisticManager(Configuration, TimeService) - Constructor for class org.infinispan.stats.CacheStatisticManager
- CacheStatusResponse - Class in org.infinispan.topology
- CacheStatusResponse(CacheJoinInfo, CacheTopology, CacheTopology, AvailabilityMode) - Constructor for class org.infinispan.topology.CacheStatusResponse
- CacheStatusResponse.Externalizer - Class in org.infinispan.topology
- cacheStopped(String) - Method in class org.infinispan.server.hotrod.HotRodServer
- cacheStopped(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
-
Deprecated.
- cacheStopped(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
- cacheStopped(CacheStoppedEvent) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
- CacheStopped - Annotation Type in org.infinispan.notifications.cachemanagerlistener.annotation
-
This annotation should be used on methods that need to be notified when a cache is stopped.
- CacheStoppedEvent - Interface in org.infinispan.notifications.cachemanagerlistener.event
-
This event is passed in to any method annotated with
CacheStopped
. - cacheStopping(ComponentRegistry, String) - Method in class org.infinispan.lifecycle.AbstractModuleLifecycle
-
Deprecated.
- cacheStopping(ComponentRegistry, String) - Method in interface org.infinispan.lifecycle.ModuleLifecycle
- cacheStopTimeout() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
- cacheStopTimeout(long) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
- cacheStopTimeout(long) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
- cacheStopTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
If there are any ongoing transactions when a cache is stopped, Infinispan waits for ongoing remote and local transactions to finish.
- CacheStoreFactory - Interface in org.infinispan.persistence.factory
-
Creates Cache Store instances.
- CacheStoreFactoryRegistry - Class in org.infinispan.persistence.factory
-
Registry for multiple
CacheStoreFactory
objects. - CacheStoreFactoryRegistry() - Constructor for class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
- CacheStoreFactoryRegistryFactory - Class in org.infinispan.factories
- CacheStoreFactoryRegistryFactory() - Constructor for class org.infinispan.factories.CacheStoreFactoryRegistryFactory
- CacheStream<R> - Interface in org.infinispan
- cacheTopology - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- CacheTopology - Class in org.infinispan.topology
-
The status of a cache from a distribution/state transfer point of view.
- CacheTopology(int, int, ConsistentHash, ConsistentHash, ConsistentHash, CacheTopology.Phase, List<Address>, List<PersistentUUID>) - Constructor for class org.infinispan.topology.CacheTopology
- CacheTopology(int, int, ConsistentHash, ConsistentHash, CacheTopology.Phase, List<Address>, List<PersistentUUID>) - Constructor for class org.infinispan.topology.CacheTopology
- CacheTopology.Externalizer - Class in org.infinispan.topology
- CacheTopology.Phase - Enum in org.infinispan.topology
-
Phase of the rebalance process.
- CacheTopologyControlCommand - Class in org.infinispan.topology
-
A control command for all cache membership/rebalance operations.
- CacheTopologyControlCommand() - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
- CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
- CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, int, int, Throwable, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
- CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, AvailabilityMode, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
- CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, CacheJoinInfo, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
- CacheTopologyControlCommand(String, CacheTopologyControlCommand.Type, Address, CacheTopology, AvailabilityMode, int) - Constructor for class org.infinispan.topology.CacheTopologyControlCommand
- CacheTopologyControlCommand.Type - Enum in org.infinispan.topology
- CacheTopologyHandler - Interface in org.infinispan.topology
-
The link between
LocalTopologyManager
andStateTransferManager
. - CacheTransaction - Interface in org.infinispan.transaction.xa
-
Defines the state a infinispan transaction should have.
- CacheTransaction.TransactionCompletedListener - Interface in org.infinispan.transaction.xa
- CacheUnavailableException - Exception in org.infinispan.rest.cachemanager.exceptions
- CacheUnavailableException(String) - Constructor for exception org.infinispan.rest.cachemanager.exceptions.CacheUnavailableException
- CacheUnreachableException - Exception in org.infinispan.remoting
-
Signals a backup site was unreachable.
- CacheUnreachableException(String) - Constructor for exception org.infinispan.remoting.CacheUnreachableException
- CacheUnreachableException(UnreachableException) - Constructor for exception org.infinispan.remoting.CacheUnreachableException
- CacheUsageInterceptor - Class in org.infinispan.stats.topK
-
Intercepts the VisitableCommands to calculate the corresponding top-key values.
- CacheUsageInterceptor() - Constructor for class org.infinispan.stats.topK.CacheUsageInterceptor
- CacheWriter<K,V> - Interface in org.infinispan.persistence.spi
-
Allows persisting data to an external storage, as opposed to the
CacheLoader
. - CacheXid - Class in org.infinispan.server.hotrod.tx.table
-
A key used in the global transaction table.
- CacheXid(ByteString, XidImpl) - Constructor for class org.infinispan.server.hotrod.tx.table.CacheXid
- calcCacheControl(Date) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- calcFreshness(Date) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- calculateConflictHash(ConsistentHash, Set<ConsistentHash>, List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
- calculateRank(ViewChangedEvent) - Method in class org.infinispan.container.versioning.NumericVersionGenerator.RankCalculator
- calculateSize(Object, Object) - Method in class org.infinispan.container.entries.PrimitiveEntrySizeCalculator
- calculateSize(K, InternalCacheEntry<K, V>) - Method in class org.infinispan.container.entries.CacheEntrySizeCalculator
- calculateSize(K, V) - Method in interface org.infinispan.commons.util.EntrySizeCalculator
-
Method used to calculate how much memory in size the key and value use.
- calculateSize(K, V) - Method in class org.infinispan.marshall.core.WrappedByteArraySizeCalculator
- calculateSize(K, V, Metadata) - Method in class org.infinispan.container.entries.CacheEntrySizeCalculator
- calculateSize(WrappedBytes, WrappedBytes, Metadata) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
-
Method used to calculate how much memory in size the key, value and metadata use.
- calculateSize(WrappedBytes, WrappedBytes, Metadata) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
- calculateState(long, long, long) - Static method in class org.infinispan.counter.util.Utils
-
Calculates the
CounterState
to use based on the value and the boundaries. - call() - Method in class org.infinispan.distexec.RunnableAdapter
- call() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable
- call() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable
- call() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
- call() - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable
- call() - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask
- call() - Method in class org.infinispan.remoting.LocalInvocation
- call() - Method in class org.infinispan.remoting.transport.AbstractRequest
- callable(Callable<T>) - Method in interface org.infinispan.distexec.DistributedTaskBuilder
-
Provide relevant
Callable
for theDistributedTask
- callAsync() - Method in class org.infinispan.remoting.LocalInvocation
- callbackHandler() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- callbackHandler(CallbackHandler) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Specifies a
CallbackHandler
to be used during the authentication handshake. - CALLTIME - org.infinispan.jmx.annotations.DataType
- canBlock() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
- canBlock() - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- canBlock() - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- canBlock() - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
- canBlock() - Method in class org.infinispan.statetransfer.StateRequestCommand
- canBlock() - Method in class org.infinispan.statetransfer.StateResponseCommand
- canBlock() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- canBlock() - Method in class org.infinispan.topology.HeartBeatCommand
- canBlock() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- cancel() - Method in class org.infinispan.statetransfer.InboundTransferTask
-
Cancels all the segments and marks them as finished, sends a cancel command, then completes the task.
- cancel() - Method in class org.infinispan.statetransfer.OutboundTransferTask
-
Cancel the whole task.
- cancel(boolean) - Method in class org.infinispan.remoting.transport.AbstractRequest
- cancel(Exception) - Method in class org.infinispan.remoting.transport.AbstractRequest
- cancel(LockState) - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
-
It cancels the
LockPromise
if possible. - CANCEL_CONSISTENCY_CHECK - org.infinispan.statetransfer.StateRequestCommand.Type
- CANCEL_SEND - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
- CANCEL_STATE_TRANSFER - org.infinispan.statetransfer.StateRequestCommand.Type
- CANCELED - org.infinispan.remoting.inboundhandler.action.ActionStatus
-
The action is completed unsuccessfully.
- CANCELED - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
- cancellationService - Variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- cancelOutboundTransfer(Address, int, IntSet) - Method in interface org.infinispan.statetransfer.StateProvider
-
Cancel sending of cache entries that belong to the given set of segments.
- cancelOutboundTransfer(Address, int, IntSet) - Method in class org.infinispan.statetransfer.StateProviderImpl
- cancelPushState(String) - Method in class org.infinispan.xsite.GlobalXSiteAdminOperations
- cancelPushState(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
It cancels a running state transfer.
- cancelPushState(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- cancelPushState(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
- cancelQueuedTasks() - Method in class org.infinispan.executors.SemaphoreCompletionService
-
When stopping, cancel any queued tasks.
- cancelReceive(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
Sets the cluster to normal state.
- cancelReceive(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- cancelReceiveState(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
- cancelSegments(IntSet) - Method in class org.infinispan.statetransfer.InboundTransferTask
-
Cancels a set of segments and marks them as finished.
- cancelSegments(IntSet) - Method in class org.infinispan.statetransfer.OutboundTransferTask
-
Cancel some of the segments.
- cancelStateTransfer(String) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
-
It cancels the state transfer for the remote site.
- cancelStateTransfer(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
- cancelTransfers(IntSet) - Method in class org.infinispan.statetransfer.StateConsumerImpl
-
Cancel transfers for segments we no longer own.
- canExecute() - Method in class org.infinispan.io.GridFile
- canExpire() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- canExpire() - Method in class org.infinispan.container.entries.ImmortalCacheValue
- canExpire() - Method in interface org.infinispan.container.entries.InternalCacheEntry
- canExpire() - Method in interface org.infinispan.container.entries.InternalCacheValue
- canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
- canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
- canExpire() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- canExpire() - Method in class org.infinispan.container.entries.MortalCacheEntry
- canExpire() - Method in class org.infinispan.container.entries.MortalCacheValue
- canExpire() - Method in class org.infinispan.container.entries.TransientCacheEntry
- canExpire() - Method in class org.infinispan.container.entries.TransientCacheValue
- canExpire() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- canExpireMaxIdle() - Method in interface org.infinispan.container.entries.InternalCacheEntry
- canExpireMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- canExpireMaxIdle() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- canExpireMaxIdle() - Method in class org.infinispan.container.entries.TransientCacheEntry
- canExpireMaxIdle() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- CANNOT_ASSUME_DENOM_IS_POWER_OF_TWO - Static variable in class org.infinispan.io.ModularArithmetic
- canRead() - Method in class org.infinispan.io.GridFile
- canWrite() - Method in class org.infinispan.io.GridFile
- capacity() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- capacity() - Method in interface org.infinispan.container.DataContainer
-
Returns the capacity of the underlying container.
- capacity() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- CAPACITY_FACTOR - org.infinispan.configuration.parsing.Attribute
- CAPACITY_FACTOR - Static variable in class org.infinispan.configuration.cache.HashConfiguration
- capacityFactor() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Controls the proportion of entries that will reside on the local node, compared to the other nodes in the cluster.
- capacityFactor(float) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Controls the proportion of entries that will reside on the local node, compared to the other nodes in the cluster.
- cas(BaseLockingAction.InternalState, BaseLockingAction.InternalState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
- Casting - Class in org.infinispan.util
- Casting() - Constructor for class org.infinispan.util.Casting
- cause() - Method in interface org.infinispan.distexec.FailoverContext
-
Returns the Throwable which was the cause of the task failure.
- CAUSE - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- cdl - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- cdl - Variable in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- CERTIFICATE_PASSWORD - org.infinispan.persistence.remote.configuration.Attribute
- ch - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareCollection
- ch - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- ch - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- CH_UPDATE - org.infinispan.topology.CacheTopologyControlCommand.Type
- challenge(InfinispanRequest) - Method in interface org.infinispan.rest.authentication.Authenticator
-
Challenges specific
InfinispanRequest
for authentication. - CHANGED - org.infinispan.container.entries.ReadCommittedEntry.Flags
- channel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- channel - Variable in class org.infinispan.server.hotrod.BaseRequestProcessor
- CHANNEL_LOOKUP - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- channelActive(Channel) - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
- channelActive(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.StatsChannelHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.infinispan.rest.cors.CorsHandler
- channelRead(ChannelHandlerContext, Object) - Method in class org.infinispan.server.core.transport.StatsChannelHandler
- channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class org.infinispan.rest.Http11RequestHandler
- channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class org.infinispan.rest.Http20RequestHandler
- characteristics() - Method in class org.infinispan.commons.util.ArrayCollector
- characteristics() - Method in class org.infinispan.commons.util.FilterSpliterator
- characteristics() - Method in class org.infinispan.commons.util.FlattenSpliterator
- characteristics() - Method in class org.infinispan.commons.util.SpliteratorMapper
- charset(Charset) - Method in class org.infinispan.rest.InfinispanResponse
-
Adds a charset.
- Charset - Class in org.infinispan.rest.operations.mediatypes
-
Represents Charset.
- CHARSET - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- check(ActionState) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
-
It checks this action.
- check(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
- check(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.CheckTopologyAction
- check(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.TriangleOrderAction
- check(ActionState) - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- CheckedClassResolver - Class in org.infinispan.commons.marshall.jboss
- CheckedClassResolver(ClassWhiteList, ClassLoader) - Constructor for class org.infinispan.commons.marshall.jboss.CheckedClassResolver
- CheckedInputStream - Class in org.infinispan.commons.marshall
- CheckedInputStream(InputStream, ClassWhiteList) - Constructor for class org.infinispan.commons.marshall.CheckedInputStream
- checkForReadyTasks() - Method in class org.infinispan.executors.LazyInitializingBlockingTaskAwareExecutorService
- checkForReadyTasks() - Method in interface org.infinispan.util.concurrent.BlockingTaskAwareExecutorService
-
It checks for tasks ready to be processed in this
ExecutorService
. - checkForReadyTasks() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- checking(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
- checking(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.LockAction
- checking(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.PendingTxAction
- CHECKING - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
- checkLockAndStore(Object, EntryVersion, Function<CompletableFuture<?>, CompletableFuture<?>>, Consumer<Object>) - Method in interface org.infinispan.persistence.manager.OrderedUpdatesManager
- checkLockAndStore(Object, EntryVersion, Function<CompletableFuture<?>, CompletableFuture<?>>, Consumer<Object>) - Method in class org.infinispan.persistence.manager.OrderedUpdatesManagerImpl
- checkParentDirs(String, boolean) - Method in class org.infinispan.io.GridFile
-
Checks whether the parent directories are present (and are directories).
- checkPendingTransactionsForKey(TxInvocationContext<?>, Object, long, TimeUnit) - Method in interface org.infinispan.util.concurrent.locks.PendingLockManager
-
Same as
PendingLockManager.awaitPendingTransactionsForKey(TxInvocationContext, Object, long, TimeUnit)
but non-blocking. - 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, String) - Method in interface org.infinispan.security.AuthorizationManager
-
Verifies that the
Subject
has the requested permission and role. - checkPermission(AuthorizationPermission) - Method in interface org.infinispan.security.AuthorizationManager
-
Verifies that the
Subject
associated with the currentAccessControlContext
has the requested permission. - 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(CachePermission) - Static method in class org.infinispan.security.Security
- checkProtection() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- checkResponse(Object, Address, boolean) - Method in class org.infinispan.remoting.transport.AbstractTransport
-
Deprecated.
- CheckTopologyAction - Class in org.infinispan.remoting.inboundhandler.action
-
An
Action
implementation that checks if the command topology id is valid. - CheckTopologyAction(BasePerCacheInboundInvocationHandler) - Constructor for class org.infinispan.remoting.inboundhandler.action.CheckTopologyAction
- checkTopologyId(TopologyAffectedCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- checkTopologyId(TopologyAffectedCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
- checkTopologyId(TopologyAffectedCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
- checkTotalOrderSupported() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- checkTotalOrderSupported() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- checkTotalOrderSupported() - Method in interface org.infinispan.remoting.transport.Transport
-
check if the transport has configured with total order deliver properties (has the sequencer in JGroups protocol stack.
- checkTxCommandResponses(Map<Address, Response>, TransactionBoundaryCommand, TxInvocationContext<LocalTransaction>, Collection<Address>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- CHUNK_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
- CHUNK_SIZE - org.infinispan.configuration.parsing.Attribute
- CHUNK_SIZE - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
- CHUNK_SIZE - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- ChunkCacheKey - Class in org.infinispan.lucene
-
Used as a key to distinguish file chunk in cache.
- ChunkCacheKey(String, String, int, int, int) - Constructor for class org.infinispan.lucene.ChunkCacheKey
- ChunkCacheKey.Externalizer - Class in org.infinispan.lucene
- chunkSize - Variable in class org.infinispan.statetransfer.StateProviderImpl
- chunkSize() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
-
The state will be transferred in batches of
chunkSize
cache entries. - chunkSize() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- chunkSize(int) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
-
The state will be transferred in batches of
chunkSize
cache entries. - chunkSize(int) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
-
If > 0, the state will be transferred in batches of
chunkSize
cache entries. - chunkSize(int) - Method in interface org.infinispan.lucene.directory.BuildContext
-
Sets the chunkSize option for the Directory being created.
- CLASS - org.infinispan.configuration.parsing.Attribute
- CLASS_LOADER - Static variable in class org.infinispan.factories.KnownComponentNames
- CLASS_RESOLVER - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
- classBuilder(String, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- classes() - Method in annotation type org.infinispan.factories.annotations.DefaultFactoryFor
-
Components that may be constructed by a factory annotated with this annotation.
- ClassFinder - Class in org.infinispan.commons.util
-
Find infinispan classes utility
- ClassFinder() - Constructor for class org.infinispan.commons.util.ClassFinder
- classLoader - Variable in class org.infinispan.factories.GlobalComponentRegistry
- classLoader() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Get the classloader in use by this configuration.
- classLoader(ClassLoader) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- ClassLoaderAwareFilteringListenable<K,V> - Interface in org.infinispan.notifications
-
Interface that enhances
FilteringListenable
with the possibility of specifying 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 - classResolver() - Method in class org.infinispan.configuration.global.SerializationConfiguration
- classResolver(ClassResolver) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
-
Class resolver to use when unmarshalling objects.
- ClassWhiteList - Class in org.infinispan.commons.configuration
-
The
ClassWhiteList
maintains classes definitions either by name or regular expression and is used for permissioning. - ClassWhiteList() - Constructor for class org.infinispan.commons.configuration.ClassWhiteList
- ClassWhiteList(List<String>) - Constructor for class org.infinispan.commons.configuration.ClassWhiteList
- cleanup() - Static method in class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
-
Deprecated.
- cleanup() - Static method in class org.infinispan.transaction.lookup.EmbeddedTransactionManagerLookup
- CLEANUP_TASK_FREQUENCY - Static variable in class org.infinispan.configuration.cache.L1Configuration
- cleanupBackupLocks() - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
It cleans up the backup locks for this transaction.
- cleanupLeaverTransactions(List<Address>) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
-
First moves the prepared transactions originated on the leavers into the recovery cache and then cleans up the transactions that are not yet prepared.
- cleanupTaskFrequency() - Method in class org.infinispan.configuration.cache.L1Configuration
-
Determines how often a cleanup thread runs to clean up an internal log of requestors for a specific key
- cleanupTaskFrequency(long) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
-
How often the L1 requestors map is cleaned up of stale items
- cleanupTaskFrequency(long, TimeUnit) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
-
How often the L1 requestors map is cleaned up of stale items
- clear() - Method in interface org.infinispan.Cache
-
Removes all mappings from the cache.
- clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.EntrySet
-
Deprecated.
- clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
-
Deprecated.
- clear() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Removes all of the elements from this set.
- clear() - Method in class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
-
Deprecated.
- clear() - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
-
Clear the cached marshallable type hints.
- clear() - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- clear() - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- clear() - Method in class org.infinispan.commons.util.ArrayMap
- clear() - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- clear() - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- clear() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Removes all of the mappings from this map.
- clear() - Method in class org.infinispan.commons.util.FastCopyHashMap
- clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.EntrySet
- clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.KeySet
- clear() - Method in class org.infinispan.commons.util.FastCopyHashMap.Values
- clear() - Method in class org.infinispan.commons.util.ForwardingList
- clear() - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- clear() - Method in class org.infinispan.commons.util.RangeSet
-
Deprecated.
- clear() - Method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- clear() - Method in class org.infinispan.commons.util.WeakValueHashMap
- clear() - Method in interface org.infinispan.container.DataContainer
-
Removes all entries in the container
- clear() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- clear() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- clear() - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheWriter
- clear() - Method in class org.infinispan.persistence.file.SingleFileStore
- clear() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- clear() - Method in class org.infinispan.persistence.jpa.JpaStore
- clear() - Method in class org.infinispan.persistence.remote.RemoteStore
- clear() - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- clear() - Method in interface org.infinispan.persistence.spi.AdvancedCacheWriter
-
Removes all the data from the storage.
- clear() - Method in class org.infinispan.persistence.support.AdvancedSingletonCacheWriter
-
Deprecated.
- clear() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- clear() - Method in interface org.infinispan.scattered.BiasManager
-
The cache has been cleared and therefore all biases are forgotten.
- clear() - Method in class org.infinispan.spring.provider.SpringCache
- clear() - Method in class org.infinispan.util.CollectionMapper
- clear() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- clear() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- clear() - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- clear(IntSet) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- clear(IntSet) - Method in class org.infinispan.persistence.remote.RemoteStore
- clear(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Removes all the data that maps to the given segments from the storage.
- clear(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- Clear - Class in org.infinispan.persistence.modifications
- Clear() - Constructor for class org.infinispan.persistence.modifications.Clear
- CLEAR - org.infinispan.persistence.modifications.Modification.Type
- CLEAR - org.infinispan.server.hotrod.HotRodOperation
- CLEAR_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- CLEAR_STATUS - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
- CLEAR_THRESHOLD - org.infinispan.persistence.leveldb.configuration.Attribute
- clearAll() - Method in class org.infinispan.util.DependencyGraph
- clearAllStores(Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Invokes
AdvancedCacheWriter.clear()
on all the stores that aloes it. - clearAllStores(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- clearAllStores(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- clearAsync() - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
Map.clear()
. - ClearCacheEntry<K,V> - Class in org.infinispan.container.entries
-
Used in
ClearInvocationContext
to process theClearCommand
. - clearClusterStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
Clears the completed state transfer status in all the cluster.
- clearClusterStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- clearCounters() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
-
Clears all the configured counters.
- clearEntireCache(InfinispanCacheAPIRequest) - Method in class org.infinispan.rest.operations.CacheOperations
-
Implementation of HTTP DELETE request invoked on root context.
- clearFactories() - Method in class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
-
Removes all factories associated to this registry.
- clearGroupers() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
-
Clear the groupers
- clearInvalidations() - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Forget all non-processed invalidations scheduled through
ScatteredVersionManager.scheduleKeyInvalidation(Object, EntryVersion, boolean)
- clearLockedKeys() - Method in interface org.infinispan.context.InvocationContext
- clearLockedKeys() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- clearLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- clearLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- clearModules() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- clearModules() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- clearProperties() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Clears the interceptor properties
- clearProperties() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Clears the transport properties
- clearPushStateStatus() - Method in class org.infinispan.xsite.XSiteAdminOperations
- clearStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
-
Clears the completed state transfer status.
- clearStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- clearStore() - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheWriter
- clearStore() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- clearStores() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
-
Removes any configured stores from this builder.
- clearThreadLocal() - Method in interface org.infinispan.context.InvocationContextContainer
-
Deprecated.Remove the stored InvocationContext from the calling thread.
- clearThreadLocal(InvocationContext) - Method in interface org.infinispan.context.InvocationContextContainer
-
Deprecated.
- clearThreshold(int) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- CLIENT_ADDRESS - Static variable in class org.infinispan.server.core.ExternalizerIds
- CLIENT_ENCODING - Static variable in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
- CLIENT_ERROR_BAD_FORMAT - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- ClientAddress - Class in org.infinispan.server.hotrod.tx.table
-
A
Address
implementation for a client transaction. - ClientAddress(Address) - Constructor for class org.infinispan.server.hotrod.tx.table.ClientAddress
- ClientCounterEvent - Class in org.infinispan.server.hotrod.counter.listener
-
A counter event to send to a client.
- ClientCounterManagerNotificationManager - Class in org.infinispan.server.hotrod.counter.listener
-
The
CounterManager
notification manager. - ClientCounterManagerNotificationManager(CounterManager) - Constructor for class org.infinispan.server.hotrod.counter.listener.ClientCounterManagerNotificationManager
- clientEncoding() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
- clientEncoding(MediaType) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
-
The encoding to be used by clients of the memcached text protocol.
- clientSubject() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- clientSubject(Subject) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Sets the client subject, necessary for those SASL mechanisms which require it to access client credentials (i.e.
- clone() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- clone() - Method in class org.infinispan.commons.util.FastCopyHashMap
- clone() - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- clone() - Method in interface org.infinispan.container.entries.CacheEntry
- clone() - Method in class org.infinispan.container.entries.ClearCacheEntry
- clone() - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- clone() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- clone() - Method in class org.infinispan.container.entries.ImmortalCacheValue
- clone() - Method in interface org.infinispan.container.entries.InternalCacheEntry
- clone() - Method in class org.infinispan.container.entries.MortalCacheEntry
- clone() - Method in class org.infinispan.container.entries.MortalCacheValue
- clone() - Method in interface org.infinispan.container.entries.MVCCEntry
- clone() - Method in class org.infinispan.container.entries.NullCacheEntry
- clone() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- clone() - Method in class org.infinispan.container.entries.RepeatableReadEntry
- clone() - Method in class org.infinispan.container.entries.TransientCacheEntry
- clone() - Method in class org.infinispan.container.entries.TransientCacheValue
- clone() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- clone() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
- clone() - Method in class org.infinispan.container.entries.VersionedRepeatableReadEntry
- clone() - Method in interface org.infinispan.context.InvocationContext
-
Clones the invocation context.
- clone() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- clone() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- clone() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- clone() - Method in class org.infinispan.transaction.xa.GlobalTransaction
- clone(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- cloneWithMarshaller(Marshaller, T) - Static method in class org.infinispan.commons.util.Util
-
Clones parameter x of type T with a given Marshaller reference;
- close() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- close() - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- close() - Method in class org.infinispan.commons.util.Base64.OutputStream
-
Deprecated.Flushes and closes (I think, in the superclass) the stream.
- close() - Method in interface org.infinispan.commons.util.CloseableIterable
- close() - Method in interface org.infinispan.commons.util.CloseableIterator
- close() - Method in class org.infinispan.commons.util.CloseableIteratorMapper
-
Deprecated.
- close() - Method in interface org.infinispan.commons.util.CloseableSpliterator
- close() - Method in class org.infinispan.commons.util.CloseableSpliteratorMapper
-
Deprecated.
- close() - Method in class org.infinispan.commons.util.ConcatIterator
- close() - Method in class org.infinispan.commons.util.FilterIterator
- close() - Method in class org.infinispan.commons.util.FilterSpliterator
- close() - Method in class org.infinispan.commons.util.IteratorMapper
- close() - Method in class org.infinispan.commons.util.RemovableCloseableIterator
- close() - Method in class org.infinispan.commons.util.SpliteratorMapper
- close() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- close() - Method in class org.infinispan.io.GridInputStream
- close() - Method in class org.infinispan.io.GridOutputStream
- close() - Method in class org.infinispan.io.ReadableGridFileChannel
- close() - Method in class org.infinispan.io.UnclosableObjectInputStream
- close() - Method in class org.infinispan.io.UnclosableObjectOutputStream
- close() - Method in class org.infinispan.io.WritableGridFileChannel
- close() - Method in class org.infinispan.manager.DefaultCacheManager
- close() - Method in class org.infinispan.persistence.jdbc.connectionfactory.C3P0ConnectionPool
-
Deprecated.
- close() - Method in interface org.infinispan.persistence.jdbc.connectionfactory.ConnectionPool
- close() - Method in class org.infinispan.persistence.jdbc.connectionfactory.HikariConnectionPool
- close() - Method in class org.infinispan.persistence.util.PersistenceManagerCloseableSupplier
-
Deprecated.
- close() - Method in interface org.infinispan.query.ResultIterator
-
This method must be called on your iterator once you have finished so that any local or remote resources can be freed up.
- close() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- close() - Method in class org.infinispan.util.CloseableSuppliedIterator
- close() - Method in class org.infinispan.util.concurrent.ReclosableLatch
- close() - Method in interface org.infinispan.util.function.CloseableSupplier
- close() - Method in class org.infinispan.util.LazyConcatIterator
- close(ChannelHandlerContext, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
- close(InputStream) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to close an InputStream.
- close(InputStream[]) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to close an array of InputStreams.
- close(OutputStream) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to close an OutputStream.
- close(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to close an array of OutputStreams.
- close(AutoCloseable) - Static method in class org.infinispan.commons.util.Util
- close(AutoCloseable...) - Static method in class org.infinispan.commons.util.Util
- close(Object) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to close an InputStream or OutputStream.
- close(Object[]) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to close an array of InputStreama and/or OutputStreams.
- close(String) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
- close(String) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
- close(Socket) - Static method in class org.infinispan.commons.util.Util
- close(Context) - Static method in class org.infinispan.commons.util.Util
- CloseableIterable<E> - Interface in org.infinispan.commons.util
-
Interface that provides semantics of a
Iterable
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
- CloseableIteratorMapper<E,S> - Class in org.infinispan.commons.util
-
Deprecated.since 9.3 users can just use
IteratorMapper
as it handles CloseableIterators now - CloseableIteratorMapper(Iterator<? extends E>, Function<? super E, ? extends S>) - Constructor for class org.infinispan.commons.util.CloseableIteratorMapper
-
Deprecated.
- CloseableIteratorSet<E> - Interface in org.infinispan.commons.util
-
A set that defines an iterator method that returns a
CloseableIterator
instead of a non closeable one. - CloseableIteratorSetAdapter<E> - Class in org.infinispan.commons.util
-
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. - CloseableSpliteratorMapper<E,S> - Class in org.infinispan.commons.util
-
Deprecated.since 9.3 users can just use
SpliteratorMapper
as it handles CloseableSpliterators now - CloseableSpliteratorMapper(Spliterator<E>, Function<? super E, ? extends S>) - Constructor for class org.infinispan.commons.util.CloseableSpliteratorMapper
-
Deprecated.
- CloseableSuppliedIterator<E> - Class in org.infinispan.util
- CloseableSuppliedIterator(CloseableSupplier<? extends E>) - Constructor for class org.infinispan.util.CloseableSuppliedIterator
- CloseableSupplier<T> - Interface in org.infinispan.util.function
- closeChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- closeMarshaller() - Method in interface org.infinispan.commons.marshall.jboss.RiverCloseListener
- closeUnmarshaller() - Method in interface org.infinispan.commons.marshall.jboss.RiverCloseListener
- CLUSTER - org.infinispan.configuration.parsing.Attribute
- CLUSTER_EVENT - Static variable in interface org.infinispan.commons.marshall.Ids
- CLUSTER_EVENT_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
- CLUSTER_LISTENER_REMOVE_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
- CLUSTER_LISTENER_REPLICATE_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
- CLUSTER_LOADER - org.infinispan.configuration.parsing.Element
- CLUSTER_NAME - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- CLUSTER_RECOVERY_ATTEMPTS - Static variable in class org.infinispan.topology.ClusterTopologyManagerImpl
- CLUSTER_ROLE_MAPPER - org.infinispan.configuration.parsing.Element
- CLUSTER_STORE - org.infinispan.configuration.parsing.Element
- ClusterCacheNotifier<K,V> - Interface in org.infinispan.notifications.cachelistener.cluster
-
This interface describes methods required for a cluster listener to be able to be bootstrapped and properly notified when a new event has been raised from the cluster.
- ClusterCacheStats - Interface in org.infinispan.stats
-
Similar to
Stats
but cluster wide. - ClusterCacheStatus - Class in org.infinispan.topology
-
Keeps track of a cache's status: members, current/pending consistent hashes, and rebalance status
- ClusterCacheStatus(EmbeddedCacheManager, String, AvailabilityStrategy, RebalanceType, ClusterTopologyManager, Transport, PersistentUUIDManager, EventLogManager, Optional<ScopedPersistentState>, boolean) - Constructor for class org.infinispan.topology.ClusterCacheStatus
- clusterCommitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- ClusterContainerStats - Interface in org.infinispan.stats
-
Cluster wide container statistics
- clustered - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- clustered() - Method in annotation type org.infinispan.notifications.Listener
-
Defines whether the annotated listener is clustered or not.
- clustered(boolean) - Method in class org.infinispan.container.versioning.NumericVersionGenerator
- CLUSTERED_GET_COMMAND_SIZE - org.infinispan.stats.container.ExtendedStatistic
- CLUSTERED_LOCK - org.infinispan.lock.configuration.Element
- CLUSTERED_LOCKS - org.infinispan.lock.configuration.Element
- ClusteredCacheBackupReceiver - Class in org.infinispan.xsite
-
BackupReceiver
implementation for clustered caches. - ClusteredCacheQueryImpl<E> - Class in org.infinispan.query.clustered
-
An extension of CacheQueryImpl used for distributed queries.
- ClusteredCacheQueryImpl(Query, SearchIntegrator, ExecutorService, AdvancedCache<?, ?>, KeyTransformationHandler, Class<?>...) - Constructor for class org.infinispan.query.clustered.ClusteredCacheQueryImpl
- ClusteredCacheQueryImpl(QueryDefinition, ExecutorService, AdvancedCache<?, ?>, KeyTransformationHandler, IndexedTypeMap<CustomTypeMetadata>) - Constructor for class org.infinispan.query.clustered.ClusteredCacheQueryImpl
- clusteredDefault() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
-
Helper method that gets you a default constructed GlobalConfiguration, preconfigured to use the default clustering stack.
- ClusteredGetResponseValidityFilter - Class in org.infinispan.remoting.responses
-
A filter that tests the validity of
ClusteredGetCommand
s. - ClusteredGetResponseValidityFilter(Collection<Address>, Address) - Constructor for class org.infinispan.remoting.responses.ClusteredGetResponseValidityFilter
- ClusteredListenerInvocation(ListenerInvocation<Event<K, V>>, QueueingSegmentListener<K, V, CacheEntryEvent<K, V>>, CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, ?>, Class<? extends Annotation>, boolean, UUID, boolean, Listener.Observation, Set<Class<? extends Annotation>>, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.CacheNotifierImpl.ClusteredListenerInvocation
- ClusteredLock - Interface in org.infinispan.lock.api
-
ClusteredLock is a data structure used for concurrent programming between Infinispan instances in cluster mode.
- ClusteredLockConfiguration - Class in org.infinispan.lock.api
-
A Clustered Lock can be reentrant and there are different ownership levels.
- ClusteredLockConfiguration - Class in org.infinispan.lock.configuration
-
ClusteredLock
configuration. - ClusteredLockConfiguration() - Constructor for class org.infinispan.lock.api.ClusteredLockConfiguration
-
Default lock is non reentrant and the ownership level is
OwnershipLevel.NODE
- ClusteredLockConfigurationBuilder - Class in org.infinispan.lock.configuration
-
ClusteredLock
configuration builder. - ClusteredLockConfigurationBuilder() - Constructor for class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
- ClusteredLockConfigurationParser - Class in org.infinispan.lock.configuration
-
Clustered Locks configuration parser
- ClusteredLockConfigurationParser() - Constructor for class org.infinispan.lock.configuration.ClusteredLockConfigurationParser
- ClusteredLockException - Exception in org.infinispan.lock.exception
-
Exception used to handle errors on clustered locks
- ClusteredLockException(String) - Constructor for exception org.infinispan.lock.exception.ClusteredLockException
- ClusteredLockException(Throwable) - Constructor for exception org.infinispan.lock.exception.ClusteredLockException
- ClusteredLockManager - Interface in org.infinispan.lock.api
-
Provides the API to define, create and remove ClusteredLocks.
- ClusteredLockManagerConfiguration - Class in org.infinispan.lock.configuration
-
The
ClusteredLockManager
configuration. - ClusteredLockManagerConfigurationBuilder - Class in org.infinispan.lock.configuration
-
The
ClusteredLockManager
configuration builder. - ClusteredLockManagerConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
- ClusteredQueryCommand - Class in org.infinispan.query.clustered
-
Encapsulates all rpc calls for distributed queries actions.
- ClusteredQueryCommand(ByteString) - Constructor for class org.infinispan.query.clustered.ClusteredQueryCommand
-
For CommandFactory only.
- ClusterEvent<K,V> - Class in org.infinispan.notifications.cachelistener.cluster
-
This is an event designed for use with cluster listeners solely.
- ClusterEvent.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
- ClusterEventCallable<K,V> - Class in org.infinispan.notifications.cachelistener.cluster
-
This DistributedCallable is used to invoke a raised notification on the cluster listener that registered to listen for this event.
- ClusterEventCallable(UUID, Collection<? extends ClusterEvent<K, V>>) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable
- ClusterEventCallable(UUID, ClusterEvent<K, V>) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable
- ClusterEventCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
- ClusterEventManager<K,V> - Interface in org.infinispan.notifications.cachelistener.cluster
- ClusterEventManagerFactory - Class in org.infinispan.notifications.cachelistener.cluster
-
Constructs the data container
- ClusterEventManagerFactory() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEventManagerFactory
- ClusterExecutionPolicy - Enum in org.infinispan.manager
-
ClusterExecutionPolicy controls how which nodes commands submitted via
ClusterExecutor
. - ClusterExecutor - Interface in org.infinispan.manager
-
A cluster executor that can be used to invoke a given command across the cluster.
- ClusterHealth - Interface in org.infinispan.health
-
Cluster health information.
- clustering() - Method in class org.infinispan.configuration.cache.Configuration
- clustering() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- clustering() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- CLUSTERING - org.infinispan.configuration.parsing.Element
- ClusteringConfiguration - Class in org.infinispan.configuration.cache
-
Defines clustered characteristics of the cache.
- ClusteringConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Defines clustered characteristics of the cache.
- ClusteringConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
- ClusteringDependentLogic - Interface in org.infinispan.interceptors.locking
-
Abstractization for logic related to different clustering modes: replicated or distributed.
- ClusteringDependentLogic.AbstractClusteringDependentLogic - Class in org.infinispan.interceptors.locking
- ClusteringDependentLogic.Commit - Enum in org.infinispan.interceptors.locking
- ClusteringDependentLogic.DistributionLogic - Class in org.infinispan.interceptors.locking
-
This logic is used in distributed mode caches.
- ClusteringDependentLogic.InvalidationLogic - Class in org.infinispan.interceptors.locking
-
This logic is used in invalidation mode caches.
- ClusteringDependentLogic.LocalLogic - Class in org.infinispan.interceptors.locking
-
This logic is used in local mode caches.
- ClusteringDependentLogic.ReplicationLogic - Class in org.infinispan.interceptors.locking
-
This logic is used in replicated mode caches.
- ClusteringDependentLogic.ScatteredLogic - Class in org.infinispan.interceptors.locking
- ClusterListenerRemoveCallable<K,V> - Class in org.infinispan.notifications.cachelistener.cluster
-
This DistributedCallable is used to remove registered
RemoteClusterListener
on each of the various nodes when a cluster listener is unregistered from the cache. - ClusterListenerRemoveCallable(UUID) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable
- ClusterListenerRemoveCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
- ClusterListenerReplicateCallable<K,V> - Class in org.infinispan.notifications.cachelistener.cluster
-
This DistributedCallable is used to install a
RemoteClusterListener
on the resulting node. - ClusterListenerReplicateCallable(UUID, Address, CacheEventFilter<K, V>, CacheEventConverter<K, V, ?>, boolean, Set<Class<? extends Annotation>>, DataConversion, DataConversion, boolean) - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
- ClusterListenerReplicateCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
- ClusterLoader - Class in org.infinispan.persistence.cluster
-
Cache loader that consults other members in the cluster for values.
- ClusterLoader() - Constructor for class org.infinispan.persistence.cluster.ClusterLoader
- ClusterLoaderConfiguration - Class in org.infinispan.configuration.cache
-
ClusterLoaderConfiguration.
- ClusterLoaderConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.configuration.cache.ClusterLoaderConfiguration
- ClusterLoaderConfigurationBuilder - Class in org.infinispan.configuration.cache
- ClusterLoaderConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
- clusterName() - Method in class org.infinispan.configuration.global.TransportConfiguration
- clusterName(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Defines the name of the cluster.
- clusterNodeName(String) - Method in class org.infinispan.rest.InfinispanCacheResponse
-
Adds
Cluster-Node-Name
header. - clusterPrimaryOwner(String) - Method in class org.infinispan.rest.InfinispanCacheResponse
-
Adds
Cluster-Primary-Owner
header. - clusterServerAddress(String) - Method in class org.infinispan.rest.InfinispanCacheResponse
-
Adds
Cluster-Server-Address
header. - clusterStatus() - Method in class org.infinispan.xsite.XSiteAdminOperations
- ClusterTopologyManager - Interface in org.infinispan.topology
-
Maintains the topology for all the caches in the cluster.
- ClusterTopologyManager.ClusterManagerStatus - Enum in org.infinispan.topology
- ClusterTopologyManagerFactory - Class in org.infinispan.topology
-
Factory for ClusterTopologyManager implementations
- ClusterTopologyManagerFactory() - Constructor for class org.infinispan.topology.ClusterTopologyManagerFactory
- ClusterTopologyManagerImpl - Class in org.infinispan.topology
-
The
ClusterTopologyManager
implementation. - ClusterTopologyManagerImpl() - Constructor for class org.infinispan.topology.ClusterTopologyManagerImpl
- ClusterTopologyManagerImpl.ClusterViewListener - Class in org.infinispan.topology
- clusterView - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- ClusterView - Class in org.infinispan.remoting.transport.jgroups
-
Information about the JGroups cluster.
- ClusterViewListener() - Constructor for class org.infinispan.topology.ClusterTopologyManagerImpl.ClusterViewListener
- collect(Supplier<Collector<? super R, ?, R1>>) - Method in interface org.infinispan.CacheStream
-
Performs a mutable reduction operation on the elements of this stream using a
Collector
that is lazily created from theSupplier
provided. - collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that transforms the traversable into a result container, first constructed with the given supplier, and then accumulating elements over it with the given consumer.
- collect(Supplier<R1>, BiConsumer<R1, ? super R>, BiConsumer<R1, R1>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- collect(Collector<? super R, A, R1>) - Method in interface org.infinispan.CacheStream
- collect(Collector<? super R, A, R1>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- collect(Collector<? super T, A, R>) - Method in interface org.infinispan.functional.Traversable
-
A terminal operation that transforms the traversable into a result container using a
Collector
. - collect(SerializableSupplier<Collector<? super R, ?, R1>>) - Method in interface org.infinispan.CacheStream
-
Performs a mutable reduction operation on the elements of this stream using a
Collector
that is lazily created from theSerializableSupplier
provided. - collect(SerializableSupplier<R>, SerializableObjDoubleConsumer<R>, SerializableBiConsumer<R, R>) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleStream.collect(Supplier, ObjDoubleConsumer, BiConsumer)
except that the arguments must also 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
Stream.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
- CollectionExternalizer - Class in org.infinispan.marshall.exts
- CollectionExternalizer() - Constructor for class org.infinispan.marshall.exts.CollectionExternalizer
- CollectionFactory - Class in org.infinispan.commons.util
-
A factory for ConcurrentMaps.
- CollectionFactory() - Constructor for class org.infinispan.commons.util.CollectionFactory
- CollectionKeyFilter<K> - Class in org.infinispan.filter
-
Filter based on accepting/rejecting the keys that are present in a supplied collection.
- CollectionKeyFilter(Collection<? extends K>) - Constructor for class org.infinispan.filter.CollectionKeyFilter
- CollectionKeyFilter(Collection<? extends K>, boolean) - Constructor for class org.infinispan.filter.CollectionKeyFilter
- CollectionKeyFilter.Externalizer - Class in org.infinispan.filter
- CollectionMapper<E,R> - Class in org.infinispan.util
-
A collection that maps another one to a new one of a possibly different type.
- CollectionMapper(Collection<E>, Function<? super E, ? extends R>) - Constructor for class org.infinispan.util.CollectionMapper
- COLLECTIONS - Static variable in interface org.infinispan.commons.marshall.Ids
- collector(Supplier<Collector<T, ?, R>>) - Static method in class org.infinispan.stream.CacheCollectors
-
Similar to
CacheCollectors.serializableCollector(SerializableSupplier)
except that the supplier provided must be marshable through ISPN marshalling techniques. - Collector<T> - Interface in org.infinispan.interceptors.distribution
-
Represents the ack collector for a write operation in triangle algorithm.
- collectorFor(Address) - Method in interface org.infinispan.util.concurrent.CommandAckCollector.MultiTargetCollector
- combinePredicate(IntSet, KeyPartitioner, Predicate<? super K>) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
- combiner() - Method in class org.infinispan.commons.util.ArrayCollector
- command - Variable in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
- command - Variable in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
- command - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- COMMAND_ID - Static variable in class org.infinispan.query.affinity.AffinityUpdateCommand
- COMMAND_ID - Static variable in class org.infinispan.query.clustered.ClusteredQueryCommand
- COMMAND_ID - Static variable in class org.infinispan.query.indexmanager.IndexUpdateCommand
- COMMAND_ID - Static variable in class org.infinispan.query.indexmanager.IndexUpdateStreamCommand
- COMMAND_ID - Static variable in class org.infinispan.statetransfer.StateRequestCommand
- COMMAND_ID - Static variable in class org.infinispan.statetransfer.StateResponseCommand
- COMMAND_ID - Static variable in class org.infinispan.topology.CacheTopologyControlCommand
- COMMAND_ID - Static variable in class org.infinispan.topology.HeartBeatCommand
- COMMAND_ID - Static variable in class org.infinispan.xsite.SingleXSiteRpcCommand
- COMMAND_ID - Static variable in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- COMMAND_ID - Static variable in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- COMMAND_ID - Static variable in class org.infinispan.xsite.XSiteAdminCommand
- COMMAND_RETRY - org.infinispan.context.Flag
-
If a write operation encounters a retry due to a topology change this flag should be used to tell the new owner that such a thing happened.
- commandAckCollector - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- CommandAckCollector - Class in org.infinispan.util.concurrent
-
An acknowledge collector for Triangle algorithm used in non-transactional caches for write operations.
- CommandAckCollector() - Constructor for class org.infinispan.util.concurrent.CommandAckCollector
- CommandAckCollector.MultiTargetCollector - Interface in org.infinispan.util.concurrent
- CommandInterceptor - Class in org.infinispan.interceptors.base
-
Deprecated.Since 9.0, please extend
BaseAsyncInterceptor
instead. - CommandInterceptor() - Constructor for class org.infinispan.interceptors.base.CommandInterceptor
-
Deprecated.
- commandsFactory - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- commandsFactory - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- commandsFactory - Variable in class org.infinispan.statetransfer.StateProviderImpl
- commandTopologyId - Variable in class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
- comment() - Method in annotation type org.infinispan.commons.util.Experimental
- commit() - Method in interface org.infinispan.atomic.DeltaAware
-
Deprecated.Indicate that all deltas collected to date has been extracted (via a call to
DeltaAware.delta()
) and can be discarded. - commit() - Method in class org.infinispan.commons.tx.TransactionImpl
-
Attempt to commit this transaction.
- commit() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- commit() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.Commit the transaction associated with the calling thread.
- commit() - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.Attempt to commit this transaction.
- commit() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
-
Deprecated.Attempt to commit this transaction.
- commit() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
- commit(int, InternalDataContainer) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- commit(Transaction) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- commit(Transaction) - Method in interface org.infinispan.persistence.spi.TransactionalCacheWriter
-
Commit the provided transaction's changes to the underlying store.
- commit(Xid, boolean) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
-
Same comment as for
TransactionXaAdapter.prepare(javax.transaction.xa.Xid)
applies for commit. - commit(Xid, boolean) - Method in class org.infinispan.transaction.xa.XaTransactionTable
- commit(DataContainer) - Method in class org.infinispan.container.entries.AbstractInternalCacheEntry
- commit(DataContainer) - Method in class org.infinispan.container.entries.ForwardingCacheEntry
- commit(DataContainer) - Method in class org.infinispan.container.entries.NullCacheEntry
- commit(DataContainer) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- commit(DataContainer<K, V>) - Method in interface org.infinispan.container.entries.CacheEntry
-
Commits changes
- commit(DataContainer<K, V>) - Method in class org.infinispan.container.entries.ClearCacheEntry
- commit(DataContainer<K, V>, Metadata) - Method in interface org.infinispan.container.entries.CacheEntry
-
Deprecated.since 9.1
- commit(CacheEntry, Flag, int, boolean, InvocationContext) - Method in class org.infinispan.statetransfer.CommitManager
-
It tries to commit the cache entry.
- COMMIT_COMMAND_SIZE - org.infinispan.stats.container.ExtendedStatistic
- COMMIT_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- COMMIT_LOCAL - org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
-
Commit the entry, this is the owner.
- COMMIT_NON_LOCAL - org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
-
Commit the entry but this node is not an owner, therefore, listeners should not be fired.
- COMMIT_TX - org.infinispan.server.hotrod.HotRodOperation
- COMMIT_TX - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- commitAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Perform the commit operation for the provided transaction on all Tx stores.
- commitAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- commitAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- commitContextEntry(CacheEntry, InvocationContext, FlagAffectedCommand, Flag, boolean) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
- commitEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- commitEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
- commitLocalTransaction(AdvancedCache<?, ?>, XidImpl, long) - Static method in class org.infinispan.server.hotrod.tx.operation.Util
- commitManager - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- commitManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- CommitManager - Class in org.infinispan.statetransfer
-
Keeps track of the keys updated by normal operation and state transfer.
- CommitManager() - Constructor for class org.infinispan.statetransfer.CommitManager
- commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
- commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
- commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
- commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
- commitSingleEntry(CacheEntry, FlagAffectedCommand, InvocationContext, Flag, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ScatteredLogic
- COMMITTED - org.infinispan.container.entries.ReadCommittedEntry.Flags
- COMMITTED - org.infinispan.server.hotrod.tx.table.Status
-
The client transaction is committed.
- CommitTransactionOperation - Class in org.infinispan.server.hotrod.tx.operation
-
It commits a transaction in all involved caches.
- CommitTransactionOperation(HotRodHeader, HotRodServer, Subject, XidImpl, BiConsumer<HotRodHeader, Integer>) - Constructor for class org.infinispan.server.hotrod.tx.operation.CommitTransactionOperation
- commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
-
Determines what type of commit this is.
- commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
- commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
- commitType(FlagAffectedCommand, InvocationContext, int, boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
- COMMON_NAME_ROLE_MAPPER - org.infinispan.configuration.parsing.Element
- compare(byte[], byte[]) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
-
Deprecated.
- compare(Object, Object) - Method in class org.infinispan.commons.equivalence.AnyServerEquivalence
-
Deprecated.
- compare(T, T) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- compare(T, T) - Method in interface org.infinispan.commons.equivalence.Equivalence
-
Deprecated.Compares the two given objects for order.
- compare(T, T) - Method in class org.infinispan.commons.equivalence.IdentityEquivalence
-
Deprecated.
- compareAndSet(long, long) - Method in interface org.infinispan.counter.api.StrongCounter
-
Atomically sets the value to the given updated value if the current value
==
the expected value. - compareAndSet(long, long) - Method in interface org.infinispan.counter.api.SyncStrongCounter
- compareAndSwap(long, long) - Method in interface org.infinispan.counter.api.StrongCounter
-
Atomically sets the value to the given updated value if the current value
==
the expected value. - compareAndSwap(long, long) - Method in interface org.infinispan.counter.api.SyncStrongCounter
- compareTo(byte[]) - Static method in class org.infinispan.Version
- compareTo(File) - Method in class org.infinispan.io.GridFile
- compareTo(EntryVersion) - Method in interface org.infinispan.container.versioning.EntryVersion
-
Compares the given version against the current instance.
- compareTo(EntryVersion) - Method in class org.infinispan.container.versioning.NumericVersion
- compareTo(EntryVersion) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
- compareTo(Address) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
- compareTo(Address) - Method in class org.infinispan.remoting.transport.LocalModeAddress
- compareTo(Address) - Method in class org.infinispan.server.hotrod.ServerAddress
- compareTo(Address) - Method in class org.infinispan.server.hotrod.tx.table.ClientAddress
- compareTo(Address) - Method in class org.infinispan.topology.PersistentUUID
- COMPAT - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- compatibility() - Method in class org.infinispan.configuration.cache.Configuration
- compatibility() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
-
Deprecated.
- compatibility() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
-
Deprecated.since 9.4, replace with
ConfigurationBuilder.encoding()
to specify the key and value'sMediaType
as "application/x-java-object", or preferably, avoid storing unmarshalled content when using the server and use the new endpoint interoperability mechanism - COMPATIBILITY - org.infinispan.configuration.parsing.Element
- CompatibilityModeConfiguration - Class in org.infinispan.configuration.cache
-
Compatibility mode configuration
- CompatibilityModeConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Compatibility mode configuration builder
- CompatibilityProtoStreamMarshaller - Class in org.infinispan.query.remote
-
A per
EmbeddedCacheManager
marshaller that should be used as compatibility mode marshaller in server. - CompatibilityProtoStreamMarshaller() - Constructor for class org.infinispan.query.remote.CompatibilityProtoStreamMarshaller
- CompletableFutures - Class in org.infinispan.util.concurrent
-
Utility methods connecting
CompletableFuture
futures. - CompletableFutures() - Constructor for class org.infinispan.util.concurrent.CompletableFutures
- complete() - Method in interface org.infinispan.scattered.BiasManager.Revocation
- complete(T) - Method in class org.infinispan.remoting.transport.AbstractRequest
- COMPLETE - org.infinispan.topology.RebalancingStatus
- COMPLETE_FUNCTION - Static variable in class org.infinispan.server.core.ExternalizerIds
- COMPLETED_TX_TIMEOUT - org.infinispan.configuration.parsing.Attribute
- COMPLETED_TX_TIMEOUT - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- completedEmptyMap() - Static method in class org.infinispan.util.concurrent.CompletableFutures
- completedExceptionFuture(Throwable) - Static method in class org.infinispan.util.concurrent.CompletableFutures
- completedFalse() - Static method in class org.infinispan.util.concurrent.CompletableFutures
- completedNull() - Static method in class org.infinispan.util.concurrent.CompletableFutures
- completedTrue() - Static method in class org.infinispan.util.concurrent.CompletableFutures
- completedTxTimeout() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- completedTxTimeout(long) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
The duration (millis) in which to keep information about the completion of a transaction.
- completeExceptionally(long, Throwable, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
-
Acknowledges an exception during the operation execution.
- completeExceptionally(Throwable) - Method in class org.infinispan.remoting.transport.AbstractRequest
- completeManyWriteOnPrimaryOriginator(WriteCommand, Address, CountDownCompletableFuture) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- completeManyWriteOnPrimaryOriginator(WriteCommand, Address, CountDownCompletableFuture) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
-
This is a hook for bias-enabled mode where the primary performs additional RPCs but replication to another node.
- completeSingleWriteOnPrimaryOriginator(DataWriteCommand, Address, CompletionStage<?>) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- completeSingleWriteOnPrimaryOriginator(DataWriteCommand, Address, CompletionStage<?>) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
-
This is a hook for bias-enabled mode where the primary performs additional RPCs but replication to another node.
- completionQueue - Variable in class org.infinispan.distexec.DistributedExecutionCompletionService
- CompletionStages - Class in org.infinispan.util.concurrent
-
Utility methods for handling
CompletionStage
instances. - COMPONENT_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
- ComponentFactory - Interface in org.infinispan.factories
-
Factory for Infinispan components.
- ComponentMetadata - Class in org.infinispan.factories.components
-
This class contains all of the metadata and implications expressed via the
Scope
,SurvivesRestarts
,DefaultFactoryFor
,ComponentName
,Inject
,Start
andStop
annotations. - ComponentMetadata(Class<?>, List<Field>, List<Method>, List<Method>, List<Method>, List<Method>, boolean, boolean) - Constructor for class org.infinispan.factories.components.ComponentMetadata
- ComponentMetadata(Class<?>, List<Field>, List<Method>, List<Method>, List<Method>, List<Method>, Scopes, boolean) - Constructor for class org.infinispan.factories.components.ComponentMetadata
- ComponentMetadata.InjectFieldMetadata - Class in org.infinispan.factories.components
- ComponentMetadata.InjectMethodMetadata - Class in org.infinispan.factories.components
-
This class encapsulates metadata on an inject method, such as one annotated with
Inject
- ComponentMetadata.PrioritizedMethodMetadata - Class in org.infinispan.factories.components
- ComponentMetadataPersister - Class in org.infinispan.factories.components
-
A utility class used by the Infinispan build process to scan metadata and persist it.
- ComponentMetadataPersister() - Constructor for class org.infinispan.factories.components.ComponentMetadataPersister
- ComponentMetadataRepo - Class in org.infinispan.factories.components
-
This is a repository of component metadata, which is populated when the Infinispan core jar is loaded up.
- ComponentMetadataRepo() - Constructor for class org.infinispan.factories.components.ComponentMetadataRepo
- ComponentName - Annotation Type in org.infinispan.factories.annotations
-
Mechanism for specifying the name of components to retrieve
- componentRegistry - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
-
Deprecated.
- ComponentRegistry - Class in org.infinispan.factories
-
Named cache specific components
- ComponentRegistry(String, Configuration, AdvancedCache<?, ?>, GlobalComponentRegistry, ClassLoader) - Constructor for class org.infinispan.factories.ComponentRegistry
-
Creates an instance of the component registry.
- ComponentsJmxRegistration - Class in org.infinispan.jmx
-
Registers a set of components on an MBean server.
- ComponentsJmxRegistration(MBeanServer, String) - Constructor for class org.infinispan.jmx.ComponentsJmxRegistration
-
C-tor.
- ComponentStatus - Enum in org.infinispan.lifecycle
-
Different states a component may be in.
- ComposedSegmentedLoadWriteStore<K,V,T extends AbstractSegmentedStoreConfiguration> - Class in org.infinispan.persistence.support
-
Segmented store that creates multiple inner stores for each segment.
- ComposedSegmentedLoadWriteStore(AbstractSegmentedStoreConfiguration<T>) - Constructor for class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- composeFalse() - Static method in class org.infinispan.util.concurrent.CompletableFutures
- composeTrue() - Static method in class org.infinispan.util.concurrent.CompletableFutures
- 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.
- 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
- CompositeAction - Class in org.infinispan.remoting.inboundhandler.action
-
A
ReadyAction
implementation that delegates it logic to a collection of otherReadyAction
. - CompositeAction(Collection<ReadyAction>) - Constructor for class org.infinispan.remoting.inboundhandler.action.CompositeAction
- 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
- CompositeKeyFilter<K> - Class in org.infinispan.filter
-
Allows AND-composing several filters.
- CompositeKeyFilter(KeyFilter<? super K>...) - Constructor for class org.infinispan.filter.CompositeKeyFilter
- CompositeKeyFilter.Externalizer - Class in org.infinispan.filter
- 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 - org.infinispan.persistence.leveldb.configuration.Element
- COMPRESSION_LEVEL - Static variable in class org.infinispan.rest.configuration.RestServerConfiguration
- COMPRESSION_TYPE - org.infinispan.persistence.leveldb.configuration.Attribute
- compressionLevel(int) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- compressionType(CompressionType) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- CompressionType - Enum in org.infinispan.persistence.leveldb.configuration
- 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.commons.util.AbstractDelegatingMap
- 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, 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>, 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, DataContainer.ComputeAction<K, V>) - Method in interface org.infinispan.container.DataContainer
-
Computes the new value for the key.
- 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>, Metadata) - Method in interface org.infinispan.AdvancedCache
- 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
- 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>, 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, 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>, Metadata) - Method in interface org.infinispan.AdvancedCache
-
Overloaded
#computeAsync(K, BiFunction)
, which stores metadata alongside the value. - computeAsync(K, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
- computeCapacity(int) - Static method in class org.infinispan.commons.util.CollectionFactory
- computeCapacity(int, float) - Static method in class org.infinispan.commons.util.CollectionFactory
- 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.Since 9.1
- 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.commons.util.AbstractDelegatingMap
- 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, 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>, 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, 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
- 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>, 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, 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>, 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, SerializableFunction<? super K, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
- 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.commons.util.AbstractDelegatingMap
- 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, 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>, 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, 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
- 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>, 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, 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>, 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, SerializableBiFunction<? super K, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
- 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()
. - computeTotalCapacity(Collection<Address>, Map<Address, Float>) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
- 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 - org.infinispan.configuration.parsing.Attribute
- CONCURRENCY_LEVEL - 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.
- ConcurrentChangeException - Exception in org.infinispan.interceptors.distribution
-
Thrown when the version of entry has changed between loading the entry to the context and committing new value.
- ConcurrentChangeException() - Constructor for exception org.infinispan.interceptors.distribution.ConcurrentChangeException
-
Throwing this exception is cheaper because it does not fill in the stack trace.
- 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.stats.container
-
Thread safe cache statistics that allows multiple writers and reader at the same time.
- ConcurrentGlobalContainer(TimeService) - Constructor for class org.infinispan.stats.container.ConcurrentGlobalContainer
- ConcurrentHashSet<E> - Class in org.infinispan.commons.util.concurrent
-
A simple Set implementation backed by a
ConcurrentHashMap
to deal with the fact that the JDK does not have a proper concurrent Set implementation that uses efficient lock striping. - ConcurrentHashSet() - Constructor for class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- ConcurrentHashSet(int) - Constructor for class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- ConcurrentHashSet(int, float, int) - Constructor for class org.infinispan.commons.util.concurrent.ConcurrentHashSet
-
Params passed in to the underlying CHM.
- 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
- ConcurrentWeakKeyHashMap<K,V> - Class in org.infinispan.commons.util.concurrent
-
An alternative weak-key
ConcurrentMap
which is similar toConcurrentHashMap
. - ConcurrentWeakKeyHashMap() - Constructor for class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Creates a new, empty map with a default initial capacity (16), reference types (weak keys, strong values), default load factor (0.75) and concurrencyLevel (16).
- ConcurrentWeakKeyHashMap(int) - Constructor for class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Creates a new, empty map with the specified initial capacity, and with default reference types (weak keys, strong values), load factor (0.75) and concurrencyLevel (16).
- ConcurrentWeakKeyHashMap(int, float) - Constructor for class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Creates a new, empty map with the specified initial capacity and load factor and with the default reference types (weak keys, strong values), and concurrencyLevel (16).
- ConcurrentWeakKeyHashMap(int, float, int) - Constructor for class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Creates a new, empty map with the specified initial capacity, load factor and concurrency level.
- ConcurrentWeakKeyHashMap(Map<? extends K, ? extends V>) - Constructor for class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Creates a new map with the same mappings as the given map.
- ConcurrentWeakKeyHashMap.ReusableIterator<E> - Interface in org.infinispan.commons.util.concurrent
- 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
- config - Variable in class org.infinispan.context.AbstractInvocationContextFactory
-
Deprecated.
- CONFIG_STATE_CACHE_NAME - Static variable in interface org.infinispan.globalstate.GlobalConfigurationManager
- configToParsedConfig(String, CounterConfiguration) - Static method in class org.infinispan.counter.configuration.ConvertUtil
- configuration - Variable in class org.infinispan.factories.AbstractNamedCacheComponentFactory
- configuration - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- configuration - Variable in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- 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.Http20RequestHandler
- configuration - Variable in class org.infinispan.server.core.AbstractProtocolServer
- configuration - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- Configuration - Class in org.infinispan.configuration.cache
- CONFIGURATION - org.infinispan.configuration.parsing.Attribute
- CONFIGURATION_FILE - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- CONFIGURATION_STORAGE - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
- CONFIGURATION_STORAGE_SUPPLIER - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
- 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.configuration.cache
- 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
- ConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
- ConfigurationFor - Annotation Type in org.infinispan.commons.configuration
-
ConfigurationFor.
- ConfigurationForClassExtractor - Class in org.infinispan.persistence.factory
- ConfigurationForClassExtractor() - Constructor for class org.infinispan.persistence.factory.ConfigurationForClassExtractor
- ConfigurationHolder - Class in org.infinispan.configuration.serializing
-
ConfigurationHolder.
- ConfigurationHolder(GlobalConfiguration, Map<String, Configuration>) - Constructor for class org.infinispan.configuration.serializing.ConfigurationHolder
- 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
- ConfigurationParser - Interface in org.infinispan.configuration.parsing
-
ConfigurationParser.
- configurationProperties() - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- ConfigurationPropertiesOverrides - Class in org.infinispan.spring
-
Provides a mechanism to override selected configuration properties using explicit setters for each configuration setting.
- ConfigurationPropertiesOverrides() - Constructor for class org.infinispan.spring.ConfigurationPropertiesOverrides
- Configurations - Class in org.infinispan.configuration.cache
-
Helper configuration methods.
- ConfigurationSerializer<T> - Interface in org.infinispan.configuration.serializing
- configurationStorage() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
- configurationStorage(ConfigurationStorage) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
-
Defines the
ConfigurationStorage
strategy to use. - 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
. - ConfigurationUtils - Class in org.infinispan.commons.configuration
-
ConfigurationUtils.
- configure() - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- configure() - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- ConfiguredBy - Annotation Type in org.infinispan.commons.configuration
-
Defines the configuration used to configure the given class instances
- configureHttp1(ChannelPipeline) - Method in class org.infinispan.rest.Http11To2UpgradeHandler
- configureHttp2(ChannelPipeline) - Method in class org.infinispan.rest.Http11To2UpgradeHandler
- configurePipeline(ChannelHandlerContext, String) - Method in class org.infinispan.rest.Http11To2UpgradeHandler
- configurePipeline(ChannelPipeline, String) - Method in class org.infinispan.rest.Http11To2UpgradeHandler
- CONFIRM_REVOKED_SEGMENTS - org.infinispan.statetransfer.StateRequestCommand.Type
- 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(String, int, int, Throwable) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- confirmRebalancePhase(Address, int) - Method in class org.infinispan.topology.ClusterCacheStatus
- 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.XSiteStateTransferCollector
- CONFLICT_RESOLUTION - 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 - 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 - org.infinispan.persistence.remote.configuration.Attribute
- connectChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- CONNECTION_ATTEMPTS - org.infinispan.configuration.parsing.Attribute
- CONNECTION_ATTEMPTS - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
- CONNECTION_INTERVAL - org.infinispan.configuration.parsing.Attribute
- CONNECTION_INTERVAL - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
- CONNECTION_POOL - org.infinispan.persistence.jdbc.configuration.Element
- CONNECTION_POOL - org.infinispan.persistence.remote.configuration.Element
- CONNECTION_POOL - org.infinispan.persistence.rest.configuration.Element
- CONNECTION_TIMEOUT - org.infinispan.persistence.rest.configuration.Attribute
- CONNECTION_TIMEOUT - Static variable in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- CONNECTION_URL - org.infinispan.persistence.jdbc.configuration.Attribute
- connectionAttempts() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- connectionAttempts(int) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- connectionFactory - Variable in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- connectionFactory() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- connectionFactory(C) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
-
Use the specified
ConnectionFactoryConfigurationBuilder
to configure connections to the database - connectionFactory(C) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
- connectionFactory(C) - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationChildBuilder
-
Use the specified
ConnectionFactoryConfigurationBuilder
to configure connections to the database - connectionFactory(Class<C>) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
-
Use the specified ConnectionFactory to handle connection to the database
- connectionFactory(Class<C>) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
- connectionFactory(Class<C>) - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationChildBuilder
-
Use the specified ConnectionFactory to handle connection to the database
- ConnectionFactory - Class in org.infinispan.persistence.jdbc.connectionfactory
-
Defines the functionality a connection factory should implement.
- ConnectionFactory() - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
- connectionFactoryClass() - Method in interface org.infinispan.persistence.jdbc.configuration.ConnectionFactoryConfiguration
- connectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfiguration
- connectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
- connectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
- ConnectionFactoryConfig - Class in org.infinispan.persistence.jdbc.connectionfactory
-
Contains configuration elements for a
ConnectionFactory
. - ConnectionFactoryConfig() - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- ConnectionFactoryConfig(String, String, String, String, String) - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- ConnectionFactoryConfiguration - Interface in org.infinispan.persistence.jdbc.configuration
-
ConnectionFactoryConfiguration.
- ConnectionFactoryConfigurationBuilder<T extends ConnectionFactoryConfiguration> - Interface in org.infinispan.persistence.jdbc.configuration
- 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.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- connectionPool() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
- connectionPool() - Method in interface org.infinispan.persistence.jdbc.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
- connectionPool() - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- connectionPool() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- connectionPool() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- connectionPool() - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
Configures the connection pool
- ConnectionPool - Interface in org.infinispan.persistence.jdbc.connectionfactory
-
A simple interface that must be implemented by ConnectionPool wrapper classes.
- ConnectionPoolConfiguration - Class in org.infinispan.persistence.remote.configuration
- ConnectionPoolConfiguration - Class in org.infinispan.persistence.rest.configuration
-
ConnectionPoolConfiguration.
- ConnectionPoolConfiguration(AttributeSet) - Constructor for class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- ConnectionPoolConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
-
ConnectionPoolConfigurationBuilder.
- ConnectionPoolConfigurationBuilder - Class in org.infinispan.persistence.rest.configuration
-
ConnectionPoolConfigurationBuilder.
- connectionTimeout() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- connectionTimeout() - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- connectionTimeout(int) - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfigurationBuilder
- 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.configuration.PooledConnectionFactoryConfiguration
- connectionUrl() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
- connectionUrl(String) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- connectionUrl(String) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
- CONSISTENT - 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 - org.infinispan.lock.configuration.Reliability
- CONSISTENT_HASH_FACTORY - org.infinispan.configuration.parsing.Attribute
- CONSISTENT_HASH_FACTORY - Static variable in class org.infinispan.configuration.cache.HashConfiguration
- consistentHash() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Deprecated.Since 5.2, replaced by
HashConfiguration.consistentHashFactory()
. - consistentHash(ConsistentHash) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Deprecated.Since 5.2, replaced by
HashConfigurationBuilder.consistentHashFactory(ConsistentHashFactory)
. - ConsistentHash - Interface in org.infinispan.distribution.ch
-
A consistent hash algorithm implementation.
- consistentHashFactory() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
The consistent hash factory in use.
- consistentHashFactory(ConsistentHashFactory<? extends ConsistentHash>) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
The consistent hash factory in use.
- ConsistentHashFactory<CH extends ConsistentHash> - Interface in org.infinispan.distribution.ch
-
Factory for
ConsistentHash
instances. - ConstantLambdaExternalizer() - Constructor for class org.infinispan.marshall.core.MarshallableFunctionExternalizers.ConstantLambdaExternalizer
- Constants - Class in org.infinispan.server.hotrod
-
Constant values
- construct(Class<RecoveryManager>) - Method in class org.infinispan.factories.RecoveryManagerFactory
- construct(Class<T>) - Method in class org.infinispan.factories.AbstractComponentFactory
-
Deprecated.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.factories.AbstractComponentFactory
- construct(String) - Method in class org.infinispan.factories.AuthorizationManagerFactory
- construct(String) - Method in class org.infinispan.factories.CacheStoreFactoryRegistryFactory
- 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.InternalCacheFactory
- 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.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.StreamManagerFactory
- 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.notifications.cachelistener.cluster.ClusterEventManagerFactory
- construct(String) - Method in class org.infinispan.topology.ClusterTopologyManagerFactory
- construct(String) - Method in class org.infinispan.topology.LocalTopologyManagerFactory
- constructDouble(Class<?>, Object) - Static method in class org.infinispan.commons.util.Util
- consumer - Variable in class org.infinispan.commons.util.RemovableIterator
- ContainerEmbeddedCacheManagerFactoryBean - Class in org.infinispan.spring.provider
- ContainerEmbeddedCacheManagerFactoryBean(EmbeddedCacheManager) - Constructor for class org.infinispan.spring.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.provider
- ContainerRemoteCacheManagerFactoryBean(RemoteCacheManager) - Constructor for class org.infinispan.spring.provider.ContainerRemoteCacheManagerFactoryBean
- ContainerSiteStatusBuilder - Class in org.infinispan.xsite.status
-
A per-container
SiteStatus
builder. - ContainerSiteStatusBuilder() - Constructor for class org.infinispan.xsite.status.ContainerSiteStatusBuilder
- 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
-
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.commons.equivalence.EquivalentHashMap.EntrySet
-
Deprecated.
- contains(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
-
Deprecated.
- contains(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Returns
true
if this set contains the specified element. - 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.concurrent.ConcurrentHashSet
- contains(Object) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Legacy method testing if some key maps into the specified value in this table.
- 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.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
- contains(Object) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
- contains(Object) - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
- contains(Object) - Method in class org.infinispan.persistence.async.AsyncCacheLoader
- contains(Object) - Method in class org.infinispan.persistence.cluster.ClusterLoader
- contains(Object) - Method in class org.infinispan.persistence.file.SingleFileStore
-
The base class implementation calls
SingleFileStore.load(Object)
for this, we can do better because we keep all keys in memory. - contains(Object) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- contains(Object) - Method in class org.infinispan.persistence.jpa.JpaStore
- contains(Object) - Method in class org.infinispan.persistence.remote.RemoteStore
- contains(Object) - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- contains(Object) - Method in interface org.infinispan.persistence.spi.CacheLoader
-
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
-
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.ReadOnlyCollectionAsSet
- contains(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- 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(AttributeDefinition<T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Returns whether this set contains the specified attribute definition
- CONTAINS_ENTRY_MULTIMAP - org.infinispan.server.hotrod.HotRodOperation
- CONTAINS_ENTRY_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- CONTAINS_KEY - org.infinispan.server.hotrod.HotRodOperation
- CONTAINS_KEY_MULTIMAP - 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_VALUE_MULTIMAP - 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
-
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
-
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.commons.util.AbstractDelegatingCollection
- containsAll(Collection<?>) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- containsAll(Collection<?>) - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- 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.util.ReadOnlyCollectionAsSet
- containsAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- 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.
- containsAny(long, long) - Static method in class org.infinispan.commons.util.EnumUtil
- containsAny(Object...) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
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
-
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. - 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
- containsInstance(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Checks whether the chain contains the supplied interceptor instance.
- 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
- containsInterceptorType(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.
- containsInterceptorType(Class<? extends CommandInterceptor>, boolean) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.
- containsKey(int, Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- containsKey(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- 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.concurrent.ConcurrentWeakKeyHashMap
-
Tests if the specified object is a key in this table.
- 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.offheap.BoundedOffHeapDataContainer
- containsKey(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- containsKey(Object) - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- containsKey(K) - Method in interface org.infinispan.multimap.api.BasicMultimapCache
-
Returns
Boolean.TRUE
if this multimap cache contains the key. - containsKeyAsync(K) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
Map.containsKey(Object)
- containsLockOrBackupLock(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.
- containsProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
-
Returns whether the state contains a property
- containsValue(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- 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.concurrent.ConcurrentWeakKeyHashMap
-
Returns true if this map maps one or more keys to the specified value.
- 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(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. - contentAsBytes(byte[]) - Method in class org.infinispan.rest.InfinispanResponse
-
Adds content as binary array.
- contentAsText(String) - Method in class org.infinispan.rest.InfinispanResponse
-
Adds content as text.
- contentType - Variable in class org.infinispan.remoting.MIMECacheEntry
-
The MIME Content type value, for example application/octet-stream.
- contentType - Variable in class org.infinispan.rest.operations.mime.MimeMetadata
- contentType() - Method in class org.infinispan.rest.operations.mime.MimeMetadata
- contentType(String) - Method in class org.infinispan.rest.InfinispanResponse
-
Adds
Content-Type
header. - contentType(String) - Method in class org.infinispan.rest.operations.mime.MimeMetadataBuilder
- ContentTypeConfiguration - Class in org.infinispan.configuration.cache
- ContentTypeConfigurationBuilder - Class in org.infinispan.configuration.cache
- ContentTypeConfigurationBuilder(EncodingConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- CONTEXT_PATH - Static variable in class org.infinispan.rest.configuration.RestServerConfiguration
- contextPath() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
- contextPath(String) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- continueOnExecutor(CompletionStage<V>, Executor, Object) - Static method in class org.infinispan.util.concurrent.CompletionStages
-
When the provided stage is complete, continue the completion chain of the returned CompletionStage on the supplied executor.
- 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. - ContinuousQuery<K,V> - Interface in org.infinispan.query.api.continuous
-
A container of continuous query listeners for a cache.
- ContinuousQueryListener<K,V> - Interface in org.infinispan.query.api.continuous
-
Listener for continuous query events.
- ContinuousQueryResult - Class in org.infinispan.query.remote.client
- ContinuousQueryResult(ContinuousQueryResult.ResultType, byte[], byte[], Object[]) - Constructor for class org.infinispan.query.remote.client.ContinuousQueryResult
- ContinuousQueryResult.ResultType - Enum in org.infinispan.query.remote.client
- 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
- convert(Object, MediaType, MediaType) - Method in class org.infinispan.encoding.DataConversion
- 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(MarshalledEntry<K, V>, InternalEntryFactory) - Static method in class org.infinispan.persistence.internal.PersistenceUtil
- convert(MarshalledEntry<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.
- 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.
- convertJavaToOctetStream(Object, MediaType, Marshaller) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
-
Converts a java object to a sequence of bytes applying standard java serialization.
- convertJavaToText(Object, MediaType, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
-
Converts a java object to a text/plain representation.
- convertNanosToMicro(double) - Static method in class org.infinispan.stats.CacheStatisticCollector
- convertNanosToSeconds(double) - Static method in class org.infinispan.stats.CacheStatisticCollector
- convertOctetStreamToJava(byte[], MediaType, Marshaller) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
-
Converts an octet stream to a Java object
- convertOctetStreamToText(byte[], MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
-
Converts generic byte[] to text.
- convertOctetStreamToUrlEncoded(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
- convertParameters(TaskContext) - Method in class org.infinispan.scripting.utils.ScriptConversions
- 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
-
Converts text content to binary.
- 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
-
Convert text format to a URL safe format.
- convertToOctetStream(Object, MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.DefaultTranscoder
- convertToRequestFormat(Object, MediaType) - Method in class org.infinispan.encoding.DataConversion
- convertToRequestType(Object, MediaType, MediaType) - Method in class org.infinispan.scripting.utils.ScriptConversions
- convertUrlEncodedToObject(Object) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
-
Handle x-www-form-urlencoded as single values for now.
- convertUrlEncodedToOctetStream(Object) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
- convertUrlEncodedToText(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
- 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
- COORDINATOR - org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
- copier() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- copier(AttributeCopier) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- copy() - Method in interface org.infinispan.atomic.CopyableDeltaAware
-
Deprecated.
- 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(InputStream, OutputStream) - Static method in class org.infinispan.util.stream.Streams
-
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
-
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
-
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
- CopyableDeltaAware - Interface in org.infinispan.atomic
-
Deprecated.since 9.1
- 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
-
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.
- copyForCache(ByteString) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- copyForLocal(C, List<Object>) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
- copyForLocal(ReadOnlyManyCommand, List<Object>) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
- copyForRemote(C, List<Object>, InvocationContext) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
- copyForRemote(ReadOnlyManyCommand, List<Object>, InvocationContext) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
- copyForUpdate() - Method in interface org.infinispan.container.entries.MVCCEntry
-
Deprecated.since 9.0 noop
- copyForUpdate(DataContainer<? super K, ? super V>) - Method in interface org.infinispan.container.entries.MVCCEntry
-
Deprecated.Since 8.0, use
MVCCEntry.copyForUpdate()
instead. - copySome(InputStream, OutputStream, byte[], long) - Static method in class org.infinispan.util.stream.Streams
-
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
-
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
-
Copy a limited number of bytes from the input stream to the output stream.
- copyStateFlagsFrom(StateChangingEntry) - Method in interface org.infinispan.container.entries.StateChangingEntry
-
Deprecated.
- copyValue(ExtendedStatistic, ExtendedStatistic) - Method in class org.infinispan.stats.TransactionStatistics
-
Copies a statistic value and adds it to another statistic.
- copyWithoutRemotableFlags(long) - Static method in enum org.infinispan.context.Flag
-
Deprecated.Since 9.0
- copyWithoutRemotableFlags(Set<Flag>) - Static method in enum org.infinispan.context.Flag
-
Deprecated.Since 9.0
- CORE_THREADS - org.infinispan.configuration.parsing.Attribute
- CoreImmutables - Class in org.infinispan.util
-
Factory for generating immutable type wrappers for core types.
- CoreImmutables() - Constructor for class org.infinispan.util.CoreImmutables
- coreThreads() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
- CORS_RULES - Static variable in class org.infinispan.rest.configuration.RestServerConfiguration
- corsAllowForLocalhost(String, int) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- CorsHandler - Class in org.infinispan.rest.cors
-
Handles Cross Origin Resource Sharing (CORS) requests.
- CorsHandler(List<CorsConfig>, boolean) - Constructor for class org.infinispan.rest.cors.CorsHandler
-
Creates a new instance with the specified config list.
- 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() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- count(String) - Static method in interface org.infinispan.query.dsl.Expression
- count(AdvancedCacheLoader<K, V>, Predicate<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
- count(AdvancedCacheLoader<K, V>, KeyFilter<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Deprecated.Please use
PersistenceUtil.count(AdvancedCacheLoader, Predicate)
instead - count(SegmentedAdvancedLoadWriteStore<?, ?>, IntSet) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Counts how many entries are present in the segmented store.
- COUNT - org.infinispan.eviction.EvictionType
- COUNTER_ADD_AND_GET - org.infinispan.server.hotrod.HotRodOperation
- COUNTER_ADD_AND_GET_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- COUNTER_ADD_LISTENER - org.infinispan.server.hotrod.HotRodOperation
- COUNTER_ADD_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- COUNTER_CAS - 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_CREATE - org.infinispan.server.hotrod.HotRodOperation
- COUNTER_CREATE_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- COUNTER_EVENT - org.infinispan.server.hotrod.HotRodOperation
- COUNTER_GET - org.infinispan.server.hotrod.HotRodOperation
- COUNTER_GET_CONFIGURATION - org.infinispan.server.hotrod.HotRodOperation
- COUNTER_GET_CONFIGURATION_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- COUNTER_GET_NAMES - 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 - org.infinispan.server.hotrod.HotRodOperation
- COUNTER_IS_DEFINED_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- COUNTER_NOT_FOUND - org.infinispan.server.hotrod.counter.listener.ListenerOperationStatus
-
The counter wasn't found.
- COUNTER_REMOVE - org.infinispan.server.hotrod.HotRodOperation
- COUNTER_REMOVE_LISTENER - 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 - 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
- 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
. - 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
- CounterConfigurationParser - Class in org.infinispan.counter.configuration
-
Counters configuration parser
- CounterConfigurationParser() - Constructor for class org.infinispan.counter.configuration.CounterConfigurationParser
- counterConfigurationResponse(HotRodHeader, HotRodServer, ByteBufAllocator, CounterConfiguration) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- counterConfigurationResponse(HotRodHeader, HotRodServer, ByteBufAllocator, 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
. - 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
- counterNamesResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Collection<String>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- counterNamesResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Collection<String>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- 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
- counters() - Method in class org.infinispan.counter.configuration.CounterManagerConfiguration
- COUNTERS - org.infinispan.counter.configuration.Element
- CounterState - Enum in org.infinispan.counter.api
-
The possible states for a counter value.
- CounterType - Enum in org.infinispan.counter.api
-
The counter types.
- CQCommandType - Enum in org.infinispan.query.clustered.commandworkers
-
Types of CQWorker.
- CR - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- 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
- create() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
- create() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- create() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
- create() - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
- create() - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.
- create() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.
- create() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- create() - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.
- 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.InterceptorConfigurationBuilder
- create() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- create() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
- 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.PartitionHandlingConfigurationBuilder
- create() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- 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.SingletonStoreConfigurationBuilder
-
Deprecated.
- 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.StoreAsBinaryConfigurationBuilder
-
Deprecated.
- create() - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
-
Deprecated.
- 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.VersioningConfigurationBuilder
-
Deprecated.
- create() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- 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.GlobalJmxStatisticsConfigurationBuilder
- 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.ScheduledExecutorFactoryConfigurationBuilder
- 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
- create() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- create() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- create() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
- 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() - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
- create() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
- create() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
- create() - Method in interface org.infinispan.lucene.directory.BuildContext
-
Creates a Directory instance
- create() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
- create() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
- create() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- create() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
- create() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
- create() - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationBuilder
- create() - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- 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.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.rest.configuration.ConnectionPoolConfigurationBuilder
- create() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- create() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- 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.memcached.configuration.MemcachedServerConfigurationBuilder
- create(boolean, boolean) - Static method in enum org.infinispan.remoting.inboundhandler.TopologyMode
- create(int, byte[], byte[]) - Static method in class org.infinispan.commons.tx.XidImpl
- create(int, int) - Static method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
- create(long, Collection<Address>, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
-
Creates a collector for a single key write operation.
- create(Object) - Static method in class org.infinispan.remoting.responses.SuccessfulResponse
- create(Object) - Static method in class org.infinispan.remoting.responses.UnsuccessfulResponse
- create(String) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Creates a Query based on an Ickle query string.
- create(String, IndexedQueryMode) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Creates a Query based on an Ickle query string
- create(Hash, int, int, List<Address>, Map<Address, Float>) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
-
Create a new consistent hash instance.
- create(WrappedBytes, WrappedBytes, Metadata) - Method in interface org.infinispan.container.offheap.OffHeapEntryFactory
-
Creates an off heap entry using the provided key value and metadata
- create(WrappedBytes, WrappedBytes, Metadata) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
-
Create an entry off-heap.
- create(T) - Static method in class org.infinispan.commons.util.ByRef
- CREATE_EAGER_ITERATOR - org.infinispan.query.clustered.commandworkers.CQCommandType
- CREATE_LAZY_ITERATOR - org.infinispan.query.clustered.commandworkers.CQCommandType
- CREATE_NEW - org.infinispan.persistence.remote.configuration.ExhaustedAction
- CREATE_ON_START - org.infinispan.persistence.jdbc.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
- createAsyncWriter(CacheWriter) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- createBackingEmbeddedCacheManager() - Method in class org.infinispan.spring.AbstractEmbeddedCacheManagerFactory
- createBiased(long, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
- 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 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, Configuration, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Creates the cache using the supplied template, configuration and flags.
- 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, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.GlobalConfigurationManager
-
Defines a cluster-wide cache configuration
- createCache(Configuration, GlobalComponentRegistry, String) - Method in class org.infinispan.factories.InternalCacheFactory
-
This implementation clones the configuration passed in before using it.
- createClearNonTxInvocationContext() - Method in class org.infinispan.context.AbstractInvocationContextFactory
-
Deprecated.
- createClearNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
-
Will create an
ClearInvocationContext
with theAbstractInvocationContext.isOriginLocal()
returning true. - createComponentFactoryInternal(Class<?>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- createContext() - 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.container.entries.RemoteMetadata
- created() - Method in interface org.infinispan.metadata.InternalMetadata
- CREATED - org.infinispan.container.entries.ReadCommittedEntry.Flags
- createDirectoryProvider(String, Properties, WorkerBuildContext) - Method in class org.infinispan.query.affinity.AffinityIndexManager
- createDirectoryProvider(String, Properties, WorkerBuildContext) - Method in class org.infinispan.query.indexmanager.InfinispanIndexManager
- createDistributedTaskBuilder(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- createDistributedTaskBuilder(Callable<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
-
Deprecated.Returns DistributedTaskBuilder for this DistributedExecutorService and a given Callable.
- createDistributedTaskPart(DistributedTask<T>, DistributedExecuteCommand<T>, List<K>, Address, int) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- createDistributedTaskPart(DistributedTask<T>, DistributedExecuteCommand<T>, Address, int) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- createExecutor(ThreadFactory) - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
- 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
- createExternal(Class<?>, ObjectInput) - Method in class org.infinispan.commons.marshall.jboss.JBossExternalizerAdapter
- createGlobalTransaction() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
-
Deprecated.
- createGlobalTransaction() - Method in class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
-
Factory method for GlobalTransactions
- createGlobalTransaction() - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
- createGlobalTransaction() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
-
Deprecated.
- createGlobalTransaction() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
- createHashDistAwareResp(int, Map<Address, ServerAddress>, Configuration) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- createHashDistAwareResp(int, Map<Address, ServerAddress>, Configuration) - Method in class org.infinispan.server.hotrod.AbstractTopologyAwareEncoder1x
- createInitialCacheTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
- createInstance(PartitionHandlingConfiguration) - Method in interface org.infinispan.conflict.EntryMergePolicyFactory
- createInstance(PartitionHandlingConfiguration) - Method in class org.infinispan.conflict.EntryMergePolicyFactoryRegistry
- createInstance(StoreConfiguration) - Method in interface org.infinispan.persistence.factory.CacheStoreFactory
-
Returns new instance based on
StoreConfiguration
. - createInstance(StoreConfiguration) - Method in class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
-
Creates new Object based on configuration.
- createInstance(StoreConfiguration) - Method in class org.infinispan.persistence.factory.LocalClassLoaderCacheStoreFactory
- createInvocationContext(boolean, int) - Method in interface org.infinispan.context.InvocationContextFactory
-
If we are in a tx scope this will return an
TxInvocationContext
. - createInvocationContext(boolean, int) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
-
Deprecated.
- createInvocationContext(boolean, int) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- createInvocationContext(Transaction, boolean) - Method in interface org.infinispan.context.InvocationContextFactory
-
Creates an invocation context
- createInvocationContext(Transaction, boolean) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
-
Deprecated.
- createInvocationContext(Transaction, boolean) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- createJdkSslContext(SslConfiguration, SslEngineConfiguration) - Static method in class org.infinispan.server.core.utils.SslUtils
- createLocalExecutor(Cache<?, ?>) - Static method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- createLocalizedCacheTopology(CacheTopology) - Method in interface org.infinispan.distribution.DistributionManager
- createLocalTx(Xid, 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.
- createMarshaller(MarshallingConfiguration) - Method in class org.infinispan.commons.marshall.jboss.JBossMarshallerFactory
- createMetadata(Configuration, Optional<Long>, Optional<Long>) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- 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
- createMultiTargetCollector(long, int, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
- createMultiTargetCollector(C, int) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- createMultiTargetCollector(C, int) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- createNettySslContext(SslConfiguration, SslEngineConfiguration, ApplicationProtocolConfig) - Static method in class org.infinispan.server.core.utils.SslUtils
- createNewFile() - Method in class org.infinispan.io.GridFile
- createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- createNewVersionsAndCheckForWriteSkews(VersionGenerator, TxInvocationContext, VersionedPrepareCommand) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
- createNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
-
Will create an
NonTxInvocationContext
with theAbstractInvocationContext.isOriginLocal()
returning true. - createNonTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
-
Deprecated.
- createNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- 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
- createPushStateTask() - Method in class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.
- createRemoteInvocationContext(Address) - Method in interface org.infinispan.context.InvocationContextFactory
-
Returns an
NonTxInvocationContext
whoseAbstractInvocationContext.isOriginLocal()
flag will be true. - createRemoteInvocationContext(Address) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
-
Deprecated.
- createRemoteInvocationContext(Address) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- createRemoteInvocationContextForCommand(VisitableCommand, Address) - Method in class org.infinispan.context.AbstractInvocationContextFactory
-
Deprecated.
- 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 interface org.infinispan.context.InvocationContextFactory
-
Returns an
RemoteTxInvocationContext
. - createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
-
Deprecated.
- createRemoteTxInvocationContext(RemoteTransaction, Address) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.infinispan.server.core.security.external.ExternalSaslServerFactory
- createSegmentBasedCollector(long, Map<Address, Collection<Integer>>, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
-
Creates a collector for
PutMapCommand
. - createSession() - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- createSingleKeyNonTxInvocationContext() - Method in interface org.infinispan.context.InvocationContextFactory
-
Will create an
NonTxInvocationContext
with theAbstractInvocationContext.isOriginLocal()
returning true. - createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
-
Deprecated.
- createSingleKeyNonTxInvocationContext() - Method in class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- 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
- createTopologyCacheConfig(long) - Method in class org.infinispan.server.hotrod.HotRodServer
- createTransaction() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- createTransaction() - Method in class org.infinispan.transaction.tm.EmbeddedBaseTransactionManager
- createTxInvocationContext(LocalTransaction) - Method in interface org.infinispan.context.InvocationContextFactory
-
Returns a
LocalTxInvocationContext
. - createTxInvocationContext(LocalTransaction) - Method in class org.infinispan.context.NonTransactionalInvocationContextFactory
-
Deprecated.
- createTxInvocationContext(LocalTransaction) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- createUnmarshaller(MarshallingConfiguration) - Method in class org.infinispan.commons.marshall.jboss.JBossMarshallerFactory
- createWorkspaceHolder(String, Properties, WorkerBuildContext) - Method in class org.infinispan.query.indexmanager.InfinispanIndexManager
- CRLF - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- CRLFBytes - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- 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
- 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 - org.infinispan.configuration.cache.BackupFailurePolicy
- CUSTOM - org.infinispan.conflict.MergePolicy
- CUSTOM - org.infinispan.globalstate.ConfigurationStorage
-
Lets you provide a configuration storage provider.
- CUSTOM_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
- CUSTOM_INTERCEPTORS - org.infinispan.configuration.parsing.Element
- CUSTOM_ROLE_MAPPER - 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
- CustomFailurePolicy<K,V> - Interface in org.infinispan.xsite
-
Used for implementing custom policies in case of communication failures with a remote site.
- customInterceptors() - Method in class org.infinispan.configuration.cache.Configuration
- customInterceptors() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- customInterceptors() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- CustomInterceptorsConfiguration - Class in org.infinispan.configuration.cache
-
Configures custom interceptors to be added to the cache.
- CustomInterceptorsConfiguration() - Constructor for class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
- CustomInterceptorsConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Configures custom interceptors to be added to the cache.
- 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, SingletonStoreConfiguration) - 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
- data - Variable in class org.infinispan.remoting.MIMECacheEntry
-
The payload.
- data() - Method in class org.infinispan.rest.InfinispanRequest
- DATA_COLUMN - org.infinispan.persistence.jdbc.configuration.Element
- DATA_COLUMN_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- DATA_COLUMN_TYPE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- DATA_CONTAINER - org.infinispan.configuration.parsing.Attribute
- DATA_CONTAINER - org.infinispan.configuration.parsing.Element
- DATA_CONTAINER - Static variable in class org.infinispan.configuration.cache.DataContainerConfiguration
-
Deprecated.
- DATA_CONVERSION - Static variable in interface org.infinispan.commons.marshall.Ids
- DATA_REHASHED - org.infinispan.notifications.cachelistener.event.Event.Type
- DATA_SOURCE - org.infinispan.persistence.jdbc.configuration.Element
- DatabaseType - Enum in org.infinispan.persistence.jdbc
-
Supported database dialects for the JDBC cache stores
- dataColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- dataColumnName(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
The name of the database column used to store the entries
- dataColumnType() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- dataColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
The type of the database column used to store the entries
- dataContainer - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- dataContainer - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- dataContainer - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- dataContainer - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- dataContainer - Variable in class org.infinispan.statetransfer.StateProviderImpl
- dataContainer() - Method in class org.infinispan.configuration.cache.Configuration
- dataContainer() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- dataContainer() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- dataContainer() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
-
Deprecated.data container is no longer to exposed via configuration at a later point
- dataContainer(DataContainer) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.data container is no longer to exposed via configuration at a later point
- 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
- DataContainerConfiguration - Class in org.infinispan.configuration.cache
-
Deprecated.Please use
MemoryConfiguration
- DataContainerConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Deprecated.Please use
MemoryConfiguration
- 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
- DataLocality - Enum in org.infinispan.distribution
-
Used to determine whether a key is mapped to a local node.
- DataPartitioner - Interface in org.infinispan.persistence.remote.upgrade
-
Creates data partitions to allow parallel processing.
- 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
. - dataSource() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- dataSource() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
- dataSource() - Method in interface org.infinispan.persistence.jdbc.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
- dataType() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
- DataType - Enum in org.infinispan.jmx.annotations
- DAYS - org.infinispan.server.hotrod.TimeUnitValue
- DB_MAJOR_VERSION - org.infinispan.persistence.jdbc.configuration.Attribute
- DB_MINOR_VERSION - org.infinispan.persistence.jdbc.configuration.Attribute
- DB2 - org.infinispan.persistence.jdbc.DatabaseType
- DB2_390 - org.infinispan.persistence.jdbc.DatabaseType
- dbMajorVersion() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- dbMajorVersion(Integer) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- dbMinorVersion() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- dbMinorVersion(Integer) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- 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
- 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
- deadlockDetection() - Method in class org.infinispan.configuration.cache.Configuration
-
Deprecated.Since 9.0, will be ignored.
- deadlockDetection() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
-
Deprecated.Since 9.0, deadlock detection is always disabled.
- deadlockDetection() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
-
Deprecated.Since 9.0, deadlock detection is always disabled.
- DeadlockDetectionConfiguration - Class in org.infinispan.configuration.cache
-
Deprecated.Since 9.0, deadlock detection is always disabled.
- DeadlockDetectionConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Deprecated.Since 9.0, deadlock detection is always disabled.
- DEADLOCKED - 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
- DEBUG_DEPENDENCIES - Static variable in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- DebuggingExceptionListener() - Constructor for class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
- DECISION_FUNCTION - Static variable in class org.infinispan.server.core.ExternalizerIds
- decode(byte) - Static method in enum org.infinispan.server.hotrod.TimeUnitValue
- decode(byte[], int, int) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Very low-level access to decoding ASCII characters in the form of a byte array.
- decode(int) - Static method in class org.infinispan.commons.io.SignedNumeric
- 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.util.Base64
-
Deprecated.Decodes data from Base64 notation, automatically detecting gzip-compressed data and decompressing it.
- DECODE - Static variable in class org.infinispan.commons.util.Base64
-
Deprecated.Specify decoding.
- DECODE_HEADER - org.infinispan.server.hotrod.HotRodDecoderState
- DECODE_HEADER - org.infinispan.server.memcached.MemcachedDecoderState
- DECODE_HEADER_CUSTOM - org.infinispan.server.hotrod.HotRodDecoderState
- DECODE_KEY - org.infinispan.server.hotrod.HotRodDecoderState
- DECODE_KEY - org.infinispan.server.memcached.MemcachedDecoderState
- DECODE_KEY_CUSTOM - org.infinispan.server.hotrod.HotRodDecoderState
- DECODE_PARAMETERS - org.infinispan.server.hotrod.HotRodDecoderState
- DECODE_PARAMETERS - org.infinispan.server.memcached.MemcachedDecoderState
- DECODE_VALUE - org.infinispan.server.hotrod.HotRodDecoderState
- DECODE_VALUE - org.infinispan.server.memcached.MemcachedDecoderState
- DECODE_VALUE_CUSTOM - org.infinispan.server.hotrod.HotRodDecoderState
- decodeConfiguration(Supplier<Byte>, LongSupplier, IntSupplier) - Static method in class org.infinispan.counter.util.EncodeUtil
- decodeFromFile(String) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Convenience method for reading a base64-encoded file and decoding it.
- 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
-
Decode UTF-8 as a java object.
- decodeOctetStream(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
-
Decode a octet-stream content that is not a byte[].
- 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
- decodeStorage(byte) - Static method in class org.infinispan.counter.util.EncodeUtil
-
Decodes the
CounterType
. - decodeToFile(String, String) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Convenience method for decoding data to a file.
- decodeToObject(String) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Attempts to decode Base64 data and deserialize a Java Object within.
- decodeType(byte) - Static method in class org.infinispan.counter.util.EncodeUtil
-
Decodes the
Storage
. - decodeVersion(short) - Static method in class org.infinispan.Version
- decodeVersionForSerialization(short) - Static method in class org.infinispan.Version
-
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.
- decrement() - Method in interface org.infinispan.counter.api.SyncWeakCounter
- decrement() - Method in interface org.infinispan.counter.api.WeakCounter
-
Decrements the counter.
- 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 - org.infinispan.server.memcached.MemcachedOperation
- DEF_CLASS_COUNT - Static variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- DEF_INSTANCE_COUNT - Static variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- DEFAULT - org.infinispan.configuration.global.ShutdownHookBehavior
-
By default a shutdown hook is registered if no MBean server (apart from the JDK default) is detected.
- DEFAULT - org.infinispan.configuration.parsing.Element
- DEFAULT - org.infinispan.eviction.EvictionThreadPolicy
- DEFAULT - org.infinispan.server.hotrod.TimeUnitValue
- DEFAULT - org.infinispan.transaction.TransactionProtocol
-
uses the 2PC protocol
- DEFAULT_BUFFER_SIZE - Static variable in class org.infinispan.util.stream.Streams
-
The default buffer size that will be used for buffered operations.
- DEFAULT_CACHE - org.infinispan.configuration.parsing.Attribute
- DEFAULT_CACHE_NAME - Static variable in interface org.infinispan.commons.api.BasicCacheContainer
-
Deprecated.
- DEFAULT_CACHE_NAME - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- DEFAULT_CACHE_NAME - Static variable in annotation type org.infinispan.spring.session.configuration.EnableInfinispanEmbeddedHttpSession
- DEFAULT_CACHE_NAME - Static variable in annotation type org.infinispan.spring.session.configuration.EnableInfinispanRemoteHttpSession
- DEFAULT_CHUNK_SIZE - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- 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_CONTEXT_PATH - Static variable in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- DEFAULT_DOUBLING_SIZE - Static variable in class org.infinispan.commons.io.ExposedByteArrayOutputStream
-
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
-
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.ExposedByteArrayOutputStream
-
Deprecated.Default buffer size after which if more buffer capacity is needed the buffer will grow by 25% rather than 100%
- 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
- DEFAULT_KEY - Static variable in class org.infinispan.encoding.DataConversion
- DEFAULT_MARSHALL_VERSION - Static variable in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated.Since 9.4, use
Version.getVersionShort()
instead. - DEFAULT_MAX_RETRIES - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- DEFAULT_MEDIA_TYPE - Static variable in class org.infinispan.configuration.cache.ContentTypeConfiguration
- 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_NAME - Static variable in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- DEFAULT_NUMBER_SHARDS - Static variable in class org.infinispan.query.affinity.AffinityShardIdentifierProvider
- DEFAULT_PATTERN - Static variable in class org.infinispan.factories.threads.DefaultThreadFactory
- DEFAULT_PORT - Static variable in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- DEFAULT_RECOVERY_INFO_CACHE - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
- DEFAULT_SNI_DOMAIN - Static variable in class org.infinispan.server.core.configuration.SslConfiguration
- DEFAULT_TIMEOUT - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- DEFAULT_TOP_KEY - Static variable in class org.infinispan.stats.topK.CacheUsageInterceptor
- DEFAULT_TOPOLOGY_ID - Static variable in class org.infinispan.server.hotrod.Constants
- DEFAULT_TRANSPORT - Static variable in class org.infinispan.configuration.global.TransportConfigurationBuilder
- DEFAULT_VALUE - Static variable in class org.infinispan.encoding.DataConversion
- DEFAULT_WAIT_TIME - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- DefaultBuilder() - Constructor for class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl.DefaultBuilder
- 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(Configuration) - Constructor for class org.infinispan.manager.DefaultCacheManager
-
Constructs and starts a new instance of the CacheManager, using the default configuration passed in.
- DefaultCacheManager(Configuration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
-
Constructs a new instance of the CacheManager, using the default configuration passed in.
- 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
-
Constructs and starts a new instance of the CacheManager, using the global and default configurations passed in.
- DefaultCacheManager(GlobalConfiguration, Configuration, boolean) - Constructor for class org.infinispan.manager.DefaultCacheManager
-
Constructs a new instance of the CacheManager, using the global and default configurations passed in.
- 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.GlobalConfiguration
- defaultCacheName() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- defaultCacheName() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- 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
CacheContainer.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
- 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
- DefaultContextClassResolver - Class in org.infinispan.commons.marshall.jboss
-
This class refines
ContextClassLoader
to add a default class loader. - DefaultContextClassResolver(ClassLoader) - Constructor for class org.infinispan.commons.marshall.jboss.DefaultContextClassResolver
- DefaultDistributedTaskLifecycle - Class in org.infinispan.distexec.spi
- DefaultDistributedTaskLifecycle() - Constructor for class org.infinispan.distexec.spi.DefaultDistributedTaskLifecycle
- 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
- DefaultExecutorService - Class in org.infinispan.distexec
-
Deprecated.since 9.1 Please use
EmbeddedCacheManager.executor()
orCacheStream
instead. - DefaultExecutorService(Cache<?, ?>) - Constructor for class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.Creates a new DefaultExecutorService given a master cache node for local task execution.
- DefaultExecutorService(Cache<?, ?>, ExecutorService) - Constructor for class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.Creates a new DefaultExecutorService given a master cache node and an ExecutorService for parallel execution of tasks ran on this node.
- DefaultExecutorService(Cache<?, ?>, ExecutorService, boolean) - Constructor for class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.Creates a new DefaultExecutorService given a master cache node and an ExecutorService for parallel execution of task ran on this node.
- 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
- DefaultIterationManager - Class in org.infinispan.server.hotrod.iteration
- DefaultIterationManager(TimeService) - Constructor for class org.infinispan.server.hotrod.iteration.DefaultIterationManager
- DefaultLifespan - org.infinispan.server.hotrod.ProtocolFlag
- defaultMapEntryFromDataContainer(InternalCacheEntry, InternalEntryFactory) - Static method in class org.infinispan.statetransfer.OutboundTransferTask
- defaultMapEntryFromStore(MarshalledEntry, InternalEntryFactory) - Static method in class org.infinispan.statetransfer.OutboundTransferTask
- DefaultMaxIdle - org.infinispan.server.hotrod.ProtocolFlag
- 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
-
Use this method if the remote cache that backups in this cache is the default cache.
- 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
- DefaultSimpleStat - Class in org.infinispan.commons.stat
-
A default
SimpleStat
implementation. - DefaultSimpleStat() - Constructor for class org.infinispan.commons.stat.DefaultSimpleStat
- 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
- DefaultTopologyRunnable - Class in org.infinispan.remoting.inboundhandler
-
The default
Runnable
for the remote commands receives. - DefaultTopologyRunnable(BasePerCacheInboundInvocationHandler, CacheRpcCommand, Reply, TopologyMode, int, boolean) - Constructor for class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
- DefaultTranscoder - Class in org.infinispan.commons.dataconversion
-
Handle conversions between text/plain, url-encoded, java objects, and octet-stream contents.
- DefaultTranscoder() - Constructor for class org.infinispan.commons.dataconversion.DefaultTranscoder
- DefaultTranscoder(GenericJBossMarshaller, JavaSerializationMarshaller) - Constructor for class org.infinispan.commons.dataconversion.DefaultTranscoder
- 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
- defensive() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.Store as binary configuration is always defensive now.
- defensive(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
-
Deprecated.Store as binary configuration is always defensive now.
- defineConfiguration(String, String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
- defineConfiguration(String, String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Defines a named cache's configuration using by first reading the template configuration and then applying the override afterwards to generate a configuration.
- defineConfiguration(String, Configuration) - Method in class org.infinispan.manager.DefaultCacheManager
- defineConfiguration(String, Configuration) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Defines a named cache's configuration by using the provided configuration
- 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
. - 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 interface org.infinispan.counter.api.CounterManager
-
Defines a counter with the specific
name
andCounterConfiguration
. - 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
. - defineMappings(Cache, SearchMapping) - Method in interface org.infinispan.query.spi.ProgrammaticSearchMappingProvider
-
Supply some custom programmatic mappings to Hibernate Search.
- DEGRADED_MODE - org.infinispan.partitionhandling.AvailabilityMode
-
Data can not be safely accessed because of a network split or successive nodes leaving.
- 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. - delegate - Variable in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- delegate - Variable in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
- 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.container.entries.ForwardingCacheEntry
- 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.util.AbstractDelegatingCacheCollection
- delegate() - Method in class org.infinispan.util.AbstractDelegatingCacheSet
- delegate() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorCollection
- delegate() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorSet
- 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 - Class in org.infinispan.persistence.support
- DelegatingCacheWriter(CacheWriter) - Constructor for class org.infinispan.persistence.support.DelegatingCacheWriter
- 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
- delete() - Method in class org.infinispan.io.GridFile
- delete(int, Object) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
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(Object) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- delete(Object) - Method in class org.infinispan.persistence.file.SingleFileStore
- delete(Object) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- delete(Object) - Method in class org.infinispan.persistence.jpa.JpaStore
- delete(Object) - Method in class org.infinispan.persistence.remote.RemoteStore
- delete(Object) - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- delete(Object) - Method in interface org.infinispan.persistence.spi.CacheWriter
- delete(Object) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
- delete(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
- delete(Object) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.
- delete(String) - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- deleteBatch(Iterable) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- deleteBatch(Iterable<Object>) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- deleteBatch(Iterable<Object>) - Method in class org.infinispan.persistence.jpa.JpaStore
- deleteBatch(Iterable<Object>) - Method in interface org.infinispan.persistence.spi.CacheWriter
-
Remove all provided keys from the store in a single batch operation.
- deleteBatch(Iterable<Object>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- deleteBatchFromAllNonTxStores(Iterable<Object>, Predicate<? super StoreConfiguration>, long) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Remove all entries from the underlying non-transactional stores as a single batch.
- deleteBatchFromAllNonTxStores(Iterable<Object>, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- deleteBatchFromAllNonTxStores(Iterable<Object>, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- deleteCacheValue(InfinispanCacheAPIRequest) - Method in class org.infinispan.rest.operations.CacheOperations
-
Implementation of HTTP DELETE request invoked with a key.
- DELETED - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- deleteFromAllStores(Object, int, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
- deleteFromAllStores(Object, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- deleteFromAllStores(Object, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- deleteOnExit() - Method in class org.infinispan.io.GridFile
- deleteOperationsExecutor(Executor) - Method in interface org.infinispan.lucene.directory.BuildContext
-
Provides an Executor to handle delete operations in a background thread
- deleteOrReleaseReadLock(String) - Method in class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
-
Deletes or releases a read-lock for the specified filename, so that if it was marked as deleted and no other
InfinispanIndexInput
instances are reading from it, then it will be effectively deleted. - deleteOrReleaseReadLock(String) - Method in class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
-
It will release a previously acquired readLock, or if no readLock was acquired it will mark the file to be deleted as soon as all pending locks are releases.
- deleteOrReleaseReadLock(String) - Method in class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
-
doesn't do anything
- deleteOrReleaseReadLock(String) - Method in interface org.infinispan.lucene.readlocks.SegmentReadLocker
-
It will release a previously acquired readLock, or if no readLock was acquired it will mark the file to be deleted as soon as all pending locks are releases.
- delistResource(XAResource, int) - Method in class org.infinispan.commons.tx.TransactionImpl
-
De-list an XA resource from this transaction.
- delistResource(XAResource, int) - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.De-list an XA resource from this transaction.
- deliverMode(DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
-
Deprecated.
- deliverOrder() - Method in class org.infinispan.remoting.rpc.RpcOptions
- DeliverOrder - Enum in org.infinispan.remoting.inboundhandler
-
Used in RPC, it defines how the messages are delivered to the nodes.
- delta() - Method in interface org.infinispan.atomic.DeltaAware
-
Deprecated.Extracts changes made to implementations, in an efficient format that can easily and cheaply be serialized and deserialized.
- Delta - Interface in org.infinispan.atomic
-
Deprecated.since 9.1
- DELTA_COMPOSITE_KEY - Static variable in interface org.infinispan.commons.marshall.Ids
- DELTA_WRITE - org.infinispan.context.Flag
-
Deprecated.since 9.1
- DeltaAware - Interface in org.infinispan.atomic
-
Deprecated.since 9.1
- DeltaCompositeKey - Class in org.infinispan.atomic
-
Deprecated.since 9.1
- DeltaCompositeKey(Object, Object) - Constructor for class org.infinispan.atomic.DeltaCompositeKey
-
Deprecated.
- DeltaCompositeKey.DeltaCompositeKeyExternalizer - Class in org.infinispan.atomic
-
Deprecated.
- DeltaCompositeKeyExternalizer() - Constructor for class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
-
Deprecated.
- DENY - org.infinispan.security.AuditResponse
- DENY_READ_WRITES - 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.
- DERBY - org.infinispan.persistence.jdbc.DatabaseType
- deregister(ChannelHandlerContext, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
- DESC - org.infinispan.query.dsl.SortOrder
- description() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
- description() - Method in annotation type org.infinispan.jmx.annotations.ManagedOperation
- description() - Method in annotation type org.infinispan.jmx.annotations.MBean
- description() - Method in annotation type org.infinispan.jmx.annotations.Parameter
- destroy() - Method in class org.infinispan.persistence.file.SingleFileStore
- destroy() - Method in interface org.infinispan.persistence.spi.ExternalStore
-
Method to be used to destroy and clean up any resources associated with this store.
- destroy() - Method in class org.infinispan.spring.InfinispanDefaultCacheFactoryBean
-
Shuts down the
org.infinispan.Cache
created by thisFactoryBean
. - destroy() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
-
Shuts down the
SpringEmbeddedCacheManager
instance created by thisFactoryBean
. - destroy() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
-
thestop
RemoteCacheManager
created by this factory. - destroy() - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- destroy() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
-
Shuts down the
EmbeddedCacheManager
instance created by thisFactoryBean
. - destroy() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
-
Shuts down the
org.infinispan.Cache
created by thisFactoryBean
. - destroy() - Method in class org.infinispan.spring.support.remote.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.DummyTransactionManager
-
Deprecated.
- destroy() - Static method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
- DESTROY_LAZY_ITERATOR - org.infinispan.query.clustered.commandworkers.CQCommandType
- DETAIL - org.infinispan.jmx.annotations.DisplayType
- detectScope(Class<?>) - Static method in class org.infinispan.factories.scopes.ScopeDetector
- dialect() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- dialect(DatabaseType) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- DIALECT - org.infinispan.persistence.jdbc.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 - org.infinispan.manager.ClusterExecutionPolicy
-
The command will be executed only on a different machine.
- DIFFERENT_RACK - org.infinispan.manager.ClusterExecutionPolicy
-
The command will be executed on machine on a different rack.
- DIFFERENT_SITE - org.infinispan.manager.ClusterExecutionPolicy
-
The command will be executed on a different site.
- DIR - Static variable in class org.infinispan.io.GridFile.Metadata
- DirectoryBuilder - Class in org.infinispan.lucene.directory
-
Builder class to create instances of the
Directory
implementation which stored data in the data grid. - disable() - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
- disable() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
- disable() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
-
Disables compatibility mode between embedded.
- disable() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.Since 9.0, deadlock detection is always disabled.
- disable() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
Deprecated.Use
IndexingConfigurationBuilder.index(Index)
instead - disable() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- disable() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
-
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.SingletonStoreConfigurationBuilder
-
Deprecated.Enable the singleton store cache store
- disable() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
-
Deprecated.Disables storing both keys and values as binary.
- disable() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
-
Deprecated.
- disable() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- disable() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
- 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.server.core.configuration.SslConfigurationBuilder
-
Disables the SSL support
- disable() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- DISABLE_BACKUPS - Static variable in class org.infinispan.configuration.cache.SitesConfiguration
- disableBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
-
Returns true if this cache won't backup its data remotely.
- disableBackups(boolean) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
-
Returns true if this cache won't backup its data remotely.
- 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 - disableFullTextFilter(String) - Method in interface org.infinispan.query.CacheQuery
-
Disable a given filter by its name.
- 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.util.AbstractDelegatingCacheStream
- disableStore(String) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Marks the given storage as disabled.
- disableStore(String) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- disableStore(String) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- disconnect(ChannelHandlerContext, ChannelPromise) - Method in class org.infinispan.server.core.transport.SaslQopHandler
- disconnectChannel - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- 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 class org.infinispan.persistence.rest.upgrade.RestTargetMigrator
-
Deprecated.
- disconnectSource(Cache<Object, Object>) - Method in interface org.infinispan.upgrade.TargetMigrator
-
Disconnects the target from the source.
- displayName() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
- displayName() - Method in annotation type org.infinispan.jmx.annotations.ManagedOperation
- displayType() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
- DisplayType - Enum in org.infinispan.jmx.annotations
- dispose() - Method in class org.infinispan.server.hotrod.iteration.IterationReaper
- dissociateTransaction() - Static method in class org.infinispan.commons.tx.TransactionManagerImpl
- DIST - org.infinispan.configuration.parsing.ParsedCacheMode
- DIST_ASYNC - org.infinispan.configuration.cache.CacheMode
-
Async DIST
- DIST_SYNC - 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.util.AbstractDelegatingCacheStream
- distLostDataCheck(ConsistentHash, List<Address>) - Static method in class org.infinispan.topology.ClusterTopologyManagerImpl
- DISTRIBUTED_CACHE - org.infinispan.configuration.parsing.Element
- DISTRIBUTED_CACHE_CONFIGURATION - org.infinispan.configuration.parsing.Element
- DISTRIBUTED_SYNC_TIMEOUT - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- 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.util.AbstractDelegatingCacheStream
- DistributedCallable<K,V,T> - Interface in org.infinispan.distexec
-
A task that returns a result and may throw an exception capable of being executed in another JVM.
- DistributedExecutionCompletionService<V> - Class in org.infinispan.distexec
-
A
CompletionService
that uses a suppliedDistributedExecutorService
to execute tasks. - DistributedExecutionCompletionService(DistributedExecutorService) - Constructor for class org.infinispan.distexec.DistributedExecutionCompletionService
-
Creates an ExecutorCompletionService using the supplied executor for base task execution and a
LinkedBlockingQueue
as a completion queue. - DistributedExecutionCompletionService(DistributedExecutorService, BlockingQueue<CompletableFuture<V>>) - Constructor for class org.infinispan.distexec.DistributedExecutionCompletionService
-
Creates an ExecutorCompletionService using the supplied executor for base task execution and the supplied queue as its completion queue.
- DistributedExecutorService - Interface in org.infinispan.distexec
-
Deprecated.since 9.1 Please use
ClusterExecutor
orCacheStream
instead. - DistributedSegmentReadLocker - Class in org.infinispan.lucene.readlocks
-
DistributedSegmentReadLocker stores reference counters in the cache to keep track of the number of clients still needing to be able to read a segment.
- DistributedSegmentReadLocker(Cache<?, ?>, String, int) - Constructor for class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
- DistributedSegmentReadLocker(Cache<Object, Integer>, Cache<?, ?>, Cache<?, ?>, String, int) - Constructor for class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
- DistributedSegmentReadLocker(Cache<Object, Integer>, Cache<?, ?>, Cache<?, ?>, String, int, boolean) - Constructor for class org.infinispan.lucene.readlocks.DistributedSegmentReadLocker
- 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.
- DistributedTask<T> - Interface in org.infinispan.distexec
-
DistributedTask describes all relevant attributes of a distributed task, most importantly its execution policy, fail over policy and its timeout.
- DistributedTaskBuilder<T> - Interface in org.infinispan.distexec
-
DistributedTaskBuilder is a factory interface for DistributedTask
- DistributedTaskExecutionPolicy - Enum in org.infinispan.distexec
-
DistributedTaskExecutionPolicy allows task to specify its custom task execution policy across Infinispan cluster.
- DistributedTaskFailoverPolicy - Interface in org.infinispan.distexec
-
DistributedTaskFailoverPolicy allows pluggable fail over target selection for a failed remotely executed distributed task.
- DistributedTaskLifecycle - Interface in org.infinispan.distexec.spi
- DistributedTaskLifecycleService - Class in org.infinispan.distexec.spi
- DistributionBulkInterceptor<K,V> - Class in org.infinispan.interceptors.distribution
-
Interceptor that handles bulk entrySet and keySet commands when using in a distributed/replicated environment.
- DistributionBulkInterceptor() - Constructor for class org.infinispan.interceptors.distribution.DistributionBulkInterceptor
- DistributionBulkInterceptor.BackingEntrySet<K,V> - Class in org.infinispan.interceptors.distribution
- DistributionBulkInterceptor.BackingKeySet<K,V> - Class in org.infinispan.interceptors.distribution
- DistributionBulkInterceptor.TxBackingEntrySet<K,V> - Class in org.infinispan.interceptors.distribution
- DistributionInfo - Class in org.infinispan.distribution
- DistributionInfo(int, Address, List<Address>, List<Address>, Collection<Address>, Address) - Constructor for class org.infinispan.distribution.DistributionInfo
- DistributionLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
- distributionManager - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- distributionManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- distributionManager - Variable in class org.infinispan.statetransfer.StateProviderImpl
- 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
- DLD_NORECOVERY_NOXA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
-
Deprecated.
- DLD_NORECOVERY_XA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
-
Deprecated.
- DLD_RECOVERY_XA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
-
Deprecated.
- DldGlobalTransaction - Class in org.infinispan.transaction.xa
-
Deprecated.Since 9.0, no longer used.
- DldGlobalTransaction() - Constructor for class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- DldGlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- DldGlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa
-
Deprecated.
- doAfterCall(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.Callback that is invoked after every handleXXX() method defined above.
- 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
. - doBeforeCall(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- doHandleClusterView(int) - Method in class org.infinispan.topology.ClusterCacheStatus
- 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.GlobalJmxStatisticsConfiguration
- doMergePartitions(Map<Address, CacheStatusResponse>) - Method in class org.infinispan.topology.ClusterCacheStatus
- DONT_BREAK_LINES - Static variable in class org.infinispan.commons.util.Base64
-
Deprecated.Don't break lines when encoding (violates strict Base64 specification)
- DONT_REGISTER - org.infinispan.configuration.global.ShutdownHookBehavior
-
Forces the cache NOT to register a shutdown hook, even if no MBean server is detected.
- 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.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
- DOUBLE - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- DOUBLE_SUMMARY_STATISTICS - Static variable in interface org.infinispan.commons.marshall.Ids
- 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
- downgradeLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
- 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 - org.infinispan.persistence.jdbc.configuration.Attribute
- driverClass() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
- driverClass() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
- driverClass(Class<? extends Driver>) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- driverClass(Class<? extends Driver>) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
- driverClass(String) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- driverClass(String) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
- DROP_ON_EXIT - org.infinispan.persistence.jdbc.configuration.Attribute
- DROP_ON_EXIT - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- dropEvents() - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterEventManager
-
Drops and ignores all previously added events on this thread.
- 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
- DummyBaseTransactionManager - Class in org.infinispan.transaction.tm
-
Deprecated.
- DummyBaseTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.
- DummyNoXaXid - Class in org.infinispan.transaction.tm
-
Deprecated.it will be removed and
EmbeddedXid
would be used instead. - DummyNoXaXid() - Constructor for class org.infinispan.transaction.tm.DummyNoXaXid
-
Deprecated.
- DummyTransaction - Class in org.infinispan.transaction.tm
-
Deprecated.
- DummyTransaction(DummyBaseTransactionManager) - Constructor for class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.
- DummyTransactionManager - Class in org.infinispan.transaction.tm
-
Deprecated.
- DummyTransactionManager() - Constructor for class org.infinispan.transaction.tm.DummyTransactionManager
-
Deprecated.
- DummyTransactionManagerLookup - Class in org.infinispan.transaction.lookup
-
Deprecated.
- DummyTransactionManagerLookup() - Constructor for class org.infinispan.transaction.lookup.DummyTransactionManagerLookup
-
Deprecated.
- DummyUserTransaction - Class in org.infinispan.transaction.tm
-
Deprecated.
- DummyUserTransaction(DummyTransactionManager) - Constructor for class org.infinispan.transaction.tm.DummyUserTransaction
-
Deprecated.
- DummyXid - Class in org.infinispan.transaction.tm
-
Deprecated.use
EmbeddedXid
. - DummyXid(UUID) - Constructor for class org.infinispan.transaction.tm.DummyXid
-
Deprecated.
- dumpCacheStatistics() - Method in class org.infinispan.stats.CacheStatisticManager
- dumpCacheStatisticsTo(PrintStream) - Method in class org.infinispan.stats.CacheStatisticManager
-
Prints the cache statistics values to a
PrintStream
. - dumpStatistics() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- dumpStatisticsToSystemOut() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- dumpStatisticToFile(String) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- dumpTo(PrintWriter) - Method in class org.infinispan.stats.CacheStatisticCollector
-
Prints the cache statistics values to a
PrintStream
. - dumpTo(PrintWriter) - Method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- dumpTo(StringBuilder) - Method in class org.infinispan.stats.CacheStatisticCollector
-
Dumps all the cache statistic values to a
StringBuilder
- duplicateAttribute(XMLStreamReader, 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.
- duplicateCollection(Collection<E>) - Static method in class org.infinispan.commons.util.ObjectDuplicator
- 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
- duplicateNamedElement(XMLStreamReader, 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.
- duplicateSet(Set<E>) - Static method in class org.infinispan.commons.util.ObjectDuplicator
- DYNAMIC - org.infinispan.jmx.annotations.MeasurementType
- dynamicBuffer() - Static method in class org.infinispan.server.core.transport.ExtendedByteBuf
- dynamicBuffer() - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
E
- EAGER - org.infinispan.query.FetchOptions.FetchMode
-
With eager mode all results are loaded as soon as the query is performed; this results in a larger initial transfer of entries but no remote operations during iteration of the resultset.
- 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 - 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.configuration
-
An enumeration of all the recognized XML element local names for the JDBC cache stores
- Element - Enum in org.infinispan.persistence.jpa.configuration
-
An enumeration of all the recognized XML element local names for the JPA cache stores
- Element - Enum in org.infinispan.persistence.leveldb.configuration
-
An enumeration of all the recognized XML element local names for the LevelDB 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.rest.configuration
-
An enumeration of all the recognized XML element local names for the
RestStore
- elements() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Returns an enumeration of the values in this table.
- elements() - Method in class org.infinispan.security.CachePermissionCollection
- EMBEDDED_METADATA - Static variable in interface org.infinispan.commons.marshall.Ids
- EmbeddedApplicationPublishedBridge - Class in org.infinispan.spring.session
-
A bridge between Infinispan Embedded events and Spring.
- EmbeddedApplicationPublishedBridge(SpringCache) - Constructor for class org.infinispan.spring.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.base.BaseCustomInterceptor
-
Deprecated.
- 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 cached. - EmbeddedCounterManagerFactory - Class in org.infinispan.counter
-
A
CounterManager
factory for embedded cached. - EmbeddedMetadata - Class in org.infinispan.metadata
-
Metadata class for embedded caches.
- EmbeddedMetadata.Builder - Class in org.infinispan.metadata
- EmbeddedMetadata.Externalizer - Class in org.infinispan.metadata
- EmbeddedMetadataHelper - Class in org.infinispan.persistence.rest.metadata
- EmbeddedMetadataHelper() - Constructor for class org.infinispan.persistence.rest.metadata.EmbeddedMetadataHelper
- 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
. - EmbeddedXid - Class in org.infinispan.transaction.tm
-
Implementation of
Xid
used byEmbeddedTransactionManager
. - EmbeddedXid(UUID) - Constructor for class org.infinispan.transaction.tm.EmbeddedXid
- emitSessionCreatedEvent(String) - Method in class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- emitSessionDeletedEvent(String) - Method in class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- emitSessionDestroyedEvent(String) - Method in class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- emitSessionExpiredEvent(String) - Method in class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- empty() - Static method in class org.infinispan.marshall.core.MarshalledEntryImpl
-
Returns the value that should be used as an empty MarshalledEntry.
- EMPTY - Static variable in class org.infinispan.metadata.EmbeddedMetadata
- EMPTY - Static variable in class org.infinispan.remoting.responses.UnsuccessfulResponse
- EMPTY_ARRAY - Static variable in interface org.infinispan.remoting.transport.Address
- EMPTY_ARRAY - Static variable in class org.infinispan.util.concurrent.CompletableFutures
- 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_INJECT_METHODS - Static variable in class org.infinispan.factories.components.ComponentMetadata
- EMPTY_OBJECT_ARRAY - Static variable in class org.infinispan.commons.util.Util
- EMPTY_PRIORITIZED_METHODS - Static variable in class org.infinispan.factories.components.ComponentMetadata
- EMPTY_STRING_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
- emptyResponse(HotRodHeader, HotRodServer, ByteBufAllocator, OperationStatus) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- emptyResponse(HotRodHeader, HotRodServer, ByteBufAllocator, OperationStatus) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- emptyResponseWithMediaTypes(HotRodHeader, HotRodServer, ByteBufAllocator, OperationStatus) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- emptyString() - Static method in class org.infinispan.util.ByteString
- 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
- enable() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
-
Enables compatibility mode between embedded and different remote endpoints (Hot Rod, Memcached, REST...etc).
- enable() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.Since 9.0, deadlock detection is always disabled.
- enable() - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
Deprecated.Use
IndexingConfigurationBuilder.index(Index)
instead - enable() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- enable() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
-
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.SingletonStoreConfigurationBuilder
-
Deprecated.Enable the singleton store cache store
- enable() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
-
Deprecated.Enables storing both keys and values as binary.
- enable() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
-
Deprecated.
- enable() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- enable() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
- 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.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
- 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
- enabled() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
- enabled() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
-
Deprecated.Since 9.0, always returns
false
. - 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
-
Deprecated.Use
IndexingConfiguration.index()
instead - enabled() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
- enabled() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
- enabled() - Method in class org.infinispan.configuration.cache.L1Configuration
- enabled() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
-
Deprecated.Since 9.2, replaced with
PartitionHandlingConfiguration.whenSplit()
. - 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.SingletonStoreConfiguration
-
Deprecated.If true, the singleton store cache store is enabled.
- enabled() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.use
MemoryConfiguration.storageType()
instead - enabled() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- enabled() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
-
Deprecated.
- enabled() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- enabled() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- enabled() - Method in class org.infinispan.configuration.global.GlobalStateConfiguration
- enabled() - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
- 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.server.core.configuration.SslConfiguration
- enabled() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- enabled(boolean) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
- enabled(boolean) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
- enabled(boolean) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
-
Configures whether this site is used for backing up data or not (defaults to true).
- enabled(boolean) - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
-
Sets whether compatibility mode is enabled or disabled.
- enabled(boolean) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.Since 9.0, deadlock detection is always disabled.
- 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
-
Deprecated.Use
IndexingConfigurationBuilder.index(Index)
instead - enabled(boolean) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
-
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.PartitionHandlingConfigurationBuilder
-
Deprecated.Since 9.2, please use
PartitionHandlingConfigurationBuilder.whenSplit(PartitionHandling)
instead. - enabled(boolean) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
-
Enable recovery for this cache
- enabled(boolean) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
-
Deprecated.If true, the singleton store cache store is enabled.
- enabled(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.
- enabled(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
-
Deprecated.Sets whether this feature is enabled or disabled.
- enabled(boolean) - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
-
Deprecated.
- enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- enabled(boolean) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
- 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.server.core.configuration.SslConfigurationBuilder
-
Enables or disables the SSL support
- enabled(boolean) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- ENABLED - org.infinispan.configuration.parsing.Attribute
- 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.BackupConfiguration
- ENABLED - Static variable in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
- ENABLED - Static variable in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
-
Deprecated.
- ENABLED - Static variable in class org.infinispan.configuration.cache.GroupsConfiguration
- ENABLED - Static variable in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
- ENABLED - Static variable in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
- ENABLED - Static variable in class org.infinispan.configuration.cache.L1Configuration
- ENABLED - Static variable in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
-
Deprecated.
- ENABLED - Static variable in class org.infinispan.configuration.cache.RecoveryConfiguration
- ENABLED - Static variable in class org.infinispan.configuration.cache.SingletonStoreConfiguration
-
Deprecated.
- ENABLED - Static variable in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.
- ENABLED - Static variable in class org.infinispan.configuration.cache.VersioningConfiguration
-
Deprecated.
- ENABLED - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- ENABLED - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- ENABLED - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
- enabledBackups() - Method in class org.infinispan.configuration.cache.SitesConfiguration
-
Returns the list of
BackupConfiguration
that haveBackupConfiguration.enabled()
== true. - enableFullTextFilter(String) - Method in interface org.infinispan.query.CacheQuery
-
Enable a given filter by its name.
- EnableInfinispanEmbeddedHttpSession - Annotation Type in org.infinispan.spring.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.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.
- encode(int) - Static method in class org.infinispan.commons.io.SignedNumeric
- ENCODE - Static variable in class org.infinispan.commons.util.Base64
-
Deprecated.Specify encoding.
- encodeBytes(byte[]) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Encodes a byte array into Base64 notation.
- encodeBytes(byte[], int) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Encodes a byte array into Base64 notation.
- encodeBytes(byte[], int, int) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Encodes a byte array into Base64 notation.
- encodeBytes(byte[], int, int, int) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Encodes a byte array into Base64 notation.
- encodeConfiguration(CounterConfiguration, Consumer<Byte>, LongConsumer, IntConsumer) - Static method in class org.infinispan.counter.util.EncodeUtil
-
Encodes the configuration.
- encodeFromFile(String) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Convenience method for reading a binary file and base64-encoding it.
- encodeObject(Serializable) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Serializes an object and returns the Base64-encoded version of that serialized object.
- encodeObject(Serializable, int) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Serializes an object and returns the Base64-encoded version of that serialized object.
- 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
-
Used to convert data between read/write format and storage format.
- ENCODER - 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
- EncoderIds - Interface in org.infinispan.commons.dataconversion
- 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
- encodeToFile(byte[], String) - Static method in class org.infinispan.commons.util.Base64
-
Deprecated.Convenience method for encoding data to a file.
- 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.Configuration
- encoding() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- encoding() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- ENCODING - org.infinispan.configuration.parsing.Element
- EncodingConfiguration - Class in org.infinispan.configuration.cache
-
Controls encoding configuration for keys and values in the cache.
- EncodingConfiguration(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
- EncodingUtils - Class in org.infinispan.commons.dataconversion
-
Deprecated.Use the org.infinispan.encoding.DataConversion obtained from the AdvancedCache.
- ENCRYPTION - org.infinispan.persistence.remote.configuration.Element
- end(Xid, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- END - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- END_ITERATOR - Static variable in interface org.infinispan.commons.marshall.Ids
- END_SIZE - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- endAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
- endBatch(boolean) - Method in class org.infinispan.batch.BatchContainer
- endBatch(boolean) - Method in interface org.infinispan.commons.api.BatchingCache
-
Completes a batch if one has been started using
BatchingCache.startBatch()
. - endBatch(boolean, boolean) - Method in class org.infinispan.batch.BatchContainer
- 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
- enlist(Transaction, LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
- 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.
- enlistResource(XAResource) - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.Enlist an XA resource with this transaction.
- ensureOrder(TotalOrderRemoteTransactionState, Collection<?>) - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
-
It ensures the validation order for the transaction corresponding to the prepare command.
- ENTITY_CLASS_NAME - org.infinispan.persistence.jpa.configuration.Attribute
- entityClass() - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfiguration
- entityClass(Class<?>) - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationBuilder
- entries() - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
-
Provides a
Traversable
that allows clients to navigate all cached entries. - entryCommitted(CacheNotifier, FunctionalNotifier, boolean, boolean, boolean, CacheEntry, InvocationContext, FlagAffectedCommand, Object, Metadata) - 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.
- entryFactory - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- entryFactory - Variable in class org.infinispan.statetransfer.StateProviderImpl
- entryFreshEnough(Date, OptionalInt) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- 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
- EntryMetaFactory - Class in org.infinispan.factories
- EntryMetaFactory() - Constructor for class org.infinispan.factories.EntryMetaFactory
- entryPurged(K) - Method in interface org.infinispan.persistence.spi.AdvancedCacheWriter.PurgeListener
-
Optional.
- entryRemoved(long) - Method in interface org.infinispan.container.offheap.OffHeapConcurrentMap.EntryListener
-
Invoked when an entry is about to be removed.
- 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 - Variable in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
- 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.commons.equivalence.EquivalentHashMap
-
Deprecated.
- 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.concurrent.ConcurrentWeakKeyHashMap
-
Returns a
Set
view of the mappings contained in this map. - entrySet() - Method in class org.infinispan.commons.util.FastCopyHashMap
- entrySet() - Method in class org.infinispan.commons.util.WeakValueHashMap
- entrySet() - Method in interface org.infinispan.container.DataContainer
-
Deprecated.Please use iterator method if bulk operations are required.
- entrySet() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- entrySet() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- EntrySet() - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap.EntrySet
-
Deprecated.
- EntrySet() - Constructor for class org.infinispan.commons.util.FastCopyHashMap.EntrySet
- EntrySetFormatter - Class in org.infinispan.rest.operations.mediatypes
-
Formats collections of entries based on the associated
MediaType
; - EntrySetFormatter() - Constructor for class org.infinispan.rest.operations.mediatypes.EntrySetFormatter
- EntrySizeCalculator<K,V> - Interface in org.infinispan.commons.util
- 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.stream.StreamMarshalling
-
Provides a function that returns the value of the entry when invoked.
- 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
- EntryVersionsMap - Class in org.infinispan.container.versioning
- EntryVersionsMap() - Constructor for class org.infinispan.container.versioning.EntryVersionsMap
- EntryVersionsMap(int) - Constructor for class org.infinispan.container.versioning.EntryVersionsMap
- 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.
- 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.
- 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
- 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.
- eq(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
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
-
Alias for
FilterConditionEndContext.eq(Object)
- EQUAL - 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(byte[], Object) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
-
Deprecated.
- equals(Object) - Method in class org.infinispan.atomic.DeltaCompositeKey
-
Deprecated.
- 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.dataconversion.MediaType
- equals(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- 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.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.AuthorizationConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.BackupConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.BackupForConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.Configuration
- equals(Object) - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
-
Deprecated.
- equals(Object) - Method in class org.infinispan.configuration.cache.EncodingConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- equals(Object) - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.GroupsConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.HashConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.L1Configuration
- equals(Object) - Method in class org.infinispan.configuration.cache.LockingConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.SecurityConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
-
Deprecated.
- equals(Object) - Method in class org.infinispan.configuration.cache.SitesConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.
- equals(Object) - Method in class org.infinispan.configuration.cache.SyncConfiguration
-
Deprecated.
- equals(Object) - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
- equals(Object) - Method in class org.infinispan.configuration.cache.VersioningConfiguration
-
Deprecated.
- equals(Object) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- 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.GlobalJmxStatisticsConfiguration
- equals(Object) - Method in class org.infinispan.configuration.global.SerializationConfiguration
- equals(Object) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
- equals(Object) - Method in class org.infinispan.configuration.global.SiteConfiguration
- equals(Object) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
- equals(Object) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- equals(Object) - Method in class org.infinispan.configuration.global.TransportConfiguration
- equals(Object) - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
- 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.NumericVersion
- equals(Object) - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
- equals(Object) - Method in class org.infinispan.counter.api.CounterConfiguration
- equals(Object) - Method in class org.infinispan.encoding.DataConversion
- equals(Object) - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
- equals(Object) - Method in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
- equals(Object) - Method in class org.infinispan.functional.MetaParam.MetaLong
- equals(Object) - Method in class org.infinispan.globalstate.ScopedState
- equals(Object) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
- equals(Object) - Method in class org.infinispan.io.GridFile
- equals(Object) - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
- equals(Object) - Method in class org.infinispan.lucene.ChunkCacheKey
- equals(Object) - Method in class org.infinispan.lucene.FileCacheKey
- equals(Object) - Method in class org.infinispan.lucene.FileListCacheKey
- equals(Object) - Method in class org.infinispan.lucene.FileMetadata
- equals(Object) - Method in class org.infinispan.lucene.FileReadLockKey
- equals(Object) - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
- equals(Object) - Method in class org.infinispan.metadata.EmbeddedMetadata
- equals(Object) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
- equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfiguration
- equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
- equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
- equals(Object) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- 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.RemoteServerConfiguration
- equals(Object) - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- equals(Object) - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- equals(Object) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
- equals(Object) - Method in class org.infinispan.remoting.LocalInvocation
- equals(Object) - Method in class org.infinispan.remoting.MIMECacheEntry
- 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.rpc.RpcOptionsBuilder
-
Deprecated.
- 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.rest.operations.mime.MimeMetadata
- equals(Object) - Method in class org.infinispan.security.CachePermission
- 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.ServerAddress
- 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.server.memcached.MemcachedMetadata
- equals(Object) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
- 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.synchronization.SynchronizationAdapter
- equals(Object) - Method in class org.infinispan.transaction.tm.DummyNoXaXid
-
Deprecated.
- equals(Object) - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.
- equals(Object) - Method in class org.infinispan.transaction.tm.DummyXid
-
Deprecated.
- equals(Object) - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
- equals(Object) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- equals(Object) - Method in class org.infinispan.transaction.xa.GlobalTransaction
- equals(Object) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- equals(Object) - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
- equals(Object) - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
-
Deprecated.
- 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.statetransfer.XSiteStateTransferCollector
- equals(Object, Object) - Method in class org.infinispan.commons.equivalence.AnyServerEquivalence
-
Deprecated.
- equals(SimpleUserPrincipal) - Method in class org.infinispan.server.core.security.simple.SimpleUserPrincipal
- equals(T, Object) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- equals(T, Object) - Method in interface org.infinispan.commons.equivalence.Equivalence
-
Deprecated.Indicates whether the objects passed are "equal to" each other.
- equals(T, Object) - Method in class org.infinispan.commons.equivalence.IdentityEquivalence
-
Deprecated.
- 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) - Method in class org.infinispan.container.offheap.OffHeapEntryFactoryImpl
-
Assumes the address points to the entry excluding the pointer reference at the beginning
- equalsWrappedBytes(WrappedBytes) - Method in class org.infinispan.commons.marshall.WrappedByteArray
- equalsWrappedBytes(WrappedBytes) - Method in interface org.infinispan.commons.marshall.WrappedBytes
- Equivalence<T> - Interface in org.infinispan.commons.equivalence
-
Deprecated.
- EQUIVALENCE - Static variable in interface org.infinispan.commons.marshall.Ids
- EquivalenceExternalizer - Class in org.infinispan.commons.marshall.exts
- EquivalenceExternalizer() - Constructor for class org.infinispan.commons.marshall.exts.EquivalenceExternalizer
- EquivalentHashMap<K,V> - Class in org.infinispan.commons.equivalence
-
Deprecated.
- EquivalentHashMap(int, float, Equivalence<? super K>, Equivalence<? super V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- EquivalentHashMap(int, Equivalence<? super K>, Equivalence<? super V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- EquivalentHashMap(Map<? extends K, ? extends V>, Equivalence<? super K>, Equivalence<? super V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- EquivalentHashMap(Equivalence<? super K>, Equivalence<? super V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- EquivalentHashMap.EntrySet - Class in org.infinispan.commons.equivalence
-
Deprecated.
- EquivalentHashMap.Node<K,V> - Class in org.infinispan.commons.equivalence
-
Deprecated.
- EquivalentHashMap.Values - Class in org.infinispan.commons.equivalence
-
Deprecated.
- EquivalentHashSet<E> - Class in org.infinispan.commons.equivalence
-
Deprecated.
- EquivalentHashSet(int, Equivalence<? super E>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Constructs a new, empty set, with a given initial capacity and a particular equivalence function to compare entries.
- EquivalentHashSet(Equivalence<? super E>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Constructs a new, empty set, with a given equivalence function
- EquivalentLinkedHashMap<K,V> - Class in org.infinispan.commons.equivalence
-
Deprecated.
- EquivalentLinkedHashMap(int, float, EquivalentLinkedHashMap.IterationOrder, Equivalence<? super K>, Equivalence<? super V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
-
Deprecated.
- EquivalentLinkedHashMap.IterationOrder - Enum in org.infinispan.commons.equivalence
-
Deprecated.
- ERROR - org.infinispan.security.AuditResponse
- ERROR - org.infinispan.server.hotrod.HotRodOperation
- ERROR - 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
- errorOccurred(ErrorContext) - Method in class org.infinispan.query.affinity.AffinityErrorHandler
- errorResponse(HotRodHeader, HotRodServer, ByteBufAllocator, String, OperationStatus) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- errorResponse(HotRodHeader, HotRodServer, ByteBufAllocator, String, OperationStatus) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- ERRORS_KEY_SUFFIX - Static variable in interface org.infinispan.query.remote.client.ProtobufMetadataManagerConstants
-
All error status keys end with this suffix.
- errorStatus(Throwable) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- errorStatus(Throwable) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- 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 class org.infinispan.rest.InfinispanCacheResponse
-
Adds ETAG.
- 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, 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.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, 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, 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, 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(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(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>, 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>, 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>, 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.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>, 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
- 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.Type - Enum in org.infinispan.notifications.cachelistener.event
- Event.Type - Enum in org.infinispan.notifications.cachemanagerlistener.event
- eventSource - Variable in class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- 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.
- EventWrapper(K, E) - Constructor for class org.infinispan.notifications.cachelistener.EventWrapper
- evict(int, WrappedBytes) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- evict(Object) - Method in class org.infinispan.spring.provider.SpringCache
- evict(K) - Method in interface org.infinispan.Cache
-
Evicts an entry from the memory of the cache.
- evict(K) - Method in interface org.infinispan.container.DataContainer
-
Atomically, it removes the key from
DataContainer
and passivates it to persistence. - evict(WrappedBytes) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- EVICTED - org.infinispan.container.entries.ReadCommittedEntry.Flags
- eviction() - Method in class org.infinispan.configuration.cache.Configuration
-
Deprecated.please use
Configuration.memory()
- eviction() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
-
Deprecated.Since 9.0, Use
ConfigurationBuilder.memory()
instead - eviction() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
-
Deprecated.Use
ConfigurationBuilder.memory()
instead - EVICTION - org.infinispan.configuration.parsing.Attribute
- EVICTION - org.infinispan.configuration.parsing.Element
- EVICTION_EXECUTOR - org.infinispan.configuration.parsing.Attribute
-
Deprecated.
- EVICTION_MAX_SIZE - Static variable in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.
- EVICTION_STRATEGY - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
- EVICTION_TYPE - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
- EvictionConfiguration - Class in org.infinispan.configuration.cache
-
Deprecated.Use
MemoryConfiguration
instead - EvictionConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Deprecated.Use
MemoryConfiguration
instead - EvictionListener<K,V> - Interface in org.infinispan.commons.util
-
Eviction listener that is notified when entries are evicted from the underlying container due to the given eviction policy.
- 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.
- evictionScheduledExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated.This method always returns null now. Look for a thread pool named as
GlobalConfiguration.expirationThreadPool()
instead. - evictionSize() - Method in interface org.infinispan.container.DataContainer
-
Returns how large the eviction size is currently.
- evictionSize() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- evictionStrategy() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
-
The configured eviction strategy
- evictionStrategy() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
The configured eviction strategy, please see
MemoryConfigurationBuilder.evictionStrategy(EvictionStrategy)
. - evictionStrategy(EvictionStrategy) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
Sets the eviction strategy which can be: NONE - no eviction will take place MANUAL - no eviction will take place automatically, but user is assumed to manually call evict REMOVE - eviction will remove entries to make room for new entries to be inserted EXCEPTION - eviction will not take place, but instead an exception will be thrown to ensure container doesn't grow too large The eviction strategy NONE and MANUAL are essentially the same except that MANUAL does not warn the user when passivation is enabled.
- EvictionStrategy - Enum in org.infinispan.eviction
-
Supported eviction strategies
- EvictionThreadPolicy - Enum in org.infinispan.eviction
-
Supported eviction thread policy
- evictionThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated.Use
GlobalConfiguration.expirationThreadPool
instead - evictionThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
-
Deprecated.
- evictionThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Deprecated.
- evictionType() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
-
The configured eviction type
- evictionType() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
The configured eviction type, please see
MemoryConfigurationBuilder.evictionType(EvictionType)
. - evictionType(EvictionType) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
Sets the eviction type which can either be COUNT - entries will be evicted when the number of entries exceeds the
MemoryConfigurationBuilder.size(long)
MEMORY - entries will be evicted when the approximate combined size of all values exceeds theMemoryConfigurationBuilder.size(long)
Cache size is guaranteed not to exceed upper limit specified by size. - EvictionType - Enum in org.infinispan.eviction
-
Supported eviction type
- EXCEPTION - org.infinispan.eviction.EvictionStrategy
-
Strategy where the cache will block new entries from being written if they would exceed the configured size
- EXCEPTION - org.infinispan.persistence.remote.configuration.ExhaustedAction
- EXCEPTION_RESPONSE - Static variable in interface org.infinispan.commons.marshall.Ids
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.infinispan.rest.Http20RequestHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.infinispan.server.memcached.MemcachedDecoder
- 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
- EXCLUSIVE - org.infinispan.registry.InternalCacheRegistry.Flag
-
means that the cache must be declared only once
- exec(HotRodHeader, Subject, String, Map<String, byte[]>) - Method in class org.infinispan.server.hotrod.TaskRequestProcessor
- EXEC - org.infinispan.security.AuthorizationPermission
-
Allows performing task execution (e.g.
- EXEC - org.infinispan.server.hotrod.HotRodOperation
- EXEC_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- execute() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
- execute() - Method in class org.infinispan.rest.InfinispanRequest
- execute() - Method in class org.infinispan.rest.search.InfinispanSearchRequest
- execute(Runnable) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- execute(Runnable) - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
- execute(ExecutorService) - Method in class org.infinispan.statetransfer.OutboundTransferTask
- execute(EmbeddedCacheManager, Map<String, String>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.AdminServerTask
- execute(EmbeddedCacheManager, Map<String, String>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
- execute(EmbeddedCacheManager, Map<String, String>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheGetOrCreateTask
- execute(EmbeddedCacheManager, Map<String, String>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheNamesTask
- execute(EmbeddedCacheManager, Map<String, String>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheReindexTask
- execute(EmbeddedCacheManager, Map<String, String>, EnumSet<CacheContainerAdmin.AdminFlag>) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheRemoveTask
- execute(RpcManager, long, TimeUnit) - Method in class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand
-
Invokes remotely the command using the
Transport
passed as parameter. - 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. - executeOnCoordinatorRetry(ReplicableCommand, int) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- executeTask(KeyFilter<? super K>, BiConsumer<? super K, InternalCacheEntry<K, V>>) - Method in interface org.infinispan.container.DataContainer
-
Deprecated.since 9.3 Please use the
DataContainer.iterator()
method and apply filtering manually - executeTask(KeyValueFilter<? super K, ? super V>, BiConsumer<? super K, InternalCacheEntry<K, V>>) - Method in interface org.infinispan.container.DataContainer
-
Deprecated.since 9.3 Please use the
DataContainer.iterator()
method and apply filtering manually - EXECUTION_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
- executionCandidates() - Method in interface org.infinispan.distexec.FailoverContext
-
Returns a list of candidates for possible repeated execution governed by installed
DistributedTaskFailoverPolicy
- executionCandidates(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- executionFailureLocation() - Method in interface org.infinispan.distexec.FailoverContext
-
Returns an Address of the node where the task failed
- executionPolicy(DistributedTaskExecutionPolicy) - Method in interface org.infinispan.distexec.DistributedTaskBuilder
-
Provide
DistributedTaskExecutionPolicy
for the task being built - executor - Variable in class org.infinispan.distexec.DistributedExecutionCompletionService
- executor - Variable in class org.infinispan.executors.ManageableExecutorService
- executor - Variable in class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.Executor service used to submit tasks to push in-memory state.
- executor - Variable in class org.infinispan.server.hotrod.BaseRequestProcessor
- executor() - Method in class org.infinispan.manager.DefaultCacheManager
- executor() - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Providess the cache manager based executor.
- EXECUTOR - 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 - Interface in org.infinispan.commons.executors
-
Used to configure and create executors
- ExecutorFactoryConfiguration - Class in org.infinispan.configuration.global
- ExecutorFactoryConfiguration - Class in org.infinispan.persistence.remote.configuration
- ExecutorFactoryConfigurationBuilder - Class in org.infinispan.configuration.global
-
Configures executor factory.
- ExecutorFactoryConfigurationBuilder - Class in org.infinispan.persistence.remote.configuration
-
Configures executor factory.
- executorService - Variable in class org.infinispan.statetransfer.StateProviderImpl
- EXHAUSTED_ACTION - org.infinispan.persistence.remote.configuration.Attribute
- exhaustedAction() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- 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.persistence.remote.configuration
- exists() - Method in class org.infinispan.io.GridFile
- EXISTS - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- ExpandableMarshalledValueByteStream - Class in org.infinispan.io
-
A byte stream that can be written to and expanded on the fly, not dissimilar to
ExposedByteArrayOutputStream
but with the benefit of not having to allocate unnecessary byte arrays by not extendingByteArrayOutputStream
. - ExpandableMarshalledValueByteStream() - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
- ExpandableMarshalledValueByteStream(int) - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
- ExpandableMarshalledValueByteStream(int, int) - Constructor for class org.infinispan.io.ExpandableMarshalledValueByteStream
-
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 interface org.infinispan.server.hotrod.tx.table.CacheNameCollector
-
Sets the expected number of caches involved in the transaction.
- Experimental - Annotation Type in org.infinispan.commons.util
-
An experimental user-facing API.
- 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 - org.infinispan.configuration.parsing.Element
- EXPIRATION - org.infinispan.persistence.leveldb.configuration.Element
- EXPIRATION_DEFAULT - Static variable in class org.infinispan.server.core.ServerConstants
- EXPIRATION_EXECUTOR - 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
- 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.interceptors.distribution.BaseDistributionInterceptor
- 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
- 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
- EXPIRED - org.infinispan.container.entries.ReadCommittedEntry.Flags
- EXPIRED_LOCATION - org.infinispan.persistence.leveldb.configuration.Attribute
- expiredLocation(String) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- expires(Date) - Method in class org.infinispan.rest.InfinispanCacheResponse
-
Adds
expires
header. - EXPIRY_QUEUE_SIZE - org.infinispan.persistence.leveldb.configuration.Attribute
- 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(int) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- expiryTime() - Method in class org.infinispan.container.entries.RemoteMetadata
- expiryTime() - Method in interface org.infinispan.metadata.InternalMetadata
- explain(int) - Method in interface org.infinispan.query.CacheQuery
-
Return the Lucene
Explanation
object describing the score computation for the matching object/document in the current query - ExposedByteArrayOutputStream - Class in org.infinispan.commons.io
-
Extends ByteArrayOutputStream, but exposes the internal buffer.
- ExposedByteArrayOutputStream - Class in org.infinispan.io
-
Deprecated.
- ExposedByteArrayOutputStream() - Constructor for class org.infinispan.commons.io.ExposedByteArrayOutputStream
- ExposedByteArrayOutputStream() - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
-
Deprecated.
- ExposedByteArrayOutputStream(int) - Constructor for class org.infinispan.commons.io.ExposedByteArrayOutputStream
- ExposedByteArrayOutputStream(int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
-
Deprecated.
- ExposedByteArrayOutputStream(int, int) - Constructor for class org.infinispan.commons.io.ExposedByteArrayOutputStream
-
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
- ExposedByteArrayOutputStream(int, int) - Constructor for class org.infinispan.io.ExposedByteArrayOutputStream
-
Deprecated.Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
- Expression - Interface in org.infinispan.query.dsl
- 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.commons.marshall.jboss
-
RiverMarshaller
extension that allows Infinispan code to directly create instances of it. - ExtendedRiverMarshaller(RiverMarshallerFactory, SerializableClassRegistry, MarshallingConfiguration) - Constructor for class org.infinispan.commons.marshall.jboss.ExtendedRiverMarshaller
- ExtendedRiverUnmarshaller - Class in org.infinispan.commons.marshall.jboss
-
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.commons.marshall.jboss.ExtendedRiverUnmarshaller
- ExtendedStatistic - Enum in org.infinispan.stats.container
-
The available extended statistics
- ExtendedStatisticInterceptor - Class in org.infinispan.stats.wrappers
-
Take the statistics about relevant visitable commands.
- ExtendedStatisticInterceptor() - Constructor for class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- ExtendedStatisticLockManager - Class in org.infinispan.stats.wrappers
-
Takes statistic about lock acquisition.
- ExtendedStatisticLockManager(LockManager, CacheStatisticManager, TimeService) - Constructor for class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- ExtendedStatisticNotFoundException - Exception in org.infinispan.stats
- ExtendedStatisticNotFoundException(String) - Constructor for exception org.infinispan.stats.ExtendedStatisticNotFoundException
- ExtendedStatisticRpcManager - Class in org.infinispan.stats.wrappers
-
Takes statistics about the RPC invocations.
- ExtendedStatisticRpcManager(RpcManager, CacheStatisticManager, TimeService, StreamingMarshaller) - Constructor for class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- ExtendedStatisticsContainer - Interface in org.infinispan.stats.container
-
Contains the statistic's values and allows to perform modifications on them.
- ExtendedStatisticsMetadataFileFinder - Class in org.infinispan.stats
- ExtendedStatisticsMetadataFileFinder() - Constructor for class org.infinispan.stats.ExtendedStatisticsMetadataFileFinder
- Externalizer<T> - Interface in org.infinispan.commons.marshall
-
One of the key aspects of Infinispan is that it often needs to marshall or unmarshall objects in order to provide some of its functionality.
- 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.compat.BiFunctionMapper.Externalizer
- Externalizer() - Constructor for class org.infinispan.compat.FunctionMapper.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.encoding.DataConversion.Externalizer
- Externalizer() - Constructor for class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
- Externalizer() - Constructor for class org.infinispan.filter.CollectionKeyFilter.Externalizer
- Externalizer() - Constructor for class org.infinispan.filter.CompositeKeyFilter.Externalizer
- Externalizer() - Constructor for class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
- Externalizer() - Constructor for class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
- Externalizer() - Constructor for class org.infinispan.filter.KeyValueFilterAsKeyFilter.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.interceptors.distribution.VersionedResult.Externalizer
- Externalizer() - Constructor for class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
- Externalizer() - Constructor for class org.infinispan.lucene.ChunkCacheKey.Externalizer
- Externalizer() - Constructor for class org.infinispan.lucene.FileCacheKey.Externalizer
- Externalizer() - Constructor for class org.infinispan.lucene.FileListCacheKey.Externalizer
- Externalizer() - Constructor for class org.infinispan.lucene.FileMetadata.Externalizer
- Externalizer() - Constructor for class org.infinispan.lucene.FileReadLockKey.Externalizer
- Externalizer() - Constructor for class org.infinispan.metadata.EmbeddedMetadata.Externalizer
- Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
- Externalizer() - Constructor for class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.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.cluster.MultiClusterEventCallable.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.KeyFilterAsCacheEventFilter.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.MigrationTask.Externalizer
- Externalizer() - Constructor for class org.infinispan.persistence.remote.upgrade.RemovedFilter.Externalizer
- Externalizer() - Constructor for class org.infinispan.query.clustered.NodeTopDocs.Externalizer
- Externalizer() - Constructor for class org.infinispan.query.clustered.QueryResponse.Externalizer
- Externalizer() - Constructor for class org.infinispan.remoting.MIMECacheEntry.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.rest.operations.mime.MimeMetadata.Externalizer
- Externalizer() - Constructor for class org.infinispan.server.core.security.InetAddressPrincipal.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.server.core.security.simple.SimpleUserPrincipal.Externalizer
- Externalizer() - Constructor for class org.infinispan.statetransfer.StateChunk.Externalizer
- Externalizer() - Constructor for class org.infinispan.statetransfer.TransactionInfo.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.DldGlobalTransaction.Externalizer
-
Deprecated.
- Externalizer() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
- Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
- Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
-
Deprecated.
- Externalizer() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
- Externalizer() - Constructor for class org.infinispan.util.KeyValuePair.Externalizer
- Externalizer(StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
- EXTERNALIZER - Static variable in class org.infinispan.commons.tx.XidImpl
- EXTERNALIZER - Static variable in class org.infinispan.counter.api.CounterConfiguration
- EXTERNALIZER - Static variable in enum org.infinispan.counter.api.CounterState
- 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
- ExternalizerIds - Class in org.infinispan.server.core
-
Externalizer ids used by Server module
AdvancedExternalizer
implementations. - ExternalizerIds - Interface in org.infinispan.lucene
-
Identifiers used by the Marshaller to delegate to specialized Externalizers.
- ExternalizerIds - Interface in org.infinispan.persistence.remote
-
1800 to 1899 range is reserved for this module
- Externalizers - Class in org.infinispan.query.remote.client
-
JBMAR externalizers for QueryRequest/Response objects.
- Externalizers.NamedParameterExternalizer - Class in org.infinispan.query.remote.client
- Externalizers.QueryRequestExternalizer - Class in org.infinispan.query.remote.client
- Externalizers.QueryResponseExternalizer - Class in org.infinispan.query.remote.client
- ExternallyMarshallable - Class in org.infinispan.marshall.core
-
As much as possible, Infinispan consumers should provide
Externalizer
orAdvancedExternalizer
instances for the types being marshalled, so that these types can be marshalled as efficiently as possible. - ExternalPojo - Interface in org.infinispan.marshall.core
-
Marker interface for those pojos that are allowed to be marshalled externally.
- ExternalSaslServerFactory - Class in org.infinispan.server.core.security.external
- ExternalSaslServerFactory(Principal) - Constructor for class org.infinispan.server.core.security.external.ExternalSaslServerFactory
- ExternalStore<K,V> - Interface in org.infinispan.persistence.spi
-
Basic interface for interacting with an external store in a read-write mode.
- extractCreated(CacheEntry) - Static method in class org.infinispan.server.hotrod.MetadataUtils
- extractDependencyType(Type, Type, boolean) - Method in class org.infinispan.factories.components.ComponentMetadata
- extractException(Throwable) - Static method in class org.infinispan.util.concurrent.CompletableFutures
- extractFieldName(String) - Static method in class org.infinispan.commons.util.ReflectionUtil
- extractIndexable(Object) - Method in class org.infinispan.encoding.DataConversion
- 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
- extractResults(SerializationContext) - Method in interface org.infinispan.query.remote.client.BaseQueryResponse
- extractResults(SerializationContext) - Method in class org.infinispan.query.remote.client.JsonClientQueryResponse
- extractResults(SerializationContext) - Method in class org.infinispan.query.remote.client.QueryResponse
- extractVersion(CacheEntry) - Static method in class org.infinispan.server.hotrod.MetadataUtils
F
- factory - Static variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- factory - Variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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.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 - org.infinispan.persistence.remote.configuration.Attribute
- fail() - Method in interface org.infinispan.scattered.BiasManager.Revocation
- FAIL - org.infinispan.configuration.cache.BackupFailurePolicy
- FAIL_SILENTLY - org.infinispan.configuration.parsing.Attribute
- FAIL_SILENTLY - 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
- failAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
- FAILED - org.infinispan.lifecycle.ComponentStatus
-
The component is in a failed state due to a problem with one of the other lifecycle transition phases.
- failover(FailoverContext) - Method in interface org.infinispan.distexec.DistributedTaskFailoverPolicy
-
As parts of distributively executed task can fail due to the task itself throwing an exception or it can be an Infinispan system caused failure (e.g node failed or left cluster during task execution etc).
- FailoverContext - Interface in org.infinispan.distexec
-
As
DistributedTask
might potentially fail on subset of executing nodes FailureContext provides details of such task failure. - failoverPolicy(DistributedTaskFailoverPolicy) - Method in interface org.infinispan.distexec.DistributedTaskBuilder
-
Provide
DistributedTaskFailoverPolicy
for the task being built - failSilently() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
- failSilently(boolean) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
- FAILURE_POLICY - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
- FAILURE_POLICY_CLASS - org.infinispan.configuration.parsing.Attribute
- FAILURE_POLICY_CLASS - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
- failureCompletingTransaction(Transaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- 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
- 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
- fclose(OutputStream) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to flush and close an OutputStream.
- fclose(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to flush and close an array of OutputStreams.
- FEATURE_PREFIX - Static variable in class org.infinispan.commons.util.Features
- 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 - org.infinispan.query.dsl.IndexedQueryMode
-
Query is executed locally in the caller.
- FETCH_IN_MEMORY_STATE - Static variable in class org.infinispan.configuration.cache.StateTransferConfiguration
- FETCH_PERSISTENT_STATE - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- FETCH_SIZE - org.infinispan.persistence.jdbc.configuration.Attribute
- FETCH_SIZE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- FETCH_STATE - org.infinispan.configuration.parsing.Attribute
- FETCH_TX_RECOVERY - org.infinispan.server.hotrod.HotRodOperation
- FETCH_TX_RECOVERY - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- 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. - fetchMode(FetchOptions.FetchMode) - Method in class org.infinispan.query.FetchOptions
-
Set the fetch mode to be used to fetch matching results
- FetchOptions - Class in org.infinispan.query
- FetchOptions() - Constructor for class org.infinispan.query.FetchOptions
- FetchOptions.FetchMode - Enum in org.infinispan.query
-
Specifies the fetching strategy for query results.
- fetchPersistentState - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Deprecated.
- fetchPersistentState() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
-
If true, fetch persistent state when joining a cluster.
- fetchPersistentState() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
-
Loops through all individual cache loader configs and checks if fetchPersistentState is set on any of them
- 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
-
If true, fetch persistent state when joining a cluster.
- fetchPersistentState(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- fetchPersistentState(boolean) - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
If true, fetch persistent state when joining a cluster.
- fetchRebalancingStatusFromCoordinator() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- fetchRequiredKeys(LocalizedCacheTopology, Map<Address, List<Object>>, List<Object>, InvocationContext, C) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
- fetchRequiredKeys(LocalizedCacheTopology, Map<Address, List<Object>>, List<Object>, InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
- 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)
. - fetchSize(int) - Method in class org.infinispan.query.FetchOptions
-
Set the fetch size for batch loading of matches
- FIFO - org.infinispan.eviction.EvictionStrategy
-
Deprecated.
- FILE - Static variable in class org.infinispan.io.GridFile.Metadata
- FILE_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
- FILE_LIST_CACHE_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
- FILE_LIST_CACHE_VALUE - Static variable in interface org.infinispan.lucene.ExternalizerIds
- FILE_LIST_DELTA_ADD - Static variable in interface org.infinispan.lucene.ExternalizerIds
- FILE_LIST_DELTA_DEL - Static variable in interface org.infinispan.lucene.ExternalizerIds
- FILE_LIST_VALUE_DELTA - Static variable in interface org.infinispan.lucene.ExternalizerIds
- FILE_METADATA - Static variable in interface org.infinispan.lucene.ExternalizerIds
- FILE_READLOCK_KEY - Static variable in interface org.infinispan.lucene.ExternalizerIds
- FILE_STORE - org.infinispan.configuration.parsing.Element
- FileCacheKey - Class in org.infinispan.lucene
-
Used as a key for file headers in a cache
- FileCacheKey(String, String, int) - Constructor for class org.infinispan.lucene.FileCacheKey
- FileCacheKey.Externalizer - Class in org.infinispan.lucene
- FileListCacheKey - Class in org.infinispan.lucene
-
Cache key for a list with current files in cache
- FileListCacheKey(String, int) - Constructor for class org.infinispan.lucene.FileListCacheKey
- FileListCacheKey.Externalizer - Class in org.infinispan.lucene
- 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
- FileMetadata - Class in org.infinispan.lucene
-
Header for Lucene files.
- FileMetadata(int) - Constructor for class org.infinispan.lucene.FileMetadata
- FileMetadata.Externalizer - Class in org.infinispan.lucene
- filename(String) - Static method in class org.infinispan.io.GridFile
- FILENAME - org.infinispan.persistence.remote.configuration.Attribute
- FileReadLockKey - Class in org.infinispan.lucene
-
Lucene's index segment files are chunked, for safe deletion of elements a read lock is implemented so that all chunks are deleted only after the usage counter is decremented to zero.
- FileReadLockKey(String, String, int) - Constructor for class org.infinispan.lucene.FileReadLockKey
- FileReadLockKey.Externalizer - Class in org.infinispan.lucene
- 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 instance matches the filter.
- filter(DoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
- filter(IntPredicate) - Method in interface org.infinispan.IntCacheStream
- filter(LongPredicate) - Method in interface org.infinispan.LongCacheStream
- 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 R>) - Method in interface org.infinispan.CacheStream
- 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(Filter) - Method in interface org.infinispan.query.CacheQuery
-
Allows lucene to filter the results.
- filter(SerializableDoublePredicate) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.filter(DoublePredicate)
except that the DoublePredicate must also implementSerializable
- filter(SerializableIntPredicate) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.filter(IntPredicate)
except that the IntPredicate must also implementSerializable
- filter(SerializableLongPredicate) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.filter(LongPredicate)
except that the LongPredicate must also implement Serializable. - 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
- 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.
- FilterConditionBeginContext - Interface in org.infinispan.query.dsl
-
The beginning context of an incomplete condition.
- FilterConditionContext - Interface in org.infinispan.query.dsl
-
The context of a complete filter.
- FilterConditionContextQueryBuilder - Interface in org.infinispan.query.dsl
- FilterConditionEndContext - Interface in org.infinispan.query.dsl
-
The context that ends a condition.
- filterEntries(Map<K, V>, Collection<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- 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.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.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.util.AbstractDelegatingCacheStream
- filterPrivateCaches(Set<String>) - Method in interface org.infinispan.registry.InternalCacheRegistry
-
Removes the private caches from the specified set of cache names
- FilterResult - Class in org.infinispan.query.remote.client
- FilterResult(Object, Object[], Comparable[]) - Constructor for class org.infinispan.query.remote.client.FilterResult
- 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.
- find() - Method in interface org.infinispan.functional.EntryView.ReadEntryView
-
Optional value.
- 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.util.AbstractDelegatingCacheStream
- findAnyLockedOrBackupLocked(Collection<Object>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.
- findByIndexNameAndIndexValue(String, String) - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- findClass(String) - Method in class org.infinispan.commons.util.AggregatedClassLoader
- findClass(String) - Method in class org.infinispan.commons.util.OsgiClassLoader
-
Load the class and break on first found match.
- findComponentMetadata(Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
-
Deprecated.Since 9.4, please use
ComponentMetadataRepo.findComponentMetadata(String)
instead. - findComponentMetadata(String) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
-
Deprecated.Since 9.4, please use
ComponentMetadataRepo.findComponentMetadata(String)
instead. - findCreatedEntries() - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
-
This method is to be called just before marking the transfer as complete and after all keys have been manually processed.
- findExternalizerFor(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- findFactoryForComponent(Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
-
Locates the fully qualified class name of a factory capable of constructing an instance of
- findFactoryForComponent(String) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
-
Locates the fully qualified class name of a factory capable of constructing an instance of
- findFirst() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- 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
- 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
- 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.
- findResource(String) - Method in class org.infinispan.commons.util.AggregatedClassLoader
- findResource(String) - Method in class org.infinispan.commons.util.OsgiClassLoader
-
Load the resource and break on first found match.
- findResources(String) - Method in class org.infinispan.commons.util.OsgiClassLoader
-
Load the resources and return an Enumeration Note: Since they're Enumerations, do not cache these results!
- findSetterForField(Class<?>, String) - Static method in class org.infinispan.commons.util.ReflectionUtil
- FineGrainedAtomicMap<K,V> - Interface in org.infinispan.atomic
-
FineGrainedAtomicMap is a special type of Map geared for use in Infinispan.
- finish() - Method in class org.infinispan.commons.marshall.jboss.ExtendedRiverMarshaller
- finish() - Method in class org.infinispan.commons.marshall.jboss.ExtendedRiverUnmarshaller
- finish() - Method in interface org.infinispan.interceptors.distribution.BiasedCollector
- finish() - Method in class org.infinispan.interceptors.distribution.RemoteGetSingleKeyCollector
- 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_RECEIVE - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
- FINISH_SEND - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
- finisher() - Method in class org.infinispan.commons.util.ArrayCollector
- finishObjectInput(ObjectInput) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- finishObjectInput(ObjectInput) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- finishObjectInput(ObjectInput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Finish using the given ObjectInput.
- finishObjectInput(ObjectInput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- finishObjectOutput(ObjectOutput) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- finishObjectOutput(ObjectOutput) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- finishObjectOutput(ObjectOutput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Finish using the given ObjectOutput.
- finishObjectOutput(ObjectOutput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- FIREBIRD - org.infinispan.persistence.jdbc.DatabaseType
- fireParsingComplete() - Method in class org.infinispan.configuration.parsing.AbstractParserContext
- fireParsingComplete() - Method in interface org.infinispan.configuration.parsing.ParserContext
- first() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- FIRST - 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.DummyTransaction
-
Deprecated.
- firstEnlistedResource() - Method in class org.infinispan.transaction.tm.DummyTransactionManager
-
Deprecated.
- 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.CacheQuery
-
Sets a result with a given index to the first result.
- firstResult(int) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
- fixedArray(ByteBuf, int) - Static method in class org.infinispan.server.hotrod.Intrinsics
- 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
- FlagAffectedStore<K,V> - Interface in org.infinispan.persistence.spi
-
Implemented by stores that can skip writes based on certain flags present in the invocation.
- flags - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- flags - Variable in class org.infinispan.server.memcached.MemcachedMetadata
- FLAGS - org.infinispan.server.core.admin.AdminOperationParameter
- flatMap(DoubleFunction<? extends DoubleStream>) - Method in interface org.infinispan.DoubleCacheStream
- 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.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(LongFunction<? extends LongStream>) - Method in interface org.infinispan.LongCacheStream
- flatMap(SerializableDoubleFunction<? extends DoubleStream>) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.flatMap(DoubleFunction)
except that the DoubleFunction must also implementSerializable
- 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(SerializableLongFunction<? extends LongStream>) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.flatMap(LongFunction)
except that the LongFunction must also implement Serializable. - flatMapToDouble(Function<? super R, ? extends DoubleStream>) - Method in interface org.infinispan.CacheStream
- 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.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.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 - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- FlowableFromIntSetFunction<T> - Class in org.infinispan.util.rxjava
-
Flowable implementation that will produce entries by providing every int in the given set to the provided IntFunction.
- FlowableFromIntSetFunction(IntSet, IntFunction<T>) - Constructor for class org.infinispan.util.rxjava.FlowableFromIntSetFunction
- 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.marshall.DelegatingObjectOutput
- flush() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- flush() - Method in class org.infinispan.io.GridOutputStream
- flush() - Method in class org.infinispan.io.UnclosableObjectOutputStream
- flush() - Method in class org.infinispan.io.WritableGridFileChannel
- flush(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.SaslQopHandler
- flush(OutputStream) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to flush an OutputStream.
- flush(OutputStream[]) - Static method in class org.infinispan.util.stream.Streams
-
Attempt to flush an array of OutputStreams.
- FLUSH_LOCK_TIMEOUT - org.infinispan.configuration.parsing.Attribute
-
Deprecated.
- FlushAllRequest - org.infinispan.server.memcached.MemcachedOperation
- flushAndClose(IndexingBackend) - Method in class org.infinispan.query.indexmanager.LazyInitializingBackend
- flushAndClose(IndexingBackend) - Method in class org.infinispan.query.indexmanager.LockAcquiringBackend
- flushAndCloseOutput(ObjectOutput) - Static method in class org.infinispan.commons.util.Util
- flushAndCloseStream(OutputStream) - Static method in class org.infinispan.commons.util.Util
- flushAndReleaseResources() - Method in class org.infinispan.query.affinity.AffinityIndexManager
- flushBase64() - Method in class org.infinispan.commons.util.Base64.OutputStream
-
Deprecated.Method added by PHIL.
- 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
- flushing() - Method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- flushLockTimeout() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
-
Deprecated.
- flushLockTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
-
Deprecated.
- flushLockTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
-
Deprecated.
- flushLockTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
-
Deprecated.
- flushTo(ConcurrentGlobalContainer) - Method in class org.infinispan.stats.TransactionStatistics
-
Merges this statistics in the global container.
- forCacheMode(CacheMode) - Static method in enum org.infinispan.configuration.parsing.Parser.Mode
- FORCE_ASYNCHRONOUS - org.infinispan.context.Flag
-
Forces asynchronous network calls where possible, even if otherwise configured to use synchronous network calls.
- FORCE_RETURN_VALUES - org.infinispan.persistence.remote.configuration.Attribute
- FORCE_ROLLBACK_MESSAGE - Static variable in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.
- FORCE_SYNCHRONOUS - org.infinispan.context.Flag
-
Forces synchronous network calls where possible, even if otherwise configured to use asynchronous network calls.
- FORCE_WRITE_LOCK - org.infinispan.context.Flag
-
Forces a write lock, even if the invocation is a read operation.
- 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
- forceC3P0() - Static method in class org.infinispan.persistence.jdbc.connectionfactory.C3P0ConnectionPool
-
Deprecated.
- forceCommit(int, byte[], byte[]) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
- forceCommit(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
- forceOffline() - Method in class org.infinispan.xsite.OfflineStatus
- 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 - org.infinispan.server.hotrod.ProtocolFlag
- forceReturnValues() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- 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(Xid, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
Replays the given transaction by re-running the prepare and commit.
- forceTransactionCompletion(Xid, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- forceTransactionCompletionFromCluster(Xid, Address, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
This method invokes
RecoveryManager.forceTransactionCompletion(javax.transaction.xa.Xid, boolean)
on the specified node. - forceTransactionCompletionFromCluster(Xid, Address, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- forEach(BiConsumer<? super K, ? super V>) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- 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 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.util.AbstractDelegatingCacheStream
- 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 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 R>) - Method in interface org.infinispan.CacheStream
- 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(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(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(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(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(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(SerializableIntConsumer) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntStream.forEach(IntConsumer)
except that the IntConsumer must also implementSerializable
- forEach(SerializableLongConsumer) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongStream.forEach(LongConsumer)
except that the LongConsumer must also implement Serializable. - forEach(SerializableObjDoubleConsumer<Cache<K, V>>) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.forEach(ObjDoubleConsumer)
except that theBiConsumer
must also implementSerializable
- forEach(SerializableObjIntConsumer<Cache<K, V>>) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.forEach(ObjIntConsumer)
except that theBiConsumer
must also implementSerializable
- forEach(SerializableObjLongConsumer<Cache<K, V>>) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.forEach(ObjLongConsumer)
except that theBiConsumer
must also implementSerializable
- forEach(T[], Consumer<T>) - Static method in class org.infinispan.commons.util.InfinispanCollections
- forEachBackupLock(Consumer<Object>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Invokes the
Consumer
with each backup lock. - 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.SingleKeyNonTxInvocationContext
-
Deprecated.
- forEachOrdered(Consumer<? super R>) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- 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
- forEachValue(BiConsumer<Object, CacheEntry>) - Method in interface org.infinispan.context.EntryLookup
-
Execute an action for each value in the context.
- 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 - 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.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
- forMediaType(MediaType) - Static method in class org.infinispan.rest.operations.mediatypes.EntrySetFormatter
- 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.configuration.Attribute
- forName(String) - Static method in enum org.infinispan.persistence.jdbc.configuration.Element
- forName(String) - Static method in enum org.infinispan.persistence.jpa.configuration.Attribute
- forName(String) - Static method in enum org.infinispan.persistence.jpa.configuration.Element
- forName(String) - Static method in enum org.infinispan.persistence.leveldb.configuration.Attribute
- forName(String) - Static method in enum org.infinispan.persistence.leveldb.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.rest.configuration.Attribute
- forName(String) - Static method in enum org.infinispan.persistence.rest.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
- forwardCommandIfNeeded(TopologyAffectedCommand, Set<Object>, Address) - Method in interface org.infinispan.statetransfer.StateTransferManager
-
If there is an state transfer happening at the moment, this method forwards the supplied command to the nodes that are new owners of the data, in order to assure consistency.
- forwardCommandIfNeeded(TopologyAffectedCommand, Set<Object>, Address) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- 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
- FOUR_PHASE - org.infinispan.statetransfer.RebalanceType
-
Used by distributed and replicated caches.
- FRAGMENTATION_FACTOR - 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 interface org.infinispan.util.concurrent.AggregateCompletionStage
-
Marks this composed stage as frozen, allowing it to complete when all stages it depends on complete
- 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(Class<?>) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Creates a QueryBuilder for the given entity type.
- from(String) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Creates a QueryBuilder for the given entity type.
- 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(CacheMode) - Static method in enum org.infinispan.statetransfer.RebalanceType
- from(EmbeddedCacheManager) - Static method in class org.infinispan.lock.EmbeddedClusteredLockManagerFactory
- from(EmbeddedCacheManager) - Static method in class org.infinispan.multimap.api.embedded.EmbeddedMultimapCacheManagerFactory
- fromCacheLoader(MarshalledEntry) - Static method in class org.infinispan.xsite.statetransfer.XSiteState
- fromCode(byte) - Static method in enum org.infinispan.server.hotrod.OperationStatus
- fromConfiguration(EntryMergePolicy) - Static method in enum org.infinispan.conflict.MergePolicy
- fromConfiguration(TransactionMode, boolean, boolean, boolean) - Static method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
- fromDataContainer(InternalCacheEntry) - Static method in class org.infinispan.xsite.statetransfer.XSiteState
- fromEvent(CacheEntryEvent<K, V>) - Static method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- fromJGroupsAddress(Address) - Static method in class org.infinispan.remoting.transport.jgroups.JGroupsAddressCache
- 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
-
Recreates a ConsistentHash from a previously stored persistent state.
- 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 class org.infinispan.commons.dataconversion.BinaryEncoder
- fromStorage(Object) - Method in interface org.infinispan.commons.dataconversion.Encoder
-
Convert from storage format to the read/write format.
- fromStorage(Object) - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
- fromStorage(Object) - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
- fromStorage(Object) - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
- 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, ByteString) - Method in class org.infinispan.marshall.exts.ReplicableCommandExternalizer
- fromString(String) - Static method in enum org.infinispan.commons.api.CacheContainerAdmin.AdminFlag
- fromString(String) - Static method in class org.infinispan.commons.dataconversion.MediaType
- fromString(String) - Static method in enum org.infinispan.conflict.MergePolicy
- fromString(String) - Method in interface org.infinispan.query.Transformer
-
Transforms a String into an Object.
- fromString(String) - Static method in class org.infinispan.topology.PersistentUUID
- fromString(String) - Static method in class org.infinispan.util.ByteString
- FULL_XA - org.infinispan.configuration.cache.TransactionMode
- FULL_XA - org.infinispan.configuration.parsing.Parser.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.
- functionalNotifier - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- functionalNotifier - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- FunctionMapper - Class in org.infinispan.compat
- FunctionMapper(Function, DataConversion, DataConversion) - Constructor for class org.infinispan.compat.FunctionMapper
- FunctionMapper.Externalizer - Class in org.infinispan.compat
G
- GATHER - org.infinispan.functional.Param.StatisticsMode
-
Statistics from this command are recorded
- 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
- generateRandomId() - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- GENERIC_MARSHALLER - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- GenericJBossMarshaller - Class in org.infinispan.commons.marshall.jboss
-
A marshaller that makes use of JBoss Marshalling to serialize and deserialize objects.
- GenericJBossMarshaller() - Constructor for class org.infinispan.commons.marshall.jboss.GenericJBossMarshaller
- GenericJBossMarshaller(ClassLoader) - Constructor for class org.infinispan.commons.marshall.jboss.GenericJBossMarshaller
- GenericJBossMarshaller(ClassLoader, ClassWhiteList) - Constructor for class org.infinispan.commons.marshall.jboss.GenericJBossMarshaller
- GenericJBossMarshaller(List<String>) - Constructor for class org.infinispan.commons.marshall.jboss.GenericJBossMarshaller
-
Deprecated.Use
GenericJBossMarshaller(ClassWhiteList)
instead - GenericJBossMarshaller(ClassWhiteList) - Constructor for class org.infinispan.commons.marshall.jboss.GenericJBossMarshaller
- GenericJbossMarshallerEncoder - Class in org.infinispan.commons.dataconversion
- GenericJbossMarshallerEncoder(GenericJBossMarshaller) - Constructor for class org.infinispan.commons.dataconversion.GenericJbossMarshallerEncoder
- 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
- 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 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 interface org.infinispan.functional.MetaParam
-
Returns the value of the meta parameter.
- get() - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
- get() - Method in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
- 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.distribution.L1WriteSynchronizer
- 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() - Method in class org.infinispan.persistence.util.PersistenceManagerCloseableSupplier
-
Deprecated.
- 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, Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- get(long, TimeUnit) - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
- get(ByteBuf) - Method in class org.infinispan.server.memcached.MemcachedDecoder
- get(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- get(Object) - Method in class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
-
Deprecated.
- 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.concurrent.ConcurrentWeakKeyHashMap
-
Returns the value to which the specified key is mapped, or
null
if this map contains no mapping for the key. - 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.since 10.1 - Please use
DataContainer.peek(Object)
instead. - 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.spring.provider.SpringCache
- get(Object, Class<T>) - Method in class org.infinispan.spring.provider.SpringCache
- get(Object, Callable<T>) - Method in class org.infinispan.spring.provider.SpringCache
- 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, String) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
- get(AtomicLongFieldUpdater<T>) - Method in class org.infinispan.commons.util.concurrent.StripedCounters
- 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(AdvancedCache<K, V>) - Static method in class org.infinispan.conflict.ConflictManagerFactory
- GET - org.infinispan.server.hotrod.HotRodOperation
- GET_ALL - org.infinispan.server.hotrod.HotRodOperation
- GET_ALL_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- GET_CACHE_LISTENERS - org.infinispan.statetransfer.StateRequestCommand.Type
- GET_MULTIMAP - org.infinispan.server.hotrod.HotRodOperation
- GET_MULTIMAP_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- GET_MULTIMAP_WITH_METADATA - 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_RESULT_SIZE - org.infinispan.query.clustered.commandworkers.CQCommandType
- GET_SOME_KEYS - org.infinispan.query.clustered.commandworkers.CQCommandType
- GET_STATUS - org.infinispan.topology.CacheTopologyControlCommand.Type
- GET_STREAM - org.infinispan.server.hotrod.HotRodOperation
- GET_STREAM_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- GET_TRANSACTIONS - org.infinispan.statetransfer.StateRequestCommand.Type
- GET_WITH_METADATA - org.infinispan.server.hotrod.HotRodOperation
- GET_WITH_METADATA - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- GET_WITH_VERSION - org.infinispan.server.hotrod.HotRodOperation
- GET_WITH_VERSION - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- getAbortRate() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAbsoluteFile() - Method in class org.infinispan.io.GridFile
- getAbsolutePath() - Method in class org.infinispan.io.GridFile
- getAcceptContentType() - Method in class org.infinispan.rest.InfinispanRequest
- getActions() - Method in class org.infinispan.security.CachePermission
- getActivationCount() - Method in interface org.infinispan.eviction.ActivationManager
-
Get number of activations executed.
- getActivations() - Method in interface org.infinispan.stats.ClusterCacheStats
- getActiveCount() - Method in class org.infinispan.executors.ManageableExecutorService
- getActual() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- getActualAddressCount(int) - Static method in class org.infinispan.container.offheap.OffHeapDataContainer
- getActualMembers() - Method in class org.infinispan.topology.CacheTopology
- getAddress() - Method in class org.infinispan.container.entries.RemoteMetadata
- getAddress() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- getAddress() - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
- getAddress() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
- 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 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.stats.wrappers.ExtendedStatisticRpcManager
- 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
- getAddressCache() - Method in class org.infinispan.server.hotrod.HotRodServer
- getAdvancedCache() - Method in interface org.infinispan.Cache
- getAffectedKeys() - Method in class org.infinispan.persistence.support.BatchModification
- getAffinitySegmentId() - Method in interface org.infinispan.distribution.ch.AffinityTaggedKey
-
This numeric id is used exclusively for storage affinity in Infinispan.
- getAffinitySegmentId() - Method in class org.infinispan.lucene.ChunkCacheKey
- getAffinitySegmentId() - Method in class org.infinispan.lucene.FileCacheKey
- getAffinitySegmentId() - Method in class org.infinispan.lucene.FileListCacheKey
- getAffinitySegmentId() - Method in class org.infinispan.lucene.FileReadLockKey
- getAffinitySegmentId() - Method in interface org.infinispan.lucene.IndexScopedKey
-
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. - getAllAsync(Set<?>) - Method in interface org.infinispan.commons.api.AsyncCache
- 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. - getAllFields(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
- getAllLoaders() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- 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 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
- getAllowedRole() - Method in interface org.infinispan.tasks.Task
-
An optional role, for which the task is accessible.
- getAllResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Map<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- getAllResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Map<byte[], byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- getAllShardIdentifiers() - Method in class org.infinispan.query.affinity.AffinityShardIdentifierProvider
- getAllSites() - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
- getAllTxWriters() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- getAllVersions(K) - Method in interface org.infinispan.conflict.ConflictManager
-
Get all CacheEntry's that exists for a given key.
- getAllWriters() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- getAlpnConfiguration() - Method in class org.infinispan.rest.Http11To2UpgradeHandler
- getAlpnConfiguration() - Method in class org.infinispan.rest.RestChannelInitializer
- getAlpnConfiguration() - Method in class org.infinispan.server.core.transport.NettyChannelInitializer
- getAnalyzer(Class<?>) - Method in interface org.infinispan.query.SearchManager
-
Retrieves the scoped analyzer for a given class type.
- getAnalyzer(String) - Method in interface org.infinispan.query.SearchManager
-
Retrieve an analyzer instance by its definition name
- 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. - getAndUpdateFilteredKeys(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
- 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.
- 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(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. - getAsyncInterceptorChain() - Method in interface org.infinispan.AdvancedCache
-
Allows the modification of the interceptor chain.
- getAsyncXSiteAcksCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getAsyncXSiteCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getAsyncXSitePendingRequests() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- getAsyncXSiteRequestQueueTime() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- getAsyncXSiteRequestRunningTime() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- getAsyncXSiteRequestsReceived() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- getAsyncXSiteRunningRequests() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- getAtomicMap(Cache<MK, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
-
Retrieves an atomic map from a given cache, stored under a given key.
- getAtomicMap(Cache<MK, ?>, MK, boolean) - Static method in class org.infinispan.atomic.AtomicMapLookup
-
Retrieves an atomic map from a given cache, stored under a given key.
- getAttribute(String) - Method in class org.infinispan.jmx.ResourceDMBean
- getAttribute(ExtendedStatistic) - Method in class org.infinispan.stats.CacheStatisticCollector
- getAttribute(ExtendedStatistic) - Method in class org.infinispan.stats.CacheStatisticManager
- getAttribute(ExtendedStatistic) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAttributeDefinition() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- getAttributeMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
- getAttributes(String[]) - Method in class org.infinispan.jmx.ResourceDMBean
- getAuthorization() - Method in class org.infinispan.rest.InfinispanRequest
- getAuthorizationManager() - Method in interface org.infinispan.AdvancedCache
-
Retrieves the
AuthorizationManager
if the cache has security enabled. - getAuthorizationPermission() - Method in class org.infinispan.security.CachePermission
- getAvailability() - Method in interface org.infinispan.AdvancedCache
-
Returns the cache's availability.
- getAvailabilityMode() - Method in interface org.infinispan.notifications.cachelistener.event.PartitionStatusChangedEvent
-
The mode the current cluster is in.
- getAvailabilityMode() - Method in class org.infinispan.topology.CacheStatusResponse
- getAvailabilityMode() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- getAvailabilityMode() - Method in class org.infinispan.topology.ClusterCacheStatus
- getAvailableExtendedStatistics() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAverage(long) - Method in class org.infinispan.commons.stat.DefaultSimpleStat
- getAverage(long) - Method in interface org.infinispan.commons.stat.SimpleStat
- getAverageAsyncXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getAverageQueueTimeNanos() - Method in class org.infinispan.util.concurrent.ActionSequencer
- getAverageReadTime() - Method in interface org.infinispan.stats.Stats
- getAverageReadTimeNanos() - Method in interface org.infinispan.stats.Stats
- getAverageRemoveTime() - Method in interface org.infinispan.stats.Stats
- 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 interface org.infinispan.stats.Stats
- getAverageWriteTimeNanos() - Method in interface org.infinispan.stats.Stats
- getAverageXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getAvgAbortedWriteTxDuration() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgClusteredGetCommandSize() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgCommitCommandSize() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgCommitRtt() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgCommitTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgCompleteNotificationAsync() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgGetsPerROTransaction() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgGetsPerWrTransaction() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgLocalCommitTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgLocalGetTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgLocalLockHoldTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgLocalPrepareTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgLocalRollbackTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgLockHoldTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgLockWaitingTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgNumNodesCommit() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgNumNodesCompleteNotification() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgNumNodesPrepare() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgNumNodesRemoteGet() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgNumNodesRollback() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgNumOfLockLocalTx() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgNumOfLockRemoteTx() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgNumOfLockSuccessLocalTx() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgPrepareCommandSize() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgPrepareRtt() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgPutsPerWrTransaction() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgReadOnlyTxDuration() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRemoteCommitTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRemoteGetRtt() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRemoteGetsPerROTransaction() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRemoteGetsPerWrTransaction() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRemoteLockHoldTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRemotePrepareTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRemotePutsPerWrTransaction() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRemoteRollbackTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgResponseTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRollbackRtt() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgRollbackTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgTxArrivalRate() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getAvgWriteTxDuration() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getBackupLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.Since 9.3, please use
CacheTransaction.forEachBackupLock(Consumer)
- getBackupReceiver(String, String) - Method in interface org.infinispan.xsite.BackupReceiverRepository
-
Returns the local cache associated defined as backup for the provided remote (site, cache) combo, or throws an exception if no such site is defined.
- getBackupReceiver(String, String) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
-
Returns the local cache defined as backup for the provided remote (site, cache) combo, or throws an exception if no such site is defined.
- getBatchContainer() - Method in interface org.infinispan.AdvancedCache
-
Returns the component in charge of batching cache operations.
- getBatchTransaction() - Method in class org.infinispan.batch.BatchContainer
- getBlockingFuture(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
- 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
- getBranchQualifier() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
-
Deprecated.
- getBranchQualifier() - Method in class org.infinispan.transaction.tm.DummyXid
-
Deprecated.
- getBranchQualifier() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
-
Deprecated.
- getBrandName() - Static method in class org.infinispan.Version
- getBuf() - Method in interface org.infinispan.commons.io.ByteBuffer
-
Returns the underlying buffer.
- getBuf() - Method in class org.infinispan.commons.io.ByteBufferImpl
- getBufferSize() - Method in class org.infinispan.lucene.ChunkCacheKey
-
Get the bufferSize.
- getBufferSize() - Method in class org.infinispan.lucene.FileMetadata
- 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.commons.marshall.AbstractDelegatingMarshaller
- 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
- 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. - 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.
- getCache() - Method in interface org.infinispan.commons.api.BasicCacheContainer
-
Retrieves the default cache associated with this cache container.
- getCache() - Method in interface org.infinispan.manager.CacheContainer
-
This method overrides the underlying
CacheContainer.getCache()
, to return aCache
instead of aBasicCache
- getCache() - Method in class org.infinispan.manager.DefaultCacheManager
-
Retrieves the default cache associated with this cache manager.
- 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.persistence.InitializationContextImpl
- getCache() - Method in interface org.infinispan.persistence.spi.InitializationContext
- getCache() - Method in class org.infinispan.tasks.TaskContext
-
The default cache.
- getCache() - Method in interface org.infinispan.xsite.BackupReceiver
- getCache() - Method in class org.infinispan.xsite.BaseBackupReceiver
- getCache(String) - Method in interface org.infinispan.commons.api.BasicCacheContainer
-
Retrieves a named cache from the system.
- getCache(String) - Method in interface org.infinispan.manager.CacheContainer
-
This method overrides the underlying
CacheContainer.getCache(String)
, to return aCache
instead of aBasicCache
- getCache(String) - Method in class org.infinispan.manager.DefaultCacheManager
-
Retrieves a named cache from the system.
- getCache(String) - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManager
- getCache(String) - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
- getCache(String, boolean) - Method in class org.infinispan.manager.DefaultCacheManager
- getCache(String, boolean) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Retrieves a named cache from the system in the same way that
CacheContainer.getCache(String)
does except that if offers the possibility for the named cache not to be retrieved if it has not yet been started, or if it's been removed after being started. - getCache(String, String) - Method in class org.infinispan.manager.DefaultCacheManager
- getCache(String, String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Deprecated.as of 9.0. Use
EmbeddedCacheManager.defineConfiguration(String, String, Configuration)
andCacheContainer.getCache(String)
instead - getCache(String, String, boolean) - Method in class org.infinispan.manager.DefaultCacheManager
- getCache(String, String, boolean) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Deprecated.
- getCache(String, Subject) - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- getCache(String, MediaType, MediaType, Subject) - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- 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(String) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Retrieves the availability state of a cache.
- getCacheAvailability(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- getCacheAvailability(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- GetCacheAvailabilityAction - Class in org.infinispan.security.actions
-
GetCacheAvailabilityAction.
- GetCacheAvailabilityAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheAvailabilityAction
- 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(String) - Method in class org.infinispan.manager.DefaultCacheManager
- getCacheConfiguration(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Returns the configuration for the given cache.
- 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.DefaultCacheManager
- getCacheConfigurationNames() - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
This method returns a collection of cache configuration names which contains the cache configurations that have been defined via XML or programmatically, and the cache configurations that have been defined at runtime via this cache manager instance.
- getCacheControl() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
- GetCacheDistributionManagerAction - Class in org.infinispan.security.actions
-
GetCacheDistributionManagerAction.
- GetCacheDistributionManagerAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheDistributionManagerAction
- getCacheEntries() - Method in class org.infinispan.statetransfer.StateChunk
- getCacheEntry() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- getCacheEntry(Object) - Method in interface org.infinispan.AdvancedCache
-
Retrieves a CacheEntry corresponding to a specific key.
- 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.
- GetCacheGlobalComponentRegistryAction - Class in org.infinispan.security.actions
-
GetCacheGlobalComponentRegistryAction.
- GetCacheGlobalComponentRegistryAction(AdvancedCache<?, ?>) - Constructor for class org.infinispan.security.actions.GetCacheGlobalComponentRegistryAction
- getCacheHealth() - Method in interface org.infinispan.health.Health
-
Returns per cache health.
- getCacheHealth() - Method in interface org.infinispan.health.jmx.HealthJMXExposer
-
Returns per Cache statuses.
- getCacheInfo(AdvancedCache<byte[], byte[]>, 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
- getCacheLoaderMisses() - Method in interface org.infinispan.stats.ClusterCacheStats
- 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 interface org.infinispan.notifications.cachemanagerlistener.event.Event
- getCacheManager() - Method in interface org.infinispan.security.PrincipalRoleMapperContext
-
Returns the
EmbeddedCacheManager
in which this role mapper is being instantiated - getCacheManager() - Method in class org.infinispan.server.core.AbstractProtocolServer
- getCacheManager() - Method in class org.infinispan.tasks.TaskContext
-
CacheManager for this task execution
- 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
- 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
- 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.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
-
Caching shortcut for #getComponent(StreamingMarshaller.class, KnownComponentNames.CACHE_MARSHALLER);
- getCacheMode() - Method in class org.infinispan.topology.CacheJoinInfo
- 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.rest.InfinispanRequest
- 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.CacheTopologyControlCommand
- getCacheName() - Method in class org.infinispan.topology.ClusterCacheStatus
- getCacheNames() - Method in interface org.infinispan.commons.api.BasicCacheContainer
-
This method returns a collection of caches names which contains the caches that have been defined via XML or programmatically, and the caches that have been created at runtime via this cache manager instance.
- getCacheNames() - Method in class org.infinispan.manager.DefaultCacheManager
- getCacheNames() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManager
- getCacheNames() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
- 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.stats.wrappers.ExtendedStatisticInterceptor
- 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.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- getCacheTopology() - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
- getCacheTopology() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
- getCacheTopology() - Method in interface org.infinispan.statetransfer.StateConsumer
-
Deprecated.Since 9.3, please use
DistributionManager.getCacheTopology()
instead. - getCacheTopology() - Method in class org.infinispan.statetransfer.StateConsumerImpl
- getCacheTopology() - Method in interface org.infinispan.statetransfer.StateTransferManager
-
Deprecated.Since 9.3, please use
DistributionManager.getCacheTopology()
instead. - getCacheTopology() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- 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
- getCacheTopology(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- getCacheValue(InfinispanCacheAPIRequest) - Method in class org.infinispan.rest.operations.CacheOperations
-
Implementation of HTTP GET and HTTP HEAD requests invoked with a key.
- getCacheValues(InfinispanCacheAPIRequest) - Method in class org.infinispan.rest.operations.CacheOperations
-
Implementation of HTTP GET request invoked on root context.
- getCacheWithFlags(Cache<K, V>, FlagAffectedCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
-
Deprecated.
- getCallable() - Method in interface org.infinispan.distexec.DistributedTask
-
Returns
Callable
for this task - 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
-
Get a callback handler for the given mechanism name.
- getCallbackHandler(String, Map<String, String>) - Method in class org.infinispan.server.core.security.simple.SimpleServerAuthenticationProvider
-
Get a callback handler for the given mechanism name.
- getCanonicalFile() - Method in class org.infinispan.io.GridFile
- getCanonicalPath() - Method in class org.infinispan.io.GridFile
- getCapacity() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getCapacity() - Method in class org.infinispan.stats.topK.StreamSummaryContainer
- getCapacityFactor() - Method in class org.infinispan.topology.CacheJoinInfo
- getCapacityFactors() - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
The capacity factor of each member.
- getCapacityFactors() - Method in class org.infinispan.topology.ClusterCacheStatus
- getCause() - Method in class org.infinispan.query.remote.json.JsonQueryErrorResult
- getChannel() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- getCharset() - Method in class org.infinispan.commons.dataconversion.MediaType
- getChecksum() - Method in interface org.infinispan.globalstate.ScopedPersistentState
-
Returns the checksum of the properties excluding those prefixed with @
- getChunk() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- getChunkId() - Method in class org.infinispan.lucene.ChunkCacheKey
-
Get the chunkId.
- getChunkSize() - Method in class org.infinispan.io.GridFile
-
Guaranteed to be a power of two
- getChunkSize() - Method in class org.infinispan.io.GridFile.Metadata
- getClassBasedOnConfigurationAnnotation(StoreConfiguration, Log) - Static method in class org.infinispan.persistence.factory.ConfigurationForClassExtractor
- getClassForName(String, ClassLoader) - Static method in class org.infinispan.commons.util.ReflectionUtil
- getClassLoader() - Method in interface org.infinispan.AdvancedCache
-
Returns the cache loader associated associated with this cache.
- getClassLoader() - Method in class org.infinispan.commons.marshall.jboss.DefaultContextClassResolver
- getClassLoader() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- getClassLoader() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- getClassLoader() - Method in interface org.infinispan.context.InvocationContext
-
Deprecated.Not in use any more, implementations might return null.
- getClassLoader() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- 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
- 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.manager.DefaultCacheManager
- getClassWhiteList() - Method in interface org.infinispan.manager.EmbeddedCacheManager
- getClazz() - Method in class org.infinispan.factories.components.ComponentMetadata
- 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
- getClientListenerRegistry() - Method in class org.infinispan.server.hotrod.HotRodServer
- getClusterAvailability() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- getClusteredQuery(Query, Class<?>...) - Method in interface org.infinispan.query.SearchManager
-
Deprecated.since 9.2, to be removed in 10.0; equivalent to
getQuery(luceneQuery, IndexedQueryMode.BROADCAST, classes)
- 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 interface org.infinispan.health.jmx.HealthJMXExposer
-
Returns cluster health status.
- getClusterListenersToInstall() - Method in interface org.infinispan.statetransfer.StateProvider
- getClusterListenersToInstall() - Method in class org.infinispan.statetransfer.StateProviderImpl
- getClusterMembers() - Method in class org.infinispan.manager.DefaultCacheManager
- 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.DefaultCacheManager
- getClusterName() - Method in interface org.infinispan.manager.EmbeddedCacheManager
- getClusterSize() - Method in class org.infinispan.manager.DefaultCacheManager
- getClusterStatus() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
- getClusterStatus() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- getCode() - Method in enum org.infinispan.server.hotrod.OperationStatus
- getCode() - Method in enum org.infinispan.server.hotrod.TimeUnitValue
- getCodename() - Static method in class org.infinispan.Version
- getCoinToss() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- getCollocatedKey(K) - Method in interface org.infinispan.affinity.KeyAffinityService
-
Returns a key that will be distributed on the same node as the supplied key.
- getCommand() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
- getCommandId() - Method in class org.infinispan.query.affinity.AffinityUpdateCommand
- getCommandId() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
- getCommandId() - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- getCommandId() - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
- getCommandId() - Method in class org.infinispan.query.indexmanager.IndexUpdateStreamCommand
- 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.statetransfer.StateRequestCommand
- getCommandId() - Method in class org.infinispan.statetransfer.StateResponseCommand
- getCommandId() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- getCommandId() - Method in class org.infinispan.topology.HeartBeatCommand
- getCommandId() - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
- getCommandId() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- getCommandId() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- getCommandId() - Method in class org.infinispan.xsite.XSiteAdminCommand
- getCommandsFactory() - Method in class org.infinispan.factories.ComponentRegistry
-
Caching shortcut for #getLocalComponent(CommandsFactory.class);
- getCommandTopologyId() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
- 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
- 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>, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- getComponent(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- 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
- getComponentClass() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- getComponentMetadata(Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
-
Look up metadata for a component class.
- getComponentMetadataRepo() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- getComponentMetadataRepo() - Method in class org.infinispan.factories.ComponentRegistry
- getComponentMetadataRepo() - Method in class org.infinispan.factories.GlobalComponentRegistry
- getComponentName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- getComponentRegistry() - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 10.0, with no public API replacement
- getComponentType() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- getCompressionLevel() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
- 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.factories.AbstractComponentRegistry
-
Deprecated.Retrieves the configuration component.
- getConfiguration() - Method in class org.infinispan.factories.ComponentRegistry
- 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.server.core.AbstractProtocolServer
- getConfiguration() - Method in interface org.infinispan.server.core.ProtocolServer
-
Returns the configuration used to start this server
- 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, boolean) - Method in class org.infinispan.configuration.ConfigurationManager
- getConfiguration(String, String) - Method in class org.infinispan.configuration.ConfigurationManager
- getConfiguration(String, String) - Method in class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
- getConfigurations() - Method in class org.infinispan.configuration.serializing.ConfigurationHolder
- 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.connectionfactory.C3P0ConnectionPool
-
Deprecated.
- getConnection() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
-
Fetches a connection from the factory.
- getConnection() - Method in interface org.infinispan.persistence.jdbc.connectionfactory.ConnectionPool
- getConnection() - Method in class org.infinispan.persistence.jdbc.connectionfactory.HikariConnectionPool
- getConnectionFactory() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- getConnectionFactory(Class<? extends ConnectionFactory>) - Static method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
-
Constructs a
ConnectionFactory
based on the supplied class name. - getConnectionFactoryClass() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- getConnectionUrl() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- getConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
-
Deprecated.Since 9.0, please use
DistributionManager.getWriteConsistentHash()
instead. - getConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
- getConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
-
Deprecated.
- getConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
- getConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
-
Deprecated.
- getConsistentHashFactory() - Method in class org.infinispan.topology.CacheJoinInfo
- getContentType() - Method in class org.infinispan.rest.InfinispanRequest
- getContentType(MarshalledEntry) - Method in class org.infinispan.persistence.rest.metadata.EmbeddedMetadataHelper
- getContentType(MarshalledEntry) - Method in interface org.infinispan.persistence.rest.metadata.MetadataHelper
- getContext() - Method in class org.infinispan.rest.InfinispanRequest
- getContext(String, char[], char[], String, char[]) - Static method in class org.infinispan.commons.util.SslContextFactory
- getContext(String, char[], char[], String, char[], String) - Static method in class org.infinispan.commons.util.SslContextFactory
- getContext(String, char[], String, char[]) - Static method in class org.infinispan.commons.util.SslContextFactory
- getContext(String, char[], String, char[], String) - Static method in class org.infinispan.commons.util.SslContextFactory
- getContext(String, String, char[], char[], String, String, String, char[], String, ClassLoader) - Static method in class org.infinispan.commons.util.SslContextFactory
- getContext(String, String, char[], String, String, char[]) - Static method in class org.infinispan.commons.util.SslContextFactory
- getContinuousQuery(Cache<K, V>) - Static method in class org.infinispan.query.Search
-
Obtain the
ContinuousQuery
object for a cache. - 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.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.DefaultCacheManager
- getCorsRules() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
- getCounterListener() - Method in interface org.infinispan.counter.api.Handle
- getCounterNames() - Method in interface org.infinispan.counter.api.CounterManager
-
Returns a
Collection
of defined counter names. - 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
- getCreatedCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
- getCreationTime() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- getCurrentCH() - Method in class org.infinispan.topology.CacheTopology
-
The current consistent hash.
- getCurrentCH() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- getCurrentConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- getCurrentIndexingBackend() - Method in class org.infinispan.query.indexmanager.LocalOnlyBackend
- getCurrentIndexingBackend() - Method in interface org.infinispan.query.indexmanager.SwitchingBackend
- getCurrentNumberOfEntries() - Method in interface org.infinispan.stats.Stats
-
Returns the number of entries currently in this cache instance.
- getCurrentNumberOfEntriesInMemory() - Method in interface org.infinispan.stats.Stats
-
The same as
Stats.getCurrentNumberOfEntries()
, however passivated entries are not included. - getCurrentStateSending() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
- getCurrentStateSending() - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
- getCurrentTasks() - Method in interface org.infinispan.tasks.TaskManager
-
Retrieves the currently executing tasks.
- getCurrentTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
- getCustomInterceptorsBuilder() - Method in class org.infinispan.configuration.cache.AbstractCustomInterceptorsConfigurationChildBuilder
- getDataContainer() - Method in interface org.infinispan.AdvancedCache
-
Returns the container where data is stored in the cache.
- getDataMemoryUsed() - Method in interface org.infinispan.stats.Stats
-
Provides how much memory the current eviction algorithm estimates is in use for data.
- getDatasourceJndiLocation() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- 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
- getDefaultCacheConfiguration() - Method in class org.infinispan.manager.DefaultCacheManager
- getDefaultCacheConfiguration() - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Returns default configuration for this CacheManager
- getDefaultConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- GetDefaultExecutorServiceAction - Class in org.infinispan.security.actions
-
GetDefaultExecutorServiceAction.
- GetDefaultExecutorServiceAction(Cache<?, ?>) - Constructor for class org.infinispan.security.actions.GetDefaultExecutorServiceAction
- 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
- getDefaultRpcOptions(boolean) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Deprecated.Since 9.2, please use
RpcManager.getSyncRpcOptions()
instead. - getDefaultRpcOptions(boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getDefaultRpcOptions(boolean) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- getDefaultRpcOptions(boolean, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Deprecated.Since 9.2, please use
RpcManager.getSyncRpcOptions()
orRpcManager.getTotalSyncRpcOptions()
instead. - getDefaultRpcOptions(boolean, DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getDefaultRpcOptions(boolean, DeliverOrder) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- getDefaultScope() - Static method in enum org.infinispan.factories.scopes.Scopes
- 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
- getDefinedConfigurations() - Method in class org.infinispan.configuration.ConfigurationManager
- getDelegate() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- getDeltaAwareValueKey() - Method in class org.infinispan.atomic.DeltaCompositeKey
-
Deprecated.
- getDependencies() - Method in class org.infinispan.factories.components.ComponentMetadata
- getDependencyName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- getDependencyName(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- getDependents(T) - Method in class org.infinispan.util.DependencyGraph
-
Return the dependents
- getDescForKnownTypeIds() - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
- getDescription() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
- getDescription() - Method in class org.infinispan.factories.components.JmxOperationMetadata
- getDescription() - Method in class org.infinispan.factories.components.JmxOperationParameter
- getDescription() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
- getDestination() - Method in class org.infinispan.statetransfer.OutboundTransferTask
- 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.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.factories.ComponentRegistry
-
Caching shortcut for #getComponent(DistributionManager.class);
- getDriverClass() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- getElement() - Method in enum org.infinispan.configuration.cache.StorageType
- 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
- getEncoder(Class<? extends Encoder>, short) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
- getEncoderClass() - Method in class org.infinispan.encoding.DataConversion
- getEngine(SSLContext, boolean, boolean) - Static method in class org.infinispan.commons.util.SslContextFactory
- getEngines() - Method in interface org.infinispan.tasks.TaskManager
-
Retrieves the installed task engines
- getEnlistedResources() - Method in class org.infinispan.commons.tx.TransactionImpl
- getEnlistedResources() - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.
- getEnlistedSynchronization() - Method in class org.infinispan.commons.tx.TransactionImpl
- getEnlistedSynchronization() - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.
- 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.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.
- 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.
- getEtagIfMatch() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
-
Returns
If-Match
header value. - getEtagIfModifiedSince() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
-
Returns
If-Modified-Since
header value. - getEtagIfNoneMatch() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
-
Returns
If-None-Match
header value. - getEtagIfUnmodifiedSince() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
-
Returns
If-Unmodified-Since
header value. - getEvent() - Method in class org.infinispan.notifications.cachelistener.EventWrapper
- getEventTypes() - Method in interface org.infinispan.objectfilter.FilterSubscription
-
The event types.
- getEvictionManager() - Method in interface org.infinispan.AdvancedCache
- getEvictions() - Method in interface org.infinispan.stats.Stats
- 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
-
Provides info whether the task execution should be local - on one node or distributed - on all nodes.
- getExecutor() - Method in class org.infinispan.persistence.InitializationContextImpl
- getExecutor() - Method in interface org.infinispan.persistence.spi.InitializationContext
-
Returns the preferred executor to be used by stores if needed.
- getExecutor() - Method in class org.infinispan.server.core.AbstractProtocolServer
- 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 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
- 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
- getExpiryTime(InternalMetadata) - Static method in class org.infinispan.persistence.PersistenceUtil
- getExtended() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
-
Returns whether client wishes to return 'Extended Headers'.
- getExternalizer(Class<?>) - Method in class org.infinispan.commons.marshall.jboss.SerializeWithExtFactory
- getFacetManager() - Method in interface org.infinispan.query.CacheQuery
- getFactory(Class<?>) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Retrieves a component factory instance capable of constructing components of a specified type.
- getFactoryClazz() - Method in enum org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- 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
- getFailureCount() - Method in class org.infinispan.xsite.OfflineStatus
- getFailurePolicy(String) - Method in class org.infinispan.configuration.cache.SitesConfiguration
- getFetchedValue() - Method in class org.infinispan.query.clustered.QueryResponse
- getFetchMode() - Method in class org.infinispan.query.FetchOptions
- getFetchSize() - Method in class org.infinispan.query.FetchOptions
- getField() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- getField(String, Class<?>) - Static method in class org.infinispan.commons.util.ReflectionUtil
- getFieldClassName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- getFieldName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- getFile(File, String) - Method in class org.infinispan.io.GridFilesystem
- getFile(File, String, int) - Method in class org.infinispan.io.GridFilesystem
- getFile(String) - Method in class org.infinispan.io.GridFilesystem
-
Returns the file denoted by pathname.
- getFile(String, int) - Method in class org.infinispan.io.GridFilesystem
-
Returns the file denoted by pathname.
- getFile(String, String) - Method in class org.infinispan.io.GridFilesystem
- getFile(String, String, int) - Method in class org.infinispan.io.GridFilesystem
- 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.
- getFileName() - Method in class org.infinispan.lucene.ChunkCacheKey
-
Get the fileName.
- getFileName() - Method in class org.infinispan.lucene.FileCacheKey
-
Get the fileName.
- getFileName() - Method in class org.infinispan.lucene.FileReadLockKey
-
Get the fileName.
- 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.
- getFilteredKeys() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
- getFineGrainedAtomicMap(Cache<MK, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
-
Retrieves a fine grained atomic map from a given cache, stored under a given key.
- getFineGrainedAtomicMap(Cache<MK, ?>, MK, boolean) - Static method in class org.infinispan.atomic.AtomicMapLookup
-
Retrieves an atomic map from a given cache, stored under a given key.
- getFirstException() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- getFirstInChain() - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.
- getFirstTopologyAsMember() - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
- getFirstTopologyAsMember() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- getFirstTopologyAsMember() - Method in interface org.infinispan.remoting.inboundhandler.PerCacheInboundInvocationHandler
- getFirstTopologyAsMember() - Method in interface org.infinispan.statetransfer.StateTransferManager
-
Deprecated.Since 9.4, will be removed.
- getFirstTopologyAsMember() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- getFlag() - Method in class org.infinispan.server.hotrod.HotRodHeader
- getFloatProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
-
Retrieves a float state property
- getFormatId() - Method in class org.infinispan.commons.tx.XidImpl
- getFormatId() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
-
Deprecated.
- getFormatId() - Method in class org.infinispan.transaction.tm.DummyXid
-
Deprecated.
- getFormatId() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
-
Deprecated.
- 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
- getFuture() - Method in interface org.infinispan.interceptors.distribution.Collector
- getFuture() - Method in class org.infinispan.interceptors.distribution.PrimaryOwnerOnlyCollector
- 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.Since 10.0, with no public API replacement
- GetGlobalComponentRegistryAction - Class in org.infinispan.security.actions
-
GetGlobalComponentRegistryAction.
- GetGlobalComponentRegistryAction(EmbeddedCacheManager) - Constructor for class org.infinispan.security.actions.GetGlobalComponentRegistryAction
- 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
- getGlobalConfigurationAsProperties() - Method in class org.infinispan.manager.DefaultCacheManager
- getGlobalConfigurationBuilder() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- getGlobalTransaction() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- 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.statetransfer.TransactionInfo
- getGlobalTransaction() - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Returns the transaction identifier.
- getGlobalTransaction(Transaction) - Method in interface org.infinispan.transaction.TransactionTable
- getGlobalTransactionId() - Method in class org.infinispan.commons.tx.XidImpl
- getGlobalTransactionId() - Method in class org.infinispan.transaction.tm.DummyNoXaXid
-
Deprecated.
- getGlobalTransactionId() - Method in class org.infinispan.transaction.tm.DummyXid
-
Deprecated.
- getGlobalTransactionId() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
-
Deprecated.
- getGroup(String) - Method in interface org.infinispan.AdvancedCache
-
It fetches all the keys which belong to the group.
- 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
- getHashFunction() - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Deprecated.Since 8.2, the
Hash
is optional - replaced in the configuration by theKeyPartitioner
- getHashFunction() - Method in class org.infinispan.topology.CacheJoinInfo
- getHeader() - Method in class org.infinispan.server.hotrod.HotRodDecoder
- 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.
- getHealthStatus() - Method in interface org.infinispan.health.ClusterHealth
-
Returns total cluster health.
- getHitRatio() - Method in interface org.infinispan.stats.CacheContainerStats
- getHitRatio() - Method in interface org.infinispan.stats.ClusterCacheStats
- getHits() - Method in class org.infinispan.query.remote.json.JsonQueryResult
- getHits() - Method in class org.infinispan.query.remote.json.ProjectedJsonResult
- getHits() - Method in interface org.infinispan.stats.Stats
- getHost() - Method in class org.infinispan.server.core.AbstractProtocolServer
- getHost() - Method in class org.infinispan.server.hotrod.ServerAddress
- getHostInfo() - Method in interface org.infinispan.health.Health
-
Gets basic information about the host.
- getHostName() - Method in class org.infinispan.server.core.transport.NettyTransport
- getHostName() - Method in interface org.infinispan.server.core.transport.Transport
- getHttp11To2ConnectionHandler() - Method in class org.infinispan.rest.Http11To2UpgradeHandler
-
Creates a handler for HTTP/1.1 -> HTTP/2 upgrade
- getHttp11To2UpgradeHandler() - Method in class org.infinispan.rest.RestChannelInitializer
- getHttp1Handler() - Method in class org.infinispan.rest.Http11To2UpgradeHandler
-
Gets HTTP/1.1 handler.
- getHttp2Handler() - Method in class org.infinispan.rest.Http11To2UpgradeHandler
-
Gets HTTP/2 handler.
- getId() - Method in class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
-
Deprecated.
- 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
-
Returns an integer that identifies the externalizer type.
- getId() - Method in class org.infinispan.commons.marshall.exts.EquivalenceExternalizer
- 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.Immutables.ImmutableMapWrapperExternalizer
- getId() - Method in class org.infinispan.commons.util.Immutables.ImmutableSetWrapperExternalizer
- getId() - Method in class org.infinispan.compat.BiFunctionMapper.Externalizer
- getId() - Method in class org.infinispan.compat.FunctionMapper.Externalizer
- 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.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.CollectionKeyFilter.Externalizer
- getId() - Method in class org.infinispan.filter.CompositeKeyFilter.Externalizer
- getId() - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
- getId() - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
- getId() - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter.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.interceptors.distribution.VersionedResult.Externalizer
- getId() - Method in class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
- getId() - Method in class org.infinispan.lucene.ChunkCacheKey.Externalizer
- getId() - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
- getId() - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
- getId() - Method in class org.infinispan.lucene.FileMetadata.Externalizer
- getId() - Method in class org.infinispan.lucene.FileReadLockKey.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.core.MarshalledEntryImpl.Externalizer
- getId() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
- 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.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.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.notifications.cachelistener.cluster.ClusterEvent.Externalizer
- getId() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.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.MultiClusterEventCallable.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.KeyFilterAsCacheEventFilter.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.query.clustered.NodeTopDocs.Externalizer
- getId() - Method in class org.infinispan.query.clustered.QueryResponse.Externalizer
- getId() - Method in class org.infinispan.remoting.MIMECacheEntry.Externalizer
- 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.statetransfer.StateChunk.Externalizer
- getId() - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
- 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.DldGlobalTransaction.Externalizer
-
Deprecated.
- 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.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
- getId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
-
Deprecated.
- getId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
- getId() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
-
Deprecated.
- getId() - Method in class org.infinispan.util.IntSetExternalizer
- getId() - Method in class org.infinispan.util.KeyValuePair.Externalizer
- 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
- getIdleTimeout() - Method in class org.infinispan.server.core.transport.NettyTransport
- getIdleTimeout() - Method in interface org.infinispan.server.core.transport.Transport
- getIgnoredCaches() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
-
Deprecated.Use
ProtocolServerConfiguration.ignoredCaches()
instead. - getIndex(ExtendedStatistic) - Method in class org.infinispan.stats.container.BaseExtendedStatisticsContainer
- getIndex(ExtendedStatistic) - Method in class org.infinispan.stats.container.LocalExtendedStatisticsContainer
- getIndex(ExtendedStatistic) - Method in class org.infinispan.stats.container.RemoteExtendedStatisticsContainer
- getIndexedQueryMode() - Method in class org.infinispan.query.remote.client.QueryRequest
- getIndexName() - Method in class org.infinispan.lucene.ChunkCacheKey
-
Get the indexName.
- getIndexName() - Method in class org.infinispan.lucene.FileCacheKey
-
Get the indexName.
- getIndexName() - Method in class org.infinispan.lucene.FileListCacheKey
-
Get the indexName.
- getIndexName() - Method in class org.infinispan.lucene.FileReadLockKey
-
Get the indexName.
- getIndexName() - Method in interface org.infinispan.lucene.IndexScopedKey
-
Different indexes are required to use different names
- getIndexName() - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- 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
- getInjectFields() - Method in class org.infinispan.factories.components.ComponentMetadata
- getInjectMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
- getInput(File) - Method in class org.infinispan.io.GridFilesystem
-
Opens an InputStream for reading from the given file.
- getInput(String) - Method in class org.infinispan.io.GridFilesystem
-
Opens an InputStream for reading from the file denoted by pathname.
- getInstance() - Static method in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- getInstance() - Static method in class org.infinispan.commons.hash.MurmurHash3
- getInstance() - Static method in class org.infinispan.commons.util.OsgiClassLoader
- 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.counter.api.PropertyFormatter
- getInstance() - Static method in class org.infinispan.distexec.spi.DistributedTaskLifecycleService
- getInstance() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
-
Deprecated.
- getInstance() - Static method in class org.infinispan.filter.AcceptAllKeyValueFilter
- getInstance() - Method in interface org.infinispan.objectfilter.ObjectFilter.FilterResult
-
Returns the matched object.
- getInstance() - Method in class org.infinispan.query.remote.client.FilterResult
- getInstance() - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- getInstance() - Static method in class org.infinispan.transaction.tm.BatchModeTransactionManager
- getInstance() - Static method in class org.infinispan.transaction.tm.DummyTransactionManager
-
Deprecated.
- getInstance() - Static method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
- 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.equivalence.AnyEquivalence
-
Deprecated.
- 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.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(Class<T>) - Static method in class org.infinispan.commons.util.Util
- getInstanceSupplier(String, ClassLoader) - Static method in class org.infinispan.commons.util.Util
- getIntAccessibly(Field, Object) - Static method in class org.infinispan.commons.util.ReflectionUtil
- getInterceptorChain() - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 9.0, use
AdvancedCache.getAsyncInterceptorChain()
instead. - getInterceptors() - Method in interface org.infinispan.interceptors.AsyncInterceptorChain
- getInterceptors() - Method in class org.infinispan.interceptors.EmptyAsyncInterceptorChain
- getInterceptorsWhichExtend(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Returns all interceptors which extend the given command interceptor.
- getInterceptorsWithClass(Class) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Returns all the interceptors that have the fully qualified name of their class equal with the supplied class name.
- getInternalCacheNames() - Method in interface org.infinispan.registry.InternalCacheRegistry
-
Retrieves the names of all the internal caches
- getInternalEntry(String, Object, boolean, MediaType, MediaType, Subject) - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- getInternalEntry(String, Object, MediaType, MediaType, Subject) - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- getInternalEntry(AdvancedCache<Object, V>, Object, boolean) - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- getInternalId() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- getInternalId() - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
- getInternalId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
-
Deprecated.
- getInternalId() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
- getInternalId() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
-
Each xid has a unique long object associated to it.
- 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
- getInvalidations() - Method in interface org.infinispan.stats.ClusterCacheStats
- getInvocationContext(boolean) - Method in interface org.infinispan.context.InvocationContextContainer
-
Deprecated.Returns the
InvocationContext
that is currently associated with the calling thread. - getInvocationContextContainer() - Method in interface org.infinispan.AdvancedCache
-
Deprecated.No longer in use, implementations might return null.
- 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. - getJGroupsAddress() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsAddress
- getJGroupsChannel(Properties) - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
-
Retrieves a JGroups channel.
- getJmxObjectName() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
- getJndiLookup() - Method in enum org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- getJoinInfo() - Method in class org.infinispan.topology.ClusterCacheStatus
- getKeepAliveTime() - Method in class org.infinispan.executors.ManageableExecutorService
- getKey() - Method in interface org.infinispan.affinity.KeyGenerator
- getKey() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Node
-
Deprecated.
- 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.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.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- getKey() - Method in interface org.infinispan.marshall.core.MarshalledEntry
-
Returns the same key as
MarshalledEntry.getKeyBytes()
, but unmarshalled. - getKey() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
- 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.EventWrapper
- getKey() - Method in class org.infinispan.persistence.modifications.Remove
- getKey() - Method in class org.infinispan.persistence.modifications.Store
- getKey() - Method in class org.infinispan.query.remote.client.ContinuousQueryResult
- getKey() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
- getKey() - Method in exception org.infinispan.transaction.WriteSkewException
- getKey() - Method in class org.infinispan.util.KeyValuePair
- 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
- getKeyBytes() - Method in interface org.infinispan.marshall.core.MarshalledEntry
-
Returns the key in serialized format.
- getKeyBytes() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
- getKeyContentType() - Method in class org.infinispan.rest.InfinispanRequest
- getKeyDataConversion() - Method in interface org.infinispan.AdvancedCache
- 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
- getKeyEncoder() - Method in interface org.infinispan.AdvancedCache
-
Deprecated.
- getKeyEquivalence() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- 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(String, String, char[], char[], String, ClassLoader) - Static 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.lucene.LuceneKey2StringMapper
-
This method has to perform the inverse transformation of the keys used in the Lucene Directory from String to object.
- 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.
- getKeysToLock() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
-
It returns a
Collection
with the keys to be lock. - getKeysToRemove() - Method in class org.infinispan.persistence.support.BatchModification
- getKeyType() - Method in interface org.infinispan.distribution.group.Grouper
- getKeyWrapper() - Method in interface org.infinispan.AdvancedCache
-
Deprecated.
- getKlass() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- getKPercentile(int) - Method in class org.infinispan.stats.percentiles.ReservoirSampler
- getLargestPoolSize() - Method in class org.infinispan.executors.ManageableExecutorService
- getLastResetTime() - Method in class org.infinispan.stats.container.StatisticsSnapshot
- 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
- getLeastSignificantBits() - Method in class org.infinispan.topology.PersistentUUID
- 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
- 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
- getList() - Method in class org.infinispan.persistence.modifications.ModificationsList
- getListAttributeValue(int) - Method in interface org.infinispan.configuration.parsing.XMLExtendedStreamReader
-
Get the value of an attribute as a space-delimited string list.
- 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
- getListeners() - Method in class org.infinispan.manager.DefaultCacheManager
- getListeners() - Method in interface org.infinispan.notifications.Listenable
- getListeners() - Method in interface org.infinispan.query.api.continuous.ContinuousQuery
-
Get the list of currently registered listeners.
- getLocal(ExtendedStatistic) - Method in class org.infinispan.stats.container.StatisticsSnapshot
- getLocalActiveTransactions() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getLocalAddress() - Method in class org.infinispan.distribution.LocalizedCacheTopology
- getLocalAddress() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
- getLocalCacheName() - Method in exception org.infinispan.xsite.BackupFailureException
- 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.stats.wrappers.ExtendedStatisticInterceptor
- getLocalGlobalTransaction() - Method in interface org.infinispan.transaction.TransactionTable
- getLocalIndex() - Method in enum org.infinispan.stats.container.ExtendedStatistic
- getLocalIndex(ExtendedStatistic) - Static method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- getLocality(Object) - Method in interface org.infinispan.distribution.DistributionManager
-
Deprecated.Since 9.0, please use
getCacheTopology().getDistributionInfo(key)
instead. - 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.configuration.Attribute
-
Get the local name of this element.
- getLocalName() - Method in enum org.infinispan.persistence.jdbc.configuration.Element
-
Get the local name of this element.
- getLocalName() - Method in enum org.infinispan.persistence.jpa.configuration.Attribute
-
Get the local name of this element.
- getLocalName() - Method in enum org.infinispan.persistence.jpa.configuration.Element
-
Get the local name of this element.
- getLocalName() - Method in enum org.infinispan.persistence.leveldb.configuration.Attribute
-
Get the local name of this element.
- getLocalName() - Method in enum org.infinispan.persistence.leveldb.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.rest.configuration.Attribute
-
Get the local name of this element.
- getLocalName() - Method in enum org.infinispan.persistence.rest.configuration.Element
-
Get the local name of this element.
- getLocalPreparedXids() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- getLocalReadSegments() - Method in class org.infinispan.distribution.LocalizedCacheTopology
- getLocalStatsSize() - Static method in enum org.infinispan.stats.container.ExtendedStatistic
- getLocalTopGets() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getLocalTopPuts() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getLocalTransaction() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- getLocalTransaction(Xid) - Method in class org.infinispan.transaction.xa.XaTransactionTable
- getLocalTx(Xid) - Method in class org.infinispan.server.hotrod.tx.table.PerCacheTxTable
- getLocalTxCount() - Method in class org.infinispan.transaction.xa.XaTransactionTable
- getLocalTxThatFailedToComplete() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- getLocationId(TopologyLevel, Address) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
- getLock(Object) - Method in class org.infinispan.container.offheap.StripedLock
-
Retrieves the read write lock attributed to the given object using its hashCode for lookup.
- getLock(Object) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- getLock(Object) - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- getLock(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
- getLockAcquisitionTimeout(FlagAffectedCommand, boolean) - Method in class org.infinispan.interceptors.base.CommandInterceptor
-
Deprecated.
- getLockedKeys() - Method in interface org.infinispan.context.InvocationContext
-
Returns the set of keys that are locked for writing.
- getLockedKeys() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- getLockedKeys() - Method in class org.infinispan.statetransfer.TransactionInfo
- getLockedKeys() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- getLockFromHashCode(int) - Method in class org.infinispan.container.offheap.StripedLock
-
Retrieves the lock associated with the given hashCode
- getLockIntention() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.Returns the key this transaction intends to lock.
- getLockManager() - Method in interface org.infinispan.AdvancedCache
-
Returns the component that deals with all aspects of acquiring and releasing locks for cache entries.
- getLockOwner() - Method in interface org.infinispan.context.InvocationContext
-
Returns the in behalf of which locks will be acquired.
- getLockOwner() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- getLocks() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- getLocksHeldAtOrigin() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- getLockTimeoutMillis(FlagAffectedCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- 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.interceptors.base.CommandInterceptor
-
Deprecated.
- getLog() - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- getLog() - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- getLog() - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- getLog() - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- getLog() - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
- getLog() - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- getLog() - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
- getLog() - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
- getLog() - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
- getLog() - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
- getLog() - Method in class org.infinispan.interceptors.totalorder.TotalOrderStateTransferInterceptor
- getLog() - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
- getLog() - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- getLog() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- getLog() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- getLog() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- getLog() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
- getLog() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
- getLog() - Method in class org.infinispan.remoting.inboundhandler.TotalOrderTxPerCacheInboundInvocationHandler
- getLog() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- 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.statetransfer.StateTransferInterceptor
- 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
-
Deprecated.Since 9.3, please use
EntryLookup.forEachEntry(BiConsumer)
orEntryLookup.lookedUpEntriesCount()
instead. - getLookedUpEntries() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- getLookedUpEntries() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- getLookedUpRemoteVersion(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.since 9.0
- getMachineId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- getMachineId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
- getMachineNodes(String, String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
- getMajor() - Method in class org.infinispan.configuration.parsing.Schema
- getMajor() - Static method in class org.infinispan.Version
- getMajorMinor() - Static method in class org.infinispan.Version
- getMapForSegment(int) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- 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
- getMarshalledEntries() - Method in class org.infinispan.persistence.support.BatchModification
- getMarshalledEntryFactory() - Method in class org.infinispan.persistence.InitializationContextImpl
- getMarshalledEntryFactory() - Method in interface org.infinispan.persistence.spi.InitializationContext
-
To be used for building
MarshalledEntry
objects. - getMarshaller() - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
- getMarshaller() - Method in class org.infinispan.persistence.InitializationContextImpl
- getMarshaller() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- getMarshaller() - Method in interface org.infinispan.persistence.spi.InitializationContext
- getMarshaller() - Method in class org.infinispan.server.hotrod.HotRodServer
- getMarshaller() - Method in class org.infinispan.tasks.TaskContext
-
Marshaller for this task execution
- getMarshallVersion() - Static method in class org.infinispan.Version
- getMask() - Method in enum org.infinispan.security.AuthorizationPermission
- getMask() - Method in interface org.infinispan.security.Role
-
Returns a pre-computed access mask which contains the permissions specified by this role
- getMassIndexer() - Method in interface org.infinispan.query.SearchManager
-
The MassIndexer can be used to rebuild the Lucene indexes from the entries stored in Infinispan.
- getMax(long) - Method in class org.infinispan.commons.stat.DefaultSimpleStat
- getMax(long) - Method in interface org.infinispan.commons.stat.SimpleStat
- getMaxDoublingSize() - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
-
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
-
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.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%.
- 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
- getMaxIdleTimeSeconds() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
-
Returns
maxIdleTimeSeconds
header value. - getMaximumAsyncXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getMaximumPoolSize() - Method in class org.infinispan.executors.ManageableExecutorService
- getMaximumXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getMaxPoolSize() - Method in class org.infinispan.persistence.jdbc.connectionfactory.C3P0ConnectionPool
-
Deprecated.
- getMaxPoolSize() - Method in interface org.infinispan.persistence.jdbc.connectionfactory.ConnectionPool
- getMaxPoolSize() - Method in class org.infinispan.persistence.jdbc.connectionfactory.HikariConnectionPool
- getMaxResults() - Method in class org.infinispan.query.remote.client.QueryRequest
- getMaxResults() - Method in class org.infinispan.query.remote.json.JsonQueryRequest
- getMBeanInfo() - Method in class org.infinispan.jmx.ResourceDMBean
- getMBeanServer() - Method in interface org.infinispan.commons.jmx.MBeanServerLookup
- getMBeanServer(Properties) - Method in class org.infinispan.commons.jmx.JBossMBeanServerLookup
- getMBeanServer(Properties) - Method in interface org.infinispan.commons.jmx.MBeanServerLookup
-
Retrieves an
MBeanServer
instance. - getMBeanServer(Properties) - Method in class org.infinispan.commons.jmx.PlatformMBeanServerLookup
- getMBeanServer(Properties) - Method in class org.infinispan.jmx.JBossMBeanServerLookup
-
Deprecated.
- getMBeanServer(Properties) - Method in class org.infinispan.jmx.PlatformMBeanServerLookup
-
Deprecated.
- getMechanism() - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
- getMechanismNames(Map<String, ?>) - Method in class org.infinispan.server.core.security.external.ExternalSaslServerFactory
- getMediaType(Short) - Static method in class org.infinispan.commons.dataconversion.MediaTypeIds
- getMembers() - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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.manager.DefaultCacheManager
- getMembers() - Method in interface org.infinispan.manager.EmbeddedCacheManager
- 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.stats.wrappers.ExtendedStatisticRpcManager
- getMembers() - Method in class org.infinispan.topology.CacheTopology
- getMembersAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
- getMembersAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
- getMembersPersistentUUIDs() - Method in class org.infinispan.topology.CacheTopology
- getMembersSet() - Method in class org.infinispan.distribution.LocalizedCacheTopology
- getMembersSet() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
- getMemoryAddress(Object) - Method in class org.infinispan.container.offheap.MemoryAddressHash
- 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.ClusterContainerStats
- getMemoryMax() - Method in interface org.infinispan.stats.ClusterContainerStats
- getMemoryTotal() - Method in interface org.infinispan.stats.ClusterContainerStats
- getMemoryUsed() - Method in interface org.infinispan.stats.ClusterContainerStats
- getMessage() - Method in class org.infinispan.query.remote.json.JsonQueryErrorResult
- getMessage() - Method in exception org.infinispan.xsite.BackupFailureException
- getMessageId() - Method in class org.infinispan.server.hotrod.HotRodHeader
- 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.factories.AbstractComponentRegistry.Component
-
Deprecated.
- getMetadata() - Method in interface org.infinispan.marshall.core.MarshalledEntry
- getMetadata() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
- 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.
- getMetadataBytes() - Method in interface org.infinispan.marshall.core.MarshalledEntry
- getMetadataBytes() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
- getMetadataFilename() - Method in interface org.infinispan.factories.components.ModuleMetadataFileFinder
- getMetadataFilename() - Method in class org.infinispan.server.core.ServerCoreMetadataFileFinder
- getMetadataFilename() - Method in class org.infinispan.server.hotrod.ServerMetadataFileFinder
- getMetadataFilename() - Method in class org.infinispan.stats.ExtendedStatisticsMetadataFileFinder
- getMethod() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- getMethod() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
- getMethodName() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- getMethodName() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
- getMethodName() - Method in class org.infinispan.factories.components.JmxOperationMetadata
- getMethodParameters() - Method in class org.infinispan.factories.components.JmxOperationMetadata
- getMin(long) - Method in class org.infinispan.commons.stat.DefaultSimpleStat
- getMin(long) - Method in interface org.infinispan.commons.stat.SimpleStat
- getMinimumAsyncXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getMinimumXSiteReplicationTime() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getMinor() - Method in class org.infinispan.configuration.parsing.Schema
- 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.Parser.TransactionMode
- getModifications() - Method in class org.infinispan.server.hotrod.tx.table.TxState
- getModifications() - Method in class org.infinispan.statetransfer.TransactionInfo
- 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
- getModuleCommandFactory() - Method in class org.infinispan.server.hotrod.command.HotRodModuleCommandExtensions
- getModuleCommandInitializer() - Method in class org.infinispan.server.hotrod.command.HotRodModuleCommandExtensions
- getModuleCommandInitializers() - Method in class org.infinispan.factories.GlobalComponentRegistry
- getModuleMetadataFiles(ClassLoader) - Static method in class org.infinispan.util.ModuleProperties
-
Retrieves an Iterable containing metadata file finders declared by each module.
- getModuleProperties() - Method in class org.infinispan.factories.GlobalComponentRegistry
- getModuleSlot() - Static method in class org.infinispan.Version
- getMostSignificantBits() - Method in class org.infinispan.topology.PersistentUUID
- 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 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.factories.AbstractComponentRegistry.Component
-
Deprecated.
- getName() - Method in class org.infinispan.factories.components.ComponentMetadata
- getName() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
- getName() - Method in class org.infinispan.factories.components.JmxOperationParameter
- 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.globalstate.ScopedState
- getName() - Method in class org.infinispan.io.GridFile
- 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.rest.upgrade.RestTargetMigrator
-
Deprecated.
- getName() - Method in class org.infinispan.query.remote.client.QueryRequest.NamedParameter
- getName() - Method in interface org.infinispan.security.Role
-
Returns the name of this role
- getName() - Method in class org.infinispan.server.core.admin.AdminOperationsHandler
- getName() - Method in class org.infinispan.server.core.admin.AdminServerTask
- 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.provider.SpringCache
- getName() - Method in interface org.infinispan.tasks.spi.TaskEngine
-
Returns the name of the engine
- getName() - Method in interface org.infinispan.tasks.Task
-
Provides a name for the task.
- getName() - Method in interface org.infinispan.tasks.TaskExecution
-
Returns the name of the task
- getName() - Method in interface org.infinispan.upgrade.TargetMigrator
-
Returns the name of this migrator
- 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.remote.client.QueryRequest
- getNamedParametersMap() - Method in class org.infinispan.query.remote.client.QueryRequest
- getNamespaceAnnotations(Class<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- getNamespaceContext() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- 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.lock.configuration.ClusteredLockConfigurationParser
- getNamespaces() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser
- getNamespaces() - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationParser
- getNamespaces() - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationParser
-
Deprecated.
- getNamespaces() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationParser
- getNamespaces() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationParser
- getNativeCache() - Method in class org.infinispan.spring.provider.SpringCache
- getNativeCacheManager() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManager
-
Return the
that backs thisorg.infinispan.manager.EmbeddedCacheManager
CacheManager
. - getNativeCacheManager() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
-
Return the
that backs thisorg.infinispan.client.hotrod.RemoteCacheManager
SpringRemoteCacheManager
. - getNewBufferSize(int, int) - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
-
Gets the number of bytes to which the internal buffer should be resized.
- getNewBufferSize(int, int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
-
Gets the number of bytes to which the internal buffer should be resized.
- getNewBufferSize(int, int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
-
Deprecated.Gets the number of bytes to which the internal buffer should be resized.
- getNewMembers() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
-
Gets the current list of members.
- getNewState() - Method in interface org.infinispan.counter.api.CounterEvent
- getNewTopologyId() - Method in interface org.infinispan.notifications.cachelistener.event.DataRehashedEvent
- getNewTopologyId() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
- getNewValue() - Method in interface org.infinispan.counter.api.CounterEvent
- 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.interceptors.base.CommandInterceptor
-
Deprecated.Retrieves the next interceptor in the chain.
- 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
- getNextFromIterator() - Method in class org.infinispan.commons.util.RemovableIterator
- getNLocalTopGets(int) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getNLocalTopPuts(int) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getNodeAddress() - Method in class org.infinispan.manager.DefaultCacheManager
- getNodeName() - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- getNodeNames() - Method in interface org.infinispan.health.ClusterHealth
-
Returns node names.
- getNodeTopDocs() - Method in class org.infinispan.query.clustered.QueryResponse
- getNonCacheComponents(Collection<ResourceDMBean>) - Method in class org.infinispan.jmx.CacheJmxRegistration
- 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.
- getNRemoteTopGets(int) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getNRemoteTopPuts(int) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getNTopContendedKeys(int) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getNTopLockedKeys(int) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getNTopLockFailedKeys(int) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getNTopWriteSkewFailedKeys(int) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getNumAbortedTxDueDeadlock() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getNumAbortedTxDueTimeout() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getNumberIOThreads() - Method in class org.infinispan.server.core.transport.NettyTransport
- getNumberIOThreads() - Method in interface org.infinispan.server.core.transport.Transport
- getNumberOfChunks() - Method in class org.infinispan.lucene.FileMetadata
- getNumberOfCommits() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- 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.
- getNumberOfGets() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getNumberOfGlobalConnections() - Method in class org.infinispan.server.core.transport.NettyTransport
- getNumberOfGlobalConnections() - Method in interface org.infinispan.server.core.transport.Transport
- getNumberOfLocalCommits() - Method in class org.infinispan.stats.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
- getNumberOfLocksHeld() - Method in interface org.infinispan.stats.ClusterCacheStats
- getNumberOfLocksHeld() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- getNumberOfLocksHeld() - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- 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.stats.wrappers.ExtendedStatisticInterceptor
- getNumberOfRemoteGets() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getNumberOfRemotePuts() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getNumBusyConnectionsAllUsers() - Method in class org.infinispan.persistence.jdbc.connectionfactory.C3P0ConnectionPool
-
Deprecated.
- getNumBusyConnectionsAllUsers() - Method in interface org.infinispan.persistence.jdbc.connectionfactory.ConnectionPool
- getNumBusyConnectionsAllUsers() - Method in class org.infinispan.persistence.jdbc.connectionfactory.HikariConnectionPool
- getNumConnectionsAllUsers() - Method in class org.infinispan.persistence.jdbc.connectionfactory.C3P0ConnectionPool
-
Deprecated.
- getNumConnectionsAllUsers() - Method in interface org.infinispan.persistence.jdbc.connectionfactory.ConnectionPool
- getNumConnectionsAllUsers() - Method in class org.infinispan.persistence.jdbc.connectionfactory.HikariConnectionPool
- getNumNodes() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getNumOwners() - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Deprecated.Since 9.1, it should not be used to obtain the number of owners of a particular key.
- getNumOwners() - Method in class org.infinispan.topology.CacheJoinInfo
- getNumResults() - Method in class org.infinispan.query.remote.client.QueryResponse
- getNumSegments() - Method in interface org.infinispan.distribution.ch.ConsistentHash
- getNumSegments() - Method in class org.infinispan.topology.CacheJoinInfo
- getNumSegments() - Method in class org.infinispan.util.StripedHashFunction
- getObject() - Method in class org.infinispan.spring.InfinispanDefaultCacheFactoryBean
- getObject() - Method in class org.infinispan.spring.provider.ContainerEmbeddedCacheManagerFactoryBean
- getObject() - Method in class org.infinispan.spring.provider.ContainerRemoteCacheManagerFactoryBean
- getObject() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
- getObject() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
- getObject() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
- getObject() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
- getObject() - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
- getObject() - Method in class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
- 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
- getObjectName() - Method in class org.infinispan.jmx.ResourceDMBean
- getObjectName() - Method in interface org.infinispan.query.remote.ProtobufMetadataManager
- getObjectName(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
- getObjectName(String, String, String) - Static method in class org.infinispan.jmx.ComponentsJmxRegistration
- getObjectType() - Method in class org.infinispan.spring.InfinispanDefaultCacheFactoryBean
- getObjectType() - Method in class org.infinispan.spring.provider.ContainerEmbeddedCacheManagerFactoryBean
- getObjectType() - Method in class org.infinispan.spring.provider.ContainerRemoteCacheManagerFactoryBean
- getObjectType() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
- getObjectType() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
- getObjectType() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
- getObjectType() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
- getObjectType() - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
- getObjectType() - Method in class org.infinispan.spring.support.remote.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 interface org.infinispan.stats.Stats
-
The amount of off-heap memory used by this cache
- getOffline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
- getOfflineStatus(String) - Method in interface org.infinispan.xsite.BackupSender
- getOfflineStatus(String) - Method in class org.infinispan.xsite.BackupSenderImpl
- 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 interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
-
Gets the previous list of members.
- getOldMetadata() - Method in class org.infinispan.container.entries.RepeatableReadEntry
- getOldState() - Method in interface org.infinispan.counter.api.CounterEvent
- getOldValue() - Method in class org.infinispan.container.entries.RepeatableReadEntry
- 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.CacheEntryRemovedEvent
-
Regardless of whether isPre() is true or is false, this method returns the value of the entry being deleted.
- getOnline() - Method in class org.infinispan.xsite.status.AbstractMixedSiteStatus
- getOp() - Method in class org.infinispan.server.hotrod.HotRodHeader
- getOperationMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
- getOperationName() - Method in class org.infinispan.factories.components.JmxOperationMetadata
- getOperationName() - Method in class org.infinispan.jmx.IspnMBeanOperationInfo
- getOptionalComponent(Class<T>) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- 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 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, 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
- 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
- getOrCreateStreamLibContainer(Cache) - Static method in class org.infinispan.stats.topK.StreamSummaryContainer
- getOrDefault(Object, V) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- getOrigin() - Method in interface org.infinispan.context.InvocationContext
- getOrigin() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- getOrigin() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- getOriginator() - Method in class org.infinispan.server.hotrod.tx.table.TxState
- getOriginSite() - Method in class org.infinispan.xsite.XSiteReplicateCommand
- getOutput(String) - Method in class org.infinispan.io.GridFilesystem
-
Opens an OutputStream for writing to the file denoted by pathname.
- getOutput(String, boolean) - Method in class org.infinispan.io.GridFilesystem
-
Opens an OutputStream for writing to the file denoted by pathname.
- getOutput(String, boolean, int) - Method in class org.infinispan.io.GridFilesystem
-
Opens an OutputStream for writing to the file denoted by pathname.
- getOutput(GridFile) - Method in class org.infinispan.io.GridFilesystem
-
Opens an OutputStream for writing to the given file.
- getOwnedSegments(ConsistentHash) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- getOwner() - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
- getOwner(Object) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- getOwner(Object) - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- getOwner(Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Retrieves the owner of the lock for the
key
. - getOwner(String) - Method in class org.infinispan.query.affinity.ShardAllocationManagerImpl
- getOwner(String) - Method in interface org.infinispan.query.affinity.ShardAllocatorManager
- getOwnerAddress() - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
- getOwners() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- getOwners() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
-
Returns the set of nodes where this transaction information is maintained.
- getOwners(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
-
Deprecated.Since 9.0, please use
getCacheTopology().getWriteOwners(key)
instead. - getOwners(Object) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
- getOwners(Collection<Object>) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
-
Deprecated.Since 9.0, please use
getCacheTopology().getWriteOwners(keys)
instead. - getOwners(Collection<Object>) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
- getOwnershipLevel() - Method in class org.infinispan.lock.api.ClusteredLockConfiguration
- getParameter(String) - Method in class org.infinispan.commons.dataconversion.MediaType
- getParameter(Map<String, String>, String) - Method in class org.infinispan.server.core.admin.AdminServerTask
- getParameterClasses() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- getParameterLazy(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- getParameterName(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
-
Deprecated.Singe 9.4, please use
ComponentMetadata.InjectMethodMetadata.getDependencyName(int)
instead. - getParameterNames() - Method in interface org.infinispan.objectfilter.ObjectFilter
-
Returns the parameter names or an empty Set if there are no parameters.
- getParameterNames() - Method in class org.infinispan.rest.InfinispanRequest
- getParameters() - Method in class org.infinispan.commons.dataconversion.MediaType
- getParameters() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- getParameters() - Method in interface org.infinispan.objectfilter.ObjectFilter
- getParameters() - Method in interface org.infinispan.query.dsl.ParameterContext
-
Returns the named parameters Map.
- getParameters() - Method in class org.infinispan.rest.InfinispanRequest
- getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheCreateTask
- getParameters() - Method in class org.infinispan.server.core.admin.embeddedserver.CacheNamesTask
- 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 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
- getParameterValue(String) - Method in class org.infinispan.rest.InfinispanRequest
- getParameterValues(String) - Method in class org.infinispan.rest.InfinispanRequest
- getParent() - Method in class org.infinispan.io.GridFile
- getParentFile() - Method in class org.infinispan.io.GridFile
- getParserContext(Class<? extends ConfigurationParser>) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- getPassivations() - Method in interface org.infinispan.eviction.PassivationManager
- getPassivations() - Method in interface org.infinispan.stats.ClusterCacheStats
- getPassword() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- getPath() - Method in class org.infinispan.io.GridFile
-
Returns path of this file.
- getPath() - Method in interface org.infinispan.objectfilter.SortField
-
The field path.
- getPendingActions() - Method in class org.infinispan.util.concurrent.ActionSequencer
- getPendingCH() - Method in class org.infinispan.topology.CacheTopology
-
The future consistent hash.
- getPendingCH() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- 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.stats.wrappers.ExtendedStatisticInterceptor
- getPercentageWriteTransactions() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getPercentile(PercentileStatistic, int) - Method in class org.infinispan.stats.CacheStatisticCollector
- getPercentile(PercentileStatistic, int) - Method in class org.infinispan.stats.CacheStatisticManager
- getPercentileLocalReadOnlyTransaction(int) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getPercentileLocalRWriteTransaction(int) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getPercentileRemoteReadOnlyTransaction(int) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getPercentileRemoteWriteTransaction(int) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getPermissions() - Method in interface org.infinispan.security.Role
-
Returns the list of permissions associated with this role
- getPersistenceMode(Storage) - Static method in class org.infinispan.counter.util.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
- getPersistentUUID() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- getPhase() - Method in class org.infinispan.topology.CacheTopology
- getPhase() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- 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.
- 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.ServerAddress
- getPostStartMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
- getPrefix(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- getPreparedTransaction(Xid) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
Local call returning the remote transaction identified by the supplied xid or null.
- getPreparedTransaction(Xid) - 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
- getPrimaryLocation(Object) - Method in interface org.infinispan.distribution.DistributionManager
-
Deprecated.Since 9.0, please use
getCacheTopology().getDistributionInfo(key)
instead. - getPrimaryOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
-
Deprecated.Since 9.0, please use
getCacheTopology().getDistributionInfo(key).primary()
instead. - getPrimaryOwner(String, Object) - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- getPrimarySegmentsForOwner(Address) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Returns the segments that this cache member is the primary owner for.
- 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.
- getPriority() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
- getPrivateSingletonSetClass() - Static method in class org.infinispan.marshall.exts.CollectionExternalizer
- getPrivateSynchronizedSetClass() - Static method in class org.infinispan.marshall.exts.CollectionExternalizer
- getPrivilegedInternalEntry(AdvancedCache<Object, V>, Object, boolean) - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- 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
- getProjection() - Method in class org.infinispan.query.remote.client.ContinuousQueryResult
- getProjection() - Method in class org.infinispan.query.remote.client.FilterResult
- getProjectionSize() - Method in class org.infinispan.query.remote.client.QueryResponse
- getProjectionTypes() - Method in interface org.infinispan.objectfilter.ObjectFilter
- getProperty(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- getProperty(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- getProperty(String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
-
Retrieves a state property
- 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
- getProtofile(String) - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
-
Gets the contents of a registered *.proto schema file.
- getProtofileNames() - Method in interface org.infinispan.query.remote.client.ProtobufMetadataManagerMBean
-
Get the full names of all registered schema files.
- getPushStateStatus() - Method in class org.infinispan.xsite.XSiteAdminOperations
- getQualifiedName() - Method in class org.infinispan.server.core.AbstractProtocolServer
- getQuery() - Method in class org.infinispan.query.remote.json.JsonQueryRequest
- getQuery(String, IndexedQueryMode, Class<?>...) - Method in interface org.infinispan.query.SearchManager
-
Builds a
CacheQuery
from an Ickle query string. - getQuery(Query, Class<?>...) - Method in interface org.infinispan.query.SearchManager
- getQuery(Query, IndexedQueryMode, Class<?>...) - Method in interface org.infinispan.query.SearchManager
-
This is a simple method that will just return a
CacheQuery
, filtered according to a set of classes passed in. - getQuery(QueryDefinition, IndexedQueryMode, IndexedTypeMap<CustomTypeMetadata>) - Method in interface org.infinispan.query.spi.SearchManagerImplementor
-
Creates a cache query based on a
QueryDefinition
and a custom metadata. - getQueryFactory(Cache<?, ?>) - Static method in class org.infinispan.query.Search
-
Obtain the query factory for building DSL based Ickle queries.
- getQueryFromJSON(byte[]) - Static method in class org.infinispan.query.remote.json.JsonQueryReader
- getQueryMode() - Method in class org.infinispan.query.remote.json.JsonQueryRequest
- getQueryString() - Method in interface org.infinispan.query.dsl.Query
-
Returns the Ickle query string.
- getQueryString() - Method in class org.infinispan.query.remote.client.QueryRequest
- getQueueSize() - Method in class org.infinispan.executors.ManageableExecutorService
- getRackId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- getRackId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
- getRackMachines(String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
- getRackNodes(String, String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
- getRaw() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
-
Gets the internal buffer array.
- getRaw() - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
- getRaw() - Method in class org.infinispan.io.MarshalledValueByteStream
- getRawBuffer() - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
-
Gets the internal buffer array.
- getRawBuffer() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
-
Deprecated.Gets the internal buffer array.
- getRawContext() - Method in class org.infinispan.rest.InfinispanRequest
- getRawRequest() - Method in class org.infinispan.rest.InfinispanRequest
- getReadableChannel(String) - Method in class org.infinispan.io.GridFilesystem
-
Opens a ReadableGridFileChannel for reading from the file denoted by the given file path.
- getReadConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
- getReadConsistentHash() - Method in class org.infinispan.topology.CacheTopology
-
Read operations should always go to the "current" owners.
- getReadConsistentHashAtEnd() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
- getReadConsistentHashAtStart() - Method in interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
- getReadOnlyAtomicMap(Cache<MK, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
-
Retrieves an atomic map from a given cache, stored under a given key, for reading only.
- getReadTimeout() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
- getReadWriteRatio() - Method in interface org.infinispan.stats.CacheContainerStats
- getReadWriteRatio() - Method in interface org.infinispan.stats.ClusterCacheStats
- 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 interface org.infinispan.statetransfer.StateTransferManager
- getRebalancingStatus() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- 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
- getRebalancingStatus(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- getReceiveBufferSize() - Method in class org.infinispan.server.core.transport.NettyTransport
- getReceiveBufferSize() - Method in interface org.infinispan.server.core.transport.Transport
- getRegisteredComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Returns an immutable set containing all the components that exists in the repository at this moment.
- 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 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.stats.container.StatisticsSnapshot
- getRemoteBias(Object) - Method in interface org.infinispan.scattered.BiasManager
- getRemoteCache() - Method in class org.infinispan.persistence.remote.RemoteStore
- getRemoteExecutor() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- getRemoteGetExecutionTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getRemoteGlobalTransaction() - Method in interface org.infinispan.transaction.TransactionTable
- getRemoteIndex() - Method in enum org.infinispan.stats.container.ExtendedStatistic
- getRemoteIndex(ExtendedStatistic) - Static method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- getRemoteLockIntention() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- getRemotePutExecutionTime() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getRemoteSiteNames() - Method in exception org.infinispan.xsite.BackupFailureException
- getRemoteStatsSize() - Static method in enum org.infinispan.stats.container.ExtendedStatistic
- getRemoteStoreBuilder() - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- getRemoteTopGets() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getRemoteTopPuts() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getRemoteTransaction(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- 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.
- getRemoveHits() - Method in interface org.infinispan.stats.Stats
- getRemoveMisses() - Method in interface org.infinispan.stats.Stats
- getReplicationCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getReplicationDegree() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getReplicationFailures() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- GetRequest - org.infinispan.server.memcached.MemcachedOperation
- getRequestId() - Method in class org.infinispan.remoting.transport.AbstractRequest
- 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
- 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
- getResourceDMBean(Object) - Method in class org.infinispan.jmx.AbstractJmxRegistration
- getResourceDMBean(Object, String) - Method in class org.infinispan.jmx.AbstractJmxRegistration
- getResourceDMBeansFromComponents(Collection<ComponentRef<?>>) - Method in class org.infinispan.jmx.AbstractJmxRegistration
- getResources(String) - Method in class org.infinispan.commons.util.AggregatedClassLoader
- 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.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
- getRestChannelInitializer() - Method in class org.infinispan.rest.RestServer
-
Returns Netty Channel Initializer for REST.
- getResultFunction() - Method in class org.infinispan.server.hotrod.iteration.IterableIterationResult
- getResults() - Method in class org.infinispan.query.remote.client.QueryResponse
- getResultSize() - Method in interface org.infinispan.query.CacheQuery
-
Gets the total number of results matching the query, ignoring pagination (firstResult, maxResult).
- getResultSize() - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
- getResultSize() - Method in class org.infinispan.query.clustered.QueryResponse
- getResultSize() - Method in interface org.infinispan.query.dsl.Query
-
Gets the total number of results matching the query, ignoring pagination (firstResult, maxResult).
- getResultType() - Method in class org.infinispan.query.remote.client.ContinuousQueryResult
- getRetrievals() - Method in interface org.infinispan.stats.Stats
- getReturnType() - Method in class org.infinispan.factories.components.JmxOperationMetadata
- getRootCause(Throwable) - Method in class org.infinispan.jmx.ResourceDMBean
- getRoutingTableAsString() - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Returns a string containing all the segments and their associated addresses.
- getRpcManager() - Method in interface org.infinispan.AdvancedCache
-
Returns the component in charge of communication with other caches in the cluster.
- getRpcOptionsBuilder(ResponseMode) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Deprecated.Since 9.2, please use
RpcManager.getSyncRpcOptions()
instead. - getRpcOptionsBuilder(ResponseMode) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getRpcOptionsBuilder(ResponseMode) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- getRpcOptionsBuilder(ResponseMode, DeliverOrder) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Deprecated.Since 9.2, please use
RpcManager.getSyncRpcOptions()
instead. - getRpcOptionsBuilder(ResponseMode, DeliverOrder) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getRpcOptionsBuilder(ResponseMode, DeliverOrder) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- getRunningActions() - Method in class org.infinispan.util.concurrent.ActionSequencer
- getRunningCacheCount() - Method in class org.infinispan.manager.DefaultCacheManager
- getRunningStateTransfer() - Method in class org.infinispan.xsite.XSiteAdminOperations
-
for debug only!
- getRunningStateTransfers() - Method in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
- getRunningStateTransfers() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- getSaslClientFactories() - Static method in class org.infinispan.commons.util.SaslUtils
-
Returns an iterator of all of the registered
SaslClientFactory
s where the order is based on the order of the Provider registration and/or class path order. - getSaslClientFactories(ClassLoader, boolean) - Static method in class org.infinispan.commons.util.SaslUtils
-
Returns an iterator of all of the registered
SaslClientFactory
s where the order is based on the order of the Provider registration and/or class path order. - getSaslServerFactories() - Static method in class org.infinispan.commons.util.SaslUtils
-
Returns an iterator of all of the registered
SaslServerFactory
s where the order is based on the order of the Provider registration and/or class path order. - getSaslServerFactories(ClassLoader, boolean) - Static method in class org.infinispan.commons.util.SaslUtils
-
Returns an iterator 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
- getScheduledTasks() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- getSchema() - Method in interface org.infinispan.configuration.parsing.XMLExtendedStreamReader
-
Returns the schema of currently being processed
- getSchemaVersion() - Static method in class org.infinispan.Version
- getScope() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- getScope() - Method in class org.infinispan.factories.components.ComponentMetadata
- 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.
- getSearchManager(Cache<?, ?>) - Static method in class org.infinispan.query.Search
-
Obtain the
SearchManager
object for a cache. - getSecurityPermission() - Method in enum org.infinispan.security.AuthorizationPermission
- getSegment(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Deprecated.Since 9.0, please use
KeyPartitioner.getSegment(Object)
orLocalizedCacheTopology.getSegment(Object)
instead. - getSegment(Object) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
-
Obtains the segment for a key.
- getSegment(Object) - Method in class org.infinispan.distribution.LocalizedCacheTopology
- getSegmentDistribution(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
- getSegmentForKey(Object) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- getSegmentId() - Method in class org.infinispan.statetransfer.StateChunk
- getSegments() - Method in class org.infinispan.statetransfer.InboundTransferTask
-
Returns a copy of segments currently tied to this task
- getSegments() - Method in class org.infinispan.statetransfer.OutboundTransferTask
- getSegments() - Method in class org.infinispan.statetransfer.StateRequestCommand
- getSegmentsForOwner(Address) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Returns the segments owned by a cache member.
- getSegmentSize(int) - Static method in class org.infinispan.commons.util.Util
-
Returns the size of each segment, given a number of segments.
- getSegmentState(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
- getSendBufferSize() - Method in class org.infinispan.server.core.transport.NettyTransport
- getSendBufferSize() - Method in interface org.infinispan.server.core.transport.Transport
- 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
- getSendingSiteName() - Method in class org.infinispan.xsite.XSiteAdminOperations
- 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.query.remote.client.BaseProtoStreamMarshaller
-
Subclasses must implement this method in order to provide a way to lookup the
SerializationContext
- getSerializationContext() - Method in class org.infinispan.query.remote.CompatibilityProtoStreamMarshaller
- getServerAddress() - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- getSession(String) - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- getSession(String, boolean) - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
-
Returns session with optional parameter whether or not update time accessed.
- getShardFromKey(Object) - Method in class org.infinispan.query.affinity.ShardAllocationManagerImpl
- getShardFromKey(Object) - Method in interface org.infinispan.query.affinity.ShardAllocatorManager
- getShardFromSegment(int) - Method in class org.infinispan.query.affinity.ShardAllocationManagerImpl
- getShardFromSegment(int) - Method in interface org.infinispan.query.affinity.ShardAllocatorManager
- getShardIdentifier(Class<?>, Serializable, String, Document) - Method in class org.infinispan.query.affinity.AffinityShardIdentifierProvider
- getShardIdentifiersForDeletion(Class<?>, Serializable, String) - Method in class org.infinispan.query.affinity.AffinityShardIdentifierProvider
- getShardIdentifiersForQuery(FullTextFilterImplementor[]) - Method in class org.infinispan.query.affinity.AffinityShardIdentifierProvider
- getShards() - Method in class org.infinispan.query.affinity.ShardAllocationManagerImpl
- getShards() - Method in interface org.infinispan.query.affinity.ShardAllocatorManager
- getShardsForModification(Address) - Method in class org.infinispan.query.affinity.ShardAllocationManagerImpl
- getShardsForModification(Address) - Method in interface org.infinispan.query.affinity.ShardAllocatorManager
- getSharedLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
- getSiteId() - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- getSiteId() - Method in interface org.infinispan.remoting.transport.TopologyAwareAddress
- getSiteName() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- getSiteName() - Method in class org.infinispan.xsite.XSiteBackup
- getSiteNodes(String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
- getSiteRacks(String) - Method in class org.infinispan.distribution.topologyaware.TopologyInfo
- getSitesMissingCoordinator(Collection<Address>) - Method in interface org.infinispan.xsite.statetransfer.XSiteStateProvider
- getSitesMissingCoordinator(Collection<Address>) - Method in class org.infinispan.xsite.statetransfer.XSiteStateProviderImpl
- 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.
- getSize() - Method in class org.infinispan.lucene.FileMetadata
- 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
- getSnapshot() - Method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- 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
- getSource() - Method in class org.infinispan.statetransfer.InboundTransferTask
- getStableCacheTopology(String) - Method in interface org.infinispan.topology.LocalTopologyManager
- getStableCacheTopology(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- getStableCacheTopology(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- getStableTopology() - Method in class org.infinispan.topology.CacheStatusResponse
- getStableTopology() - Method in class org.infinispan.topology.ClusterCacheStatus
- getStart() - Method in interface org.infinispan.tasks.TaskExecution
-
Returns the time when the task was started
- getStartMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
- getStartOffset() - Method in class org.infinispan.query.remote.client.QueryRequest
- getStartOffset() - Method in class org.infinispan.query.remote.json.JsonQueryRequest
- getState() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- getState(CacheXid) - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- getStateChunks() - Method in class org.infinispan.statetransfer.StateResponseCommand
- getStateFlags() - Method in interface org.infinispan.container.entries.StateChangingEntry
-
Deprecated.
- 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);
- getStateTransferProvider() - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Returns the store one configured with fetch persistent state, or null if none exist.
- getStateTransferProvider() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- getStateTransferProvider() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- getStatistics() - Method in interface org.infinispan.query.SearchManager
-
Get access to the Query specific statistics for this SearchManager instance
- getStatisticsEnabled() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
-
Returns whether an interceptor's statistics are being captured.
- getStatisticsEnabled() - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
- getStatisticsEnabled() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- getStatisticsEnabled() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getStatisticValue(String) - Method in class org.infinispan.stats.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.manager.DefaultCacheManager
- getStats() - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Returns statistics for this cache manager since 7.1
- getStatus() - Method in interface org.infinispan.Cache
- 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 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.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.DummyBaseTransactionManager
-
Deprecated.Get the status of the transaction associated with the calling thread.
- getStatus() - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.Get the status of the transaction.
- getStatus() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
-
Deprecated.Get the status of the transaction.
- getStatus() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
- getStatus() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- 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 interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
-
The value represent transaction's state as described by the
status
field. - 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
- getStopMethods() - Method in class org.infinispan.factories.components.ComponentMetadata
- getStorageFormat() - Method in class org.infinispan.commons.dataconversion.BinaryEncoder
- getStorageFormat() - Method in interface org.infinispan.commons.dataconversion.Encoder
-
Returns the
MediaType
produced by this encoder or null if the storage format is not known. - getStorageFormat() - Method in class org.infinispan.commons.dataconversion.GenericJbossMarshallerEncoder
- getStorageFormat() - Method in class org.infinispan.commons.dataconversion.GlobalMarshallerEncoder
- getStorageFormat() - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
- getStorageFormat() - Method in class org.infinispan.commons.dataconversion.JavaSerializationEncoder
- getStorageFormat() - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
- getStorageMediaType() - Method in class org.infinispan.encoding.DataConversion
- getStoredValue() - Method in class org.infinispan.persistence.modifications.Store
- getStores() - Method in interface org.infinispan.stats.Stats
- getStores(Class<T>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
- getStores(Class<T>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- getStores(Class<T>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- getStoresAsString() - Method in interface org.infinispan.persistence.manager.PersistenceManager
- getStoresAsString() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- getStoresAsString() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- getStoreWrites() - Method in interface org.infinispan.stats.ClusterCacheStats
- getStream() - Method in class org.infinispan.commons.io.ByteBufferImpl
- getStreamResponse(HotRodHeader, HotRodServer, ByteBufAllocator, int, CacheEntry<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- getStreamResponse(HotRodHeader, HotRodServer, ByteBufAllocator, int, CacheEntry<byte[], byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- getStringMapping(Object) - Method in class org.infinispan.lucene.LuceneKey2StringMapper
- 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 interface org.infinispan.counter.api.CounterManager
-
Returns the
StrongCounter
with that specific name. - getSubgroupsMerged() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.MergeEvent
- getSubject() - Method in class org.infinispan.rest.InfinispanRequest
- 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 which is not of type
Group
- 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
- 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
- getSuspect() - Method in exception org.infinispan.remoting.transport.jgroups.SuspectException
- getSyncRpcOptions() - Method in interface org.infinispan.remoting.rpc.RpcManager
- getSyncRpcOptions() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getSyncRpcOptions() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- getSyncXSiteCount() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getSyncXSiteRequestsReceived() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- GetSystemPropertyAction - Class in org.infinispan.security.actions
-
GetSystemPropertyAction.
- GetSystemPropertyAction(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
- getTakeOffline() - Method in class org.infinispan.xsite.OfflineStatus
- getTakeOfflineAfterFailures(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
- getTakeOfflineMinTimeToWait(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
- getTarget() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- getTarget() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
- getTask() - Method in class org.infinispan.distexec.RunnableAdapter
- 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
- getTaskExecutionPolicy() - Method in interface org.infinispan.distexec.DistributedTask
-
Returns custom
DistributedTaskExecutionPolicy
for this task - getTaskFailoverPolicy() - Method in interface org.infinispan.distexec.DistributedTask
-
Returns custom
DistributedTaskFailoverPolicy
for this task - 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
- getTasks() - Method in class org.infinispan.server.core.admin.AdminOperationsHandler
- getTasks() - Method in interface org.infinispan.tasks.spi.TaskEngine
-
Returns the list of tasks managed by this engine
- getTasks() - Method in interface org.infinispan.tasks.TaskManager
-
Retrieves the list of all available tasks
- getTcpNoDelay() - Method in class org.infinispan.server.core.transport.NettyTransport
- getTcpNoDelay() - Method in interface org.infinispan.server.core.transport.Transport
- 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
- getThroughput() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getThrowable() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- getTimeout() - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
- getTimeout() - Method in class org.infinispan.server.hotrod.tx.table.TxState
- getTimeout() - Method in class org.infinispan.topology.CacheJoinInfo
- getTimeout() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- getTimeout() - Method in class org.infinispan.xsite.XSiteBackup
- 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
- getTimeSinceReset() - Method in interface org.infinispan.stats.Stats
- getTimeSinceStart() - Method in interface org.infinispan.stats.Stats
- getTimeToLiveSeconds() - Method in class org.infinispan.rest.InfinispanCacheAPIRequest
-
Returns
timeToLiveSeconds
header value. - getTopContendedKeys() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getTopKFrom(StreamSummaryContainer.Stat) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
- getTopKFrom(StreamSummaryContainer.Stat, int) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
- getTopKFromAsKeyString(StreamSummaryContainer.Stat) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
-
Same as
StreamSummaryContainer.getTopKFrom(org.infinispan.stats.topK.StreamSummaryContainer.Stat)
but the keys are returned in their String format. - getTopKFromAsKeyString(StreamSummaryContainer.Stat, int) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
-
Same as
StreamSummaryContainer.getTopKFrom(org.infinispan.stats.topK.StreamSummaryContainer.Stat, int)
but the keys are returned in their String format. - getTopLockedKeys() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- getTopLockFailedKeys() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- 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.statetransfer.OutboundTransferTask
- getTopologyId() - Method in class org.infinispan.statetransfer.StateRequestCommand
- getTopologyId() - Method in class org.infinispan.statetransfer.StateResponseCommand
- getTopologyId() - Method in class org.infinispan.statetransfer.TransactionInfo
- getTopologyId() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- getTopologyId() - Method in class org.infinispan.topology.CacheTopology
- getTopologyId() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- getTopologyId() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- getTopWriteSkewFailedKeys() - Method in class org.infinispan.stats.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
- getTotalLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
-
Returns the total number of locks held by this class.
- 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 interface org.infinispan.stats.Stats
-
Number of entries stored in cache since the cache started running.
- getTotalReadLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
- getTotalResults() - Method in interface org.infinispan.query.remote.client.BaseQueryResponse
- getTotalResults() - Method in class org.infinispan.query.remote.client.JsonClientQueryResponse
- getTotalResults() - Method in class org.infinispan.query.remote.client.QueryResponse
- getTotalSpace() - Method in class org.infinispan.io.GridFile
- getTotalSyncRpcOptions() - Method in interface org.infinispan.remoting.rpc.RpcManager
- getTotalSyncRpcOptions() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- getTotalSyncRpcOptions() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- getTotalWriteLockCount() - Method in class org.infinispan.util.concurrent.locks.StripedLock
- getTransaction() - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- getTransaction() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.Get the transaction associated with the calling thread.
- getTransaction() - Method in class org.infinispan.transaction.tm.EmbeddedBaseTransactionManager
- 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.transaction.lookup.DummyTransactionManagerLookup
-
Deprecated.
- 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
- getTransactionsForSegments(Address, int, IntSet) - Method in interface org.infinispan.statetransfer.StateProvider
-
Gets the list of transactions that affect keys from the given segments.
- getTransactionsForSegments(Address, int, IntSet) - Method in class org.infinispan.statetransfer.StateProviderImpl
- getTransactionSynchronizationRegistry() - Method in interface org.infinispan.transaction.lookup.TransactionSynchronizationRegistryLookup
-
Returns a new TransactionSynchronizationRegistry.
- getTransactionTable() - Method in class org.infinispan.factories.ComponentRegistry
- getTransactionTimeout() - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- 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.manager.DefaultCacheManager
- getTransport() - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Deprecated.Since 10.0, please use
EmbeddedCacheManager.getAddress()
,EmbeddedCacheManager.getMembers()
,EmbeddedCacheManager.getCoordinator()
- 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 class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- getTransportStatus() - Method in class org.infinispan.server.core.AbstractProtocolServer
- getTriangleOrderManager() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- getTrustManagerFactory(String, String, char[], ClassLoader) - Static method in class org.infinispan.commons.util.SslContextFactory
- getTxState() - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
- 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.components.JmxAttributeMetadata
- getType() - Method in class org.infinispan.factories.components.JmxOperationParameter
- 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.filter.EventType
- getType() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.Event
- 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.server.core.admin.AdminServerTask
- getType() - Method in class org.infinispan.statetransfer.StateRequestCommand
- 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.topology.CacheTopologyControlCommand
- getTypeClasses() - Method in class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
-
Deprecated.
- 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
-
Returns a collection of Class instances representing the types that this AdvancedExternalizer can marshall.
- getTypeClasses() - Method in class org.infinispan.commons.marshall.exts.EquivalenceExternalizer
- 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.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.compat.BiFunctionMapper.Externalizer
- getTypeClasses() - Method in class org.infinispan.compat.FunctionMapper.Externalizer
- 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.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.CollectionKeyFilter.Externalizer
- getTypeClasses() - Method in class org.infinispan.filter.CompositeKeyFilter.Externalizer
- getTypeClasses() - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
- getTypeClasses() - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
- getTypeClasses() - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter.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.interceptors.distribution.VersionedResult.Externalizer
- getTypeClasses() - Method in class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
- getTypeClasses() - Method in class org.infinispan.lucene.ChunkCacheKey.Externalizer
- getTypeClasses() - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
- getTypeClasses() - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
- getTypeClasses() - Method in class org.infinispan.lucene.FileMetadata.Externalizer
- getTypeClasses() - Method in class org.infinispan.lucene.FileReadLockKey.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.core.MarshalledEntryImpl.Externalizer
- getTypeClasses() - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
- 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.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.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.notifications.cachelistener.cluster.ClusterEvent.Externalizer
- getTypeClasses() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.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.cluster.MultiClusterEventCallable.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.KeyFilterAsCacheEventFilter.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.MigrationTask.Externalizer
- getTypeClasses() - Method in class org.infinispan.persistence.remote.upgrade.RemovedFilter.Externalizer
- getTypeClasses() - Method in class org.infinispan.query.clustered.NodeTopDocs.Externalizer
- getTypeClasses() - Method in class org.infinispan.query.clustered.QueryResponse.Externalizer
- getTypeClasses() - Method in class org.infinispan.remoting.MIMECacheEntry.Externalizer
- 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.rest.operations.mime.MimeMetadata.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.server.memcached.MemcachedMetadataExternalizer
- getTypeClasses() - Method in class org.infinispan.statetransfer.StateChunk.Externalizer
- getTypeClasses() - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
- 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.DldGlobalTransaction.Externalizer
-
Deprecated.
- getTypeClasses() - Method in class org.infinispan.transaction.xa.GlobalTransaction.Externalizer
- getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
- getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
-
Deprecated.
- getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
- getTypeClasses() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
-
Deprecated.
- getTypeClasses() - Method in class org.infinispan.util.IntSetExternalizer
- getTypeClasses() - Method in class org.infinispan.util.KeyValuePair.Externalizer
- getTypeClasses() - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
- getTypeSubtype() - Method in class org.infinispan.commons.dataconversion.MediaType
- getUnfinishedSegments() - Method in class org.infinispan.statetransfer.InboundTransferTask
-
Returns a copy of the unfinished segments
- 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.Since 9.0
- getUnreadBufferedCount() - Method in class org.infinispan.commons.marshall.jboss.ExtendedRiverUnmarshaller
-
Returns number unread buffered bytes.
- getUpdatedEntryVersions() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- getUsableSpace() - Method in class org.infinispan.io.GridFile
- getUseAsync() - Method in class org.infinispan.rest.InfinispanRequest
- getUserName() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- 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.DummyTransactionManagerLookup
-
Deprecated.
- 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.DummyTransactionManager
-
Deprecated.
- getUserTransaction() - Static method in class org.infinispan.transaction.tm.EmbeddedTransactionManager
- getValue() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Node
-
Deprecated.
- 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 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.ImmortalCacheEntry
- 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.metadata.MetadataMortalCacheEntry
- getValue() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- getValue() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- getValue() - Method in class org.infinispan.container.entries.MortalCacheEntry
- getValue() - Method in class org.infinispan.container.entries.NullCacheEntry
- getValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- getValue() - Method in class org.infinispan.container.entries.TransientCacheEntry
- getValue() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- 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 interface org.infinispan.marshall.core.MarshalledEntry
-
Returns the same value as
MarshalledEntry.getKeyBytes()
, but unmarshalled. - getValue() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
- 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
-
Retrieves the value of the entry being modified.
- 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.query.remote.client.ContinuousQueryResult
- getValue() - Method in class org.infinispan.query.remote.client.QueryRequest.NamedParameter
- 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.server.hotrod.ProtocolFlag
- getValue() - Method in class org.infinispan.util.KeyValuePair
- 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.stats.container.BaseExtendedStatisticsContainer
- getValue(ExtendedStatistic) - Method in interface org.infinispan.stats.container.ExtendedStatisticsContainer
- getValue(ExtendedStatistic) - Method in class org.infinispan.stats.TransactionStatistics
- getValueBytes() - Method in interface org.infinispan.marshall.core.MarshalledEntry
-
Returns the value in serialize format.
- getValueBytes() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
- getValueConfiguredFormat(String) - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- getValueDataConversion() - Method in interface org.infinispan.AdvancedCache
- 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
- getValueEncoder() - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Use
AdvancedCache.getValueDataConversion()
()} and thenDataConversion.getEncoder()
- getValueEquivalence() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- getValueMediaType() - Method in class org.infinispan.server.hotrod.HotRodHeader
- getValueWrapper() - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Use
AdvancedCache.getValueDataConversion()
()} and thenDataConversion.getWrapper()
- getVersion() - Method in interface org.infinispan.commons.api.BasicCache
-
Retrieves the version of Infinispan
- getVersion() - Method in interface org.infinispan.container.entries.versioned.Versioned
- getVersion() - Method in class org.infinispan.container.entries.VersionedRepeatableReadEntry
- 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.DefaultCacheManager
- 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
- getVersionGenerator() - Method in class org.infinispan.factories.ComponentRegistry
-
Caching shortcut for #getLocalComponent(VersionGenerator.class)
- getVersionShort() - Static method in class org.infinispan.Version
- getVersionShort(String) - Static method in class org.infinispan.Version
- getVersionsRead() - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Note: used in Repeatable Read + Write Skew + Clustering + Versioning.
- 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
- getWarningMessage(String, Location) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- 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
- getWhat() - Method in interface org.infinispan.tasks.TaskExecution
-
An optional context to which the task was applied.
- getWhere() - Method in interface org.infinispan.tasks.TaskExecution
-
The node/address where the task was initiated
- getWho() - Method in interface org.infinispan.tasks.TaskExecution
-
An optional name of the principal who has executed this task.
- getWithMetadataResponse(HotRodHeader, HotRodServer, ByteBufAllocator, CacheEntry<byte[], byte[]>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- getWithMetadataResponse(HotRodHeader, HotRodServer, ByteBufAllocator, CacheEntry<byte[], byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- GetWithVersionRequest - org.infinispan.server.memcached.MemcachedOperation
- getWorkerThreads() - Method in class org.infinispan.rest.RestServer
- getWorkerThreads() - Method in class org.infinispan.server.core.AbstractProtocolServer
-
Deprecated.Use the
AbstractProtocolServer.getExecutor()
to obtain information about the worker executor instead - getWorkerThreads() - Method in class org.infinispan.server.hotrod.HotRodServer
- getWorkerThreads() - Method in class org.infinispan.server.memcached.MemcachedServer
- getWrapper() - Method in class org.infinispan.encoding.DataConversion
- getWrapper(Class<? extends Wrapper>, byte) - Method in interface org.infinispan.marshall.core.EncoderRegistry
- getWrapper(Class<? extends Wrapper>, byte) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
- getWrapperClass() - Method in class org.infinispan.encoding.DataConversion
- getWritableChannel(String) - Method in class org.infinispan.io.GridFilesystem
-
Opens a WritableGridFileChannel for writing to the file denoted by pathname.
- getWritableChannel(String, boolean) - Method in class org.infinispan.io.GridFilesystem
-
Opens a WritableGridFileChannel for writing to the file denoted by pathname.
- getWritableChannel(String, boolean, int) - Method in class org.infinispan.io.GridFilesystem
-
Opens a WritableGridFileChannel for writing to the file denoted by pathname.
- getWriteConsistentHash() - Method in interface org.infinispan.distribution.DistributionManager
- 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 interface org.infinispan.notifications.cachelistener.event.TopologyChangedEvent
- 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
- getWriteSkewProbability() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- getWriteTimeout() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
- getXAResource() - Method in interface org.infinispan.AdvancedCache
-
Returns the
XAResource
associated with this cache which can be used to do transactional recovery. - 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.tm.DummyTransaction
-
Deprecated.
- getXid() - Method in class org.infinispan.transaction.xa.LocalXaTransaction
- getXid() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- getXid() - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
- getXid() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
-
Deprecated.
- getXid() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
- getXid() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
-
Transaction's id.
- GIBIBYTES - org.infinispan.commons.util.MemoryUnit
- GIGABYTES - org.infinispan.commons.util.MemoryUnit
- GLASSFISH - org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- global(boolean) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- GLOBAL - org.infinispan.configuration.parsing.Element
- GLOBAL - org.infinispan.configuration.parsing.ParserScope
-
The top-level scope at which cache containers, jgroups and threads are defined
- GLOBAL - org.infinispan.factories.scopes.Scopes
-
Components bounded to this scope can only be created by a
DefaultCacheManager
and exist in theDefaultCacheManager
'sComponentRegistry
. - GLOBAL - org.infinispan.registry.InternalCacheRegistry.Flag
-
means that this cache will be global to all nodes when running in clustered mode
- GLOBAL_MARSHALLER - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- GLOBAL_SCOPE - Static variable in interface org.infinispan.globalstate.ScopedPersistentState
- GLOBAL_STATE - org.infinispan.configuration.parsing.Element
- GLOBAL_TRANSACTION - Static variable in interface org.infinispan.commons.marshall.Ids
- globalACLCache() - Method in interface org.infinispan.security.GlobalSecurityManager
-
Returns the global ACL cache
- GlobalAuthorizationConfiguration - Class in org.infinispan.configuration.global
-
GlobalAuthorizationConfiguration.
- GlobalAuthorizationConfiguration(AttributeSet) - 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.AbstractComponentFactory
- GlobalComponentRegistry - Class in org.infinispan.factories
-
A global component registry where shared components are stored.
- GlobalComponentRegistry(GlobalConfiguration, EmbeddedCacheManager, Set<String>, ConfigurationManager) - Constructor for class org.infinispan.factories.GlobalComponentRegistry
-
Creates an instance of the component registry.
- globalConfiguration - Variable in class org.infinispan.factories.AbstractComponentFactory
- 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. - 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
- GlobalInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
-
InboundInvocationHandler
implementation that handles all theReplicableCommand
. - GlobalInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.GlobalInboundInvocationHandler
- globalJmxRegistration - Variable in class org.infinispan.jmx.CacheJmxRegistration
- globalJmxStatistics() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- globalJmxStatistics() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- globalJmxStatistics() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Global JMX configuration
- GlobalJmxStatisticsConfiguration - Class in org.infinispan.configuration.global
- GlobalJmxStatisticsConfigurationBuilder - Class in org.infinispan.configuration.global
-
Configures whether global statistics are gathered and reported via JMX for all caches under this cache manager.
- GlobalMarshaller - Class in org.infinispan.marshall.core
-
A globally-scoped marshaller.
- GlobalMarshaller() - Constructor for class org.infinispan.marshall.core.GlobalMarshaller
- GlobalMarshaller(Marshaller) - Constructor for class org.infinispan.marshall.core.GlobalMarshaller
- GlobalMarshallerEncoder - Class in org.infinispan.commons.dataconversion
-
Encoder that uses the GlobalMarshaller to encode/decode data.
- GlobalMarshallerEncoder(Marshaller) - Constructor for class org.infinispan.commons.dataconversion.GlobalMarshallerEncoder
- 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
- GlobalSecurityConfiguration - Class in 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.
- 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) - Constructor for class org.infinispan.configuration.global.GlobalStateConfiguration
- GlobalStateConfigurationBuilder - Class in org.infinispan.configuration.global
-
GlobalStateConfigurationBuilder.
- GlobalStateManager - Interface in org.infinispan.globalstate
-
GlobalStateManager.
- GlobalStateProvider - Interface in org.infinispan.globalstate
-
GlobalStateProvider.
- globalStatus() - Method in class org.infinispan.xsite.GlobalXSiteAdminOperations
- GlobalTransaction - Class in org.infinispan.transaction.xa
-
Uniquely identifies a transaction that spans all JVMs in a cluster.
- GlobalTransaction() - Constructor for class org.infinispan.transaction.xa.GlobalTransaction
-
empty ctor used by externalization.
- GlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.GlobalTransaction
- GlobalTransaction.AbstractGlobalTxExternalizer<T extends GlobalTransaction> - Class in org.infinispan.transaction.xa
- 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
- GlobalXSiteAdminOperations - Class in org.infinispan.xsite
-
A per-container (cache manager) cross-site admin operations.
- GlobalXSiteAdminOperations() - Constructor for class org.infinispan.xsite.GlobalXSiteAdminOperations
- 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
- GridFile - Class in org.infinispan.io
-
Subclass of File to iterate through directories and files in a grid
- GridFile.Metadata - Class in org.infinispan.io
- GridFilesystem - Class in org.infinispan.io
-
Entry point for GridFile and GridInputStream / GridOutputStream
- GridFilesystem(Cache<String, byte[]>, Cache<String, GridFile.Metadata>) - Constructor for class org.infinispan.io.GridFilesystem
- GridFilesystem(Cache<String, byte[]>, Cache<String, GridFile.Metadata>, int) - Constructor for class org.infinispan.io.GridFilesystem
-
Creates an instance.
- GridInputStream - Class in org.infinispan.io
- GridOutputStream - Class in org.infinispan.io
- Group - Annotation Type in org.infinispan.distribution.group
-
Identifies the key for a group.
- GROUP_NAME - org.infinispan.configuration.parsing.Attribute
- groupBy(String...) - Method in interface org.infinispan.query.dsl.QueryBuilder
- 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 - org.infinispan.configuration.parsing.Element
- groupers() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
-
Get's the current groupers in use
- GROUPERS - Static variable in class org.infinispan.configuration.cache.GroupsConfiguration
- groupManager - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- groups() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Configuration for various grouper definitions.
- groups() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
- GROUPS - 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
-
Checks that the left argument is greater than the given value.
- gte(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Checks that the left argument is greater than or equal to the given value.
- GUARANTEED_DELIVERY - org.infinispan.context.Flag
-
Using a synchronous cache (whether replicated or distributed) provides the cache caller guarantees that data has been sent to other cluster nodes correctly and has been applied successfully.
- GZIP - Static variable in class org.infinispan.commons.util.Base64
-
Deprecated.Specify that data should be gzip-compressed.
H
- H2 - org.infinispan.persistence.jdbc.DatabaseType
- handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
- handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
- handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
- handle(CacheRpcCommand, Reply, DeliverOrder) - Method in interface org.infinispan.remoting.inboundhandler.PerCacheInboundInvocationHandler
-
Handles the
CacheRpcCommand
from other node. - handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.TotalOrderTxPerCacheInboundInvocationHandler
- handle(CacheRpcCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- 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. - handleAny(ConfigurationBuilderHolder) - Method in interface org.infinispan.configuration.parsing.XMLExtendedStreamReader
-
Handle an
<xs:any>
-type nested element, passing in the given value, returning after the end of the element. - 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
- handleCacheShutdown(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- handleCacheStopped(CacheStoppedEvent) - Method in class org.infinispan.affinity.ListenerRegistration
- handleClear(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- handleClear(InvocationContext, VisitableCommand, Object) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- handleClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handleClearFailure(String) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
- handleClearFailure(String) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleClusterEvents(CacheEntryEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
- handleCommitCommand(InvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handleCommitFailure(String, Transaction) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
- handleCommitFailure(String, Transaction) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- 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.xsite.CustomFailurePolicy
- handleComputeIfAbsentFailure(String, K, Function<? super K, ? extends V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
-
Deprecated.The default behaviour of the visitXXX methods, which is to ignore the call and pass the call up to the next interceptor in the chain.
- handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderStateTransferInterceptor
- handleDefault(InvocationContext, VisitableCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- 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.
- handleEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handleFromCluster(Address, ReplicableCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.GlobalInboundInvocationHandler
- handleFromCluster(Address, ReplicableCommand, Reply, DeliverOrder) - Method in interface org.infinispan.remoting.inboundhandler.InboundInvocationHandler
-
Handles the
ReplicableCommand
from other node belonging to local site. - handleFromRemoteSite(String, XSiteReplicateCommand, Reply, DeliverOrder) - Method in class org.infinispan.remoting.inboundhandler.GlobalInboundInvocationHandler
- handleFromRemoteSite(String, XSiteReplicateCommand, Reply, DeliverOrder) - Method in interface org.infinispan.remoting.inboundhandler.InboundInvocationHandler
-
Handles the
ReplicableCommand
from remote site. - handleFunctionalReadManyCommand(InvocationContext, C, BaseDistributionInterceptor.ReadManyCommandHelper<C>) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- handleGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handleInMemoryExpiration(InternalCacheEntry<K, V>, long) - Method in interface org.infinispan.expiration.ExpirationManager
-
Deprecated.since 9.3 this method is not intended for external use
- handleInStoreExpiration(K) - Method in interface org.infinispan.expiration.ExpirationManager
-
Deprecated.since 9.3 this method is not intended for external use
- handleInStoreExpiration(MarshalledEntry<K, V>) - Method in interface org.infinispan.expiration.ExpirationManager
-
Deprecated.since 9.3 this method is not intended for external use
- 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
- handleMarshallingException(Throwable, Object) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
- handleNonTxWriteCommand(InvocationContext, AbstractDataWriteCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- handleObject(Object) - Method in class org.infinispan.container.entries.PrimitiveEntrySizeCalculator
- handlePrepareCommand(InvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handlePrepareFailure(String, Transaction) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
- handlePrepareFailure(String, Transaction) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handlePutAllFailure(String, Map<K, V>) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
- handlePutAllFailure(String, Map<K, V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handlePutFailure(String, K, V, boolean) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
- handlePutFailure(String, K, V, boolean) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handlePutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handlePutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handler - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
- handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
- handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
- handleReadManyCommand(InvocationContext, FlagAffectedCommand, Collection<?>) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
- handleReadWriteKeyFailure(String, K) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleReadWriteKeyValueFailure(String, K) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleReadWriteManyEntriesFailure(String, Map<? extends K, ? extends V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleReadWriteManyFailure(String, Collection<? extends K>) - Method in interface org.infinispan.xsite.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
- handleRebalance(String, CacheTopology, int, Address) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- 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
- handleRemoteCommand(VisitableCommand, boolean) - Method in interface org.infinispan.xsite.BackupReceiver
- handleRemoteCommand(VisitableCommand, boolean) - Method in class org.infinispan.xsite.BaseBackupReceiver
- handleRemotelyRetrievedKeys(InvocationContext, WriteCommand, List<?>) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- handleRemotelyRetrievedKeys(InvocationContext, WriteCommand, List<?>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- handleRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handleRemoveFailure(String, K, V) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
- handleRemoveFailure(String, K, V) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handleReplaceFailure(String, K, V, V) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
- handleReplaceFailure(String, K, V, V) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleRollbackCommand(InvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- handleRollbackFailure(String, Transaction) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
- handleRollbackFailure(String, Transaction) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handlerRemoved0(ChannelHandlerContext) - Method in class org.infinispan.server.core.transport.SaslQopHandler
- handles(String) - Method in class org.infinispan.server.core.admin.AdminOperationsHandler
- handles(String) - Method in interface org.infinispan.tasks.spi.TaskEngine
-
Returns whether this task engine knows about a specified named task
- handleSegments(boolean, IntSet, IntSet) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- handleShutdownRequest(String) - Method in interface org.infinispan.topology.ClusterTopologyManager
- handleShutdownRequest(String) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- handleSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- 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
- handleStableTopologyUpdate(String, CacheTopology, Address, int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- handleStateTransferControl(XSiteStateTransferControlCommand) - Method in interface org.infinispan.xsite.BackupReceiver
-
It handles the state transfer control from a remote site.
- handleStateTransferControl(XSiteStateTransferControlCommand) - Method in class org.infinispan.xsite.ClusteredCacheBackupReceiver
- handleStateTransferControl(XSiteStateTransferControlCommand) - Method in class org.infinispan.xsite.LocalCacheBackupReceiver
- handleStateTransferState(XSiteStatePushCommand) - Method in interface org.infinispan.xsite.BackupReceiver
-
It handles the state transfer state from a remote site.
- handleStateTransferState(XSiteStatePushCommand) - Method in class org.infinispan.xsite.ClusteredCacheBackupReceiver
- handleStateTransferState(XSiteStatePushCommand) - Method in class org.infinispan.xsite.LocalCacheBackupReceiver
- 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
- handleStatusRequest(int) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- handleTopology(TopologyChangedEvent<K, V>) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- 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
- handleTopologyUpdate(String, CacheTopology, AvailabilityMode, int, Address) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- handleTxFunctionalCommand(InvocationContext, C) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- handleTxWriteManyCommand(InvocationContext, C, Collection<K>, BiFunction<C, List<K>, C>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- handleTxWriteManyEntriesCommand(InvocationContext, C, Map<K, V>, BiFunction<C, Map<K, V>, C>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- handleUnmarshallingException(Throwable) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
- handleUnmarshallingException(Throwable, Class<?>) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller.DebuggingExceptionListener
- handleViewChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.affinity.ListenerRegistration
- handleViewChange(ViewChangedEvent) - Method in class org.infinispan.topology.ClusterTopologyManagerImpl.ClusterViewListener
- handleWriteManyCommand(InvocationContext, WriteCommand, Collection<K>, boolean) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- handleWriteManyCommand(InvocationContext, WriteCommand, Collection<K>, boolean) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
- handleWriteManyCommand(InvocationContext, WriteCommand, Collection<K>, boolean) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
- handleWriteManyCommand(InvocationContext, WriteCommand, Collection<K>, boolean) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
- handleWriteOnlyKeyFailure(String, K) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleWriteOnlyKeyValueFailure(String, K) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleWriteOnlyManyEntriesFailure(String, Map<? extends K, ? extends V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- handleWriteOnlyManyFailure(String, Collection<? extends K>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
- hasActiveTransfers() - Method in class org.infinispan.statetransfer.StateConsumerImpl
- hasAnyLockAcquired() - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
- hasAnyLockAtOrigin(DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- hasCharacteristics(int) - Method in class org.infinispan.commons.util.SpliteratorMapper
- 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
- hasEnum(long, Enum<?>) - Static method in class org.infinispan.commons.util.EnumUtil
- hasFactory(String) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
- hasFlag(byte) - Method in enum org.infinispan.server.hotrod.tx.ControlByte
- hasFlag(ProtocolFlag) - Method in class org.infinispan.server.hotrod.HotRodHeader
- 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() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Deprecated.Since 8.2, use
HashConfiguration.keyPartitioner()
instead. - 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(Hash) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Deprecated.Since 8.2, use
HashConfigurationBuilder.keyPartitioner(KeyPartitioner)
instead. - Hash - Interface in org.infinispan.commons.hash
-
Interface that governs implementations
- HASH - org.infinispan.configuration.parsing.Element
- HASH - Static variable in class org.infinispan.configuration.cache.HashConfiguration
- hashCode() - Method in class org.infinispan.atomic.DeltaCompositeKey
-
Deprecated.
- 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.dataconversion.MediaType
- hashCode() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Returns the hash code value for this set using the
Equivalence
function associated with it. - 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.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.AuthorizationConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.Configuration
- hashCode() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.HashConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.L1Configuration
- hashCode() - Method in class org.infinispan.configuration.cache.LockingConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.RecoveryConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.SecurityConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.cache.SyncConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
- hashCode() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
-
Deprecated.
- hashCode() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- 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.GlobalJmxStatisticsConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.SerializationConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
- hashCode() - Method in class org.infinispan.configuration.global.SiteConfiguration
- hashCode() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
- hashCode() - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- hashCode() - Method in class org.infinispan.configuration.global.TransportConfiguration
- hashCode() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
- 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.NumericVersion
- hashCode() - Method in class org.infinispan.container.versioning.SimpleClusteredVersion
- hashCode() - Method in class org.infinispan.counter.api.CounterConfiguration
- hashCode() - Method in class org.infinispan.encoding.DataConversion
- hashCode() - Method in class org.infinispan.functional.MetaParam.MetaEntryVersion
- hashCode() - Method in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
- hashCode() - Method in class org.infinispan.functional.MetaParam.MetaLong
- hashCode() - Method in class org.infinispan.globalstate.ScopedState
- hashCode() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
- hashCode() - Method in class org.infinispan.io.GridFile
- hashCode() - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
- hashCode() - Method in class org.infinispan.lucene.ChunkCacheKey
- hashCode() - Method in class org.infinispan.lucene.FileCacheKey
- hashCode() - Method in class org.infinispan.lucene.FileListCacheKey
- hashCode() - Method in class org.infinispan.lucene.FileMetadata
- hashCode() - Method in class org.infinispan.lucene.FileReadLockKey
- hashCode() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
- hashCode() - Method in class org.infinispan.metadata.EmbeddedMetadata
- hashCode() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
- hashCode() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- 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.RemoteServerConfiguration
- hashCode() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- hashCode() - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- hashCode() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
- hashCode() - Method in class org.infinispan.remoting.LocalInvocation
- hashCode() - Method in class org.infinispan.remoting.MIMECacheEntry
- 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.rpc.RpcOptionsBuilder
-
Deprecated.
- 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.rest.operations.mime.MimeMetadata
- hashCode() - Method in class org.infinispan.security.CachePermission
- 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.ServerAddress
- 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.server.memcached.MemcachedMetadata
- hashCode() - Method in class org.infinispan.stats.topK.StreamSummaryContainer
- 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.tm.DummyNoXaXid
-
Deprecated.Implementing an efficient hashCode is critical for performance:
- hashCode() - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.Must be defined for increased performance
- hashCode() - Method in class org.infinispan.transaction.tm.DummyXid
-
Deprecated.
- hashCode() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
- hashCode() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- hashCode() - Method in class org.infinispan.transaction.xa.GlobalTransaction
- hashCode() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- hashCode() - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
- hashCode() - Method in class org.infinispan.transaction.xa.recovery.SerializableXid
-
Deprecated.
- hashCode() - Method in class org.infinispan.util.ByteString
- hashCode() - Method in class org.infinispan.util.KeyValuePair
- 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.
- hashCode(Object) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- hashCode(Object) - Method in class org.infinispan.commons.equivalence.AnyServerEquivalence
-
Deprecated.
- hashCode(Object) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
-
Deprecated.
- hashCode(Object) - Method in interface org.infinispan.commons.equivalence.Equivalence
-
Deprecated.Returns a hash code value for the object passed.
- hashCode(Object) - Method in class org.infinispan.commons.equivalence.IdentityEquivalence
-
Deprecated.
- 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.
- 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
- hasLifespan() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- hasLocalBias(Object) - Method in interface org.infinispan.scattered.BiasManager
-
Check if we can read local data and update last-read timestamp for this key.
- 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.
- hasLockedKey(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- hasMaxIdle() - Method in class org.infinispan.metadata.EmbeddedMetadata.Builder
- hasModification(Class<?>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Checks if a modification of the given class (or subclass) is present in this transaction.
- 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.interceptors.base.CommandInterceptor
-
Deprecated.Note: Unlike
CommandInterceptor.getNext()
, this method does not ignore interceptors that do not extendCommandInterceptor
- 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
- 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.stats.CacheStatisticManager
- hasSharedCacheLoaderOrWriter(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
- hasSkipLocking() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
-
It checks if this command should acquire locks.
- hasSkipLocking(FlagAffectedCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
-
Deprecated.
- hasStringType() - Method in class org.infinispan.commons.dataconversion.MediaType
- 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
- hasZeroLockAcquisition() - Method in interface org.infinispan.util.concurrent.locks.RemoteLockCommand
- having(String) - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
- having(String) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Creates a condition on the given attribute path that is to be completed later by using it as a sub-condition.
- having(Expression) - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
- having(Expression) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Creates a condition on the given attribute path that is to be completed later by using it as a sub-condition.
- header - Variable in class org.infinispan.server.memcached.MemcachedDecoder
- header(String) - Method in class org.infinispan.rest.InfinispanRequest
- headers(String) - Method in class org.infinispan.rest.InfinispanRequest
- Health - Interface in org.infinispan.health
-
An entry point for checking health status.
- 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 - org.infinispan.health.HealthStatus
-
Given entity is healthy.
- 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
- hexDump(byte[]) - Static method in class org.infinispan.commons.util.Util
- hexDump(ByteBuffer) - 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
- HikariConnectionPool - Class in org.infinispan.persistence.jdbc.connectionfactory
- HikariConnectionPool(ClassLoader, PooledConnectionFactoryConfiguration) - Constructor for class org.infinispan.persistence.jdbc.connectionfactory.HikariConnectionPool
- 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 interface org.infinispan.query.remote.json.JSONConstants
- HITS - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- HitSerializer - Class in org.infinispan.query.remote.json
- HitSerializer() - Constructor for class org.infinispan.query.remote.json.HitSerializer
- 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.persistence.remote.configuration.RemoteServerConfiguration
- host() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- host() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- host(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
- host(String) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- host(String) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- host(String) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
The host to connect to
- 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 - org.infinispan.persistence.remote.configuration.Attribute
- HOST - org.infinispan.persistence.rest.configuration.Attribute
- HOST - Static variable in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- HOST - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- HostInfo - Interface in org.infinispan.health
-
Information about the host.
- HOTROD_10 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_11 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_12 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_13 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_20 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_21 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_22 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_23 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_24 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_25 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_26 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_27 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_28 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_29 - org.infinispan.server.hotrod.HotRodVersion
- HOTROD_WRAPPING - org.infinispan.persistence.remote.configuration.Attribute
- HotRodConstants - Interface in org.infinispan.server.hotrod
-
Defines constants defined by Hot Rod specifications.
- 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
-
HotRodEntryMarshaller.
- HotRodEntryMarshaller(ByteBufferFactory) - Constructor for class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
- 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) - 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
andHotRodCommandInitializer
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.CacheInfo - 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
- HotRodVersion - Enum in org.infinispan.server.hotrod
-
The various Hot Rod versions
- hotRodWrapping() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- hotRodWrapping(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- hotRodWrapping(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- 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 - org.infinispan.server.hotrod.TimeUnitValue
- HSQL - org.infinispan.persistence.jdbc.DatabaseType
- Http11RequestHandler - Class in org.infinispan.rest
-
Netty REST handler for HTTP/1.1
- Http11RequestHandler(RestServer) - Constructor for class org.infinispan.rest.Http11RequestHandler
-
Creates new
Http11RequestHandler
. - Http11To2UpgradeHandler - Class in org.infinispan.rest
-
Handler responsible for TLS/ALPN negotiation as well as HTTP/1.1 Upgrade header handling
- Http11To2UpgradeHandler(RestServer) - Constructor for class org.infinispan.rest.Http11To2UpgradeHandler
- Http20RequestHandler - Class in org.infinispan.rest
-
Netty REST handler for HTTP/2.0
- Http20RequestHandler(RestServer) - Constructor for class org.infinispan.rest.Http20RequestHandler
-
Creates new
Http20RequestHandler
. - httpVersion(HttpVersion) - Method in class org.infinispan.rest.InfinispanResponse
-
Adds HTTP version header.
I
- icf - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- id - Variable in class org.infinispan.transaction.xa.GlobalTransaction
- id() - Method in class org.infinispan.commons.dataconversion.BinaryEncoder
- id() - Method in class org.infinispan.commons.dataconversion.ByteArrayWrapper
- id() - Method in interface org.infinispan.commons.dataconversion.Encoder
-
Each encoder is associated with an unique id in order to optimize serialization.
- id() - Method in class org.infinispan.commons.dataconversion.GenericJbossMarshallerEncoder
- id() - Method in class org.infinispan.commons.dataconversion.GlobalMarshallerEncoder
- id() - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
- id() - Method in class org.infinispan.commons.dataconversion.IdentityWrapper
- id() - Method in class org.infinispan.commons.dataconversion.JavaSerializationEncoder
- id() - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
- 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 - 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 - Static variable in interface org.infinispan.query.ProjectionConstants
- ID_COLUMN - org.infinispan.persistence.jdbc.configuration.Element
- ID_COLUMN_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- ID_COLUMN_TYPE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- idColumnName() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- 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.TableManipulationConfiguration
- 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
- identity() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- 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 - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- IDENTITY_KEY - Static variable in class org.infinispan.encoding.DataConversion
- IDENTITY_ROLE_MAPPER - org.infinispan.configuration.parsing.Element
- IDENTITY_VALUE - Static variable in class org.infinispan.encoding.DataConversion
- IDENTITY_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
- IdentityAttributeCopier<T> - Class in org.infinispan.commons.configuration.attributes
-
IdentityAttributeCopier.
- IdentityEncoder - Class in org.infinispan.commons.dataconversion
-
Encoder that does not change the content.
- IdentityEncoder() - Constructor for class org.infinispan.commons.dataconversion.IdentityEncoder
- IdentityEquivalence<T> - Class in org.infinispan.commons.equivalence
-
Deprecated.
- IdentityEquivalence() - Constructor for class org.infinispan.commons.equivalence.IdentityEquivalence
-
Deprecated.
- 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
- 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
- idFromValue(Object) - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
- idFromValueAndType(Object, Class<?>) - Method in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
- 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
- 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. - ifMatchDoesntMatchEtag(Optional<String>, String) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- ifModifiedIsAfterEntryModificationDate(Optional<String>, Date) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- ifNoneMatchMathesEtag(Optional<String>, String) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- ifUnmodifiedIsBeforeEntryModificationDate(Optional<String>, Date) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- IGNORE - org.infinispan.configuration.cache.BackupFailurePolicy
- IGNORE_MODIFICATIONS - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- IGNORE_RETURN_VALUES - 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.
- ignoreCache - Variable in class org.infinispan.server.memcached.MemcachedDecoder
- ignoreCache(String) - Method in class org.infinispan.server.core.AbstractCacheIgnoreAware
- ignoreCache(String) - Method in interface org.infinispan.server.core.CacheIgnoreAware
-
Ignores a given cache if it wasn't before
- IGNORED_CACHES - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ignoredCaches() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ignoredCaches(Set<String>) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- ignoredCaches(Set<String>) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- ignoredCaches(Set<String>) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Sets the caches to be ignored
- 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
- ignoreModifications - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Deprecated.
- 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
- IllegalLifecycleState - org.infinispan.server.hotrod.OperationStatus
- IllegalLifecycleStateException - Exception in org.infinispan
-
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() - Constructor for exception org.infinispan.IllegalLifecycleStateException
- IllegalLifecycleStateException(String) - Constructor for exception org.infinispan.IllegalLifecycleStateException
- IllegalLifecycleStateException(String, Throwable) - Constructor for exception org.infinispan.IllegalLifecycleStateException
- IllegalLifecycleStateException(Throwable) - Constructor for exception org.infinispan.IllegalLifecycleStateException
- 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.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.Externalizer - Class in org.infinispan.container.entries
- immutable() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- IMMUTABLE - org.infinispan.globalstate.ConfigurationStorage
-
Prevents the creation or removal of caches.
- IMMUTABLE_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
- IMMUTABLE_MAP - Static variable in interface org.infinispan.commons.marshall.Ids
- IMMUTABLE_SET - Static variable in interface org.infinispan.commons.marshall.Ids
- 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.
- 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.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 a new 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.ImmutableSubList<E> - 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.
- 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
-
A byte stream that is immutable.
- ImmutableMarshalledValueByteStream(byte[]) - Constructor for class org.infinispan.io.ImmutableMarshalledValueByteStream
- 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 - org.infinispan.persistence.leveldb.configuration.Element
- IMPLEMENTATION_TYPE - org.infinispan.persistence.leveldb.configuration.Attribute
- implementationType() - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfiguration
-
Deprecated.
- implementationType(LevelDBStoreConfiguration.ImplementationType) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- 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
-
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
-
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 - org.infinispan.topology.RebalancingStatus
- IN_USE_BACKUP_SITES - Static variable in class org.infinispan.configuration.cache.SitesConfiguration
- InboundInvocationHandler - Interface in org.infinispan.remoting.inboundhandler
-
Interface to invoke when the
Transport
receives a command from other node or site. - InboundInvocationHandlerFactory - Class in org.infinispan.factories
-
Factory class that creates instances of
PerCacheInboundInvocationHandler
. - InboundInvocationHandlerFactory() - Constructor for class org.infinispan.factories.InboundInvocationHandlerFactory
- InboundTransferTask - Class in org.infinispan.statetransfer
-
Inbound state transfer task.
- InboundTransferTask(IntSet, Address, int, RpcManager, CommandsFactory, long, String, boolean) - Constructor for class org.infinispan.statetransfer.InboundTransferTask
- inc() - Method in class org.infinispan.commons.util.ByRef.Integer
- include(TopologyAwareAddress, TopologyAwareAddress) - Method in enum org.infinispan.manager.ClusterExecutionPolicy
- includeCurrentState() - Method 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
- includeUpper(boolean) - Method in interface org.infinispan.query.dsl.RangeConditionContext
- 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
- increment() - Method in interface org.infinispan.counter.api.SyncWeakCounter
- increment() - Method in interface org.infinispan.counter.api.WeakCounter
-
Increments the counter.
- 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.stats.CacheStatisticManager
-
Increments the statistic value.
- 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
- IncrementRequest - org.infinispan.server.memcached.MemcachedOperation
- incrementValue(ExtendedStatistic) - Method in class org.infinispan.stats.TransactionStatistics
-
Increments a statistic value.
- incrementVersion(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Generates a new version for an entry in given segment.
- index() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
Returns the indexing mode of this cache.
- index() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- index(int) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Specifies a position in the interceptor chain to place the new interceptor.
- index(Index) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
Indicates indexing mode
- Index - Enum in org.infinispan.configuration.cache
-
Used to configure indexing of entries in the cache for index-assisted searching.
- INDEX - org.infinispan.configuration.parsing.Attribute
- INDEX - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
- INDEX - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
- INDEXED_ENTITIES - org.infinispan.configuration.parsing.Element
- INDEXED_ENTITIES - Static variable in class org.infinispan.configuration.cache.IndexingConfiguration
- INDEXED_ENTITY - org.infinispan.configuration.parsing.Element
- indexedEntities() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
- IndexedFilter<K,V,C> - Interface in org.infinispan.notifications.cachelistener.filter
-
A marker interface for filters that can be handled efficiently by a
FilterIndexingServiceProvider
. - IndexedQueryMode - Enum in org.infinispan.query.dsl
-
Defines the execution mode of an indexed query.
- 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 - 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.
- indexLocalOnly() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
Deprecated.Use
IndexingConfiguration.index()
instead - indexLocalOnly(boolean) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
Deprecated.Use
IndexingConfigurationBuilder.index(Index)
instead - indexName - Variable in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- indexOf(Object) - Method in class org.infinispan.commons.util.ForwardingList
- indexOf(Object) - Method in class org.infinispan.commons.util.ImmutableListCopy
- IndexScopedKey - Interface in org.infinispan.lucene
-
Mostly used for internal abstraction: common type for all keys which need name scoping for different indexes.
- indexShareable() - Method in class org.infinispan.configuration.cache.IndexingConfiguration
-
Check if the indexes can be shared.
- IndexUpdateCommand - Class in org.infinispan.query.indexmanager
-
Custom RPC command containing an index update request for the Master IndexManager of a specific cache and index.
- IndexUpdateCommand(ByteString) - Constructor for class org.infinispan.query.indexmanager.IndexUpdateCommand
- IndexUpdateStreamCommand - Class in org.infinispan.query.indexmanager
-
Execute a stream operation
- IndexUpdateStreamCommand(ByteString) - Constructor for class org.infinispan.query.indexmanager.IndexUpdateStreamCommand
- InDoubtTxInfoImpl - Class in org.infinispan.transaction.xa.recovery
- InDoubtTxInfoImpl(Xid, long) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- InDoubtTxInfoImpl(Xid, long, IntSet) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- InDoubtTxInfoImpl(Xid, Long, Integer) - Constructor for class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- InDoubtTxInfoImpl.Externalizer - Class in org.infinispan.transaction.xa.recovery
- 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.
- InetAddressPrincipal - Class in org.infinispan.server.core.security
-
InetAddressPrincipal.
- InetAddressPrincipal(InetAddress) - Constructor for class org.infinispan.server.core.security.InetAddressPrincipal
- InetAddressPrincipal.Externalizer - Class in org.infinispan.server.core.security
- InfinispanCacheAPIRequest - Class in org.infinispan.rest
-
Representation of a HTTP request related to Cache API operations.
- InfinispanCacheResponse - Class in org.infinispan.rest
- 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.config
- InfinispanContainerCacheManagerBeanDefinitionParser() - Constructor for class org.infinispan.spring.config.InfinispanContainerCacheManagerBeanDefinitionParser
- InfinispanDefaultCacheFactoryBean<K,V> - Class in org.infinispan.spring
-
A
for creating a native default InfinispanFactoryBean
, delegating to aorg.infinispan.Cache
configurable
.org.infinispan.manager.CacheContainer
- InfinispanDefaultCacheFactoryBean() - Constructor for class org.infinispan.spring.InfinispanDefaultCacheFactoryBean
- InfinispanEmbeddedCacheManagerBeanDefinitionParser - Class in org.infinispan.spring.config
- InfinispanEmbeddedCacheManagerBeanDefinitionParser() - Constructor for class org.infinispan.spring.config.InfinispanEmbeddedCacheManagerBeanDefinitionParser
- InfinispanEmbeddedCacheManagerFactoryBean - Class in org.infinispan.spring.support.embedded
-
A
for creating anFactoryBean
instance.Infinispan EmbeddedCacheManager
- InfinispanEmbeddedCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
- InfinispanEmbeddedHttpSessionConfiguration - Class in org.infinispan.spring.session.configuration
- InfinispanEmbeddedHttpSessionConfiguration() - Constructor for class org.infinispan.spring.session.configuration.InfinispanEmbeddedHttpSessionConfiguration
- InfinispanEmbeddedSessionRepository - Class in org.infinispan.spring.session
-
Session Repository for Infinispan in Embedded mode.
- InfinispanEmbeddedSessionRepository(SpringCache) - Constructor for class org.infinispan.spring.session.InfinispanEmbeddedSessionRepository
-
Creates new repository based on
SpringCache
- InfinispanErrorResponse - Class in org.infinispan.rest
- InfinispanIndexManager - Class in org.infinispan.query.indexmanager
-
A custom IndexManager to store indexes in the grid itself.
- InfinispanIndexManager() - Constructor for class org.infinispan.query.indexmanager.InfinispanIndexManager
- InfinispanNamedEmbeddedCacheFactoryBean<K,V> - Class in org.infinispan.spring.support.embedded
-
A
for creating a nativeFactoryBean
named
Infinispan
, delegating to aorg.infinispan.Cache
configurable
.org.infinispan.manager.EmbeddedCacheManager
- InfinispanNamedEmbeddedCacheFactoryBean() - Constructor for class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
- InfinispanNamedRemoteCacheFactoryBean<K,V> - Class in org.infinispan.spring.support.remote
-
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.support.remote.InfinispanNamedRemoteCacheFactoryBean
- InfinispanNamespaceHandler - Class in org.infinispan.spring.config
-
NamespaceHandler
for Infinispan-based caches. - InfinispanNamespaceHandler() - Constructor for class org.infinispan.spring.config.InfinispanNamespaceHandler
- InfinispanNamespaceUtils - Class in org.infinispan.spring.config
- InfinispanNamespaceUtils() - Constructor for class org.infinispan.spring.config.InfinispanNamespaceUtils
- InfinispanRemoteCacheManagerBeanDefinitionParser - Class in org.infinispan.spring.config
- InfinispanRemoteCacheManagerBeanDefinitionParser() - Constructor for class org.infinispan.spring.config.InfinispanRemoteCacheManagerBeanDefinitionParser
- InfinispanRemoteCacheManagerFactoryBean - Class in org.infinispan.spring.support.remote
-
A
for creating anFactoryBean
instance.Infinispan RemoteCacheManager
- InfinispanRemoteCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
- InfinispanRemoteHttpSessionConfiguration - Class in org.infinispan.spring.session.configuration
- InfinispanRemoteHttpSessionConfiguration() - Constructor for class org.infinispan.spring.session.configuration.InfinispanRemoteHttpSessionConfiguration
- InfinispanRemoteSessionRepository - Class in org.infinispan.spring.session
-
Session Repository for Infinispan in client/server mode.
- InfinispanRemoteSessionRepository(SpringCache) - Constructor for class org.infinispan.spring.session.InfinispanRemoteSessionRepository
-
Creates new repository based on
SpringCache
- InfinispanRequest - Class in org.infinispan.rest
-
Representation of a HTTP request tailed for Infinispan-specific requests.
- InfinispanRequest(FullHttpRequest, ChannelHandlerContext, String, String, Map<String, List<String>>) - Constructor for class org.infinispan.rest.InfinispanRequest
- InfinispanResponse - Class in org.infinispan.rest
-
Representation of a HTTP response tailed for Infinispan-specific responses.
- InfinispanResponse(Optional<InfinispanRequest>) - Constructor for class org.infinispan.rest.InfinispanResponse
- InfinispanSearchRequest - Class in org.infinispan.rest.search
- InfinispanSearchRequest(SearchOperations, FullHttpRequest, ChannelHandlerContext, String, String, Map<String, List<String>>) - Constructor for class org.infinispan.rest.search.InfinispanSearchRequest
- InfinispanSearchResponse - Class in org.infinispan.rest.search
- INFINITE - 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 - org.infinispan.security.AuditResponse
- INFORMIX - org.infinispan.persistence.jdbc.DatabaseType
- init() - Method in class org.infinispan.spring.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
- init(Cache) - Method in class org.infinispan.xsite.AbstractCustomFailurePolicy
- init(Cache<K, V>) - Method in interface org.infinispan.xsite.CustomFailurePolicy
-
Invoked during the initialization phase.
- init(Configuration) - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
-
Deprecated.Use
JBossStandaloneJTAManagerLookup.init(org.infinispan.configuration.global.GlobalConfiguration)
instead sinceConfiguration
has no access to classloader any more. - init(Configuration) - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
-
Deprecated.Use
WildflyTransactionManagerLookup.init(GlobalConfiguration)
instead sinceConfiguration
has no access to classloader any more. - init(HashConfiguration) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
-
Initialization.
- init(GlobalConfiguration) - Method in class org.infinispan.transaction.lookup.JBossStandaloneJTAManagerLookup
- init(GlobalConfiguration) - Method in class org.infinispan.transaction.lookup.WildflyTransactionManagerLookup
- init(InitializationContext) - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
- init(InitializationContext) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- init(InitializationContext) - Method in class org.infinispan.persistence.cluster.ClusterLoader
- init(InitializationContext) - Method in class org.infinispan.persistence.file.SingleFileStore
- init(InitializationContext) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- init(InitializationContext) - Method in class org.infinispan.persistence.jpa.JpaStore
- init(InitializationContext) - Method in class org.infinispan.persistence.remote.RemoteStore
- init(InitializationContext) - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- init(InitializationContext) - Method in interface org.infinispan.persistence.spi.CacheLoader
-
Used to initialize a cache loader.
- init(InitializationContext) - Method in interface org.infinispan.persistence.spi.CacheWriter
-
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(SerializationContext) - Method in interface org.infinispan.query.remote.client.ProtostreamSerializationContextInitializer
- init(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.BaseLockingAction
- init(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.LockAction
- init(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.PendingTxAction
- init(RpcManager, CommandsFactory, ComponentRef<TransactionTable>, TransactionCoordinator, TransactionFactory) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- init(Transport, Configuration, KeyPartitioner) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
- init(StateConsumer, StateReceiver) - Method in class org.infinispan.statetransfer.StateResponseCommand
- init(StateProvider, BiasManager) - Method in class org.infinispan.statetransfer.StateRequestCommand
- init(BackupSender) - Method in class org.infinispan.xsite.XSiteAdminCommand
- INIT - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
- 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
- INITIAL_CLUSTER_SIZE - org.infinispan.configuration.parsing.Attribute
- INITIAL_CLUSTER_SIZE - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- INITIAL_CLUSTER_TIMEOUT - 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_TOPOLOGY_ID - Static variable in class org.infinispan.topology.ClusterCacheStatus
- INITIAL_VALUE - 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.
- 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, StreamingMarshaller, TimeService, ByteBufferFactory, MarshalledEntryFactory, ExecutorService) - Constructor for class org.infinispan.persistence.InitializationContextImpl
- initialize() - Method in interface org.infinispan.commons.configuration.attributes.AttributeInitializer
- initialize() - Method in class org.infinispan.query.indexmanager.LocalOnlyBackend
- initialize() - Method in interface org.infinispan.query.indexmanager.SwitchingBackend
- initialize(int, int) - Method in class org.infinispan.query.affinity.ShardAllocationManagerImpl
- initialize(int, int) - Method in interface org.infinispan.query.affinity.ShardAllocatorManager
-
Initializes the
ShardAllocatorManager
with the configured number of segments and shards. - initialize(Iterable<ModuleMetadataFileFinder>, ClassLoader) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
-
Initializes this repository.
- initialize(String, Properties, Similarity, WorkerBuildContext) - Method in class org.infinispan.query.affinity.AffinityIndexManager
- initialize(Properties, BuildContext) - Method in class org.infinispan.query.affinity.AffinityShardIdentifierProvider
- initialize(EmbeddedCacheManager) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Initialization entry point for the
LocalConfigurationStorage
- initialize(RpcManager, ExecutorService) - Method in class org.infinispan.query.affinity.AffinityErrorHandler
- initialize(XSiteStateConsumer) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- initialize(XSiteStateProvider, XSiteStateConsumer, XSiteStateTransferManager) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- 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
- INITIALIZING - org.infinispan.lifecycle.ComponentStatus
-
The
start()
method has been called but not yet completed. - INITIALIZING - 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 interface org.infinispan.counter.configuration.CounterConfigurationBuilder
-
Sets the counter's initial value.
- initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.DistributionLogic
- initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
- initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
- initKeySpecificLogic(boolean) - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
- initMBeanServer(GlobalConfiguration) - Method in class org.infinispan.jmx.AbstractJmxRegistration
- initTime - Variable in class org.infinispan.stats.TransactionStatistics
- inject(Cache<?, ?>, DistributionManager) - Method in class org.infinispan.query.affinity.ShardAllocationManagerImpl
- inject(ComponentRegistry) - Method in class org.infinispan.server.hotrod.tx.table.functions.TxFunction
- inject(EmbeddedCacheManager) - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- inject(EmbeddedCacheManager) - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
- inject(CommandAckCollector, BiasManager) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- Inject - Annotation Type in org.infinispan.factories.annotations
-
Used to annotate a method as one that is used to inject a registered component into another component.
- injectCache(Cache<K, V>) - Method in interface org.infinispan.stream.CacheAware
-
Method that is invoked when a cache is to be injected.
- injectDependencies() - Method in class org.infinispan.factories.AbstractComponentRegistry.Component
-
Deprecated.Injects dependencies into this component.
- injectDependencies(Cache, EncoderRegistry) - Method in class org.infinispan.server.hotrod.iteration.IterationFilter
- injectDependencies(GlobalConfiguration, EncoderRegistry, Configuration) - Method in class org.infinispan.encoding.DataConversion
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.compat.BiFunctionMapper
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.compat.FunctionMapper
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.filter.CompositeKeyFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.filter.CompositeKeyValueFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter
- 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.KeyFilterAsCacheEventFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterAsCacheEventFilter
- injectDependencies(ComponentRegistry) - Method in class org.infinispan.notifications.cachelistener.filter.KeyValueFilterConverterAsCacheEventFilterConverter
- injectFactoryForComponent(Class<?>, Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
-
Deprecated.For testing purposes only.
- InjectFieldMetadata(String, String, String, String, boolean) - Constructor for class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- 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. - inputKeys() - Method in interface org.infinispan.distexec.FailoverContext
-
Returns a list of input keys for this task.
- InputStream(InputStream) - Constructor for class org.infinispan.commons.util.Base64.InputStream
-
Deprecated.Constructs a
Base64.InputStream
in DECODE mode. - InputStream(InputStream, int) - Constructor for class org.infinispan.commons.util.Base64.InputStream
-
Deprecated.Constructs a
Base64.InputStream
in either ENCODE or DECODE mode. - inReplyTo(InfinispanRequest) - Static method in class org.infinispan.rest.InfinispanCacheResponse
-
Creates an
InfinispanResponse
as a reply to specificInfinispanRequest
. - inReplyTo(InfinispanSearchRequest) - Static method in class org.infinispan.rest.search.InfinispanSearchResponse
- INSERT_ORDER - org.infinispan.commons.equivalence.EquivalentLinkedHashMap.IterationOrder
-
Deprecated.
- insertSample(double) - Method in class org.infinispan.stats.percentiles.ReservoirSampler
- INSTANCE - org.infinispan.commons.executors.CachedThreadPoolExecutorFactory
- INSTANCE - org.infinispan.commons.executors.ScheduledThreadPoolExecutorFactory
- INSTANCE - org.infinispan.lock.api.OwnershipLevel
- INSTANCE - Static variable in class org.infinispan.commons.configuration.attributes.CollectionAttributeCopier
- INSTANCE - Static variable in class org.infinispan.commons.configuration.attributes.CopyConstructorAttributeCopier
- INSTANCE - Static variable in class org.infinispan.commons.configuration.attributes.IdentityAttributeCopier
- 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
- INSTANCE - Static variable in class org.infinispan.commons.dataconversion.IdentityWrapper
- INSTANCE - Static variable in class org.infinispan.commons.dataconversion.UTF8Encoder
- INSTANCE - Static variable in class org.infinispan.commons.equivalence.AnyServerEquivalence
-
Deprecated.
- INSTANCE - Static variable in class org.infinispan.commons.equivalence.ByteArrayEquivalence
-
Deprecated.
- 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.interceptors.EmptyAsyncInterceptorChain
- 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.LocalModeAddress
- INSTANCE - Static variable in class org.infinispan.rest.operations.StaticContent
- INSTANCE - Static variable in exception org.infinispan.statetransfer.AllOwnersLostException
- INSTANCE - Static variable in class org.infinispan.topology.HeartBeatCommand
- INSTANCE - Static variable in class org.infinispan.transaction.lookup.GenericTransactionManagerLookup
- 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
- instant() - Method in class org.infinispan.commons.time.DefaultTimeService
- instant() - Method in interface org.infinispan.commons.time.TimeService
- INSTANTIATED - org.infinispan.lifecycle.ComponentStatus
-
Object has been instantiated, but start() has not been called.
- INT - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- INT_SET - Static variable in interface org.infinispan.commons.marshall.Ids
- INT_SUMMARY_STATISTICS - Static variable in interface org.infinispan.commons.marshall.Ids
- 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 - org.infinispan.persistence.jdbc.DatabaseType
- interceptListenerInvocation(CacheEntryListenerInvocation<K, V>) - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
-
Starts handling an invocation that uses an
IndexedFilter
. - interceptor() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
-
Deprecated.Since 9.0, please use
InterceptorConfiguration.asyncInterceptor()
instead. - interceptor(AsyncInterceptor) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
An instance of the new custom interceptor to add to the configuration.
- interceptor(CommandInterceptor) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Deprecated.Since 9.0, please use
InterceptorConfigurationBuilder.interceptor(AsyncInterceptor)
instead. - INTERCEPTOR - 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
- interceptorChain - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- InterceptorChain - Class in org.infinispan.interceptors
-
Deprecated.Since 9.0, use
AsyncInterceptorChain
instead. Some methods will ignore the interceptors that do not extendCommandInterceptor
. - InterceptorChain() - Constructor for class org.infinispan.interceptors.InterceptorChain
-
Deprecated.
- 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() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
-
Deprecated.Since 9.0, please use
InterceptorConfiguration.sequentialInterceptorClass()
instead. - interceptorClass(Class<? extends AsyncInterceptor>) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
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
-
This builder defines details of a specific custom interceptor.
- interceptors() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
-
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
- INTERMEDIATE_OPERATIONS - Static variable in interface org.infinispan.commons.marshall.Ids
- 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 interface org.infinispan.registry.InternalCacheRegistry
-
Returns whether a particular internal cache has a specific flag
- InternalCacheRegistry - Interface in org.infinispan.registry
-
InternalCacheRegistry.
- InternalCacheRegistry.Flag - Enum in org.infinispan.registry
- InternalCacheValue<V> - Interface in org.infinispan.container.entries
-
A representation of an InternalCacheEntry that does not have a reference to the key.
- internalGetCache(String, String) - Method in class org.infinispan.manager.DefaultCacheManager
- internalMetadata(InternalCacheEntry) - Static method in class org.infinispan.persistence.PersistenceUtil
- internalMetadata(InternalCacheValue) - Static method in class org.infinispan.persistence.PersistenceUtil
- InternalMetadata - Interface in org.infinispan.metadata
- INTERVAL - org.infinispan.configuration.parsing.Attribute
- Intrinsics - Class in org.infinispan.server.hotrod
- Intrinsics() - Constructor for class org.infinispan.server.hotrod.Intrinsics
- 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
- INVALID_CHAR - Static variable in class org.infinispan.commons.hash.MurmurHash3
- invalidate(Object[]) - Method in interface org.infinispan.persistence.manager.OrderedUpdatesManager
- invalidate(Object[]) - Method in class org.infinispan.persistence.manager.OrderedUpdatesManagerImpl
- INVALIDATION - org.infinispan.configuration.parsing.ParsedCacheMode
- INVALIDATION_ASYNC - org.infinispan.configuration.cache.CacheMode
-
Data invalidated asynchronously.
- INVALIDATION_BATCH_SIZE - org.infinispan.configuration.parsing.Attribute
- INVALIDATION_BATCH_SIZE - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
- INVALIDATION_CACHE - org.infinispan.configuration.parsing.Element
- INVALIDATION_CACHE_CONFIGURATION - org.infinispan.configuration.parsing.Element
- INVALIDATION_CLEANUP_TASK_FREQUENCY - org.infinispan.configuration.parsing.Attribute
- INVALIDATION_SYNC - org.infinispan.configuration.cache.CacheMode
-
Data invalidated synchronously.
- 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
- InvalidationLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.InvalidationLogic
- invalidationMode - Variable in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- 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(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an invalid XML attribute value.
- 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
- InvalidIteration - org.infinispan.server.hotrod.OperationStatus
- InvalidLockException - Exception in org.infinispan.lucene
-
Thrown when a lock is in a unexpected state.
- InvalidLockException(String) - Constructor for exception org.infinispan.lucene.InvalidLockException
- InvalidMagicOrMsgId - org.infinispan.server.hotrod.OperationStatus
- InvalidResponse - Class in org.infinispan.remoting.responses
-
An invalid response
- InvalidResponse() - Constructor for class org.infinispan.remoting.responses.InvalidResponse
- 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
- invocation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- invocation - Variable in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
- 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 - Interface in org.infinispan.interceptors
-
Base interface for all callbacks used by
BaseAsyncInterceptor
andInvocationStage
methods. - InvocationContext - Interface in org.infinispan.context
-
A context that contains information pertaining to a given invocation.
- InvocationContextContainer - Interface in org.infinispan.context
-
Deprecated.Since 9.0, this interface is going to be moved to an internal package.
- InvocationContextFactory - Interface in org.infinispan.context
-
Factory for
InvocationContext
objects. - InvocationExceptionFunction - Interface in org.infinispan.interceptors
- InvocationFinallyAction - Interface in org.infinispan.interceptors
- InvocationFinallyFunction - Interface in org.infinispan.interceptors
- invocationHandler - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- InvocationStage - Class in org.infinispan.interceptors
-
A partial command invocation, either completed or in progress.
- InvocationStage() - Constructor for class org.infinispan.interceptors.InvocationStage
- InvocationSuccessAction - Interface in org.infinispan.interceptors
- InvocationSuccessFunction - Interface in org.infinispan.interceptors
- invoke() - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- invoke() - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
- invoke(String, Object[], String[]) - Method in class org.infinispan.jmx.ResourceDMBean
- 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(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Walks the command through the interceptor chain.
- 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
- 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
- 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>>, 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(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(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.distexec.DefaultExecutorService
-
Deprecated.
- 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>>, long, TimeUnit) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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
- invokeAsync() - Method in class org.infinispan.query.affinity.AffinityUpdateCommand
- invokeAsync() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
-
Invokes a query on a (remote) cache and returns results (list of keys).
- invokeAsync() - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- invokeAsync() - Method in class org.infinispan.query.indexmanager.IndexUpdateCommand
- invokeAsync() - Method in class org.infinispan.query.indexmanager.IndexUpdateStreamCommand
- invokeAsync() - Method in class org.infinispan.statetransfer.StateRequestCommand
- invokeAsync() - Method in class org.infinispan.statetransfer.StateResponseCommand
- invokeAsync() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- invokeAsync() - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
- invokeAsync() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- invokeAsync() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- invokeAsync() - Method in class org.infinispan.xsite.XSiteAdminCommand
- 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
- 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 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(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- 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 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
- invokeCommand(Address, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- 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 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
- invokeCommandOnAll(ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, long, DeliverOrder) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated.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 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
- invokeCommands(Collection<Address>, Function<Address, ReplicableCommand>, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- 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 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
- invokeCommandStaggered(Collection<Address>, ReplicableCommand, ResponseCollector<T>, RpcOptions) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- 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, VisitableCommand, InvocationExceptionFunction) - 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, VisitableCommand, InvocationFinallyAction) - 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, VisitableCommand, InvocationFinallyFunction) - 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. - invokeNextInterceptor(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.base.CommandInterceptor
-
Deprecated.Invokes the next interceptor in the chain.
- invokeNextThenAccept(InvocationContext, VisitableCommand, InvocationSuccessAction) - 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, VisitableCommand, InvocationSuccessFunction) - 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
- 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
- invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- invokeRemotely(Collection<Address>, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated.Since 9.2, please use
Transport.invokeCommand(Collection, ReplicableCommand, ResponseCollector, DeliverOrder, long, TimeUnit)
instead. - invokeRemotely(Collection<Address>, ReplicableCommand, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Deprecated.Since 9.2, please use
RpcManager.invokeCommand(Collection, ReplicableCommand, ResponseCollector, RpcOptions)
instead. - invokeRemotely(Collection<Address>, ReplicableCommand, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeRemotely(Collection<Address>, ReplicableCommand, RpcOptions) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, boolean, ResponseFilter, boolean, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, boolean, ResponseFilter, boolean, boolean) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated.
- invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
-
Deprecated.
- invokeRemotely(Map<Address, ReplicableCommand>, ResponseMode, long, ResponseFilter, DeliverOrder, boolean) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated.Since 9.2, please use
Transport.invokeRemotelyAsync(Collection, ReplicableCommand, ResponseMode, long, ResponseFilter, DeliverOrder, boolean)
instead. - invokeRemotely(Map<Address, ReplicableCommand>, RpcOptions) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Deprecated.Since 9.2, please use
RpcManager.invokeCommands(Collection, Function, ResponseCollector, RpcOptions)
instead. - invokeRemotely(Map<Address, ReplicableCommand>, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeRemotely(Map<Address, ReplicableCommand>, RpcOptions) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- invokeRemotely(InvocationContext, DataWriteCommand, Address) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- 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 interface org.infinispan.remoting.rpc.RpcManager
-
Invokes a command on remote nodes.
- invokeRemotelyAsync(Collection<Address>, ReplicableCommand, RpcOptions) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeRemotelyAsync(Collection<Address>, ReplicableCommand, RpcOptions) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- invokeXSite(Collection<XSiteBackup>, XSiteReplicateCommand) - Method in interface org.infinispan.remoting.rpc.RpcManager
-
Invokes the
XSiteReplicateCommand
to one or more remote sites. - invokeXSite(Collection<XSiteBackup>, XSiteReplicateCommand) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- invokeXSite(Collection<XSiteBackup>, XSiteReplicateCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- IO_THREADS - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- 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
- isAbsolute() - Method in class org.infinispan.io.GridFile
- 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.
- isAlive(Address) - Method in class org.infinispan.server.hotrod.tx.PrepareCoordinator
- isAllCompleted() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- isAllowed(Class<?>) - Static method in class org.infinispan.marshall.core.ExternallyMarshallable
- isAllowed(Object) - Static method in class org.infinispan.marshall.core.ExternallyMarshallable
- isAnnotationPresent(Class<?>, Class<? extends Annotation>) - Static method in class org.infinispan.commons.util.ReflectionUtil
-
Tests whether an annotation is present on a class.
- 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
- isAutoPersist() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- isAvailable() - Method in interface org.infinispan.notifications.cachelistener.event.PersistenceAvailabilityChangedEvent
- isAvailable() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- isAvailable() - Method in class org.infinispan.persistence.file.SingleFileStore
- isAvailable() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- isAvailable() - Method in interface org.infinispan.persistence.manager.PersistenceManager
- isAvailable() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- isAvailable() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- isAvailable() - Method in class org.infinispan.persistence.remote.RemoteStore
- isAvailable() - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- isAvailable() - Method in interface org.infinispan.persistence.spi.CacheLoader
- isAvailable() - Method in interface org.infinispan.persistence.spi.CacheWriter
- isAvailable() - Method in interface org.infinispan.persistence.spi.ExternalStore
- 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
- isBasicType(Class<?>) - Static method in class org.infinispan.commons.util.Util
- isBatchingEnabled() - Method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
- isBlocked() - Method in interface org.infinispan.transaction.totalorder.TotalOrderLatch
- isBlocked() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
- isBound() - Method in class org.infinispan.counter.configuration.StrongCounterConfiguration
- isCacheIgnored(String) - Method in class org.infinispan.server.core.AbstractCacheIgnoreAware
- isCacheIgnored(String) - Method in interface org.infinispan.server.core.CacheIgnoreAware
-
Queries whether the cache is ignored
- isCacheReady() - Method in class org.infinispan.persistence.cluster.ClusterLoader
-
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
- isCacheRebalancingEnabled(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- isCancelled() - Method in class org.infinispan.statetransfer.InboundTransferTask
- isCancelled() - Method in class org.infinispan.statetransfer.OutboundTransferTask
- 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
-
Verifies whether child is a child (dir or file) of parent
- isClasspathCorrect() - Method in class org.infinispan.commons.util.uberjar.ManifestUberJarDuplicatedJarsWarner
- isClasspathCorrect() - Method in interface org.infinispan.commons.util.uberjar.UberJarDuplicatedJarsWarner
-
Synchronously checks if classpath looks correct for Uber Jar usage.
- isClasspathCorrectAsync() - Method in class org.infinispan.commons.util.uberjar.ManifestUberJarDuplicatedJarsWarner
- isClasspathCorrectAsync() - Method in interface org.infinispan.commons.util.uberjar.UberJarDuplicatedJarsWarner
-
Asynchronously checks if classpath looks correct for Uber Jar usage.
- isClustered() - Method in enum org.infinispan.configuration.cache.CacheMode
- isClustered() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- 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
- 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.
- isCommandSentBeforeFirstTopology(int) - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- isCommit() - Method in enum org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
- isCommitted() - Method in interface org.infinispan.container.entries.MVCCEntry
- isCommitted() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- isCommitted() - Method in class org.infinispan.stats.TransactionStatistics
- isComparable(Object) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- isComparable(Object) - Method in class org.infinispan.commons.equivalence.AnyServerEquivalence
-
Deprecated.
- isComparable(Object) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
-
Deprecated.
- isComparable(Object) - Method in interface org.infinispan.commons.equivalence.Equivalence
-
Deprecated.Returns whether the given object is comparable.
- isComparable(Object) - Method in class org.infinispan.commons.equivalence.IdentityEquivalence
-
Deprecated.
- isCompletedSuccessfully() - Method in class org.infinispan.statetransfer.InboundTransferTask
- 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
- isConversionSupported(MediaType) - Method in class org.infinispan.encoding.DataConversion
- 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.DefaultCacheManager
- isCoordinator() - Method in interface org.infinispan.manager.EmbeddedCacheManager
- 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.
- isCurrentState() - Method in interface org.infinispan.notifications.cachelistener.event.CacheEntryEvent
- isDefaultRunning() - Method in class org.infinispan.manager.DefaultCacheManager
- isDefaultRunning() - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Tests whether the default cache is running.
- 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.
- isDeltaFilter() - Method in interface org.infinispan.objectfilter.FilterSubscription
- isDirectory() - Method in class org.infinispan.io.GridFile
- isDirectory() - Method in class org.infinispan.io.GridFile.Metadata
- isDistributed() - Method in enum org.infinispan.configuration.cache.CacheMode
- isDistributed() - Method in class org.infinispan.topology.ClusterCacheStatus
- 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.commons.equivalence.EquivalentHashMap.EntrySet
-
Deprecated.
- isEmpty() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- isEmpty() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Returns
true
if this set contains no elements. - 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.concurrent.ConcurrentHashSet
- isEmpty() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Returns true if this map contains no key-value mappings.
- 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.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.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.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.ConfigurationPropertiesOverrides
- isEmpty() - Method in class org.infinispan.statetransfer.CommitManager
- isEmpty() - Method in class org.infinispan.util.CollectionMapper
- isEmpty() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- isEmpty() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- isEnabled() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
- isEnabled() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- isEnabled() - Method in enum org.infinispan.configuration.cache.Index
-
Is indexing enabled?
- 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.PassivationManager
- isEnabled() - Method in interface org.infinispan.expiration.ExpirationManager
- isEnabled() - Method in interface org.infinispan.persistence.manager.PersistenceManager
- isEnabled() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- isEnabled() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- isEnabled() - Method in class org.infinispan.stats.topK.StreamSummaryContainer
- isEnabled() - Method in class org.infinispan.xsite.OfflineStatus
- isEncoded() - Method in interface org.infinispan.functional.FunctionalMap
-
Tells if the underlying cache is using encoding or not
- isEncodingChanged() - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- 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 interface org.infinispan.context.InvocationContext
- isEntryRemovedInContext(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- 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 class org.infinispan.container.entries.ImmortalCacheEntry
- isExpired() - Method in class org.infinispan.container.entries.ImmortalCacheValue
- isExpired() - Method in interface org.infinispan.container.entries.InternalCacheEntry
-
Deprecated.
- isExpired() - Method in interface org.infinispan.container.entries.InternalCacheValue
-
Deprecated.
- isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheValue
- isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheValue
- isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- isExpired() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheValue
- isExpired() - Method in class org.infinispan.container.entries.MortalCacheEntry
- isExpired() - Method in class org.infinispan.container.entries.MortalCacheValue
- 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.container.entries.TransientCacheEntry
- isExpired() - Method in class org.infinispan.container.entries.TransientCacheValue
- isExpired() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- isExpired() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
- isExpired() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
- 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.RemoteMetadata
- 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 interface org.infinispan.metadata.InternalMetadata
- 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
- isFetchEnabled - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- isFile() - Method in class org.infinispan.io.GridFile
- isFile() - Method in class org.infinispan.io.GridFile.Metadata
- 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
- 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.components.ComponentMetadata
- isHidden() - Method in class org.infinispan.io.GridFile
- isIBMJavaVendor() - Static method in class org.infinispan.commons.util.Util
- 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
- 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.
- isInternalCache(String) - Method in interface org.infinispan.registry.InternalCacheRegistry
-
Returns whether the cache is internal, i.e.
- isInTxScope() - Method in interface org.infinispan.context.InvocationContext
-
Returns true if this call is performed in the context of an transaction, false otherwise.
- isInTxScope() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- isInvalidation() - Method in enum org.infinispan.configuration.cache.CacheMode
-
Returns true if the mode is invalidation, either sync or async.
- isInvalidationMode - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- isIs() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
- isJoinComplete() - Method in interface org.infinispan.distribution.DistributionManager
-
Tests whether the current instance has completed joining the cluster
- isJoinComplete() - Method in interface org.infinispan.statetransfer.StateTransferManager
- isJoinComplete() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- isKeepAlive() - Method in class org.infinispan.rest.InfinispanResponse
-
Checks whether this is a Keep Alive type of response.
- isKeyEquals(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- isKeyLocalToNode(Address, Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Deprecated.Since 9.0, please use
LocalizedCacheTopology.isReadOwner(Object)
andLocalizedCacheTopology.isWriteOwner(Object)
instead. - 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.
- isL1Enabled - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- 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
- isLastChunk() - Method in class org.infinispan.statetransfer.StateChunk
- isLazy() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- isLoaded() - Method in interface org.infinispan.container.entries.CacheEntry
-
Deprecated.since 8.1
- 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
- isLocal() - Method in enum org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
- isLocal() - Method in enum org.infinispan.stats.container.ExtendedStatistic
- isLocal() - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl
- isLocal() - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager.InDoubtTxInfo
-
Returns true if the transaction information is also present on this node.
- isLocalOnly() - Method in enum org.infinispan.configuration.cache.Index
-
Deprecated.
- isLocalTransaction() - Method in class org.infinispan.stats.LocalTransactionStatistics
- isLocalTransaction() - Method in class org.infinispan.stats.RemoteTransactionStatistics
- isLocalTransaction() - Method in class org.infinispan.stats.TransactionStatistics
- isLocked() - Method in interface org.infinispan.lock.api.ClusteredLock
-
Returns a
CompletableFuture
holdingtrue
when the lock is locked andfalse
when the lock is released. - isLocked(Object) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- isLocked(Object) - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- 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
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
- isLowerBoundReached() - Method in exception org.infinispan.counter.exception.CounterOutOfBoundsException
- isManageable() - Method in class org.infinispan.factories.components.ComponentMetadata
- isManageable() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
- 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.commons.marshall.AbstractDelegatingMarshaller
- isMarshallable(Object) - Method in class org.infinispan.commons.marshall.IdentityMarshaller
- isMarshallable(Object) - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
- isMarshallable(Object) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- 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 class org.infinispan.commons.marshall.StringMarshaller
- isMarshallable(Object) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- isMarshallable(Object) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
- isMarshallable(Object) - Method in class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
- isMarshallableCandidate(Object) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- isMarshallableCandidate(Object) - Method in class org.infinispan.marshall.core.JBossMarshaller
- isMasterLocal() - Method in class org.infinispan.query.indexmanager.InfinispanIndexManager
- isMasterLocal() - Method in class org.infinispan.query.indexmanager.LazyInitializingBackend
- isMasterLocal() - Method in class org.infinispan.query.indexmanager.LockAcquiringBackend
- 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
- isMember(Principal) - Method in class org.infinispan.server.core.security.simple.SimpleGroupPrincipal
- isMergeView() - Method in interface org.infinispan.notifications.cachemanagerlistener.event.ViewChangedEvent
- isMetadata() - Method in class org.infinispan.server.hotrod.iteration.IterableIterationResult
- 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.notifications.cachelistener.filter.EventType
- 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
- isMultiChunked() - Method in class org.infinispan.lucene.FileMetadata
- isNext(int, long, int) - Method in class org.infinispan.distribution.TriangleOrderManager
- isNoNamespaceAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- isNotificationAllowed(FlagAffectedCommand, List<CacheEntryListenerInvocation<K, V>>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- isNull() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- 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
-
Checks that the left argument is null.
- isOffline() - Method in class org.infinispan.xsite.OfflineStatus
- 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
- ISOLATION - 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
- isOnePhaseTotalOrderCommit(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
- isOpen() - Method in class org.infinispan.io.WritableGridFileChannel
- isOpened() - Method in class org.infinispan.util.concurrent.ReclosableLatch
- isOriginatorMissing(GlobalTransaction) - Method in class org.infinispan.server.hotrod.tx.ServerTransactionOriginatorChecker
- isOriginatorMissing(GlobalTransaction, Collection<Address>) - Method in class org.infinispan.server.hotrod.tx.ServerTransactionOriginatorChecker
- 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.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- isOriginLocal() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- 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.
- isOSGiContext() - Static method in class org.infinispan.commons.util.Util
-
Tries to determine if the code is running in an OSGi context.
- isOwnershipChanged(TopologyChangedEvent<?, ?>, String) - Method in class org.infinispan.query.affinity.ShardAllocationManagerImpl
- isOwnershipChanged(TopologyChangedEvent<?, ?>, String) - Method in interface org.infinispan.query.affinity.ShardAllocatorManager
- isParallel() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- isParameterNameSet(int) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- isPersistent() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- IspnMBeanOperationInfo - Class in org.infinispan.jmx
-
Infinispan allows a different JMX operation name than the actual method name that gets invoked (see
ManagedOperation.name()
. - IspnMBeanOperationInfo(String, Method, String) - Constructor for class org.infinispan.jmx.IspnMBeanOperationInfo
- IspnMBeanOperationInfo(String, String, MBeanParameterInfo[], String, int, String) - Constructor for class org.infinispan.jmx.IspnMBeanOperationInfo
- IspnMBeanOperationInfo(String, String, MBeanParameterInfo[], String, int, Descriptor, String) - Constructor for class org.infinispan.jmx.IspnMBeanOperationInfo
- isPre() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- isPre() - Method in interface org.infinispan.notifications.cachelistener.event.Event
- isPreEvent() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
- isPreloaded() - Method in interface org.infinispan.persistence.manager.PersistenceManager
- isPreloaded() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- isPreloaded() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- 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
- isPrimary() - Method in class org.infinispan.distribution.DistributionInfo
- isPrimaryOwner() - Method in enum org.infinispan.configuration.cache.Index
- isPrivateCache(String) - Method in interface org.infinispan.registry.InternalCacheRegistry
-
Returns whether the cache is private, i.e.
- isPrivileged() - Static method in class org.infinispan.security.Security
- isProtected() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Returns whether this attribute set is protected
- 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
- isReadOnly() - Method in class org.infinispan.stats.TransactionStatistics
- 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.CompositeAction
- isReady() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- isReady() - Method in interface org.infinispan.remoting.inboundhandler.action.ReadyAction
- isReady() - Method in class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
- isReady() - Method in interface org.infinispan.util.concurrent.BlockingRunnable
- isReady() - Method in interface org.infinispan.util.concurrent.locks.PendingLockPromise
- 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 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() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- 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.Parser.TransactionMode
- isReentrant() - Method in class org.infinispan.lock.api.ClusteredLockConfiguration
- isRegistered(Class<? extends Encoder>) - Method in interface org.infinispan.marshall.core.EncoderRegistry
- 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
- isRemote() - Method in enum org.infinispan.stats.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
- isReplicated - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- isReplicated() - Method in enum org.infinispan.configuration.cache.CacheMode
- isReplicated() - Method in interface org.infinispan.distribution.ch.ConsistentHash
- isReset() - Method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- isRetry() - Method in class org.infinispan.notifications.cachelistener.filter.EventType
- isReturnValueExpected() - Method in class org.infinispan.query.affinity.AffinityUpdateCommand
- isReturnValueExpected() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
- isReturnValueExpected() - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- isReturnValueExpected() - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- isReturnValueExpected() - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
- isReturnValueExpected() - Method in class org.infinispan.statetransfer.StateRequestCommand
- isReturnValueExpected() - Method in class org.infinispan.statetransfer.StateResponseCommand
- isReturnValueExpected() - Method in class org.infinispan.topology.CacheTopologyControlCommand
- isReturnValueExpected() - Method in class org.infinispan.topology.HeartBeatCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- isReturnValueExpected() - Method in class org.infinispan.xsite.XSiteAdminCommand
- isRunning(String) - Method in class org.infinispan.manager.DefaultCacheManager
- isRunning(String) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Tests whether a named cache is running.
- isSafeClass(String) - Method in class org.infinispan.commons.configuration.ClassWhiteList
- 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.
- 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
- isSegmentLocalToNode(Address, int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Check if a segment is local to a given member.
- isSegmentReadOwner(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
- isSegmentWriteOwner(int) - Method in class org.infinispan.distribution.LocalizedCacheTopology
- isServerMode() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
- isShutdown - Variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- isShutdown() - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- isShutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
- isSingleton() - Method in class org.infinispan.spring.InfinispanDefaultCacheFactoryBean
-
Always returns
true
. - isSingleton() - Method in class org.infinispan.spring.provider.ContainerEmbeddedCacheManagerFactoryBean
- isSingleton() - Method in class org.infinispan.spring.provider.ContainerRemoteCacheManagerFactoryBean
- isSingleton() - Method in class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
-
Always returns
true
. - isSingleton() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
-
Always return
true
. - isSingleton() - Method in class org.infinispan.spring.support.embedded.InfinispanEmbeddedCacheManagerFactoryBean
-
Always returns
true
. - isSingleton() - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
-
Always returns
true
. - isSingleton() - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
-
Always return true.
- isSingleton() - Method in class org.infinispan.spring.support.remote.InfinispanRemoteCacheManagerFactoryBean
-
Always return
true
. - isSkip(Params) - Static method in enum org.infinispan.functional.Param.StatisticsMode
- isStarted() - Method in interface org.infinispan.affinity.KeyAffinityService
-
Checks weather or not the service is started.
- isStateTransferInProgress() - Method in interface org.infinispan.conflict.ConflictManager
- isStateTransferInProgress() - Method in interface org.infinispan.statetransfer.StateConsumer
- isStateTransferInProgress() - Method in class org.infinispan.statetransfer.StateConsumerImpl
- isStateTransferInProgress() - Method in interface org.infinispan.statetransfer.StateProvider
- isStateTransferInProgress() - Method in class org.infinispan.statetransfer.StateProviderImpl
- isStateTransferInProgress() - Method in interface org.infinispan.statetransfer.StateTransferManager
-
Checks if an inbound state transfer is in progress.
- isStateTransferInProgress() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- isStateTransferInProgressForKey(Object) - Method in interface org.infinispan.statetransfer.StateConsumer
- isStateTransferInProgressForKey(Object) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- isStateTransferInProgressForKey(Object) - Method in interface org.infinispan.statetransfer.StateTransferManager
-
Checks if an inbound state transfer is in progress for a given key.
- isStateTransferInProgressForKey(Object) - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- isStatisticsEnabled() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- isStatisticsEnabled() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- isStatusOk() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferCollector
- isStopped() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.TaskContext
-
Deprecated.Verifies if the the TaskContext is marked as stopped.
- isStopped() - Method in class org.infinispan.persistence.TaskContextImpl
- isStopped() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- isStopped() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
- isStopping() - Method in enum org.infinispan.lifecycle.ComponentStatus
- isStorageFormatFilterable() - Method in class org.infinispan.commons.dataconversion.BinaryEncoder
- isStorageFormatFilterable() - Method in interface org.infinispan.commons.dataconversion.Encoder
- isStorageFormatFilterable() - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
- isStorageFormatFilterable() - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
- isStorageFormatFilterable() - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
- isStorageFormatFilterable() - Method in class org.infinispan.encoding.DataConversion
- isSuccessful() - Method in class org.infinispan.remoting.responses.InvalidResponse
- 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
- isSuccessfullyDone(Object) - Static method in class org.infinispan.interceptors.BaseAsyncInterceptor
- isSupportedType(Class<?>) - Method in class org.infinispan.lucene.LuceneKey2StringMapper
- 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
- isSurvivesRestarts() - Method in class org.infinispan.factories.components.ComponentMetadata
- 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.xsite.XSiteBackup
- 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
- isSynchronous() - Method in enum org.infinispan.configuration.cache.CacheMode
- isSynchronous() - Method in enum org.infinispan.configuration.parsing.Parser.Mode
- isSynchronous() - Method in enum org.infinispan.remoting.rpc.ResponseMode
- isTemplate() - Method in class org.infinispan.configuration.cache.Configuration
- isTerminated() - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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.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
- isTotalOrder - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- isTotalOrder() - Method in class org.infinispan.topology.CacheJoinInfo
- isTotalOrder() - Method in class org.infinispan.topology.ClusterCacheStatus
- isTotalOrder() - Method in enum org.infinispan.transaction.TransactionProtocol
- isTotalOrderCache(String) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Checks if the cache defined by
cacheName
is using total order. - isTotalOrderCache(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- isTotalOrderCache(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
- isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
- isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.TotalOrderTxPerCacheInboundInvocationHandler
- isTraceEnabled() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- isTracking(Flag) - Method in class org.infinispan.statetransfer.CommitManager
- isTransactional - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- isTransactional() - Method in enum org.infinispan.transaction.TransactionMode
- 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 interface org.infinispan.notifications.cachelistener.event.TransactionCompletedEvent
- isTransportEnabled() - Method in class org.infinispan.server.core.AbstractProtocolServer
- isTwoPhaseCommit() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- isTxFromRemoteSite(GlobalTransaction) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- isTxVersioned(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
- isUncertain() - Method in enum org.infinispan.distribution.DataLocality
- isUpperBoundReached() - Method in exception org.infinispan.counter.exception.CounterOutOfBoundsException
- isUseSetter() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
- isUseXaXid() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.
- isValid() - Method in interface org.infinispan.container.entries.CacheEntry
-
Deprecated.since 9.2
- 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
- isValidKeyType(Object) - Method in class org.infinispan.persistence.jpa.JpaStore
- isVersionActual(int, EntryVersion) - Method in interface org.infinispan.scattered.ScatteredVersionManager
- isViewIdAtLeast(int) - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
- isWritable() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
- 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.Parser.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 - 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 - org.infinispan.server.hotrod.HotRodOperation
- ITERATION_NEXT_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- ITERATION_START - org.infinispan.server.hotrod.HotRodOperation
- ITERATION_START_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- 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, ByteBufAllocator, IterableIterationResult) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- iterationNextResponse(HotRodHeader, HotRodServer, ByteBufAllocator, 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, ByteBufAllocator, String) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- iterationStartResponse(HotRodHeader, HotRodServer, ByteBufAllocator, String) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- IterationState - Interface in org.infinispan.server.hotrod.iteration
- iterator() - Method in interface org.infinispan.CacheStream
- iterator() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.EntrySet
-
Deprecated.
- iterator() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
-
Deprecated.
- iterator() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Returns an iterator over the elements in this set.
- 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.concurrent.ConcurrentHashSet
- 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.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.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
- iterator() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
- iterator() - Method in interface org.infinispan.LockedStream
-
This method is not supported when using a
LockedStream
- iterator() - Method in interface org.infinispan.query.CacheQuery
-
Returns the results of a search as a
ResultIterator
. - iterator() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- iterator() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorCollection
- iterator() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorSet
- iterator() - Method in class org.infinispan.util.CacheCollectionMapper
-
Deprecated.
- iterator() - Method in class org.infinispan.util.CacheSetMapper
- iterator() - Method in class org.infinispan.util.CollectionMapper
- iterator() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- iterator() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- 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.offheap.BoundedOffHeapDataContainer
- iterator(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- iterator(FetchOptions) - Method in interface org.infinispan.query.CacheQuery
-
Returns the results of a search as a
ResultIterator
. - iterator(FetchOptions) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
- iterator(Publisher<E>, int) - Static method in class org.infinispan.util.Closeables
-
Converts a
Publisher
to aCloseableIterator
by utilizing items fetched into an array and refetched as they are consumed from the iterator. - 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.offheap.OffHeapDataContainer
- 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
J
- JAVA - org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfiguration.ImplementationType
-
Deprecated.
- JAVA_COMPAT - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- JAVA_SERIALIZATION - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- JavaSerializationEncoder - Class in org.infinispan.commons.dataconversion
-
Encoder based on the default java serialization.
- JavaSerializationEncoder(ClassWhiteList) - Constructor for class org.infinispan.commons.dataconversion.JavaSerializationEncoder
- JavaSerializationMarshaller - Class in org.infinispan.commons.marshall
-
Standard Java serialization marshaller.
- JavaSerializationMarshaller() - Constructor for class org.infinispan.commons.marshall.JavaSerializationMarshaller
- JavaSerializationMarshaller(ClassWhiteList) - Constructor for class org.infinispan.commons.marshall.JavaSerializationMarshaller
- JavaSerializationTranscoder - Class in org.infinispan.server.core.dataconversion
- JavaSerializationTranscoder(ClassWhiteList) - Constructor for class org.infinispan.server.core.dataconversion.JavaSerializationTranscoder
- JBOSS_AS_4_6 - org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- JBOSS_AS_7 - org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- JBOSS_TM - org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- JBossExternalizerAdapter - Class in org.infinispan.commons.marshall.jboss
- JBossExternalizerAdapter(Externalizer<? super Object>) - Constructor for class org.infinispan.commons.marshall.jboss.JBossExternalizerAdapter
- JBossMarshaller - Class in org.infinispan.marshall.core
-
A JBoss Marshalling based marshaller that is oriented at internal, embedded, Infinispan usage.
- JBossMarshaller() - Constructor for class org.infinispan.marshall.core.JBossMarshaller
- JBossMarshaller(GlobalMarshaller, GlobalConfiguration) - Constructor for class org.infinispan.marshall.core.JBossMarshaller
- JBossMarshallerFactory - Class in org.infinispan.commons.marshall.jboss
-
A JBoss Marshalling factory class for retrieving marshaller/unmarshaller instances.
- JBossMarshallerFactory() - Constructor for class org.infinispan.commons.marshall.jboss.JBossMarshallerFactory
- JBossMarshallingTranscoder - Class in org.infinispan.server.core.dataconversion
-
Transcode between application/x-jboss-marshalling and commons formats
- JBossMarshallingTranscoder(JsonTranscoder, GenericJBossMarshaller) - Constructor for class org.infinispan.server.core.dataconversion.JBossMarshallingTranscoder
- JBossMBeanServerLookup - Class in org.infinispan.commons.jmx
-
MBeanServer lookup implementation to locate the JBoss MBeanServer.
- JBossMBeanServerLookup - Class in org.infinispan.jmx
-
Deprecated.since 9.4, use
JBossMBeanServerLookup
instead - JBossMBeanServerLookup() - Constructor for class org.infinispan.commons.jmx.JBossMBeanServerLookup
- JBossMBeanServerLookup() - Constructor for class org.infinispan.jmx.JBossMBeanServerLookup
-
Deprecated.
- 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
- JdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Interface in org.infinispan.persistence.jdbc.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, SingletonStoreConfiguration, 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
-
Contains common methods used by JDBC CacheStores.
- JdbcUtil() - Constructor for class org.infinispan.persistence.jdbc.JdbcUtil
- JGROUPS - org.infinispan.configuration.parsing.Element
- JGROUPS_ADDRESS - Static variable in interface org.infinispan.commons.marshall.Ids
- 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
- 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
- JGroupsChannelLookup - Interface in org.infinispan.remoting.transport.jgroups
-
A hook to pass in a JGroups channel.
- 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 - org.infinispan.configuration.parsing.Element
- JMX_DOMAIN - org.infinispan.configuration.parsing.Attribute
- JMX_DOMAIN - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- JMX_STATISTICS - org.infinispan.configuration.parsing.Element
- JmxAttributeMetadata - Class in org.infinispan.factories.components
-
Persistable and cacheable metadata for JMX attributes
- JmxAttributeMetadata(Field) - Constructor for class org.infinispan.factories.components.JmxAttributeMetadata
- JmxAttributeMetadata(Method) - Constructor for class org.infinispan.factories.components.JmxAttributeMetadata
- jmxDomain(String) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
-
If JMX statistics are enabled then all 'published' JMX objects will appear under this name.
- JmxDomainConflictException - Exception in org.infinispan.jmx
- JmxDomainConflictException(String) - Constructor for exception org.infinispan.jmx.JmxDomainConflictException
- JmxOperationMetadata - Class in org.infinispan.factories.components
-
Persistable and cacheable metadata for JMX operations
- JmxOperationMetadata(Method) - Constructor for class org.infinispan.factories.components.JmxOperationMetadata
- JmxOperationParameter - Class in org.infinispan.factories.components
-
JmxOperationParameter stores metadata information about MBean operation parameters which is then used at runtime to build the relevant
MBeanParameterInfo
- JmxOperationParameter(String, String, String) - Constructor for class org.infinispan.factories.components.JmxOperationParameter
- jmxStatistics() - Method in class org.infinispan.configuration.cache.Configuration
- jmxStatistics() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- jmxStatistics() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- JMXStatisticsConfiguration - Class in org.infinispan.configuration.cache
-
Determines whether statistics are gather and reported.
- JMXStatisticsConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Determines whether statistics are gather and reported.
- JmxStatisticsExposer - Interface in org.infinispan.jmx
-
Interface containing common cache management operations
- JmxUtil - Class in org.infinispan.commons.jmx
-
Class containing JMX related utility methods.
- JmxUtil() - Constructor for class org.infinispan.commons.jmx.JmxUtil
- JNDI_NAME - org.infinispan.configuration.parsing.Attribute
- JNDI_URL - org.infinispan.persistence.jdbc.configuration.Attribute
- jndiUrl() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfiguration
- jndiUrl(String) - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
- JNI - org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfiguration.ImplementationType
-
Deprecated.
- 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(String, CacheJoinInfo, CacheTopologyHandler, PartitionHandlingManager) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- 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
- JOIN - org.infinispan.topology.CacheTopologyControlCommand.Type
- JOINING - org.infinispan.query.remote.client.ContinuousQueryResult.ResultType
- JPA_STORE - org.infinispan.persistence.jpa.configuration.Element
- JpaStore<K,V> - Class in org.infinispan.persistence.jpa
-
NOTE: This store can return expired keys or entries on any given operation if
JpaStoreConfiguration.storeMetadata()
was set to false. - JpaStore() - Constructor for class org.infinispan.persistence.jpa.JpaStore
- JpaStoreConfiguration - Class in org.infinispan.persistence.jpa.configuration
-
JpaStoreConfiguration.
- JpaStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.persistence.jpa.configuration.JpaStoreConfiguration
- JpaStoreConfigurationBuilder - Class in org.infinispan.persistence.jpa.configuration
- JpaStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationBuilder
- JpaStoreConfigurationParser - Class in org.infinispan.persistence.jpa.configuration
- JpaStoreConfigurationParser() - Constructor for class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationParser
- JpaStoreConfigurationSerializer - Class in org.infinispan.persistence.jpa.configuration
-
JpaStoreConfigurationSerializer.
- JpaStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationSerializer
- JpaStoreException - Exception in org.infinispan.persistence.jpa
- JpaStoreException() - Constructor for exception org.infinispan.persistence.jpa.JpaStoreException
- JpaStoreException(String) - Constructor for exception org.infinispan.persistence.jpa.JpaStoreException
- JpaStoreException(String, Throwable) - Constructor for exception org.infinispan.persistence.jpa.JpaStoreException
- JpaStoreException(Throwable) - Constructor for exception org.infinispan.persistence.jpa.JpaStoreException
- JSArrays - Class in org.infinispan.scripting.utils
- JSArrays() - Constructor for class org.infinispan.scripting.utils.JSArrays
- JsonClientQueryResponse - Class in org.infinispan.query.remote.client
- JsonClientQueryResponse(JsonObject) - Constructor for class org.infinispan.query.remote.client.JsonClientQueryResponse
- JSONConstants - Interface in org.infinispan.query.remote.json
- JSONConstants - Interface in org.infinispan.rest
- JsonProjection - Class in org.infinispan.query.remote.json
- JsonQueryErrorResult - Class in org.infinispan.query.remote.json
- JsonQueryErrorResult() - Constructor for class org.infinispan.query.remote.json.JsonQueryErrorResult
- JsonQueryErrorResult(String, String) - Constructor for class org.infinispan.query.remote.json.JsonQueryErrorResult
- JsonQueryReader - Class in org.infinispan.query.remote.json
-
since 9.4
- JsonQueryReader() - Constructor for class org.infinispan.query.remote.json.JsonQueryReader
- JsonQueryRequest - Class in org.infinispan.query.remote.json
- JsonQueryRequest(String, Integer, Integer, IndexedQueryMode) - Constructor for class org.infinispan.query.remote.json.JsonQueryRequest
- JsonQueryResponse - Class in org.infinispan.query.remote.json
- JsonQueryResponse() - Constructor for class org.infinispan.query.remote.json.JsonQueryResponse
- JsonQueryResult - Class in org.infinispan.query.remote.json
- JsonQueryResult(List<Hit>, int) - Constructor for class org.infinispan.query.remote.json.JsonQueryResult
- JsonTranscoder - Class in org.infinispan.server.core.dataconversion
- JsonTranscoder() - Constructor for class org.infinispan.server.core.dataconversion.JsonTranscoder
- JsonTranscoder(ClassLoader, ClassWhiteList) - Constructor for class org.infinispan.server.core.dataconversion.JsonTranscoder
- JsonTranscoder(ClassWhiteList) - Constructor for class org.infinispan.server.core.dataconversion.JsonTranscoder
K
- KARAF - org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- KEEP_ALIVE_TIME - org.infinispan.configuration.parsing.Attribute
- keepAlive() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
- key - Variable in class org.infinispan.container.entries.AbstractInternalCacheEntry
- key - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- 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 class org.infinispan.xsite.statetransfer.XSiteState
- KEY - Static variable in interface org.infinispan.query.ProjectionConstants
-
Just an alias for
ProjectionConstants.ID
- KEY_ALIAS - org.infinispan.persistence.remote.configuration.Attribute
- KEY_DATA_TYPE - org.infinispan.configuration.parsing.Element
- KEY_EQUIVALENCE - 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_PARTITIONER - org.infinispan.configuration.parsing.Attribute
- KEY_PARTITIONER - Static variable in class org.infinispan.configuration.cache.HashConfiguration
- KEY_SIZE_ESTIMATE - org.infinispan.persistence.remote.configuration.Attribute
- KEY_TO_STRING_MAPPER - org.infinispan.persistence.jdbc.configuration.Attribute
- KEY_TO_STRING_MAPPER - org.infinispan.persistence.rest.configuration.Attribute
- KEY_TRANSFER - org.infinispan.scattered.ScatteredVersionManager.SegmentState
- 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
- KEY2STRING_MAPPER - Static variable in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- key2StringMapper() - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfiguration
- key2StringMapper() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- 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(Class<? extends MarshallingTwoWayKey2StringMapper>) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- key2StringMapper(Class<? extends MarshallingTwoWayKey2StringMapper>) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- key2StringMapper(Class<? extends MarshallingTwoWayKey2StringMapper>) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
The class of a
Key2StringMapper
to use for mapping keys to strings suitable for RESTful retrieval/storage. - 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(String) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- key2StringMapper(String) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- key2StringMapper(String) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
The class name of a
Key2StringMapper
to use for mapping keys to strings suitable for RESTful retrieval/storage. - 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
-
Deprecated.Extend from
KeyAffinityServiceImpl
instead. This class will be removed in the future. - KeyAffinityServiceImpl(Executor, Cache<? extends K, ?>, KeyGenerator<? extends K>, int, Collection<Address>, boolean) - Constructor for class org.infinispan.affinity.KeyAffinityServiceImpl
-
Deprecated.
- 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.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
- 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. - keyDataType() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
- KeyDoesNotExist - org.infinispan.server.hotrod.OperationStatus
- keyEquivalence() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
-
Deprecated.Equivalence is no longer used. This will be removed in the future. Only returns
AnyEquivalence
- keyEquivalence(Equivalence<K>) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.Equivalence is to be removed (byte[] are directly supported)
- KeyFilter<K> - Interface in org.infinispan.filter
-
Deprecated.since 9.3 This will be replaced by
Predicate
in the future - KeyFilterAsCacheEventFilter<K> - Class in org.infinispan.notifications.cachelistener.filter
-
CacheEventFilter that implements it's filtering solely on the use of the provided KeyFilter
- KeyFilterAsCacheEventFilter(KeyFilter<? super K>) - Constructor for class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter
- KeyFilterAsCacheEventFilter.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
- KeyFilterAsKeyValueFilter<K,V> - Class in org.infinispan.filter
-
KeyValueFilter that implements it's filtering solely on the use of the provided KeyFilter
- KeyFilterAsKeyValueFilter(KeyFilter<? super K>) - Constructor for class org.infinispan.filter.KeyFilterAsKeyValueFilter
- KeyFilterAsKeyValueFilter.Externalizer - Class in org.infinispan.filter
- keyFilterMapper - Variable in class org.infinispan.util.CacheCollectionMapper
-
Deprecated.
- keyFilterMapper - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
- KeyGenerator<K> - Interface in org.infinispan.affinity
-
Used for generating keys; used by
KeyAffinityService
to generate the affinity keys. - keyInvalidationListener - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- keyPartitioner - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- keyPartitioner - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- keyPartitioner - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- keyPartitioner - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- keyPartitioner - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- keyPartitioner - Variable in class org.infinispan.statetransfer.StateProviderImpl
- 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.
- keyRead(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.since 9.1 Use
MVCCEntry.isRead()
instead - keys - Variable in class org.infinispan.commons.util.ArrayMap
- keys - Variable in class org.infinispan.query.clustered.NodeTopDocs
- keys() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Returns an enumeration of the keys in this table.
- keys() - Method in interface org.infinispan.functional.FunctionalMap.ReadOnlyMap
-
Provides a
Traversable
that allows clients to navigate all cached keys. - keys(C) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
- keys(ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
- keySet - Variable in class org.infinispan.commons.util.AbstractMap
- keySet - Variable in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
- 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 class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- 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.concurrent.ConcurrentWeakKeyHashMap
-
Returns a
Set
view of the keys contained in this map. - keySet() - Method in class org.infinispan.commons.util.FastCopyHashMap
- keySet() - Method in interface org.infinispan.container.DataContainer
-
Deprecated.Please use iterator method if bulk operations are required.
- keySet() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- keySet() - Method in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- KeySet() - Constructor for class org.infinispan.commons.util.FastCopyHashMap.KeySet
- keySizeEstimate() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- keySizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- keySizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- keySizeEstimate(int) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
The class name of the driver used for connecting to the database.
- keysToExecutionNodes(DistributedTaskExecutionPolicy, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- KEYSTORE - org.infinispan.persistence.remote.configuration.Element
- 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.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)
. - 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.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.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.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.persistence.remote.configuration.SslConfiguration
- keyStoreType() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- 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.
- 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. - 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
- KeyValueFilterAsKeyFilter<K> - Class in org.infinispan.filter
-
This is a KeyFilter that utilizes the given
KeyValueFilter
to determine if to filter the key. - KeyValueFilterAsKeyFilter(KeyValueFilter<? super K, ?>) - Constructor for class org.infinispan.filter.KeyValueFilterAsKeyFilter
- KeyValueFilterAsKeyFilter.Externalizer - Class in org.infinispan.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.Externalizer - Class in org.infinispan.notifications.cachelistener.filter
- KeyValueFilterConverterFactory<K,V,C> - Interface in org.infinispan.filter
-
Factory for
KeyValueFilterConverter
instances - 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.KeyValueWithPreviousExternalizer - Class in org.infinispan.commons.util
- 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
- KeyValueWithPreviousExternalizer() - Constructor for class org.infinispan.commons.util.KeyValueWithPrevious.KeyValueWithPreviousExternalizer
- KeyVisitor<T> - Interface in org.infinispan.lucene
-
All objects being used as keys to store entries by the Lucene Directory implement
IndexScopedKey
which enforces visitability with aKeyVisitor
. - KIBIBYTES - org.infinispan.commons.util.MemoryUnit
- KILOBYTES - org.infinispan.commons.util.MemoryUnit
- KnownComponentNames - Class in org.infinispan.factories
-
Holder for known named component names.
- KnownComponentNames() - Constructor for class org.infinispan.factories.KnownComponentNames
L
- 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 - org.infinispan.configuration.parsing.Element
- L1_LIFESPAN - 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
- L1LastChanceInterceptor - Class in org.infinispan.interceptors.distribution
-
L1 based interceptor that flushes the L1 cache at the end after a transaction/entry is committed to the data container but before the lock has been released.
- L1LastChanceInterceptor() - Constructor for class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- l1Manager - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- 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.
- 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
- L1NonTxInterceptor - Class in org.infinispan.interceptors.distribution
-
Interceptor that handles L1 logic for non-transactional caches.
- L1NonTxInterceptor() - Constructor for class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- L1TxInterceptor - Class in org.infinispan.interceptors.distribution
-
Interceptor that handles L1 logic for transactional caches.
- L1TxInterceptor() - Constructor for class org.infinispan.interceptors.distribution.L1TxInterceptor
- L1WriteSynchronizer - Class in org.infinispan.interceptors.distribution
-
A write synchronizer that allows for a single thread to run the L1 update while others can block until it is completed.
- L1WriteSynchronizer(InternalDataContainer, long, StateTransferLock, ClusteringDependentLogic) - Constructor for class org.infinispan.interceptors.distribution.L1WriteSynchronizer
- 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 - org.infinispan.configuration.cache.InterceptorConfiguration.Position
-
Specifies that the new interceptor is placed last in the chain.
- 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
- lastModified(Date) - Method in class org.infinispan.rest.InfinispanCacheResponse
-
Add
last-modified
header. - lastModified(InternalCacheEntry<K, V>) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- 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.container.entries.RemoteMetadata
- lastUsed() - Method in interface org.infinispan.metadata.InternalMetadata
- LATEST - Static variable in enum org.infinispan.server.hotrod.HotRodVersion
- LAZY - org.infinispan.query.FetchOptions.FetchMode
-
With lazy loading the entries are not loaded until each one is specifically requested.
- 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
- LazyInitializingBackend - Class in org.infinispan.query.indexmanager
-
This backend only triggers initialization of a different backend when incoming indexing operations trigger it, then transfers the incoming operations to the new backend.
- LazyInitializingBackend(LazyInitializableBackend) - Constructor for class org.infinispan.query.indexmanager.LazyInitializingBackend
- LazyInitializingBlockingTaskAwareExecutorService - Class in org.infinispan.executors
-
A delegating executor that lazily constructs and initializes the underlying executor.
- LazyInitializingBlockingTaskAwareExecutorService(ThreadPoolExecutorFactory<ExecutorService>, ThreadFactory, TimeService, String) - 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
- leave(String) - Method in interface org.infinispan.topology.LocalTopologyManager
-
Forwards the leave request to the coordinator.
- leave(String) - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- leave(String) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- LEAVE - org.infinispan.topology.CacheTopologyControlCommand.Type
- LEAVING - org.infinispan.query.remote.client.ContinuousQueryResult.ResultType
- left() - Method in class org.infinispan.commons.util.Either
- LEFT - org.infinispan.commons.util.Either.Type
- 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
- LEVELDB_STORE - org.infinispan.persistence.leveldb.configuration.Element
- LevelDBStore - Class in org.infinispan.persistence.leveldb
-
Deprecated.Use the
RocksDBStore
instead - LevelDBStore() - Constructor for class org.infinispan.persistence.leveldb.LevelDBStore
-
Deprecated.
- LevelDBStoreConfiguration - Class in org.infinispan.persistence.leveldb.configuration
-
Deprecated.Use the RocksDB cache store instead
- LevelDBStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfiguration
-
Deprecated.
- LevelDBStoreConfiguration.ImplementationType - Enum in org.infinispan.persistence.leveldb.configuration
-
Deprecated.
- LevelDBStoreConfigurationBuilder - Class in org.infinispan.persistence.leveldb.configuration
-
Deprecated.Use the RocksDB Cache Store instead
- LevelDBStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- LevelDBStoreConfigurationParser - Class in org.infinispan.persistence.leveldb.configuration
-
Deprecated.Use the RocksDB cache store instead
- LevelDBStoreConfigurationParser() - Constructor for class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationParser
-
Deprecated.
- LevelDBStoreConfigurationSerializer - Class in org.infinispan.persistence.leveldb.configuration
-
Deprecated.Use the RocksDB Cache Store instead
- LevelDBStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationSerializer
-
Deprecated.
- 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 - Interface in org.infinispan.lifecycle
-
Deprecated.use
Lifecycle
instead - LIFECYCLE - org.infinispan.security.AuthorizationPermission
-
Allows control of a cache's lifecycle (i.e.
- LifecycleCallbacks - Class in org.infinispan.lucene
-
Module lifecycle callbacks implementation that enables module specific
AdvancedExternalizer
implementations to be registered. - LifecycleCallbacks - Class in org.infinispan.persistence.remote
- LifecycleCallbacks - Class in org.infinispan.rest
-
Module lifecycle callbacks implementation that enables module specific
AdvancedExternalizer
implementations to be registered. - LifecycleCallbacks - Class in org.infinispan.server.core
-
Module lifecycle callbacks implementation that enables module specific
AdvancedExternalizer
implementations to be registered. - 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.lucene.LifecycleCallbacks
- 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
- 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.metadata.EmbeddedMetadata
- 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() - Method in class org.infinispan.rest.operations.mime.MimeMetadata
- lifespan() - Method in class org.infinispan.server.memcached.MemcachedMetadata
- 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.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.metadata.EmbeddedMetadata.Builder
- lifespan(long, TimeUnit) - Method in interface org.infinispan.metadata.Metadata.Builder
-
Set lifespan time with a given time unit.
- LIFESPAN - org.infinispan.configuration.parsing.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
-
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.util.AbstractDelegatingCacheStream
- 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
- LIRS - org.infinispan.eviction.EvictionStrategy
-
Deprecated.
- list() - Method in class org.infinispan.io.GridFile
- list() - Method in interface org.infinispan.query.CacheQuery
-
Returns the results of a search as a list.
- list() - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
- list() - Method in interface org.infinispan.query.dsl.Query
-
Returns the results of a search as a list.
- list(FilenameFilter) - Method in class org.infinispan.io.GridFile
- LIST - org.infinispan.persistence.modifications.Modification.Type
- LISTEN - 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 - Annotation Type in org.infinispan.notifications
-
Class-level annotation used to annotate an object as being a valid cache listener.
- LISTENER_EXECUTOR - 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
- 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.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 - Class in org.infinispan.functional
-
Holder class for functional listener definitions.
- 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.
- 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
- listFiles() - Method in class org.infinispan.io.GridFile
- listFiles(FileFilter) - Method in class org.infinispan.io.GridFile
- listFiles(FilenameFilter) - Method in class org.infinispan.io.GridFile
- 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 interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Fetches an entry from the storage given a segment to optimize this lookup based on.
- load(int, Object) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- load(Class<T>, ClassLoader...) - Static method in class org.infinispan.commons.util.ServiceFinder
- load(Object) - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
- load(Object) - Method in class org.infinispan.persistence.async.AsyncCacheLoader
- load(Object) - Method in class org.infinispan.persistence.cluster.ClusterLoader
- load(Object) - Method in class org.infinispan.persistence.file.SingleFileStore
- load(Object) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- load(Object) - Method in class org.infinispan.persistence.jpa.JpaStore
- load(Object) - Method in class org.infinispan.persistence.remote.RemoteStore
- load(Object) - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- load(Object) - Method in interface org.infinispan.persistence.spi.CacheLoader
-
Fetches an entry from the storage.
- load(Object) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
- load(Object) - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
- LOAD_PERSIST - org.infinispan.functional.Param.PersistenceMode
- loadAll() - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Loads all persisted cache configurations
- 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.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.since 9.4 This method references PersistenceManager, which isn't a public class
- 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.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.since 9.4 This method references PersistenceManager, which isn't a public class
- 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 - org.infinispan.container.entries.ReadCommittedEntry.Flags
- LOADED - Static variable in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
- LOADER - 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 interface org.infinispan.persistence.manager.PersistenceManager
-
Loads an entry from the persistence store for the given key.
- loadFromAllStores(Object, boolean, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- loadFromAllStores(Object, boolean, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- loadFromAllStores(Object, int, boolean, boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Same as
PersistenceManager.loadFromAllStores(Object, boolean, boolean)
except that the segment of the key is also provided to avoid having to calculate the segment. - loadFromAllStores(Object, int, boolean, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- loadFromAllStores(Object, int, boolean, boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- loadModuleCommandHandlers(ClassLoader) - Method in class org.infinispan.util.ModuleProperties
- LOCAL - org.infinispan.configuration.cache.CacheMode
-
Data is not replicated.
- LOCAL - org.infinispan.configuration.cache.Index
-
Deprecated.since 9.1
- LOCAL - org.infinispan.configuration.parsing.ParsedCacheMode
- LOCAL - org.infinispan.distribution.DataLocality
- LOCAL - org.infinispan.functional.Param.ExecutionMode
-
Command is executed only locally, it is not sent to remote nodes.
- LOCAL_CACHE - org.infinispan.configuration.parsing.Element
- LOCAL_CACHE_CONFIGURATION - org.infinispan.configuration.parsing.Element
- LOCAL_COMMIT_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- LOCAL_EXEC_NO_CONT - org.infinispan.stats.container.ExtendedStatistic
- LOCAL_GET - org.infinispan.stats.topK.StreamSummaryContainer.Stat
- LOCAL_GET_EXECUTION - org.infinispan.stats.container.ExtendedStatistic
- LOCAL_PREPARE_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- LOCAL_PUT - org.infinispan.stats.topK.StreamSummaryContainer.Stat
- LOCAL_PUT_EXECUTION - org.infinispan.stats.container.ExtendedStatistic
- LOCAL_ROLLBACK_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- LOCAL_SITE - 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 - org.infinispan.distribution.DataLocality
- LocalCacheBackupReceiver - Class in org.infinispan.xsite
-
BackupReceiver
implementation for local caches. - LocalClassLoaderCacheStoreFactory - Class in org.infinispan.persistence.factory
-
Default implementation, which uses Local class loader.
- LocalClassLoaderCacheStoreFactory() - Constructor for class org.infinispan.persistence.factory.LocalClassLoaderCacheStoreFactory
- LocalConfigurationStorage - Interface in org.infinispan.globalstate
-
The
LocalConfigurationStorage
is responsible for applying on each node the configuration changes initiated through theGlobalConfigurationManager
and persist them if requested viaCacheContainerAdmin.AdminFlag.PERMANENT
. - localExecutorService - Variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- LocalExtendedStatisticsContainer - Class in org.infinispan.stats.container
-
Container for the statistics corresponding to local originated transactions.
- LocalExtendedStatisticsContainer() - Constructor for class org.infinispan.stats.container.LocalExtendedStatisticsContainer
- 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
- LocalLockMergingSegmentReadLocker - Class in org.infinispan.lucene.readlocks
-
LocalLockMergingSegmentReadLocker decorates the
DistributedSegmentReadLocker
to minimize remote operations in case several IndexReaders are opened on the same Infinispan basedDirectory
. - LocalLockMergingSegmentReadLocker(Cache<?, ?>, String, int) - Constructor for class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
-
Create a new LocalLockMergingSegmentReadLocker for specified cache and index name.
- LocalLockMergingSegmentReadLocker(Cache<?, ?>, Cache<?, ?>, Cache<?, ?>, String, boolean, int) - Constructor for class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
- LocalLockMergingSegmentReadLocker(Cache<?, ?>, Cache<?, ?>, Cache<?, ?>, String, int) - Constructor for class org.infinispan.lucene.readlocks.LocalLockMergingSegmentReadLocker
-
Create a new LocalLockMergingSegmentReadLocker with special purpose caches
- LocalLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.LocalLogic
- LocalModeAddress - Class in org.infinispan.remoting.transport
-
Represents the local node's address.
- localNodeIsOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
-
Deprecated.Since 9.0, please use
getCacheTopology().isWriteOwner(key)
instead. - localNodeIsPrimaryOwner(Object) - Method in interface org.infinispan.interceptors.locking.ClusteringDependentLogic
-
Deprecated.Since 9.0, please use
getCacheTopology().getDistribution(key).isPrimary()
instead. - LocalOnlyBackend - Class in org.infinispan.query.indexmanager
-
Alternative implementation to the ClusteredSwitchingBackend, meant to be used for non-clustered caches: much simpler as we have no states nor transitions to manage.
- LocalOnlyBackend(LocalBackendFactory) - Constructor for class org.infinispan.query.indexmanager.LocalOnlyBackend
- LocalOnlyCacheLoader - Interface in org.infinispan.persistence.spi
-
Marker interface for cache loaders that should only load values on the originating nodes.
- localSite() - Method in class org.infinispan.configuration.global.SiteConfiguration
-
Returns the name of the local site.
- localSite(String) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
-
Sets the name of the local site.
- localTopologyManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- 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
- localTransactionPrepared(LocalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- LocalTransactionStatistics - Class in org.infinispan.stats
-
Represents the statistics collected for a local transaction
- LocalTransactionStatistics(boolean, TimeService) - Constructor for class org.infinispan.stats.LocalTransactionStatistics
- 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
- locate(Object) - Method in interface org.infinispan.distribution.DistributionManager
-
Deprecated.Since 9.0, please use
getCacheTopology().getDistributionInfo(key)
instead. - locateAll(Collection<Object>) - Method in interface org.infinispan.distribution.DistributionManager
-
Deprecated.Since 9.0, no direct replacement.
- locateAllOwners(Collection<Object>) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Deprecated.Since 9.0, please use
LocalizedCacheTopology.getWriteOwners(Collection)
instead. - locateOwners(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Deprecated.Since 9.0, please use
LocalizedCacheTopology.getDistribution(Object)
instead. - locateOwnersForSegment(int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
- locatePrimaryOwner(Object) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Deprecated.Since 9.0, please use
LocalizedCacheTopology.getDistribution(Object)
instead. - locatePrimaryOwnerForSegment(int) - Method in interface org.infinispan.distribution.ch.ConsistentHash
- location() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- location() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
-
The location of the root directory of the index.
- 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.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
-
Path to the root directory containing all indexes.
- location(String) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- LOCATION - org.infinispan.configuration.parsing.Attribute
- LOCATION - org.infinispan.persistence.leveldb.configuration.Attribute
- 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.stats.wrappers.ExtendedStatisticLockManager
- lock(Object, Object, long, TimeUnit) - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- 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(K...) - Method in interface org.infinispan.AdvancedCache
-
Locks a given key or keys eagerly across cache nodes in a cluster.
- LOCK - org.infinispan.functional.Param.LockingMode
- LOCK_ACQUISITION_TIMEOUT - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
- LOCK_HOLD_TIME - org.infinispan.stats.container.ExtendedStatistic
- LOCK_HOLD_TIME_LOCAL - org.infinispan.stats.container.ExtendedStatistic
- LOCK_HOLD_TIME_REMOTE - org.infinispan.stats.container.ExtendedStatistic
- LOCK_HOLD_TIME_SUCCESS_LOCAL_TX - org.infinispan.stats.container.ExtendedStatistic
- LOCK_TIMEOUT - org.infinispan.configuration.parsing.Attribute
- LOCK_WAITING_TIME - org.infinispan.stats.container.ExtendedStatistic
- LockAcquiringBackend - Class in org.infinispan.query.indexmanager
-
Transitionally backend used when we receive indexing operation to be applied to the (local) IndexWriter, but the index lock is not available yet.
- LockAcquiringBackend(LazyInitializableBackend) - Constructor for class org.infinispan.query.indexmanager.LockAcquiringBackend
- 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
- LockAction - Class in org.infinispan.remoting.inboundhandler.action
-
An
Action
implementation that acquire the locks. - LockAction(LockManager, DistributionManager) - Constructor for class org.infinispan.remoting.inboundhandler.action.LockAction
- lockAll() - Method in class org.infinispan.container.offheap.StripedLock
-
Locks all write locks.
- lockAll(Collection<?>, Object, long, TimeUnit) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- lockAll(Collection<?>, Object, long, TimeUnit) - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- 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. - lockAndRecord(InvocationContext, Object, long) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- 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.
- LockContainerFactory - Class in org.infinispan.factories
-
Factory class that creates instances of
LockContainer
. - LockContainerFactory() - Constructor for class org.infinispan.factories.LockContainerFactory
- lockedStream() - Method in interface org.infinispan.AdvancedCache
-
Returns a sequential stream using this Cache as the source.
- 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. - 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 - org.infinispan.configuration.parsing.Attribute
- LOCKING - 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 - Variable in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- 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
- LockPromise - Interface in org.infinispan.util.concurrent.locks
-
A promise returned by
InfinispanLock
. - locks() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfiguration
- locksAtOrigin - Variable in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- LockState - Enum in org.infinispan.util.concurrent.locks
-
The
InfinispanLock
possible states. - log - Static variable in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- log - Static variable in class org.infinispan.commons.marshall.jboss.CheckedClassResolver
- log - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- log - Static variable in class org.infinispan.factories.AbstractComponentFactory
- log - Static variable in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- log - Variable in class org.infinispan.server.core.admin.AdminServerTask
- log - Static variable in class org.infinispan.server.hotrod.AbstractEncoder1x
- log - Static variable in class org.infinispan.stats.TransactionStatistics
- logEvent(boolean) - Method in class org.infinispan.tasks.TaskContext
-
Whether execution will generate an event in the event log
- logger - Static variable in class org.infinispan.commons.dataconversion.TranscoderMarshallerAdapter
- logger - Static variable in class org.infinispan.rest.cachemanager.RestCacheManager
- logger - Static variable in class org.infinispan.rest.Http20RequestHandler
- logger - Static variable in class org.infinispan.rest.operations.mediatypes.Charset
- logger - Static variable in class org.infinispan.server.core.dataconversion.JBossMarshallingTranscoder
- logger - Static variable in class org.infinispan.server.core.dataconversion.json.SecureTypeIdResolver
- logger - Static variable in class org.infinispan.server.core.dataconversion.JsonTranscoder
- logger - Static variable in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- logger - Static variable in class org.infinispan.spring.InfinispanDefaultCacheFactoryBean
- logRoutingTableInformation() - Method in class org.infinispan.topology.CacheTopology
- LONG - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- long_(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- LONG_SUMMARY_STATISTICS - Static variable in interface org.infinispan.commons.marshall.Ids
- LongCacheStream - Interface in org.infinispan
-
A
LongStream
that has additional methods to allow for Serializable instances. - longResponse(HotRodHeader, HotRodServer, ByteBufAllocator, long) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- longResponse(HotRodHeader, HotRodServer, ByteBufAllocator, 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
- lookedUpEntriesCount() - Method in interface org.infinispan.context.EntryLookup
- lookedUpEntriesCount() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- lookupComponent(String, String, boolean) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- 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.SingleKeyNonTxInvocationContext
-
Deprecated.
- 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
. - lookupLocalComponent(String, String, boolean) - Method in class org.infinispan.factories.ComponentRegistry
- lookupMBeanServer(MBeanServerLookup, Properties) - Static method in class org.infinispan.commons.jmx.JmxUtil
-
Looks up the
MBeanServer
instance. - 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.
- LOWER_BOUND - org.infinispan.counter.configuration.Element
- LOWER_BOUND - Static variable in exception org.infinispan.counter.exception.CounterOutOfBoundsException
- LOWER_BOUND_REACHED - 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.
- LRU - org.infinispan.eviction.EvictionStrategy
-
Deprecated.
- lruLock - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- lt(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Checks that the left argument is less than the given value.
- lte(Object) - Method in interface org.infinispan.query.dsl.FilterConditionEndContext
-
Checks that the left argument is less than or equal to the given value.
- LuceneCacheLoader<K,V> - Class in org.infinispan.lucene.cacheloader
-
A CacheLoader meant to load Lucene index(es) from filesystem based Lucene index(es).
- LuceneCacheLoader() - Constructor for class org.infinispan.lucene.cacheloader.LuceneCacheLoader
- LuceneKey2StringMapper - Class in org.infinispan.lucene
-
To configure a JdbcStringBasedCacheStoreConfig for the Lucene Directory, use this Key2StringMapper implementation.
- LuceneKey2StringMapper() - Constructor for class org.infinispan.lucene.LuceneKey2StringMapper
- LuceneLoaderConfiguration - Class in org.infinispan.lucene.cacheloader.configuration
-
Configuration bean for the
LuceneCacheLoader
. - LuceneLoaderConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration) - Constructor for class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfiguration
- LuceneLoaderConfigurationBuilder - Class in org.infinispan.lucene.cacheloader.configuration
-
ConfigurationBuilder
bean for theLuceneLoaderConfiguration
- LuceneLoaderConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
- LuceneWorkConverter - Class in org.infinispan.query.indexmanager
-
Manages conversions of
LuceneWork
. - LuceneWorkTransformationVisitor - Class in org.infinispan.query.indexmanager
-
The serialized form of LuceneWork needs to be adjusted after deserialization to apply our custom keyTransformers.
M
- MACHINE - org.infinispan.distribution.topologyaware.TopologyLevel
- MACHINE_ID - 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_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.util.BlueprintGenerator
- main(String[]) - Static method in class org.infinispan.commons.util.ProcessorInfo
- main(String[]) - Static method in class org.infinispan.factories.components.ComponentMetadataPersister
-
Usage: ComponentMetadataPersister [path containing .class files to scan] [output file to generate]
- main(String[]) - Static method in class org.infinispan.Version
-
Prints version information.
- MAKE_READY - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
- makeBoundedConcurrentMap(int) - Static method in class org.infinispan.commons.util.CollectionFactory
- makeConcurrentMap() - Static method in class org.infinispan.commons.util.CollectionFactory
- makeConcurrentMap(int) - Static method in class org.infinispan.commons.util.CollectionFactory
- makeConcurrentMap(int, float, int) - Static method in class org.infinispan.commons.util.CollectionFactory
- makeConcurrentMap(int, float, int, Equivalence<? super K>, Equivalence<? super V>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeConcurrentMap(int, float, int)
instead. - makeConcurrentMap(int, int) - Static method in class org.infinispan.commons.util.CollectionFactory
- makeConcurrentMap(int, int, Equivalence<? super K>, Equivalence<? super V>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeConcurrentMap(int, int)
instead. - makeConcurrentMap(int, Equivalence<? super K>, Equivalence<? super V>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeConcurrentMap(int)
instead. - makeConcurrentMap(Equivalence<? super K>, Equivalence<? super V>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeConcurrentMap()
instead. - makeConcurrentParallelMap(int, int) - Static method in class org.infinispan.commons.util.CollectionFactory
- makeConcurrentParallelMap(int, int, Equivalence<? super K>, Equivalence<? super V>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeConcurrentParallelMap(int, int)
instead. - makeFilter(String) - Static method in class org.infinispan.query.Search
-
Create an event filter out of an Ickle query string.
- makeFilter(String, Map<String, Object>) - Static method in class org.infinispan.query.Search
-
Create an event filter out of an Ickle query string.
- makeFilter(Query) - Static method in class org.infinispan.query.Search
-
Create an event filter out of an Ickle query.
- makeLinkedMap(int, float, boolean) - Static method in class org.infinispan.commons.util.CollectionFactory
- makeLinkedMap(int, float, boolean, Equivalence<? super K>, Equivalence<? super V>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeSet(int)
instead. - makeMap() - Static method in class org.infinispan.commons.util.CollectionFactory
- makeMap(int) - Static method in class org.infinispan.commons.util.CollectionFactory
- makeMap(int, Equivalence<? super K>, Equivalence<? super V>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeMap(int)
instead. - makeMap(Map<? extends K, ? extends V>) - Static method in class org.infinispan.commons.util.CollectionFactory
- makeMap(Map<? extends K, ? extends V>, Equivalence<? super K>, Equivalence<? super V>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeMap(Map)
instead. - makeMap(Equivalence<? super K>, Equivalence<? super V>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeMap()
instead. - 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.
- makeSet() - Static method in class org.infinispan.commons.util.CollectionFactory
- makeSet(int) - Static method in class org.infinispan.commons.util.CollectionFactory
- makeSet(int, Equivalence<? super T>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeSet(int)
instead. - makeSet(Equivalence<? super T>) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Deprecated.Since 9.0, please use
CollectionFactory.makeSet()
instead. - makeSet(T...) - Static method in class org.infinispan.commons.util.CollectionFactory
-
Create a Set backed by the specified array.
- 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
. - MalformedRequest - Exception in org.infinispan.rest.operations.exceptions
- MalformedRequest(String) - Constructor for exception org.infinispan.rest.operations.exceptions.MalformedRequest
- ManageableComponentMetadata - Class in org.infinispan.factories.components
-
A specialization of
ComponentMetadata
, this version also includes JMX related metadata, as expressed byMBean
,ManagedAttribute
andManagedOperation
annotations. - ManageableComponentMetadata(Class<?>, List<Field>, List<Method>, List<Method>, List<Method>, List<Method>, boolean, boolean, List<Field>, List<Method>, List<Method>, MBean) - Constructor for class org.infinispan.factories.components.ManageableComponentMetadata
- 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(ThreadPoolExecutor) - Constructor for class org.infinispan.server.core.utils.ManageableThreadPoolExecutorService
- manageConnectionFactory() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- manageConnectionFactory(boolean) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- MANAGED - org.infinispan.globalstate.ConfigurationStorage
-
Stores
CacheContainerAdmin.AdminFlag.PERMANENT
caches in a managed environment such as the server model. - MANAGED_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
- ManagedAttribute - Annotation Type in org.infinispan.jmx.annotations
-
Indicates that a public method or a field (any visibility) in an MBean class defines an MBean attribute.
- ManagedConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.configuration
-
ManagedConnectionFactoryConfiguration.
- ManagedConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Class in org.infinispan.persistence.jdbc.configuration
-
ManagedConnectionFactoryConfigurationBuilder.
- ManagedConnectionFactoryConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
- ManagedOperation - Annotation Type in org.infinispan.jmx.annotations
-
Indicates that a method in an MBean class defines an MBean operation.
- 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
- ManifestUberJarDuplicatedJarsWarner - Class in org.infinispan.commons.util.uberjar
-
Manifest based implementation of a
UberJarDuplicatedJarsWarner
. - ManifestUberJarDuplicatedJarsWarner() - Constructor for class org.infinispan.commons.util.uberjar.ManifestUberJarDuplicatedJarsWarner
- MANUAL - org.infinispan.eviction.EvictionStrategy
-
Strategy where the cache does nothing but the user is assumed to manually invoke evict method
- manyWriteOnRemotePrimary(Address, WriteCommand, CommandAckCollector.MultiTargetCollector) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- manyWriteOnRemotePrimary(Address, WriteCommand, CommandAckCollector.MultiTargetCollector) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- manyWriteResponse(InvocationContext, WriteCommand, Object) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- manyWriteResponse(InvocationContext, WriteCommand, Object) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- map - Variable in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- map - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- map(DoubleUnaryOperator) - Method in interface org.infinispan.DoubleCacheStream
- map(Function<? super R, ? extends R1>) - Method in interface org.infinispan.CacheStream
- 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(LongUnaryOperator) - Method in interface org.infinispan.LongCacheStream
- map(SerializableDoubleUnaryOperator) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.map(DoubleUnaryOperator)
except that the DoubleUnaryOperator must also implementSerializable
- 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(SerializableLongUnaryOperator) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.map(LongUnaryOperator)
except that the LongUnaryOperator must also implement Serializable. - 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
- 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 - org.infinispan.configuration.parsing.Attribute
- MAPS - Static variable in interface org.infinispan.commons.marshall.Ids
- mapToDouble(IntToDoubleFunction) - Method in interface org.infinispan.IntCacheStream
- mapToDouble(LongToDoubleFunction) - Method in interface org.infinispan.LongCacheStream
- mapToDouble(ToDoubleFunction<? super R>) - Method in interface org.infinispan.CacheStream
- 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(SerializableLongToDoubleFunction) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.mapToDouble(LongToDoubleFunction)
except that the LongToLongFunction must also implement Serializable. - 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(LongToIntFunction) - Method in interface org.infinispan.LongCacheStream
- mapToInt(ToIntFunction<? super R>) - Method in interface org.infinispan.CacheStream
- 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(SerializableLongToIntFunction) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.mapToInt(LongToIntFunction)
except that the LongToIntFunction must also implement Serializable. - 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(IntToLongFunction) - Method in interface org.infinispan.IntCacheStream
- mapToLong(ToLongFunction<? super R>) - Method in interface org.infinispan.CacheStream
- 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(SerializableIntToLongFunction) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.mapToLong(IntToLongFunction)
except that the IntToLongFunction must also implementSerializable
- 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(IntFunction<? extends U>) - Method in interface org.infinispan.IntCacheStream
- mapToObj(LongFunction<? extends U>) - Method in interface org.infinispan.LongCacheStream
- mapToObj(SerializableDoubleFunction<? extends U>) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleCacheStream.mapToObj(DoubleFunction)
except that the DoubleFunction must also implementSerializable
- mapToObj(SerializableIntFunction<? extends U>) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.mapToObj(IntFunction)
except that the IntFunction must also implementSerializable
- mapToObj(SerializableLongFunction<? extends U>) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.mapToObj(LongFunction)
except that the LongFunction must also implement Serializable. - MARIA_DB - org.infinispan.persistence.jdbc.DatabaseType
- MARK_COMMIT - org.infinispan.server.hotrod.tx.table.Status
-
The client
TransactionManager
decided to commit. - MARK_ROLLBACK - 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.stats.TransactionStatistics
-
Sets this transaction as a write transaction.
- markAsWriteTransaction(GlobalTransaction, boolean) - Method in class org.infinispan.stats.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 interface org.infinispan.transaction.xa.CacheTransaction
- markKeyAsProcessing(K) - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
-
This should be invoked on a key before actually processing the data.
- markMarshallable(Class<?>, boolean) - Method in class org.infinispan.commons.marshall.MarshallableTypeHints
-
Marks a particular type as being marshallable or not being not marshallable.
- 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
- marshall(Object) - Method in class org.infinispan.commons.dataconversion.BinaryEncoder
- marshall(Object) - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
- 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
- MarshalledEntry<K,V> - Interface in org.infinispan.marshall.core
-
Defines an externally persisted entry.
- MarshalledEntryFactory<K,V> - Interface in org.infinispan.marshall.core
-
Factory for
MarshalledEntry
. - MarshalledEntryFactoryImpl - Class in org.infinispan.marshall.core
- MarshalledEntryFactoryImpl() - Constructor for class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
- MarshalledEntryFactoryImpl(StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
- MarshalledEntryImpl<K,V> - Class in org.infinispan.marshall.core
- MarshalledEntryImpl(K, ByteBuffer, ByteBuffer, StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl
- MarshalledEntryImpl(K, V, InternalMetadata, StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl
- MarshalledEntryImpl(ByteBuffer, ByteBuffer, ByteBuffer, StreamingMarshaller) - Constructor for class org.infinispan.marshall.core.MarshalledEntryImpl
- MarshalledEntryImpl.Externalizer - Class in org.infinispan.marshall.core
- marshalledEntryPurged(MarshalledEntry<K, V>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheExpirationWriter.ExpirationPurgeListener
-
Optional.
- MarshalledValueByteStream - Class in org.infinispan.io
-
A stream of bytes which can be written to, and the underlying byte array can be directly accessed.
- MarshalledValueByteStream() - Constructor for class org.infinispan.io.MarshalledValueByteStream
- marshallEnum(E, ObjectOutput) - Static method in class org.infinispan.commons.marshall.MarshallUtil
- marshaller - Variable in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- marshaller - Variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- marshaller - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- marshaller() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
- marshaller() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
- 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.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.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.configuration.cache.CompatibilityModeConfigurationBuilder
-
Sets the marshaller instance to be used by the interoperability layer.
- 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 - org.infinispan.persistence.remote.configuration.Attribute
- MARSHALLER - Static variable in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
- MARSHALLER - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
- MARSHALLER_CLASS - org.infinispan.configuration.parsing.Attribute
- MarshallerEncoder - Class in org.infinispan.commons.dataconversion
-
Encoder that uses a
StreamingMarshaller
to convert objects to byte[] and back. - MarshallerEncoder(Marshaller) - Constructor for class org.infinispan.commons.dataconversion.MarshallerEncoder
- MarshallerFactory - Class in org.infinispan.factories
-
MarshallerFactory.
- MarshallerFactory() - Constructor for class org.infinispan.factories.MarshallerFactory
- MarshallerRegistration - Class in org.infinispan.query.remote.client
- 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(ObjectOutput, 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
- MassIndexer - Interface in org.infinispan.query
-
Component to rebuild the indexes from the existing data.
- 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 - org.infinispan.commons.marshall.ValueMatcherMode
- MATCH_EXPECTED - org.infinispan.commons.marshall.ValueMatcherMode
- MATCH_EXPECTED_OR_NEW - org.infinispan.commons.marshall.ValueMatcherMode
- MATCH_NEVER - org.infinispan.commons.marshall.ValueMatcherMode
- MATCH_NON_NULL - 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(String) - Method in enum org.infinispan.configuration.parsing.ParsedCacheMode
- matches(String, String, String) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTopologyAwareAddress
- 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(ClusteringConfiguration) - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
- matches(Configuration) - Method in class org.infinispan.configuration.cache.Configuration
- matches(HashConfiguration) - Method in class org.infinispan.configuration.cache.HashConfiguration
- matches(KeyPartitioner) - Method in interface org.infinispan.distribution.ch.KeyPartitioner
- matches(T) - Method in interface org.infinispan.commons.configuration.attributes.Matchable
- matchesAll() - Method in class org.infinispan.commons.dataconversion.MediaType
- max(String) - Static method in interface org.infinispan.query.dsl.Expression
- 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(SerializableComparator<? super R>) - Method in interface org.infinispan.CacheStream
-
Same as
Stream.max(Comparator)
except that the Comparator must also implementSerializable
- MAX_ACTIVE - org.infinispan.persistence.remote.configuration.Attribute
- MAX_BATCH_SIZE - org.infinispan.configuration.parsing.Attribute
- MAX_BATCH_SIZE - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- MAX_CONNECTIONS_PER_HOST - org.infinispan.persistence.rest.configuration.Attribute
- MAX_CONNECTIONS_PER_HOST - Static variable in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- MAX_CONTENT_LENGTH - org.infinispan.persistence.rest.configuration.Attribute
- MAX_CONTENT_LENGTH - Static variable in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- MAX_CONTENT_LENGTH - Static variable in class org.infinispan.rest.configuration.RestServerConfiguration
- MAX_ENTRIES - org.infinispan.configuration.parsing.Attribute
- MAX_ENTRIES - Static variable in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- MAX_HEADER_SIZE - Static variable in class org.infinispan.rest.Http11To2UpgradeHandler
- MAX_ID - Static variable in interface org.infinispan.commons.marshall.Ids
- MAX_IDLE - org.infinispan.configuration.parsing.Attribute
- MAX_IDLE - org.infinispan.persistence.remote.configuration.Attribute
- MAX_IDLE - Static variable in class org.infinispan.configuration.cache.ExpirationConfiguration
- MAX_INITIAL_LINE_SIZE - Static variable in class org.infinispan.rest.Http11To2UpgradeHandler
- MAX_RESULTS - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- MAX_RETRIES - org.infinispan.configuration.parsing.Attribute
- MAX_RETRIES - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- MAX_THREADS - org.infinispan.configuration.parsing.Attribute
- MAX_TOTAL - org.infinispan.persistence.remote.configuration.Attribute
- MAX_TOTAL_CONNECTIONS - org.infinispan.persistence.rest.configuration.Attribute
- MAX_TOTAL_CONNECTIONS - Static variable in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- MAX_UNSIGNED_LONG - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- maxActive() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- 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. - 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.
- maxConnectionsPerHost() - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- maxConnectionsPerHost(int) - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfigurationBuilder
-
Controls the maximum number of connections per host.
- maxContentLength() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- maxContentLength() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
- maxContentLength() - Method in class org.infinispan.rest.Http11To2UpgradeHandler
- maxContentLength(int) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- maxContentLength(int) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- maxContentLength(int) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
Sets the maximum content length.
- maxContentLength(int) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- maxEntries() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.use
MemoryConfiguration.size()
instead - maxEntries() - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- maxEntries(int) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.
- maxEntries(int) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
-
In order to speed up lookups, the single file cache store keeps an index of keys and their corresponding position in the file.
- maxEntries(long) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.
- maxFailoverAttempts() - Method in interface org.infinispan.distexec.DistributedTaskFailoverPolicy
-
Maximum number of fail over attempts permitted by this DistributedTaskFailoverPolicy
- 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.container.entries.RemoteMetadata
- maxIdle() - Method in class org.infinispan.metadata.EmbeddedMetadata
- 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
- maxIdle() - Method in class org.infinispan.rest.operations.mime.MimeMetadata
- maxIdle() - Method in class org.infinispan.server.memcached.MemcachedMetadata
- maxIdle(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
-
Controls the maximum number of idle persistent connections, per server, at any time.
- 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.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.InfinispanCacheResponse
-
Adds
maxIdleTimeSeconds
header. - 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.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() - Method in annotation type org.infinispan.spring.session.configuration.EnableInfinispanEmbeddedHttpSession
-
This is the session timeout in seconds.
- maxInactiveIntervalInSeconds() - Method in annotation type org.infinispan.spring.session.configuration.EnableInfinispanRemoteHttpSession
-
This is the session timeout in seconds.
- maxResults(int) - Method in interface org.infinispan.query.CacheQuery
-
Sets the maximum number of results to the number passed in as a parameter.
- maxResults(int) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
- maxResults(int) - Method in interface org.infinispan.query.dsl.PaginationContext
- maxRetries() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- maxRetries(int) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
-
The maximum number of retries when a push state command fails.
- MaxRetriesPolicy(int) - Constructor for class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand.MaxRetriesPolicy
- maxSize - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- maxThreads() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
- maxTotal() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- maxTotal(int) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
-
Sets a global limit on the number persistent connections that can be in circulation within the combined set of servers.
- maxTotalConnections() - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- maxTotalConnections(int) - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfigurationBuilder
- MBean - Annotation Type in org.infinispan.jmx.annotations
-
Classes annotated with this will be exposed as MBeans.
- MBEAN_COMPONENT_NAME - Static variable in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- MBEAN_SERVER_LOOKUP - org.infinispan.configuration.parsing.Attribute
- MBEAN_SERVER_LOOKUP - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- mbeanServerLookup() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- mBeanServerLookup(MBeanServerLookup) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
-
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.Use
MBeanServerLookup
instead - MEASUREMENT - org.infinispan.jmx.annotations.DataType
- measurementType() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
- MeasurementType - Enum in org.infinispan.jmx.annotations
- MEBIBYTES - org.infinispan.commons.util.MemoryUnit
- 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 - org.infinispan.configuration.parsing.Attribute
- MEDIA_TYPE - Static variable in class org.infinispan.configuration.cache.ContentTypeConfiguration
- mediaType() - Method in class org.infinispan.commons.marshall.IdentityMarshaller
- mediaType() - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
- mediaType() - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- mediaType() - Method in interface org.infinispan.commons.marshall.Marshaller
- 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.marshall.core.GlobalMarshaller
- mediaType() - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
- mediaType() - Method in class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
- mediaType(String) - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- mediaType(MediaType) - Method in class org.infinispan.configuration.cache.ContentTypeConfiguration
- MediaType - Class in org.infinispan.commons.dataconversion
-
Represent a content type with optional parameters.
- 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.MediaTypeExternalizer - Class in org.infinispan.commons.dataconversion
- 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
- MEGABYTES - org.infinispan.commons.util.MemoryUnit
- members() - Method in class org.infinispan.server.core.security.simple.SimpleGroupPrincipal
- MEMCACHED_COMPAT - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- 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 - Class in org.infinispan.server.memcached
-
Memcached metadata information.
- MemcachedMetadata(long, EntryVersion) - Constructor for class org.infinispan.server.memcached.MemcachedMetadata
- MemcachedMetadataExternalizer - Class in org.infinispan.server.memcached
- MemcachedMetadataExternalizer() - Constructor for class org.infinispan.server.memcached.MemcachedMetadataExternalizer
- 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.Configuration
- memory() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- memory() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- MEMORY - org.infinispan.configuration.parsing.Element
- MEMORY - org.infinispan.eviction.EvictionType
- MemoryAddressHash - Class in org.infinispan.container.offheap
- MemoryAddressHash(int, OffsetCalculator, OffHeapMemoryAllocator) - Constructor for class org.infinispan.container.offheap.MemoryAddressHash
- 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.
- MemoryUnit - Enum in org.infinispan.commons.util
- merge(double[], boolean) - Method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- 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.commons.util.AbstractDelegatingMap
- 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, 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>, 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, 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>, Metadata) - Method in interface org.infinispan.AdvancedCache
- merge(DeltaAware) - Method in interface org.infinispan.atomic.Delta
-
Deprecated.Merge the current Delta instance with a given
DeltaAware
instance, and return a coherent and completeDeltaAware
instance. - 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(EntryVersionsMap) - Method in class org.infinispan.container.versioning.EntryVersionsMap
- 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(TransactionStatistics) - Method in class org.infinispan.stats.CacheStatisticCollector
-
Merges a transaction statistics in this cache statistics.
- MERGE_FUNCTION_MAPPER - Static variable in interface org.infinispan.commons.marshall.Ids
- MERGE_POLICY - org.infinispan.configuration.parsing.Attribute
- MERGE_POLICY - Static variable in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- 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>, long, TimeUnit) - Method in interface org.infinispan.AdvancedCache
-
Overloaded
AsyncCache.mergeAsync(Object, Object, BiFunction)
which takes in lifespan parameters. - 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, long, TimeUnit) - Method in interface org.infinispan.AdvancedCache
-
Overloaded
AsyncCache.mergeAsync(Object, Object, BiFunction)
which takes in lifespan parameters. - 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>, 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, SerializableBiFunction<? super V, ? super V, ? extends V>, Metadata) - Method in interface org.infinispan.AdvancedCache
- 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 - org.infinispan.notifications.cachemanagerlistener.event.Event.Type
- 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
- mergeList(ValidResponse, List<Object>) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- 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
- MergePolicies - Class in org.infinispan.conflict
-
Deprecated.since 9.2 please use
MergePolicy
instead - MergePolicies() - Constructor for class org.infinispan.conflict.MergePolicies
-
Deprecated.
- mergePolicy() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- mergePolicy(EntryMergePolicy) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
- MergePolicy - Enum in org.infinispan.conflict
- MergePolicy.UnsupportedMergePolicy - Class in org.infinispan.conflict
- mergeTo(ConcurrentGlobalContainer) - Method in interface org.infinispan.stats.container.ExtendedStatisticsContainer
-
it merges in
this
the statistic's values inother
. - mergeTo(ConcurrentGlobalContainer) - Method in class org.infinispan.stats.container.LocalExtendedStatisticsContainer
- mergeTo(ConcurrentGlobalContainer) - Method in class org.infinispan.stats.container.RemoteExtendedStatisticsContainer
- MESSAGE - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- MESSAGE_PROTO_RES - Static variable in class org.infinispan.query.remote.client.MarshallerRegistration
- 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
- 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
- metadata() - Method in class org.infinispan.xsite.statetransfer.XSiteState
- 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
- Metadata(int, long, int, byte) - Constructor for class org.infinispan.io.GridFile.Metadata
- METADATA_HELPER - Static variable in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- 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.
- metadataHelper() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- metadataHelper(Class<? extends MetadataHelper>) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- metadataHelper(Class<? extends MetadataHelper>) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- metadataHelper(Class<? extends MetadataHelper>) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
The class of a
MetadataHelper
to use for managing appropriate metadata for the entries Defaults toEmbeddedMetadataHelper
- metadataHelper(String) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- metadataHelper(String) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- metadataHelper(String) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
The class name of a
MetadataHelper
to use for managing appropriate metadata for the entries Defaults toEmbeddedMetadataHelper
- MetadataHelper - Interface in org.infinispan.persistence.rest.metadata
-
MetadataHelper
- MetadataImmortalCacheEntry - Class in org.infinispan.container.entries.metadata
-
A form of
ImmortalCacheEntry
that isMetadataAware
- 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, Metadata) - Constructor for class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
- MetadataImmortalCacheValue.Externalizer - Class in org.infinispan.container.entries.metadata
- MetadataMortalCacheEntry - Class in org.infinispan.container.entries.metadata
-
A cache entry that is mortal and is
MetadataAware
- 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, 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, 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, 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 isVersioned
- 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 isVersioned
- 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
- 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
- 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.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.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
- method() - Method in class org.infinispan.rest.InfinispanRequest
- MICROSECONDS - org.infinispan.server.hotrod.TimeUnitValue
- MIGRATION_TASK - Static variable in interface org.infinispan.persistence.remote.ExternalizerIds
- MigrationMarshaller - Class in org.infinispan.persistence.remote.upgrade
-
MigrationMarshaller.
- MigrationMarshaller(ClassWhiteList) - Constructor for class org.infinispan.persistence.remote.upgrade.MigrationMarshaller
- MigrationTask - Class in org.infinispan.persistence.remote.upgrade
- MigrationTask(Set<Integer>, int, int) - Constructor for class org.infinispan.persistence.remote.upgrade.MigrationTask
- MigrationTask.Externalizer - Class in org.infinispan.persistence.remote.upgrade
- MILLISECONDS - org.infinispan.jmx.annotations.Units
- MILLISECONDS - org.infinispan.server.hotrod.TimeUnitValue
- millisSinceFirstFailure() - Method in class org.infinispan.xsite.OfflineStatus
- MIME_CACHE_ENTRY - Static variable in interface org.infinispan.commons.marshall.Ids
- MIME_METADATA - Static variable in class org.infinispan.server.core.ExternalizerIds
- MIMECacheEntry - Class in org.infinispan.remoting
-
Wrapper object for entries that arrive via RESTful PUT/POST interface.
- MIMECacheEntry() - Constructor for class org.infinispan.remoting.MIMECacheEntry
- MIMECacheEntry(String, byte[]) - Constructor for class org.infinispan.remoting.MIMECacheEntry
- MIMECacheEntry.Externalizer - Class in org.infinispan.remoting
- MimeMetadata - Class in org.infinispan.rest.operations.mime
-
Metadata for MIME data stored in REST servers.
- MimeMetadata(String) - Constructor for class org.infinispan.rest.operations.mime.MimeMetadata
- MimeMetadata.Externalizer - Class in org.infinispan.rest.operations.mime
- MimeMetadataBuilder - Class in org.infinispan.rest.operations.mime
-
Build for mime metadata
- MimeMetadataBuilder() - Constructor for class org.infinispan.rest.operations.mime.MimeMetadataBuilder
- min(String) - Static method in interface org.infinispan.query.dsl.Expression
- 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 - org.infinispan.persistence.remote.configuration.Attribute
- MIN_IDLE - org.infinispan.persistence.remote.configuration.Attribute
- MIN_TIME_TO_WAIT - Static variable in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- MIN_UNSIGNED - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- minEvictableIdleTime() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- 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.
- minFresh(String) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- minIdle() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- 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.
- minTimeHasElapsed() - Method in class org.infinispan.xsite.OfflineStatus
- minTimeToWait() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- minTimeToWait(long) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
-
The minimal number of millis to wait before taking this site offline, even in the case 'afterFailures' is reached.
- MINUTES - org.infinispan.server.hotrod.TimeUnitValue
- 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
- missingRequired(XMLStreamReader, Set<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting a missing, required XML attribute.
- missingRequiredElement(XMLStreamReader, Set<?>) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting a missing, required XML child element.
- MIXED_KEYED_JDBC_STORE - org.infinispan.persistence.jdbc.configuration.Element
- mixedOn(String) - Method in class org.infinispan.xsite.status.ContainerSiteStatusBuilder
-
Adds the cache with an mixed connection to the site.
- mkdir() - Method in class org.infinispan.io.GridFile
- mkdirs() - Method in class org.infinispan.io.GridFile
- mod(int, int) - Static method in class org.infinispan.io.ModularArithmetic
- mod(long, int) - Static method in class org.infinispan.io.ModularArithmetic
- modCount - Variable in class org.infinispan.commons.util.ArrayMap
- MODE - org.infinispan.configuration.parsing.Attribute
- Modification - Interface in org.infinispan.persistence.modifications
-
An interface that defines a
CacheWriter
modification - MODIFICATION_QUEUE_SIZE - 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
- 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.
- ModificationsList - Class in org.infinispan.persistence.modifications
-
ModificationsList contains a List
- ModificationsList(List<? extends Modification>) - Constructor for class org.infinispan.persistence.modifications.ModificationsList
- ModularArithmetic - Class in org.infinispan.io
-
For compatibility
- ModularArithmetic() - Constructor for class org.infinispan.io.ModularArithmetic
- module(Class<T>) - Method in class org.infinispan.configuration.cache.Configuration
- module(Class<T>) - Method in class org.infinispan.configuration.global.GlobalConfiguration
- MODULE - org.infinispan.configuration.parsing.Attribute
- MODULE_COMMAND_FACTORIES - Static variable in class org.infinispan.factories.KnownComponentNames
- MODULE_COMMAND_INITIALIZERS - Static variable in class org.infinispan.factories.KnownComponentNames
- moduleCacheRpcCommands() - Method in class org.infinispan.util.ModuleProperties
- moduleCommandFactories() - Method in class org.infinispan.util.ModuleProperties
- moduleCommandInitializers() - Method in class org.infinispan.util.ModuleProperties
- moduleCommands() - Method in class org.infinispan.util.ModuleProperties
- moduleExternalizers() - Static method in class org.infinispan.lucene.LifecycleCallbacks
-
Static helper to allow for explicit registration of Externalizers: service discovery is not always an option.
- ModuleLifecycle - Interface in org.infinispan.lifecycle
-
ModuleLifecycle is an internal API hook for delegating lifecycle events to Infinispan sub-modules.
- ModuleMetadataFileFinder - Interface in org.infinispan.factories.components
- moduleOnlyReplicableCommands() - Method in class org.infinispan.util.ModuleProperties
- ModuleProperties - Class in org.infinispan.util
-
The
ModuleProperties
class represents Infinispan's module service extensions. - ModuleProperties() - Constructor for class org.infinispan.util.ModuleProperties
- 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.GlobalConfiguration
- modules() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- modules() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Global modules configuration
- MODULES - org.infinispan.configuration.parsing.Element
- 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.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.Externalizer - Class in org.infinispan.container.entries
- MOST_CONTENDED_KEYS - org.infinispan.stats.topK.StreamSummaryContainer.Stat
- MOST_FAILED_KEYS - org.infinispan.stats.topK.StreamSummaryContainer.Stat
- MOST_LOCKED_KEYS - org.infinispan.stats.topK.StreamSummaryContainer.Stat
- MOST_WRITE_SKEW_FAILED_KEYS - org.infinispan.stats.topK.StreamSummaryContainer.Stat
- MULTI_CLUSTER_EVENT_CALLABLE - Static variable in interface org.infinispan.commons.marshall.Ids
- MultiClusterEventCallable<K,V> - Class in org.infinispan.notifications.cachelistener.cluster
-
This DistributedCallable is used to invoke a raised notification on the cluster listener that registered to listen for this event.
- MultiClusterEventCallable(Map<UUID, Collection<ClusterEvent<K, V>>>) - Constructor for class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable
- MultiClusterEventCallable.Externalizer - Class in org.infinispan.notifications.cachelistener.cluster
- multiKeyBackupAck(long, Address, int, int) - Method in class org.infinispan.util.concurrent.CommandAckCollector
-
Acknowledges a
PutMapCommand
completion in the backup owner. - multimap(HotRodHeader, Subject) - Method in class org.infinispan.server.hotrod.HotRodServer
- MultimapCache<K,V> - Interface in org.infinispan.multimap.api.embedded
-
Embedded version of MultimapCache.
- MultimapCacheManager<K,V> - Interface in org.infinispan.multimap.api.embedded
- multimapCollectionResponse(HotRodHeader, HotRodServer, ByteBufAllocator, OperationStatus, Collection<byte[]>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- multimapCollectionResponse(HotRodHeader, HotRodServer, ByteBufAllocator, OperationStatus, Collection<byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- multimapEntryResponse(HotRodHeader, HotRodServer, ByteBufAllocator, OperationStatus, CacheEntry<WrappedByteArray, Collection<WrappedByteArray>>, Collection<byte[]>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- multimapEntryResponse(HotRodHeader, HotRodServer, ByteBufAllocator, OperationStatus, CacheEntry<WrappedByteArray, Collection<WrappedByteArray>>, Collection<byte[]>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- 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
- 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.
- 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
- MYSQL - org.infinispan.persistence.jdbc.DatabaseType
N
- 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.counter.configuration.AbstractCounterConfiguration
- name() - Method in annotation type org.infinispan.filter.NamedFactory
- name() - Method in annotation type org.infinispan.jmx.annotations.ManagedOperation
- name() - Method in annotation type org.infinispan.jmx.annotations.Parameter
- name() - Method in class org.infinispan.lock.configuration.ClusteredLockConfiguration
- name() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- name() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- 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.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 server in order to easily distinguish it from other servers, e.g.
- NAME - org.infinispan.configuration.parsing.Attribute
- NAME - org.infinispan.counter.configuration.Attribute
- NAME - org.infinispan.lock.configuration.Attribute
- NAME - org.infinispan.persistence.jdbc.configuration.Attribute
- NAME - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- NAME_KEY - Static variable in class org.infinispan.jmx.ComponentsJmxRegistration
- NAMED_CACHE - org.infinispan.factories.scopes.Scopes
-
Components bounded to this scope can only be created by a
Cache
and exist in theCache
'sComponentRegistry
. - NamedCacheNotFoundException - Exception in org.infinispan.manager
-
Thrown when a named cache cannot be found.
- NamedCacheNotFoundException(String) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
- NamedCacheNotFoundException(String, String) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
- NamedCacheNotFoundException(String, String, Throwable) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
- NamedCacheNotFoundException(String, Throwable) - Constructor for exception org.infinispan.manager.NamedCacheNotFoundException
- NamedComponentFactory - Class in org.infinispan.factories
-
Deprecated.Since 9.4, please implement
AbstractComponentFactory.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
- NamedParameter(String, Object) - Constructor for class org.infinispan.query.remote.client.QueryRequest.NamedParameter
- NamedParameterExternalizer() - Constructor for class org.infinispan.query.remote.client.Externalizers.NamedParameterExternalizer
- names() - Method in annotation type org.infinispan.factories.annotations.DefaultFactoryFor
- NAMES - org.infinispan.configuration.parsing.Attribute
- NAMES - Static variable in class org.infinispan.server.core.security.external.ExternalSaslServerFactory
- Namespace - Annotation Type in org.infinispan.configuration.parsing
-
Namespace.
- NamespaceMappingParser - Interface in org.infinispan.configuration.parsing
-
NamespaceMappingParser.
- Namespaces - Annotation Type in org.infinispan.configuration.parsing
-
Namespaces.
- NANOSECONDS - org.infinispan.jmx.annotations.Units
- NANOSECONDS - org.infinispan.server.hotrod.TimeUnitValue
- 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 - 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
- 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
- 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
- NEVER - org.infinispan.configuration.cache.BiasAcquisition
-
The bias is never acquired.
- NEVER - org.infinispan.rest.configuration.ExtendedHeaders
- newByteBuffer(byte[], int, int) - Method in interface org.infinispan.commons.io.ByteBufferFactory
- newByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.io.ByteBufferFactoryImpl
- newCatchThrowableProxy(Object) - Static method in class org.infinispan.commons.util.Proxies
- newCondition() - Method in class org.infinispan.commons.util.concurrent.NonReentrantLock
- newConfigurationBuilder(String) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- newConfigurationFrom(int) - Method in class org.infinispan.configuration.cache.AbstractSegmentedStoreConfiguration
-
Method that is invoked each time a new store is created for a segment.
- newConfigurationFrom(int) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfiguration
- newDirectoryInstance(Cache<?, ?>, Cache<?, ?>, Cache<?, ?>, String) - Static method in class org.infinispan.lucene.directory.DirectoryBuilder
-
Starting point to create a Directory instance.
- 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() - Method in class org.infinispan.transaction.xa.TransactionFactory
- newGlobalTransaction() - Method in enum org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- 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(ResponseGenerator, CacheRpcCommand, CommandsFactory, Address) - Static method in class org.infinispan.remoting.LocalInvocation
- newInstance(XSiteBackup, XSiteReplicateCommand, RetryOnFailureXSiteCommand.RetryPolicy) - Static method in class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand
-
It builds a new instance with the destination site, the command and the retry policy.
- newInstanceFromCache(Cache<?, ?>, CacheRpcCommand) - Static method in class org.infinispan.remoting.LocalInvocation
- 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(Class<? extends Encoder>, Class<? extends Wrapper>, MediaType) - Static method in class org.infinispan.encoding.DataConversion
- 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
- newMarshalledEntry(Object, Object, InternalMetadata) - Method in interface org.infinispan.marshall.core.MarshalledEntryFactory
- newMarshalledEntry(Object, Object, InternalMetadata) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
- newMarshalledEntry(Object, ByteBuffer, ByteBuffer) - Method in interface org.infinispan.marshall.core.MarshalledEntryFactory
- newMarshalledEntry(Object, ByteBuffer, ByteBuffer) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
- newMarshalledEntry(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.infinispan.marshall.core.MarshalledEntryFactory
- newMarshalledEntry(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.infinispan.marshall.core.MarshalledEntryFactoryImpl
- newNonTxInvocationContext(Address) - Method in class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- newPermissionCollection() - Method in class org.infinispan.security.CachePermission
- 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
- newRight(B) - Static method in class org.infinispan.commons.util.Either
- newState(boolean, State) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- newTaskFor(Runnable, T) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- newTaskFor(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- newThread(Runnable) - Method in class org.infinispan.factories.threads.DefaultThreadFactory
- newValueDataConversion(Class<? extends Encoder>, Class<? extends Wrapper>, MediaType) - Static method in class org.infinispan.encoding.DataConversion
- next - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareIterator
- 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.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(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- 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.
- NO_COMMIT - org.infinispan.interceptors.locking.ClusteringDependentLogic.Commit
-
Do not commit the entry.
- NO_ENCODER - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- NO_FAILOVER - Static variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- NO_INDEX - Static variable in enum org.infinispan.stats.container.ExtendedStatistic
- NO_OP - Static variable in interface org.infinispan.remoting.inboundhandler.Reply
- 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_RUNNABLE - Static variable in class org.infinispan.util.concurrent.CompletionStages
- NO_OPTIONS - Static variable in class org.infinispan.commons.util.Base64
-
Deprecated.No options specified.
- NO_REBALANCE - org.infinispan.topology.CacheTopology.Phase
-
Only currentCH should be set, this works as both readCH and writeCH
- NO_RETRY - Static variable in class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand
- NO_STATE_TRANSFER_IN_PROGRESS - Static variable in class org.infinispan.statetransfer.StateConsumerImpl
- NO_SUCH_SITE - org.infinispan.xsite.BackupSender.BringSiteOnlineResponse
- NO_SUCH_SITE - org.infinispan.xsite.BackupSender.TakeSiteOfflineResponse
- NO_TRANSACTION - org.infinispan.server.hotrod.tx.table.Status
- NO_VALUE_READ_ONLY_VIEW - Static variable in interface org.infinispan.commons.marshall.Ids
- 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
- NoDataFoundException - Exception in org.infinispan.rest.operations.exceptions
- NoDataFoundException() - Constructor for exception org.infinispan.rest.operations.exceptions.NoDataFoundException
- noDataLossOnJoiner(Configuration) - Static method in class org.infinispan.configuration.cache.Configurations
- Node(K, int, V, EquivalentHashMap.Node<K, V>) - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap.Node
-
Deprecated.
- NODE - org.infinispan.distribution.topologyaware.TopologyLevel
- NODE - org.infinispan.lock.api.OwnershipLevel
- NODE_NAME - org.infinispan.configuration.parsing.Attribute
- NODE_NAME - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- nodeName() - Method in class org.infinispan.configuration.global.TransportConfiguration
- nodeName(String) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Name of the current node.
- NodeSuspected - org.infinispan.server.hotrod.OperationStatus
- NodeTopDocs - Class in org.infinispan.query.clustered
-
A TopDocs with an array with keys of each result.
- NodeTopDocs(Address, TopDocs) - Constructor for class org.infinispan.query.clustered.NodeTopDocs
- NodeTopDocs(Address, TopDocs, Object[], Object[]) - Constructor for class org.infinispan.query.clustered.NodeTopDocs
- NodeTopDocs.Externalizer - Class in org.infinispan.query.clustered
- NODLD_NORECOVERY_NOXA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- NODLD_NORECOVERY_XA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- NODLD_RECOVERY_XA - org.infinispan.transaction.xa.TransactionFactory.TxFactoryEnum
- noFilter() - Method in interface org.infinispan.manager.ClusterExecutor
-
Applies no filtering and will send any invocations to any/all current nodes.
- NoFlag - 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. - NoKeyException - Exception in org.infinispan.rest.operations.exceptions
- NoKeyException() - Constructor for exception org.infinispan.rest.operations.exceptions.NoKeyException
- NoMediaTypeException - Exception in org.infinispan.rest.operations.exceptions
- NoMediaTypeException() - Constructor for exception org.infinispan.rest.operations.exceptions.NoMediaTypeException
- NON_DURABLE_XA - org.infinispan.configuration.cache.TransactionMode
- NON_DURABLE_XA - org.infinispan.configuration.parsing.Parser.TransactionMode
- NON_EXISTING - org.infinispan.server.hotrod.tx.ControlByte
- NON_OWNER - org.infinispan.distribution.Ownership
-
This node is not an owner.
- NON_TRANSACTIONAL - org.infinispan.transaction.TransactionMode
- NON_XA - org.infinispan.configuration.cache.TransactionMode
- NON_XA - org.infinispan.configuration.parsing.Parser.TransactionMode
- 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 - org.infinispan.configuration.cache.Index
-
No indexing is performed.
- NONE - org.infinispan.configuration.cache.TransactionMode
- NONE - org.infinispan.configuration.cache.VersioningScheme
- NONE - org.infinispan.configuration.parsing.Parser.TransactionMode
- NONE - org.infinispan.conflict.MergePolicy
- NONE - 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 - org.infinispan.jmx.annotations.Units
- NONE - org.infinispan.persistence.leveldb.configuration.CompressionType
- NONE - org.infinispan.remoting.inboundhandler.DeliverOrder
-
The message is delivered as soon as it is received.
- NONE - org.infinispan.security.AuthorizationPermission
-
No permissions
- NONE - org.infinispan.statetransfer.RebalanceType
-
Used by local and invalidation cache modes.
- NONE - org.infinispan.util.concurrent.IsolationLevel
-
No isolation.
- 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
- 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.
- 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
- NonTotalOrderPerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
-
A
PerCacheInboundInvocationHandler
implementation for non-total order caches. - NonTotalOrderPerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
- NonTotalOrderTxPerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
-
A
PerCacheInboundInvocationHandler
implementation for non-total order caches. - NonTotalOrderTxPerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
- NonTransactionalBackupInterceptor - Class in org.infinispan.interceptors.xsite
-
Handles x-site data backups for non-transactional caches.
- NonTransactionalBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- NonTransactionalInvocationContextFactory - Class in org.infinispan.context
-
Deprecated.Since 9.0, this class is going to be moved to an internal package.
- NonTransactionalInvocationContextFactory() - Constructor for class org.infinispan.context.NonTransactionalInvocationContextFactory
-
Deprecated.
- NonTransactionalLockingInterceptor - Class in org.infinispan.interceptors.locking
-
Locking interceptor to be used for non-transactional caches.
- NonTransactionalLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
- NonTxDistributionInterceptor - Class in org.infinispan.interceptors.distribution
-
Non-transactional interceptor used by distributed caches that support concurrent writes.
- NonTxDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- NoopSegmentReadLocker - Class in org.infinispan.lucene.readlocks
-
NoopSegmentReadLocker ignores requests to apply a readlock, but also ignores requests to delete files.
- NoopSegmentReadLocker() - Constructor for class org.infinispan.lucene.readlocks.NoopSegmentReadLocker
- 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
- not() - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
- not() - Method in interface org.infinispan.query.dsl.QueryFactory
-
Creates a negated condition that is to be completed later by using it as a sub-condition.
- not(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionBeginContext
- not(FilterConditionContext) - Method in interface org.infinispan.query.dsl.QueryFactory
-
Creates a negated condition based on a given sub-condition.
- NOT_ASYNC - org.infinispan.persistence.manager.PersistenceManager.AccessMode
-
The operation is performed only in a
CacheWriter
orCacheLoader
that doesn't have async write behind. - NOT_FOUND - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- NOT_LOADED - Static variable in class org.infinispan.functional.MetaParam.MetaLoadedFromPersistence
- NOT_LOCAL - org.infinispan.distribution.DataLocality
- NOT_LOCAL_UNCERTAIN - org.infinispan.distribution.DataLocality
- NOT_OWNED - org.infinispan.scattered.ScatteredVersionManager.SegmentState
- NOT_READ - org.infinispan.server.hotrod.tx.ControlByte
- NOT_READY - org.infinispan.remoting.inboundhandler.action.ActionStatus
-
The action isn't completed yet.
- NOT_STORED - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- notExecutedResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[]) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- notExecutedResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[]) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- NotExecutedWithPrevious - org.infinispan.server.hotrod.OperationStatus
- NotExecutedWithPreviousObjStorage - org.infinispan.server.hotrod.OperationStatus
- notExistResponse(HotRodHeader, HotRodServer, ByteBufAllocator) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- notExistResponse(HotRodHeader, HotRodServer, ByteBufAllocator) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- NOTHING - Static variable in interface org.infinispan.transaction.xa.recovery.RecoveryManager.RecoveryIterator
- notifications() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- notifications(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- NOTIFICATIONS - org.infinispan.configuration.parsing.Attribute
- NOTIFICATIONS - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- NOTIFIED - Static variable in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
- notifiedKey(K) - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
-
This should invoked after the key has been successfully processed to tell the handler that the key is done.
- notifier - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- 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<InternalCacheEntry<? extends K, ? extends V>>, InvocationContext, FlagAffectedCommand) - Method in interface org.infinispan.notifications.cachelistener.CacheNotifier
-
Notifies all registered listeners of a
CacheEntriesEvictedEvent
event. - notifyCacheEntriesEvicted(Collection<InternalCacheEntry<? extends K, ? extends 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<? extends CacheEntryEvent<K, V>>, UUID) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- notifyClusterListeners(Collection<? extends CacheEntryEvent<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.
- 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
- notifyEndOfStateTransferIfNeeded() - Method in class org.infinispan.statetransfer.StateConsumerImpl
- 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 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
- notifyOnTransactionFinished() - Method in interface org.infinispan.transaction.xa.CacheTransaction
- 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 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() - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
-
It notifies the end of the state transfer possibly unblock waiting prepares.
- notifyStateTransferStart(int, boolean) - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
-
It notifies that a state transfer is about to start.
- 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
- notifyTopologyInstalled(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
- notifyTopologyInstalled(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- 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
- notifyTransactionDataReceived(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
- notifyTransactionDataReceived(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- 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 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
- notNull(KeyFilter) - Static method in class org.infinispan.persistence.PersistenceUtil
- noTransactionFound() - Method in interface org.infinispan.server.hotrod.tx.table.CacheNameCollector
-
Notifies that no transaction is found.
- 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
- NullCacheEntry<K,V> - Class in org.infinispan.container.entries
- NUM_ABORTED_RO_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_ABORTED_WR_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_ASYNC_COMPLETE_NOTIFY - org.infinispan.stats.container.ExtendedStatistic
- NUM_COMMIT_COMMAND - org.infinispan.stats.container.ExtendedStatistic
- NUM_COMMITTED_RO_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_COMMITTED_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_COMMITTED_WR_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_GET - org.infinispan.stats.container.ExtendedStatistic
- NUM_GETS_RO_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_GETS_WR_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_HELD_LOCKS - org.infinispan.stats.container.ExtendedStatistic
- NUM_HELD_LOCKS_SUCCESS_LOCAL_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_LOCAL_COMMITTED_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_LOCK_FAILED_DEADLOCK - org.infinispan.stats.container.ExtendedStatistic
- NUM_LOCK_FAILED_TIMEOUT - org.infinispan.stats.container.ExtendedStatistic
- NUM_LOCK_PER_LOCAL_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_LOCK_PER_REMOTE_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_NODES_COMMIT - org.infinispan.stats.container.ExtendedStatistic
- NUM_NODES_COMPLETE_NOTIFY - org.infinispan.stats.container.ExtendedStatistic
- NUM_NODES_GET - org.infinispan.stats.container.ExtendedStatistic
- NUM_NODES_PREPARE - org.infinispan.stats.container.ExtendedStatistic
- NUM_NODES_ROLLBACK - org.infinispan.stats.container.ExtendedStatistic
- NUM_OWNERS - org.infinispan.counter.configuration.Attribute
- NUM_OWNERS - org.infinispan.lock.configuration.Attribute
- NUM_OWNERS - Static variable in class org.infinispan.configuration.cache.HashConfiguration
- NUM_PREPARE_COMMAND - org.infinispan.stats.container.ExtendedStatistic
- NUM_PUT - org.infinispan.stats.container.ExtendedStatistic
- NUM_PUTS_WR_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_REMOTE_GET - org.infinispan.stats.container.ExtendedStatistic
- NUM_REMOTE_GETS_RO_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_REMOTE_GETS_WR_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_REMOTE_PUT - org.infinispan.stats.container.ExtendedStatistic
- NUM_REMOTE_PUTS_WR_TX - org.infinispan.stats.container.ExtendedStatistic
- NUM_ROLLBACK_COMMAND - org.infinispan.stats.container.ExtendedStatistic
- NUM_SEGMENTS - Static variable in class org.infinispan.configuration.cache.HashConfiguration
- NUM_SYNC_COMMIT - org.infinispan.stats.container.ExtendedStatistic
- NUM_SYNC_GET - org.infinispan.stats.container.ExtendedStatistic
- NUM_SYNC_PREPARE - org.infinispan.stats.container.ExtendedStatistic
- NUM_SYNC_ROLLBACK - org.infinispan.stats.container.ExtendedStatistic
- NUM_WAITED_FOR_LOCKS - org.infinispan.stats.container.ExtendedStatistic
- NUM_WRITE_SKEW - org.infinispan.stats.container.ExtendedStatistic
- NUMERIC_VERSION - Static variable in interface org.infinispan.commons.marshall.Ids
- 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
- 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
- NumericVersionGenerator.RankCalculator - Class in org.infinispan.container.versioning
- 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.
- 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).
- numVirtualNodes(int) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Deprecated.No longer used since 5.2, replaced by
HashConfigurationBuilder.numSegments(int)
(which works like anumVirtualNodes
value for the entire cluster).
O
- OBJECT - org.infinispan.configuration.cache.StorageType
-
Objects are stored on heap as objects as provided.
- OBJECT - org.infinispan.configuration.parsing.Element
- 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 interface org.infinispan.stats.CacheContainerStats
- 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
-
A helper that efficiently duplicates known object types.
- ObjectDuplicator() - Constructor for class org.infinispan.commons.util.ObjectDuplicator
- 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.commons.marshall.AbstractDelegatingMarshaller
- 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
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.IdentityMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.JavaSerializationMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- 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.marshall.core.GlobalMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.persistence.remote.wrapper.HotRodEntryMarshaller
- objectFromByteBuffer(byte[], int, int) - Method in class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
- objectFromInputStream(InputStream) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- 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
-
Unmarshall an object from an
InputStream
- objectFromInputStream(InputStream) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- objectFromObjectStream(ObjectInput) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- objectFromObjectStream(ObjectInput) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- objectFromObjectStream(ObjectInput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Unmarshalls an object from an
ObjectInput
- objectFromObjectStream(ObjectInput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- objectInput - Variable in class org.infinispan.commons.marshall.DelegatingObjectInput
- objectName() - Method in annotation type org.infinispan.jmx.annotations.MBean
- objectOutput - Variable in class org.infinispan.commons.marshall.DelegatingObjectOutput
- objectToBuffer(Object) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- 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
- 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.JavaSerializationMarshaller
- objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- objectToBuffer(Object, int) - Method in class org.infinispan.commons.marshall.StringMarshaller
- objectToBuffer(Object, int) - Method in class org.infinispan.query.remote.client.BaseProtoStreamMarshaller
- objectToByteBuffer(Object) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- 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
- objectToByteBuffer(Object, int) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- 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
- objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- objectToObjectStream(Object, ObjectOutput) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Marshalls an object to a given
ObjectOutput
- objectToObjectStream(Object, ObjectOutput) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- observation - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- observation() - Method 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(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(PrimitiveIterator.OfInt) - Static method in class org.infinispan.commons.util.SmallIntSet
-
Deprecated.
- OFF_HEAP - org.infinispan.configuration.cache.StorageType
-
Entries are stored in internal memory off the normal Java heap.
- OFFHEAP - org.infinispan.configuration.parsing.Element
- OffHeapConcurrentMap - Class in org.infinispan.container.offheap
- OffHeapConcurrentMap(int, 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(int) - 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
- 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 - org.infinispan.xsite.XSiteAdminCommand.Status
- OFFLINE - Static variable in class org.infinispan.xsite.XSiteAdminOperations
- 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. - OfflineStatus - Class in org.infinispan.xsite
-
Keeps state needed for knowing when a site needs to be taken offline.
- OfflineStatus(TakeOfflineConfiguration, TimeService, SiteStatusListener) - Constructor for class org.infinispan.xsite.OfflineStatus
- OFFSET - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- OK - org.infinispan.server.hotrod.counter.listener.ListenerOperationStatus
-
The operation is completed but it won't use the channel used in the request.
- OK - org.infinispan.server.hotrod.tx.table.Status
- OK - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- OK_AND_CHANNEL_IN_USE - 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.RepeatableReadEntry
- oldValue - Variable in class org.infinispan.container.entries.RepeatableReadEntry
- ON_DEMAND - org.infinispan.rest.configuration.ExtendedHeaders
- ON_READ - org.infinispan.configuration.cache.BiasAcquisition
-
Bias is acquired when the entry is read TODO: Not implemented yet
- ON_REHASH - org.infinispan.configuration.parsing.Attribute
- ON_WRITE - 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.
- 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.util.AbstractDelegatingCacheStream
- 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.CompositeAction
- onComplete() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- onCompletion() - Method in interface org.infinispan.transaction.xa.CacheTransaction.TransactionCompletedListener
- 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. - ONE_NODE - org.infinispan.tasks.TaskExecutionMode
- onEntryActivated(Object) - Method in interface org.infinispan.commons.util.EvictionListener
-
Called back when an entry has been activated
- onEntryChosenForEviction(Map.Entry<K, V>) - Method in interface org.infinispan.commons.util.EvictionListener
-
Called back before an entry is evicted
- onEntryEviction(Map<? extends K, InternalCacheEntry<? extends K, ? extends V>>) - Method in interface org.infinispan.eviction.EvictionManager
-
Handles notifications of evicted entries
- onEntryEviction(Map<K, V>) - Method in interface org.infinispan.commons.util.EvictionListener
-
Called back after entries have been evicted
- onEntryRemoved(Map.Entry<K, V>) - Method in interface org.infinispan.commons.util.EvictionListener
-
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 class org.infinispan.remoting.inboundhandler.action.LockAction
- onEvent(LockState) - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
- onEvent(LockState) - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- 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.CompositeAction
- 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(Throwable) - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- onException(ActionState) - Method in interface org.infinispan.remoting.inboundhandler.action.Action
-
Invoked when an exception occurs while processing the command.
- onException(ActionState) - Method in class org.infinispan.remoting.inboundhandler.action.LockAction
- 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.CompositeAction
- 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() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- 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
- onFinally(ActionState) - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- online - Variable in class org.infinispan.xsite.status.AbstractMixedSiteStatus
- ONLINE - org.infinispan.xsite.XSiteAdminCommand.Status
- ONLINE - Static variable in class org.infinispan.xsite.XSiteAdminOperations
- 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. - onlyPrimary - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- 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 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.jgroups.SingleSiteRequest
- onPostExecute(Callable<T>) - Method in class org.infinispan.distexec.spi.DefaultDistributedTaskLifecycle
- onPostExecute(Callable<T>) - Method in interface org.infinispan.distexec.spi.DistributedTaskLifecycle
- onPostExecute(Callable<T>) - Method in class org.infinispan.distexec.spi.DistributedTaskLifecycleService
- onPreExecute(Callable<T>, Cache<K, V>, Collection<K>) - Method in class org.infinispan.distexec.spi.DefaultDistributedTaskLifecycle
- onPreExecute(Callable<T>, Cache<K, V>, Collection<K>) - Method in interface org.infinispan.distexec.spi.DistributedTaskLifecycle
- onPreExecute(Callable<T>, Cache<K, V>, Collection<K>) - Method in class org.infinispan.distexec.spi.DistributedTaskLifecycleService
- onPrepareCommand() - Method in class org.infinispan.stats.LocalTransactionStatistics
- onPrepareCommand() - Method in class org.infinispan.stats.RemoteTransactionStatistics
- onPrepareCommand() - Method in class org.infinispan.stats.TransactionStatistics
-
Signals the reception of the
PrepareCommand
. - onPrepareCommand(GlobalTransaction, boolean) - Method in class org.infinispan.stats.CacheStatisticManager
-
Invoked when a
PrepareCommand
is received for a transaction. - onReady() - Method in class org.infinispan.remoting.inboundhandler.action.PendingTxAction
- onReady() - Method in interface org.infinispan.util.concurrent.locks.PendingLockListener
-
Invoked when
PendingLockPromise
is ready. - onRemove(Object, boolean) - Method in interface org.infinispan.eviction.ActivationManager
-
Remove key and associated value from cache store and update the activation counter.
- 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.jgroups.SingleSiteRequest
- onResponse(Address, Response) - Method in class org.infinispan.remoting.transport.jgroups.StaggeredRequest
- onStateReceived(int, boolean) - Method in class org.infinispan.statetransfer.InboundTransferTask
- onTaskCompletion(InboundTransferTask) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- onTaskCompletion(OutboundTransferTask) - Method in class org.infinispan.statetransfer.StateProviderImpl
- 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.jgroups.SingleSiteRequest
- onTimeout() - Method in class org.infinispan.remoting.transport.jgroups.StaggeredRequest
- onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.TopologyIdUpdater
- onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.query.affinity.AffinityIndexManager
- onTopologyChange(TopologyChangedEvent<?, ?>) - Method in class org.infinispan.query.affinity.ShardAllocationManagerImpl
- onTopologyUpdate(CacheTopology, boolean) - Method in interface org.infinispan.statetransfer.StateConsumer
-
Receive notification of topology changes.
- onTopologyUpdate(CacheTopology, boolean) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- onTopologyUpdate(CacheTopology, boolean) - Method in interface org.infinispan.statetransfer.StateProvider
-
Receive notification of topology changes.
- onTopologyUpdate(CacheTopology, boolean) - Method in class org.infinispan.statetransfer.StateProviderImpl
- onUpdate(Object, boolean) - Method in interface org.infinispan.eviction.ActivationManager
-
Remove key and associated value from cache store and update the activation counter.
- onUpdate(CounterEvent) - Method in interface org.infinispan.counter.api.CounterListener
- 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
- OPERATION_HOTROD - org.infinispan.context.Flag
-
Flag to identify cache operations coming from the Hot Rod server.
- OPERATION_MEMCACHED - org.infinispan.context.Flag
-
Flag to identify cache operations coming from the Memcached server.
- OPERATION_READ_TIMEOUT - Static variable in class org.infinispan.spring.ConfigurationPropertiesOverrides
- OPERATION_WRITE_TIMEOUT - Static variable in class org.infinispan.spring.ConfigurationPropertiesOverrides
- operationComplete(Future<? super Void>) - Method in class org.infinispan.server.hotrod.iteration.IterationReaper
- OperationNotExecuted - org.infinispan.server.hotrod.OperationStatus
- OperationStatus - Enum in org.infinispan.server.hotrod
-
Hot Rod operation possible status outcomes.
- OperationTimedOut - org.infinispan.server.hotrod.OperationStatus
- OPTIMISTIC - org.infinispan.transaction.LockingMode
- OptimisticBackupInterceptor - Class in org.infinispan.interceptors.xsite
-
Handles x-site data backups for optimistic transactional caches.
- OptimisticBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.OptimisticBackupInterceptor
- OptimisticLockingInterceptor - Class in org.infinispan.interceptors.locking
-
Locking interceptor to be used by optimistic transactional caches.
- OptimisticLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
- 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
- optionalString(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- or() - Method in interface org.infinispan.query.dsl.FilterConditionContext
-
Creates a new context and connects it with the current one using boolean OR.
- or(FilterConditionContext) - Method in interface org.infinispan.query.dsl.FilterConditionContext
-
Connects a given context with the current one using boolean OR.
- ORACLE - org.infinispan.persistence.jdbc.DatabaseType
- orderBy(String) - Method in interface org.infinispan.query.dsl.QueryBuilder
- orderBy(String, SortOrder) - Method in interface org.infinispan.query.dsl.QueryBuilder
- orderBy(Expression) - Method in interface org.infinispan.query.dsl.QueryBuilder
- orderBy(Expression, SortOrder) - Method in interface org.infinispan.query.dsl.QueryBuilder
- OrderedUpdatesManager - Interface in org.infinispan.persistence.manager
- OrderedUpdatesManagerImpl - Class in org.infinispan.persistence.manager
- OrderedUpdatesManagerImpl() - Constructor for class org.infinispan.persistence.manager.OrderedUpdatesManagerImpl
- 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.
- 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.atomic - package org.infinispan.atomic
-
This package contains the
AtomicMap
interfaces and API that Infinispan exposes as building blocks in creating other public interfaces such as the Tree API. - org.infinispan.batch - package org.infinispan.batch
-
Support for batching calls using the
BatchingCache.startBatch()
andBatchingCache.endBatch(boolean)
API. - 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.dataconversion - package org.infinispan.commons.dataconversion
- org.infinispan.commons.equivalence - package org.infinispan.commons.equivalence
-
Equivalence classes and interfaces to enable equivalence comparison between native types, arrays, etc.
- 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.io - package org.infinispan.commons.io
-
Commons IO package
- org.infinispan.commons.jmx - package org.infinispan.commons.jmx
- 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.marshall.jboss - package org.infinispan.commons.marshall.jboss
-
Hooks to bridge Infinispan's marshalling APIs with JBoss Marshalling internals.
- org.infinispan.commons.persistence - package org.infinispan.commons.persistence
- 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.uberjar - package org.infinispan.commons.util.uberjar
- org.infinispan.compat - package org.infinispan.compat
- 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.internal - package org.infinispan.configuration.internal
-
A private configuration package.
- 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.offheap - package org.infinispan.container.offheap
- org.infinispan.container.versioning - package org.infinispan.container.versioning
- 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.counter - package org.infinispan.counter
-
Embedded Clustered Counters.
- 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.util - package org.infinispan.counter.util
- org.infinispan.distexec - package org.infinispan.distexec
-
Distributed Executor APIs (deprecated)
- org.infinispan.distexec.spi - package org.infinispan.distexec.spi
- 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.group - package org.infinispan.distribution.group
-
Groups allow keys with differeing hash codes to be co-located on the same node.
- 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.eviction - package org.infinispan.eviction
-
Classes related to eviction.
- 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.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.components - package org.infinispan.factories.components
- org.infinispan.factories.scopes - package org.infinispan.factories.scopes
-
Scopes of components within the lifespan of a
CacheManager
and its variousCache
s, 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.globalstate - package org.infinispan.globalstate
-
Global configuration state.
- org.infinispan.health - package org.infinispan.health
- 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.interceptors.base - package org.infinispan.interceptors.base
-
Base interceptors containing common, reusable behavior.
- org.infinispan.interceptors.distribution - package org.infinispan.interceptors.distribution
-
Interceptors dealing with command replication in distributed/replicated mode.
- org.infinispan.interceptors.locking - package org.infinispan.interceptors.locking
-
Interceptors dealing with locking.
- org.infinispan.interceptors.totalorder - package org.infinispan.interceptors.totalorder
-
Interceptors dealing with total order.
- org.infinispan.interceptors.xsite - package org.infinispan.interceptors.xsite
-
Interceptors dealing with cross-site replication.
- org.infinispan.io - package org.infinispan.io
-
Provides Infinispan-specific input and output streams, buffers and related utilities.
- org.infinispan.jmx - package org.infinispan.jmx
-
Helpers that allow easy exposure of attributes and operations via JMX.
- org.infinispan.jmx.annotations - package org.infinispan.jmx.annotations
-
JMX 2.0-like annotations, with no dependencies on JMX 2.0.
- org.infinispan.lifecycle - package org.infinispan.lifecycle
-
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.lucene - package org.infinispan.lucene
-
Lucene Directory implementation which stores the index in Infinispan.
- org.infinispan.lucene.cacheloader - package org.infinispan.lucene.cacheloader
- org.infinispan.lucene.cacheloader.configuration - package org.infinispan.lucene.cacheloader.configuration
- org.infinispan.lucene.directory - package org.infinispan.lucene.directory
-
Builder for Lucene Directory implementation which stores the index in Infinispan.
- org.infinispan.lucene.readlocks - package org.infinispan.lucene.readlocks
-
Several implementations for a SegmentReadLocker, pick one depending on your use case.
- org.infinispan.manager - package org.infinispan.manager
-
Cache manager API.
- 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.metadata - package org.infinispan.metadata
-
Metadata interfaces
- 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.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.event - package org.infinispan.notifications.cachelistener.event
-
Cache
-specific listener events - 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.objectfilter - package org.infinispan.objectfilter
-
Querying on plain Java objects.
- org.infinispan.partitionhandling - package org.infinispan.partitionhandling
- 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.factory - package org.infinispan.persistence.factory
- 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.configuration - package org.infinispan.persistence.jdbc.configuration
-
Configuration for the JDBC CacheStore.
- org.infinispan.persistence.jdbc.connectionfactory - package org.infinispan.persistence.jdbc.connectionfactory
- org.infinispan.persistence.jdbc.stringbased - package org.infinispan.persistence.jdbc.stringbased
-
JDBC CacheStore implementation which maps keys to strings.
- org.infinispan.persistence.jpa - package org.infinispan.persistence.jpa
-
JPA-based
AdvancedLoadWriteStore
. - org.infinispan.persistence.jpa.configuration - package org.infinispan.persistence.jpa.configuration
-
Configuration for
JpaStore
. - org.infinispan.persistence.keymappers - package org.infinispan.persistence.keymappers
- org.infinispan.persistence.leveldb - package org.infinispan.persistence.leveldb
- org.infinispan.persistence.leveldb.configuration - package org.infinispan.persistence.leveldb.configuration
-
Configuration for
LevelDBStore
. - org.infinispan.persistence.manager - package org.infinispan.persistence.manager
-
Implementations of the
PersistenceManager
interface, which define the logic of how infinispan interacts with external stores. - 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.upgrade - package org.infinispan.persistence.remote.upgrade
- org.infinispan.persistence.remote.wrapper - package org.infinispan.persistence.remote.wrapper
- org.infinispan.persistence.rest - package org.infinispan.persistence.rest
-
RESTful
AdvancedLoadWriteStore
. - org.infinispan.persistence.rest.configuration - package org.infinispan.persistence.rest.configuration
-
Configuration for
RestStore
. - org.infinispan.persistence.rest.metadata - package org.infinispan.persistence.rest.metadata
- org.infinispan.persistence.rest.upgrade - package org.infinispan.persistence.rest.upgrade
- org.infinispan.persistence.spi - package org.infinispan.persistence.spi
-
The Persistence SPI.
- 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.
- org.infinispan.query.affinity - package org.infinispan.query.affinity
-
This package contains the implementation of the AffinityIndexManager, that maintains an index divided into shards with storage using the Infinispan Lucene directory.
- org.infinispan.query.api.continuous - package org.infinispan.query.api.continuous
-
Continuous querying API.
- org.infinispan.query.clustered - package org.infinispan.query.clustered
- org.infinispan.query.clustered.commandworkers - package org.infinispan.query.clustered.commandworkers
- org.infinispan.query.dsl - package org.infinispan.query.dsl
-
Query DSL API.
- org.infinispan.query.indexmanager - package org.infinispan.query.indexmanager
- 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
-
Hot Rod query API.
- org.infinispan.query.remote.json - package org.infinispan.query.remote.json
- org.infinispan.query.spi - package org.infinispan.query.spi
- org.infinispan.registry - package org.infinispan.registry
-
The internal cache registry API
- org.infinispan.remoting - package org.infinispan.remoting
-
Remote communication between cache instances.
- org.infinispan.remoting.inboundhandler - package org.infinispan.remoting.inboundhandler
-
Handling of inbound commands on remote nodes.
- 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.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.cachemanager - package org.infinispan.rest.cachemanager
-
Cache manager wrapper for REST interface.
- 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.context - package org.infinispan.rest.context
-
REST Context checker classes.
- org.infinispan.rest.cors - package org.infinispan.rest.cors
- org.infinispan.rest.operations - package org.infinispan.rest.operations
-
REST Server Operations classes.
- 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.operations.mime - package org.infinispan.rest.operations.mime
- org.infinispan.rest.search - package org.infinispan.rest.search
- org.infinispan.scattered - package org.infinispan.scattered
-
SCATTERED CACHE DESIGN
- org.infinispan.scripting - package org.infinispan.scripting
- org.infinispan.scripting.utils - package org.infinispan.scripting.utils
- org.infinispan.security - package org.infinispan.security
-
Security API.
- org.infinispan.security.actions - package org.infinispan.security.actions
- 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.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.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.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.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.spring - package org.infinispan.spring
-
Spring Infinispan - Shared classes.
- org.infinispan.spring.config - package org.infinispan.spring.config
- org.infinispan.spring.provider - package org.infinispan.spring.provider
-
Spring Infinispan - An implementation of Spring's Cache SPI based on JBoss Infinispan.
- org.infinispan.spring.session - package org.infinispan.spring.session
- org.infinispan.spring.session.configuration - package org.infinispan.spring.session.configuration
- org.infinispan.spring.support.embedded - package org.infinispan.spring.support.embedded
- org.infinispan.spring.support.remote - package org.infinispan.spring.support.remote
- org.infinispan.statetransfer - package org.infinispan.statetransfer
-
Transfer of state to new caches in a cluster.
- org.infinispan.stats - package org.infinispan.stats
-
Cache statistics.
- org.infinispan.stats.container - package org.infinispan.stats.container
- org.infinispan.stats.percentiles - package org.infinispan.stats.percentiles
- org.infinispan.stats.topK - package org.infinispan.stats.topK
- org.infinispan.stats.wrappers - package org.infinispan.stats.wrappers
- org.infinispan.stream - package org.infinispan.stream
-
Cache stream processing.
- org.infinispan.tasks - package org.infinispan.tasks
-
Server tasks API.
- org.infinispan.tasks.spi - package org.infinispan.tasks.spi
- org.infinispan.topology - package org.infinispan.topology
- org.infinispan.transaction - package org.infinispan.transaction
-
JTA transaction support.
- 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.totalorder - package org.infinispan.transaction.totalorder
- 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.function - package org.infinispan.util.function
- org.infinispan.util.rxjava - package org.infinispan.util.rxjava
- org.infinispan.util.stream - package org.infinispan.util.stream
- org.infinispan.xsite - package org.infinispan.xsite
- org.infinispan.xsite.notification - package org.infinispan.xsite.notification
- org.infinispan.xsite.statetransfer - package org.infinispan.xsite.statetransfer
- org.infinispan.xsite.status - package org.infinispan.xsite.status
- OsgiClassLoader - Class in org.infinispan.commons.util
- OTHER_THAN_FIRST_OR_LAST - org.infinispan.configuration.cache.InterceptorConfiguration.Position
-
Specifies that the new interceptor can be placed anywhere, except first or last.
- OUTBOUND_SOCKET_BINDING - org.infinispan.persistence.remote.configuration.Attribute
- OUTBOUND_SOCKET_BINDING - org.infinispan.persistence.rest.configuration.Attribute
- OutboundTransferTask - Class in org.infinispan.statetransfer
-
Outbound state transfer task.
- OutboundTransferTask(Address, IntSet, int, int, int, KeyPartitioner, Consumer<OutboundTransferTask>, Consumer<List<StateChunk>>, BiFunction<InternalCacheEntry, InternalEntryFactory, InternalCacheEntry>, BiFunction<MarshalledEntry, InternalEntryFactory, InternalCacheEntry>, InternalDataContainer, PersistenceManager, RpcManager, CommandsFactory, InternalEntryFactory, long, String, boolean, boolean) - Constructor for class org.infinispan.statetransfer.OutboundTransferTask
- OutdatedTopologyException - Exception in org.infinispan.statetransfer
-
An exception signalling that a command should be retried because a newer topology was seen during execution.
- OutdatedTopologyException(int) - Constructor for exception org.infinispan.statetransfer.OutdatedTopologyException
-
Deprecated.Since 10.0, the explicit topology is ignored and the delta is set to 1
- OutdatedTopologyException(String) - Constructor for exception org.infinispan.statetransfer.OutdatedTopologyException
-
Deprecated.Since 10.0, please use the constants
- OutputPrinter - Interface in org.infinispan.rest.operations.mediatypes
-
Converts binary array from
Cache
into output format. - OutputStream(OutputStream) - Constructor for class org.infinispan.commons.util.Base64.OutputStream
-
Deprecated.Constructs a
Base64.OutputStream
in ENCODE mode. - OutputStream(OutputStream, int) - Constructor for class org.infinispan.commons.util.Base64.OutputStream
-
Deprecated.Constructs a
Base64.OutputStream
in either ENCODE or DECODE mode. - OVERLAY - org.infinispan.globalstate.ConfigurationStorage
-
Persists cache configurations to the
GlobalStateConfiguration.persistentLocation()
in a - OVERLAY_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
- override(Properties) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- overrideSegmentReadLocker(SegmentReadLocker) - Method in interface org.infinispan.lucene.directory.BuildContext
-
Overrides the default SegmentReadLocker.
- overrideWrapper(Class<? extends Wrapper>, ComponentRegistry) - Method in class org.infinispan.encoding.DataConversion
- overrideWriteLocker(LockFactory) - Method in interface org.infinispan.lucene.directory.BuildContext
-
Overrides the IndexWriter LockFactory
- OWNED - org.infinispan.scattered.ScatteredVersionManager.SegmentState
- OWNERS - org.infinispan.configuration.parsing.Attribute
- Ownership - Enum in org.infinispan.distribution
- OwnershipLevel - Enum in org.infinispan.lock.api
-
Ownership level is a configuration parameter for
ClusteredLock
. - ownsData() - Method in interface org.infinispan.statetransfer.StateConsumer
- ownsData() - Method in class org.infinispan.statetransfer.StateConsumerImpl
- ownsData() - Method in interface org.infinispan.statetransfer.StateTransferManager
-
Deprecated.Since 9.4, will be removed.
- ownsData() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- ownsLock(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- ownsLock(Object, Object) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- ownsLock(Object, Object) - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- ownsLock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Tests if the
lockOwner
owns a lock on thekey
.
P
- padString(String, int) - Static method in class org.infinispan.commons.util.Util
- PaginationContext<Context extends PaginationContext> - Interface in org.infinispan.query.dsl
- 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.util.AbstractDelegatingCacheStream
- 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.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.
- 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.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
- parallelStream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
- parallelStream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.TxBackingEntrySet
- parallelStream() - Method in class org.infinispan.util.AbstractDelegatingCacheCollection
- parallelStream() - Method in class org.infinispan.util.CacheCollectionMapper
-
Deprecated.
- 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
- 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.
- Parameter - Annotation Type in org.infinispan.jmx.annotations
- ParameterContext<Context extends ParameterContext> - Interface in org.infinispan.query.dsl
- parameters - Variable in class org.infinispan.rest.InfinispanRequest
- parameters(Map<String, ?>) - Method in class org.infinispan.tasks.TaskContext
-
A map of named parameters that will be passed to the task.
- 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.server.memcached.MemcachedDecoder
- parse(InputStream) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parse(InputStream, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parse(String) - Static method in class org.infinispan.commons.dataconversion.MediaType
- parse(String) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parse(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parseBytes(String) - Static method in enum org.infinispan.commons.util.MemoryUnit
- parseCacheElement(XMLExtendedStreamReader, Element, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
- parseConfigurations(InputStream) - Method in class org.infinispan.counter.configuration.CounterConfigurationParser
-
Reads a list of counter's configuration from an
InputStream
. - parseDataType(XMLExtendedStreamReader, ConfigurationBuilder, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
- ParsedCacheMode - Enum in org.infinispan.configuration.parsing
- parsedConfigToConfig(AbstractCounterConfiguration) - Static method in class org.infinispan.counter.configuration.ConvertUtil
- parseElement(XMLExtendedStreamReader, 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(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- ParseError - org.infinispan.server.hotrod.OperationStatus
- parseFile(String) - Method in class org.infinispan.configuration.parsing.ParserRegistry
- parseFileStore(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
- parseInnerBeanDefinition(Element, ParserContext) - Static method in class org.infinispan.spring.config.InfinispanNamespaceUtils
- parseInternal(Element, ParserContext) - Method in class org.infinispan.spring.config.InfinispanContainerCacheManagerBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class org.infinispan.spring.config.InfinispanEmbeddedCacheManagerBeanDefinitionParser
- parseInternal(Element, ParserContext) - Method in class org.infinispan.spring.config.InfinispanRemoteCacheManagerBeanDefinitionParser
- parseList(String) - Static method in class org.infinispan.commons.dataconversion.MediaType
- parseLocking(XMLExtendedStreamReader, ConfigurationBuilder) - Method in class org.infinispan.configuration.parsing.Parser
- parseProperties(XMLExtendedStreamReader) - Static method in class org.infinispan.configuration.parsing.Parser
- 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
- Parser.Mode - Enum in org.infinispan.configuration.parsing
- Parser.TransactionMode - Enum in org.infinispan.configuration.parsing
- Parser72 - Class in org.infinispan.configuration.parsing
-
Deprecated.
- Parser72() - Constructor for class org.infinispan.configuration.parsing.Parser72
-
Deprecated.
- ParserContext - Interface in org.infinispan.configuration.parsing
-
ParserContext.
- ParserContextListener - Interface in org.infinispan.configuration.parsing
-
ParserContextListener.
- 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) - Constructor for class org.infinispan.configuration.parsing.ParserRegistry
- ParserRegistry.NamespaceParserPair - Class in org.infinispan.configuration.parsing
- ParserScope - Enum in org.infinispan.configuration.parsing
-
ParserScope indicates the configuration parser scope.
- parseStoreAttribute(XMLExtendedStreamReader, int, AbstractStoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser
-
This method is public static so that it can be reused by custom cache store/loader configuration parsers
- parseStoreElement(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser
- parseStoreElement(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser72
-
Deprecated.
- parseStoreProperty(XMLExtendedStreamReader, StoreConfigurationBuilder<?, ?>) - Static method in class org.infinispan.configuration.parsing.Parser
- parseStoreWriteBehind(XMLExtendedStreamReader, AsyncStoreConfigurationBuilder<?>) - Static method in class org.infinispan.configuration.parsing.Parser
- parseTransaction(XMLExtendedStreamReader, ConfigurationBuilder, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
- ParseUtils - Class in org.infinispan.configuration.parsing
- parsingComplete(ParserContext) - Method in interface org.infinispan.configuration.parsing.ParserContextListener
- 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_HANDLING - org.infinispan.configuration.parsing.Element
- PARTITION_STATUS_CHANGED - org.infinispan.notifications.cachelistener.event.Event.Type
- 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
- PartitionHandlingManagerFactory - Class in org.infinispan.factories
- PartitionHandlingManagerFactory() - Constructor for class org.infinispan.factories.PartitionHandlingManagerFactory
- 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
. - passivate(InternalCacheEntry) - Method in interface org.infinispan.eviction.PassivationManager
- passivateAll() - Method in interface org.infinispan.eviction.PassivationManager
- 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 - org.infinispan.configuration.parsing.Attribute
- PASSIVATION - org.infinispan.persistence.jdbc.configuration.Attribute
- PASSIVATION - Static variable in class org.infinispan.configuration.cache.PersistenceConfiguration
- PassivationManager - Interface in org.infinispan.eviction
-
A passivation manager
- passivator - Variable in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- password() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
- password() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
- password() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- password(char[]) - 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.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- password(String) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
- password(String) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Specifies the password to be used for authentication.
- PASSWORD - org.infinispan.persistence.jdbc.configuration.Attribute
- PASSWORD - org.infinispan.persistence.remote.configuration.Attribute
- path() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- path(String) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- path(String) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- path(String) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
The path portion of the RESTful service.
- PATH - org.infinispan.configuration.parsing.Attribute
- PATH - org.infinispan.persistence.leveldb.configuration.Attribute
- PATH - org.infinispan.persistence.rest.configuration.Attribute
- PATH - Static variable in class org.infinispan.commons.util.ClassFinder
- PATH - Static variable in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- 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.offheap.BoundedOffHeapDataContainer
- peek(Object) - Method in interface org.infinispan.commons.util.PeekableMap
-
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.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.util.AbstractDelegatingCacheStream
- peek(DoubleConsumer) - Method in interface org.infinispan.DoubleCacheStream
- peek(IntConsumer) - Method in interface org.infinispan.IntCacheStream
- peek(LongConsumer) - Method in interface org.infinispan.LongCacheStream
- 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(SerializableIntConsumer) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntCacheStream.flatMap(IntFunction)
except that the IntFunction must also implementSerializable
- peek(SerializableLongConsumer) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongCacheStream.flatMap(LongFunction)
except that the LongFunction must also implement Serializable. - PeekableMap<K,V> - Interface in org.infinispan.commons.util
- PENDING - 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
. - PendingTxAction - Class in org.infinispan.remoting.inboundhandler.action
-
An
Action
implementation that check for older topology transactions. - PendingTxAction(PendingLockManager, DistributionManager) - Constructor for class org.infinispan.remoting.inboundhandler.action.PendingTxAction
- PER_SENDER - org.infinispan.remoting.inboundhandler.DeliverOrder
-
The message is delivered by the order they are sent.
- PerCacheInboundInvocationHandler - Interface in org.infinispan.remoting.inboundhandler
-
Interface to invoke when a
CacheRpcCommand
is received from other node in the local site. - 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
- PERCENTAGE - org.infinispan.jmx.annotations.Units
- PercentileStatistic - Enum in org.infinispan.stats.percentiles
-
Percentile statistic for the transaction execution time.
- perform(AdvancedCache<?, ?>) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
- perform(AdvancedCache<?, ?>, QueryDefinition, UUID, int) - Method in enum org.infinispan.query.clustered.commandworkers.CQCommandType
- performCommandWithL1WriteIfAble(InvocationContext, DataCommand, boolean, boolean, boolean) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- performInLocalSite(BackupReceiver, boolean) - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
- performInLocalSite(BackupReceiver, boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- performInLocalSite(BackupReceiver, boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- performInLocalSite(BackupReceiver, boolean) - Method in class org.infinispan.xsite.XSiteReplicateCommand
- performOperations(List<LuceneWork>, IndexingMonitor) - Method in class org.infinispan.query.affinity.AffinityIndexManager
- performWriteSkewCheck(DataContainer, int, PersistenceManager, TxInvocationContext, EntryVersion, VersionGenerator, TimeService) - Method in class org.infinispan.container.entries.VersionedRepeatableReadEntry
- PERMANENT - org.infinispan.commons.api.CacheContainerAdmin.AdminFlag
-
If the operation affects configuration, make it permanent, which means it will survive restarts.
- permission(String) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
-
Adds a permission to a role
- permission(AuthorizationPermission) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
-
Adds a permission to a role
- PERMISSIONS - org.infinispan.configuration.parsing.Attribute
- 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 - org.infinispan.configuration.parsing.Element
- PERSISTENCE_AVAILABILITY_CHANGED - org.infinispan.notifications.cachelistener.event.Event.Type
- PERSISTENCE_EXECUTOR - org.infinispan.configuration.parsing.Attribute
- PERSISTENCE_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
- PERSISTENCE_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
- PERSISTENCE_UNIT_NAME - org.infinispan.persistence.jpa.configuration.Attribute
- 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 - 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
- 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() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated.This method always returns null now. Look for a thread pool named as
GlobalConfiguration.persistenceThreadPool()
instead. - persistenceManager - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- persistenceManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- persistenceManager - Variable in class org.infinispan.statetransfer.StateProviderImpl
- PersistenceManager - Interface in org.infinispan.persistence.manager
-
Defines the logic for interacting with the chain of external storage.
- PersistenceManager.AccessMode - Enum in org.infinispan.persistence.manager
- PersistenceManagerCloseableSupplier<K,V> - Class in org.infinispan.persistence.util
-
Deprecated.This class is to be removed when
AdvancedCacheLoader.process(KeyFilter, AdvancedCacheLoader.CacheLoaderTask, Executor, boolean, boolean)
is removed - PersistenceManagerCloseableSupplier(Executor, AdvancedCacheLoader<K, V>, Predicate<? super K>, boolean, boolean, long, TimeUnit, int) - Constructor for class org.infinispan.persistence.util.PersistenceManagerCloseableSupplier
-
Deprecated.
- PersistenceManagerImpl - Class in org.infinispan.persistence.manager
- PersistenceManagerImpl() - Constructor for class org.infinispan.persistence.manager.PersistenceManagerImpl
- PersistenceManagerStub - Class in org.infinispan.persistence.manager
- PersistenceManagerStub() - Constructor for class org.infinispan.persistence.manager.PersistenceManagerStub
- persistenceThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- persistenceThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- persistenceThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Configuration for the persistence thread pool
- persistenceUnitName() - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfiguration
- persistenceUnitName(String) - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationBuilder
- 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 - org.infinispan.counter.api.Storage
-
The counter value is stored persistently and survives a cluster restart/stop.
- PERSISTENT - org.infinispan.registry.InternalCacheRegistry.Flag
-
means the cache should be made persistent across restarts if global state persistence is enabled
- PERSISTENT_LOCATION - org.infinispan.configuration.parsing.Element
- PERSISTENT_LOCATION - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
- 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 persistent state data which needs to survive container restarts should be stored.
- 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 - org.infinispan.transaction.LockingMode
- PessimisticBackupInterceptor - Class in org.infinispan.interceptors.xsite
-
Handles x-site data backups for pessimistic transactional caches.
- PessimisticBackupInterceptor() - Constructor for class org.infinispan.interceptors.xsite.PessimisticBackupInterceptor
- PessimisticLockingInterceptor - Class in org.infinispan.interceptors.locking
-
Locking interceptor to be used by pessimistic caches.
- PessimisticLockingInterceptor() - Constructor for class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
- physicalAddress - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- pickConsistentHashFactory(GlobalConfiguration, Configuration) - Static method in class org.infinispan.statetransfer.StateTransferManagerImpl
-
If no ConsistentHashFactory was explicitly configured we choose a suitable one based on cache mode.
- pickRoute(String, List<Route>, Address) - Method in class org.infinispan.remoting.transport.jgroups.SiteMasterPickerImpl
- pickSiteMaster(List<Address>, Address) - Method in class org.infinispan.remoting.transport.jgroups.SiteMasterPickerImpl
- PIGGYBACK - org.infinispan.eviction.EvictionThreadPolicy
- PING - org.infinispan.server.hotrod.HotRodOperation
- PING_ON_STARTUP - org.infinispan.persistence.remote.configuration.Attribute
- PING_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- PlatformMBeanServerLookup - Class in org.infinispan.commons.jmx
-
Default implementation for
MBeanServerLookup
, will return the platform MBean server. - PlatformMBeanServerLookup - Class in org.infinispan.jmx
-
Deprecated.Use
PlatformMBeanServerLookup
instead - PlatformMBeanServerLookup() - Constructor for class org.infinispan.commons.jmx.PlatformMBeanServerLookup
- PlatformMBeanServerLookup() - Constructor for class org.infinispan.jmx.PlatformMBeanServerLookup
-
Deprecated.
- POINTER_SIZE - Static variable in class org.infinispan.commons.util.AbstractEntrySizeCalculatorHelper
- POLICY_DISABLE - org.infinispan.topology.CacheTopologyControlCommand.Type
- POLICY_ENABLE - org.infinispan.topology.CacheTopologyControlCommand.Type
- POLICY_GET_STATUS - org.infinispan.topology.CacheTopologyControlCommand.Type
- poll() - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
-
{@inheritDoc CompletionService}
- poll() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- poll() - Method in class org.infinispan.executors.SemaphoreCompletionService
- poll(long, TimeUnit) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
-
{@inheritDoc CompletionService}
- poll(long, TimeUnit) - Method in class org.infinispan.executors.ExecutorAllCompletionService
- poll(long, TimeUnit) - Method in class org.infinispan.executors.SemaphoreCompletionService
- pollStoreAvailability() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- PooledConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.configuration
- PooledConnectionFactoryConfiguration(String, String, String, String, String) - Constructor for class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
- PooledConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Class in org.infinispan.persistence.jdbc.configuration
-
PooledConnectionFactoryConfigurationBuilder.
- PooledConnectionFactoryConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- port() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfiguration
- port() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- port() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- port(int) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
- port(int) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- port(int) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- port(int) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
The port to connect to.
- 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 - org.infinispan.persistence.remote.configuration.Attribute
- PORT - org.infinispan.persistence.rest.configuration.Attribute
- PORT - Static variable in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- PORT - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- position() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- position() - Method in class org.infinispan.io.ReadableGridFileChannel
- position(long) - Method in class org.infinispan.io.ReadableGridFileChannel
- position(InterceptorConfiguration.Position) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
Specifies a position, denoted by the
InterceptorConfiguration.Position
enumeration, where to place the new interceptor. - POSITION - org.infinispan.configuration.parsing.Attribute
- POSITION - Static variable in class org.infinispan.configuration.cache.InterceptorConfiguration
- POST - org.infinispan.notifications.Listener.Observation
-
Observation level used to only be notified of an operation after it has completed
- 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
- POSTGRES - org.infinispan.persistence.jdbc.DatabaseType
- 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 - Annotation Type in org.infinispan.factories.annotations
-
Deprecated.Since 9.4, please use
Start
instead. - 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
- PRE - org.infinispan.notifications.Listener.Observation
-
Observation level used to only be notified of an operation before it completes
- PreconditionsFailedException - Exception in org.infinispan.rest.operations.exceptions
- PreconditionsFailedException() - Constructor for exception org.infinispan.rest.operations.exceptions.PreconditionsFailedException
- 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. - PREFERRED_ALWAYS - org.infinispan.conflict.MergePolicy
- PREFERRED_ALWAYS - Static variable in class org.infinispan.conflict.MergePolicies
-
Deprecated.
- PREFERRED_NON_NULL - org.infinispan.conflict.MergePolicy
- PREFERRED_NON_NULL - Static variable in class org.infinispan.conflict.MergePolicies
-
Deprecated.
- PREFIX - org.infinispan.persistence.jdbc.configuration.Attribute
- preload - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Deprecated.
- 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() - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Loads the data from the external store into memory during cache startup.
- preload() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- preload() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- 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 - org.infinispan.configuration.parsing.Attribute
- PRELOAD - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- PreloadManager - Class in org.infinispan.persistence.manager
-
Separate the preload into its own component
- PreloadManager() - Constructor for class org.infinispan.persistence.manager.PreloadManager
- 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(Xid) - Method in class org.infinispan.transaction.xa.XaTransactionTable
- PREPARE_COMMAND_SIZE - org.infinispan.stats.container.ExtendedStatistic
- PREPARE_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- PREPARE_TX - org.infinispan.server.hotrod.HotRodOperation
- PREPARE_TX - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- PREPARE_TX_2 - org.infinispan.server.hotrod.HotRodOperation
- PREPARE_TX_2 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- prepareAllTxStores(Transaction, BatchModification, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Perform the prepare phase of 2PC on all Tx stores.
- prepareAllTxStores(Transaction, BatchModification, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- prepareAllTxStores(Transaction, BatchModification, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- 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 - 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.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.LocalTopologyManagerImpl
- prepareOnAffectedNodes(TxInvocationContext<?>, PrepareCommand, Collection<Address>) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- prepareOnAffectedNodes(TxInvocationContext<?>, PrepareCommand, Collection<Address>) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
- prepareOnAffectedNodes(TxInvocationContext<?>, PrepareCommand, Collection<Address>) - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
- prepareOnAffectedNodes(TxInvocationContext<?>, PrepareCommand, Collection<Address>) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
- prepareWithModifications(Transaction, BatchModification) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- prepareWithModifications(Transaction, BatchModification) - Method in interface org.infinispan.persistence.spi.TransactionalCacheWriter
-
Write modifications to the store in the prepare phase, as this is the only way we know the FINAL values of the entries.
- PREPARING - 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 - org.infinispan.server.memcached.MemcachedOperation
- PrePostProcessingCommandInterceptor - Class in org.infinispan.interceptors.base
-
Deprecated.Since 9.0, please extend
AsyncInterceptor
instead. - PrePostProcessingCommandInterceptor() - Constructor for class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- preserveOrder() - Method in enum org.infinispan.remoting.inboundhandler.DeliverOrder
- 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.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
- 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
- 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
- previousValue - Variable in class org.infinispan.commons.util.RemovableIterator
- primary() - Method in class org.infinispan.distribution.DistributionInfo
- PRIMARY - org.infinispan.distribution.Ownership
-
This node is the primary owner.
- PRIMARY_OWNER - org.infinispan.configuration.cache.Index
-
Only the primary owner of an entry will add it to the index.
- primaryException(Throwable) - Method in interface org.infinispan.interceptors.distribution.Collector
-
The exception results of the primary owner.
- primaryException(Throwable) - Method in class org.infinispan.interceptors.distribution.PrimaryOwnerOnlyCollector
- primaryOnly() - Method 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.
- PrimaryOwnerFilter<K> - Class in org.infinispan.persistence
- PrimaryOwnerFilter(ClusteringDependentLogic) - Constructor for class org.infinispan.persistence.PrimaryOwnerFilter
- PrimaryOwnerOnlyCollector<T> - Class in org.infinispan.interceptors.distribution
-
A
Collector
implementation that only waits for the primary owner. - PrimaryOwnerOnlyCollector() - Constructor for class org.infinispan.interceptors.distribution.PrimaryOwnerOnlyCollector
- PrimaryResponseGenerator(CacheEntry, Object) - Constructor for class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- PrimaryResponseHandler(Object) - Constructor for class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- primaryResult(T, boolean) - Method in interface org.infinispan.interceptors.distribution.Collector
-
The write operation's return value.
- primaryResult(T, boolean) - Method in class org.infinispan.interceptors.distribution.PrimaryOwnerOnlyCollector
- 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
- PRINCIPAL_ROLE_MAPPER - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- principalName - Variable in class org.infinispan.server.hotrod.AccessLoggingHeader
- principalNameResolver - Variable in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- PrincipalNameResolver - Class in org.infinispan.spring.session
-
Extracts Principal Name from Session.
- PrincipalNameResolver() - Constructor for class org.infinispan.spring.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.
- PrincipalRoleMapperContext - Interface in org.infinispan.security
-
PrincipalRoleMapperContext.
- principalToRoles(Principal) - Method in interface org.infinispan.security.PrincipalRoleMapper
-
Maps a principal name to a set of role names.
- print(String, CacheSet<?>, Charset) - Method in interface org.infinispan.rest.operations.mediatypes.OutputPrinter
-
Converts all values in the cache to a desired output format.
- 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
- printFullVersionInformation() - Static method in class org.infinispan.Version
-
Prints full version information to the standard output.
- printLockInfo() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- printLockInfo() - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- printLockInfo() - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Prints lock information for all locks.
- printVersion() - Static method in class org.infinispan.Version
-
Returns version information as a string.
- printXid(int, byte[], byte[]) - Static method in class org.infinispan.commons.tx.XidImpl
- PrioritizedMethodMetadata(String, int) - Constructor for class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
- priority() - Method in annotation type org.infinispan.factories.annotations.PostStart
-
Deprecated.Optional parameter which defines the order in which this method will be called.
- priority() - Method in annotation type org.infinispan.factories.annotations.Start
-
Optional parameter which defines the order in which this method will be called when a component has more than one method annotated with
Start
. - priority() - Method in annotation type org.infinispan.factories.annotations.Stop
-
Optional parameter which defines the order in which this method will be called when a component has more than one method annotated with
Start
. - PRIORITY - org.infinispan.configuration.parsing.Attribute
- PRIVATE - org.infinispan.persistence.manager.PersistenceManager.AccessMode
-
The operation is performed only in non-shared
CacheWriter
orCacheLoader
- PrivateGlobalConfiguration - Class in org.infinispan.configuration.internal
-
An internal configuration.
- PrivateGlobalConfigurationBuilder - Class in org.infinispan.configuration.internal
-
A
Builder
implementation ofPrivateGlobalConfiguration
. - PrivateGlobalConfigurationBuilder(GlobalConfigurationBuilder) - Constructor for class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
- PrivateGlobalConfigurationSerializer - Class in org.infinispan.configuration.internal
-
A
ConfigurationSerializer
implementation forPrivateGlobalConfiguration
. - PrivateGlobalConfigurationSerializer() - Constructor for class org.infinispan.configuration.internal.PrivateGlobalConfigurationSerializer
- process(KeyFilter<? super K>, AdvancedCacheLoader.CacheLoaderTask<K, V>, Executor, boolean, boolean) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
-
Deprecated.since 9.3 This is to be removed and replaced by
AdvancedCacheLoader.publishEntries(Predicate, boolean, boolean)
- processBackupResponse(TxInvocationContext, VisitableCommand, BackupResponse) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- processCacheEntryCreated(ClientCacheEntryCreatedEvent) - Method in class org.infinispan.spring.session.RemoteApplicationPublishedBridge
- processCacheEntryCreated(CacheEntryCreatedEvent) - Method in class org.infinispan.spring.session.EmbeddedApplicationPublishedBridge
- processCacheEntryDestroyed(ClientCacheEntryRemovedEvent) - Method in class org.infinispan.spring.session.RemoteApplicationPublishedBridge
- processCacheEntryDestroyed(CacheEntryRemovedEvent) - Method in class org.infinispan.spring.session.EmbeddedApplicationPublishedBridge
- processCacheEntryExpired(ClientCacheEntryExpiredEvent) - Method in class org.infinispan.spring.session.RemoteApplicationPublishedBridge
- processCacheEntryExpired(CacheEntryExpiredEvent) - Method in class org.infinispan.spring.session.EmbeddedApplicationPublishedBridge
- processConfiguration(StoreConfiguration) - Method in interface org.infinispan.persistence.factory.CacheStoreFactory
- processConfiguration(StoreConfiguration) - Method in class org.infinispan.persistence.factory.LocalClassLoaderCacheStoreFactory
- processEntry(MarshalledEntry<K, V>, AdvancedCacheLoader.TaskContext) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.CacheLoaderTask
-
Deprecated.
- processExpiration() - Method in interface org.infinispan.expiration.ExpirationManager
-
Processes the expiration event queue.
- ProcessorInfo - Class in org.infinispan.commons.util
-
Provides general information about the processors on this host.
- processResponses(BackupResponse, VisitableCommand) - Method in interface org.infinispan.xsite.BackupSender
-
Processes the responses of a backup command.
- processResponses(BackupResponse, VisitableCommand) - Method in class org.infinispan.xsite.BackupSenderImpl
- processResponses(BackupResponse, VisitableCommand, Transaction) - Method in interface org.infinispan.xsite.BackupSender
- processResponses(BackupResponse, VisitableCommand, Transaction) - Method in class org.infinispan.xsite.BackupSenderImpl
- processStoreConfiguration(StoreConfiguration) - Method in class org.infinispan.persistence.factory.CacheStoreFactoryRegistry
- ProgrammaticSearchMappingProvider - Interface in org.infinispan.query.spi
-
An advanced SPI to be implemented by Infinispan modules that want to customize the
SearchMapping
object right before the bootstrap of theSearchIntegrator
belonging to an indexedCache
. - ProjectedJsonResult - Class in org.infinispan.query.remote.json
- ProjectedJsonResult(int, String[], List<Object>) - Constructor for class org.infinispan.query.remote.json.ProjectedJsonResult
- projection(String...) - Method in interface org.infinispan.query.CacheQuery
-
Defines the Lucene field names projected and returned in a query result Each field is converted back to it's object representation, an Object[] being returned for each "row"
- ProjectionConstants - Interface in org.infinispan.query
- projections - Variable in class org.infinispan.query.clustered.NodeTopDocs
- properties - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Deprecated.
- 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
-
These properties are passed directly to the embedded Hibernate Search engine, so for the complete and up to date documentation about available properties refer to the Hibernate Search reference of the version you're using with Infinispan Query.
- properties() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
- properties() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- properties() - Method in class org.infinispan.configuration.global.TransportConfiguration
- properties(Properties) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- PROPERTIES - org.infinispan.configuration.parsing.Element
- PROPERTIES - org.infinispan.persistence.remote.configuration.Element
- PROPERTIES - org.infinispan.persistence.rest.configuration.Element
- PROPERTIES - Static variable in class org.infinispan.commons.configuration.AbstractTypedPropertiesConfiguration
- PROPERTIES - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- PROPERTIES - Static variable in class org.infinispan.configuration.global.GlobalJmxStatisticsConfiguration
- PROPERTIES - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- PROPERTIES_FILE - org.infinispan.persistence.jdbc.configuration.Attribute
- property(String) - Static method in interface org.infinispan.query.dsl.Expression
- PROPERTY - org.infinispan.configuration.parsing.Element
- propertyFile() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
- propertyFile(String) - Method in class org.infinispan.persistence.jdbc.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.
- 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 - PROTECTED - org.infinispan.registry.InternalCacheRegistry.Flag
-
means that his cache requires security to be accessible remotely
- PROTO_KEY_SUFFIX - Static variable in interface org.infinispan.query.remote.client.ProtobufMetadataManagerConstants
-
All protobuf definition source files must end with this suffix.
- PROTOBUF_METADATA_CACHE_NAME - Static variable in interface org.infinispan.query.remote.client.ProtobufMetadataManagerConstants
-
The name of the Protobuf definitions cache.
- PROTOBUF_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
- ProtobufMetadataManager - Interface in org.infinispan.query.remote
-
A clustered repository of protobuf definition files.
- ProtobufMetadataManagerConstants - Interface in org.infinispan.query.remote.client
-
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. - 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.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 - org.infinispan.persistence.remote.configuration.Attribute
- PROTOCOL_VERSION - org.infinispan.persistence.remote.configuration.Attribute
- ProtocolFlag - Enum in org.infinispan.server.hotrod
- ProtocolServer<C extends ProtocolServerConfiguration> - Interface in org.infinispan.server.core
-
Represents a protocol compliant server.
- ProtocolServerConfiguration - Class in org.infinispan.server.core.configuration
-
ServerConfiguration.
- ProtocolServerConfiguration(AttributeSet, SslConfiguration) - 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() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
-
Deprecated.
- protocolVersion(String) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- protocolVersion(String) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
-
Deprecated.
- protocolVersion(String) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Deprecated.
- 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.
- PROTOSTREAM_WRAPPER - Static variable in interface org.infinispan.commons.dataconversion.WrapperIds
-
Deprecated.Replaced by PROTOBUF_WRAPPER. Will be removed in next minor version.
- ProtostreamSerializationContextInitializer - Interface in org.infinispan.query.remote.client
-
Support for custom initialization of the server cache manager's
SerializationContext
. - 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 interface org.infinispan.persistence.manager.PersistenceManager
- publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
- publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheLoader
- publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.file.SingleFileStore
- publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.jpa.JpaStore
- publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.remote.RemoteStore
- publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- publishEntries(Predicate<? super K>, boolean, boolean) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
-
Publishes all entries from this store.
- publishEntries(Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- publishEntries(Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Returns a publisher that will publish all entries stored by the underlying cache store.
- publishEntries(Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- publishEntries(Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- publishEntries(IntSet, Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- publishEntries(IntSet, Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.remote.RemoteStore
- publishEntries(IntSet, Predicate<? super K>, boolean, boolean) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Publishes all entries from this store.
- publishEntries(IntSet, Predicate<? super K>, boolean, boolean) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- publishEntries(IntSet, Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Returns a publisher that will publish entries that map to the provided segments.
- publishEntries(IntSet, Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- publishEntries(IntSet, Predicate<? super K>, boolean, boolean, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheLoader
- publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.file.SingleFileStore
- publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.jpa.JpaStore
- publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.remote.RemoteStore
- publishKeys(Predicate<? super K>) - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- publishKeys(Predicate<? super K>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
-
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 interface org.infinispan.persistence.manager.PersistenceManager
-
Returns a publisher that will publish all keys stored by the underlying cache store.
- publishKeys(Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- publishKeys(Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- publishKeys(IntSet, Predicate<? super K>) - Method in class org.infinispan.persistence.remote.RemoteStore
- publishKeys(IntSet, Predicate<? super K>) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
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>, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Returns a publisher that will publish keys that map to the provided segments.
- publishKeys(IntSet, Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- publishKeys(IntSet, Predicate<? super K>, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- purge(Class<?>) - Method in interface org.infinispan.query.SearchManager
-
Remove all entities of particular class from the index.
- purge(Executor, AdvancedCacheExpirationWriter.ExpirationPurgeListener<K, V>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheExpirationWriter
-
Using the thread in the pool, removed all the expired data from the persistence storage.
- purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.async.AdvancedAsyncCacheWriter
- purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.file.SingleFileStore
- purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.jpa.JpaStore
- purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.remote.RemoteStore
- purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- purge(Executor, AdvancedCacheWriter.PurgeListener) - Method in class org.infinispan.persistence.support.AdvancedSingletonCacheWriter
-
Deprecated.
- purge(Executor, AdvancedCacheWriter.PurgeListener<? super K>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheExpirationWriter
-
This method is never called.
- purge(Executor, AdvancedCacheWriter.PurgeListener<? super K>) - Method in interface org.infinispan.persistence.spi.AdvancedCacheWriter
-
Using the thread in the pool, removed all the expired data from the persistence storage.
- purge(Executor, AdvancedCacheWriter.PurgeListener<? super K>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- PURGE - org.infinispan.configuration.parsing.Attribute
- PURGE_ON_STARTUP - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- purgeExpired() - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Removes the expired entries from all the existing storage.
- purgeExpired() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- purgeExpired() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- purgeOnStartup - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Deprecated.
- 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.
- purgeStaleEntries() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Removes any stale entries whose keys have been finalized.
- PUSH_STATE_TIMEOUT - Static variable in class org.infinispan.configuration.cache.SingletonStoreConfiguration
-
Deprecated.
- PUSH_STATE_WHEN_COORDINATOR - Static variable in class org.infinispan.configuration.cache.SingletonStoreConfiguration
-
Deprecated.
- pushState(String) - Method in class org.infinispan.xsite.GlobalXSiteAdminOperations
- pushState(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
- pushState(Cache<?, ?>) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.Pushes the state of a specific cache by reading the cache's data and putting in the cache store.
- PushStateException(String, Throwable) - Constructor for exception org.infinispan.persistence.support.SingletonCacheWriter.PushStateException
-
Deprecated.
- pushStateTimeout() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
-
Deprecated.If pushStateWhenCoordinator is true, this property sets the maximum number of milliseconds that the process of pushing the in-memory state to the underlying cache loader should take.
- pushStateTimeout(long) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
-
Deprecated.If pushStateWhenCoordinator is true, this property sets the maximum number of milliseconds that the process of pushing the in-memory state to the underlying cache loader should take.
- pushStateTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
-
Deprecated.If pushStateWhenCoordinator is true, this property sets the maximum number of milliseconds that the process of pushing the in-memory state to the underlying cache loader should take.
- pushStateWhenCoordinator() - Method in class org.infinispan.configuration.cache.SingletonStoreConfiguration
-
Deprecated.If true, when a node becomes the coordinator, it will transfer in-memory state to the underlying cache store.
- pushStateWhenCoordinator(boolean) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
-
Deprecated.If true, when a node becomes the coordinator, it will transfer in-memory state to the underlying cache store.
- put(int, WrappedBytes, WrappedBytes, Metadata, long, long) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- put(int, WrappedBytes, WrappedBytes, Metadata, long, long) - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- put(Object, Object) - Method in class org.infinispan.spring.provider.SpringCache
- put(Object, Object, long, TimeUnit) - Method in class org.infinispan.spring.provider.SpringCache
- 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.equivalence.EquivalentHashMap
-
Deprecated.
- 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.concurrent.ConcurrentWeakKeyHashMap
-
Maps the specified key to the specified value in this table.
- 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, 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 interface org.infinispan.commons.api.BasicCache
-
An overloaded form of
BasicCache.put(Object, Object)
, which takes in lifespan parameters. - 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 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(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 - org.infinispan.server.hotrod.HotRodOperation
- PUT_ALL - org.infinispan.server.hotrod.HotRodOperation
- PUT_ALL_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- PUT_FOR_EXTERNAL_READ - org.infinispan.context.Flag
-
Flags the invocation as a
Cache.putForExternalRead(Object, Object)
call, as opposed to a regularBasicCache.put(Object, Object)
. - PUT_FOR_STATE_TRANSFER - org.infinispan.context.Flag
-
Flags the invocation as a put operation done internally by the state transfer.
- PUT_FOR_X_SITE_STATE_TRANSFER - org.infinispan.context.Flag
-
Flags the invocation as a put operation done internally by the cross-site state transfer.
- PUT_IF_ABSENT - org.infinispan.server.hotrod.HotRodOperation
- PUT_IF_ABSENT_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- PUT_MULTIMAP - 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 - 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.commons.equivalence.EquivalentHashMap
-
Deprecated.
- 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.concurrent.ConcurrentWeakKeyHashMap
-
Copies all of the mappings from the specified map to this one.
- putAll(Map<? extends K, ? extends V>) - Method in class org.infinispan.commons.util.FastCopyHashMap
- 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, 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>, 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 WrappedBytes, ? extends InternalCacheEntry<WrappedBytes, WrappedBytes>>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- 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>, 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, 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>, Metadata) - Method in interface org.infinispan.AdvancedCache
- putAsync(K, V) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.put(Object, Object)
. - 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, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.put(Object, Object, long, TimeUnit, long, TimeUnit)
. - putAsync(K, V, Metadata) - Method in interface org.infinispan.AdvancedCache
-
Asynchronous version of
AdvancedCache.put(Object, Object, Metadata)
which stores metadata alongside the value. - putConfiguration(String, Configuration) - Method in class org.infinispan.configuration.ConfigurationManager
- putConfiguration(String, ConfigurationBuilder) - Method in class org.infinispan.configuration.ConfigurationManager
- putForExternalRead(K, V) - Method in interface org.infinispan.Cache
-
Under special operating behavior, associates the value with the specified key.
- putForExternalRead(K, V, long, TimeUnit) - Method in interface org.infinispan.Cache
-
An overloaded form of
#putForExternalRead(K, V)
, which takes in lifespan parameters. - putForExternalRead(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.infinispan.Cache
-
An overloaded form of
#putForExternalRead(K, V)
, which takes in lifespan parameters. - 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. - putIfAbsent(Object, Object) - Method in class org.infinispan.spring.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, V) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- putIfAbsent(K, V) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
- 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, 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, 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(WrappedBytes, InternalCacheEntry<WrappedBytes, WrappedBytes>) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- putIfAbsentAsync(K, V) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
ConcurrentMap.putIfAbsent(Object, Object)
. - 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, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.putIfAbsent(Object, Object, long, TimeUnit, long, TimeUnit)
. - 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. - PutIfAbsentRequest - org.infinispan.server.memcached.MemcachedOperation
- 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.SingleKeyNonTxInvocationContext
-
Deprecated.
- putLookedUpEntry(Object, CacheEntry) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- putLookedUpRemoteVersion(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.since 9.0
- putMemoryAddress(Object, long) - Method in class org.infinispan.container.offheap.MemoryAddressHash
- PutRequest - org.infinispan.server.memcached.MemcachedOperation
- putValueToCache(InfinispanCacheAPIRequest) - Method in class org.infinispan.rest.operations.CacheOperations
-
Implementation of HTTP PUT and HTTP POST requests invoked with a key.
Q
- query(AdvancedCache<byte[], byte[]>, byte[]) - Method in interface org.infinispan.server.core.QueryFacade
- Query - Interface in org.infinispan.query.dsl
-
An immutable object representing both the query and the result.
- QUERY - org.infinispan.server.hotrod.HotRodOperation
- QUERY_ITERATION_FILTER - Static variable in class org.infinispan.server.core.ExternalizerIds
- QUERY_MODE - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- QUERY_PROTO_RES - Static variable in class org.infinispan.query.remote.client.MarshallerRegistration
- QUERY_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- QUERY_STRING - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- QUERYABLE - org.infinispan.registry.InternalCacheRegistry.Flag
-
means that this cache should be queryable
- QueryBox - Class in org.infinispan.query.clustered.commandworkers
-
Each indexed cache in the cluster has a QueryBox instance.
- QueryBox() - Constructor for class org.infinispan.query.clustered.commandworkers.QueryBox
- QueryBuilder - Interface in org.infinispan.query.dsl
-
A builder for
Query
objects. - QueryFacade - Interface in org.infinispan.server.core
-
Query facade
- QueryFactory - Interface in org.infinispan.query.dsl
-
Factory for query DSL objects.
- queryInterceptor - Variable in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- QueryRequest - Class in org.infinispan.query.remote.client
- QueryRequest() - Constructor for class org.infinispan.query.remote.client.QueryRequest
- QueryRequest.NamedParameter - Class in org.infinispan.query.remote.client
- QueryRequestExternalizer() - Constructor for class org.infinispan.query.remote.client.Externalizers.QueryRequestExternalizer
- QueryResponse - Class in org.infinispan.query.clustered
-
The response for a
ClusteredQueryCommand
. - QueryResponse - Class in org.infinispan.query.remote.client
- QueryResponse() - Constructor for class org.infinispan.query.clustered.QueryResponse
- QueryResponse() - Constructor for class org.infinispan.query.remote.client.QueryResponse
- QueryResponse(int) - Constructor for class org.infinispan.query.clustered.QueryResponse
- QueryResponse(Object) - Constructor for class org.infinispan.query.clustered.QueryResponse
- QueryResponse(NodeTopDocs) - Constructor for class org.infinispan.query.clustered.QueryResponse
- QueryResponse.Externalizer - Class in org.infinispan.query.clustered
- QueryResponseExternalizer() - Constructor for class org.infinispan.query.remote.client.Externalizers.QueryResponseExternalizer
- queue() - Method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- QUEUE - Static variable in interface org.infinispan.commons.marshall.Ids
- QUEUE_FLUSH_INTERVAL - org.infinispan.configuration.parsing.Attribute
-
Deprecated.
- QUEUE_LENGTH - org.infinispan.configuration.parsing.Attribute
- QUEUE_SIZE - org.infinispan.configuration.parsing.Attribute
-
Deprecated.
- QUEUE_SIZE - org.infinispan.persistence.leveldb.configuration.Attribute
- queueConflictResolution(CacheTopology, Set<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
- 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() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
- queueRebalance(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
- QuitRequest - org.infinispan.server.memcached.MemcachedOperation
R
- RACK - org.infinispan.distribution.topologyaware.TopologyLevel
- RACK_ID - 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.
- RANDOM_NODE_FAILOVER - Static variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- randomClusterMembers(List<Address>, int) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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
-
A context for ranges.
- RangeConditionContextQueryBuilder - Interface in org.infinispan.query.dsl
- RangeSet - Class in org.infinispan.commons.util
-
Deprecated.since 9.3 This class will no longer be public. Please use
IntSets.immutableRangeSet(int)
instead. - RangeSet - Class in org.infinispan.util
-
Deprecated.Use
RangeSet
instead - RangeSet(int) - Constructor for class org.infinispan.commons.util.RangeSet
-
Deprecated.
- RangeSet(int) - Constructor for class org.infinispan.util.RangeSet
-
Deprecated.
- RankCalculator() - Constructor for class org.infinispan.container.versioning.NumericVersionGenerator.RankCalculator
- RAW_VALUES - org.infinispan.persistence.remote.configuration.Attribute
- RAW_VALUES - org.infinispan.persistence.rest.configuration.Attribute
- RAW_VALUES - Static variable in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- 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
- rawValues() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- rawValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- rawValues(boolean) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- rawValues(boolean) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
Normally the
RemoteStore
stores values wrapped inInternalCacheEntry
. - rawValues(boolean) - Method in class org.infinispan.persistence.rest.configuration.AbstractRestStoreConfigurationChildBuilder
- rawValues(boolean) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- rawValues(boolean) - Method in interface org.infinispan.persistence.rest.configuration.RestStoreConfigurationChildBuilder
-
Reads/writes "raw" values to the REST server instead of marshalling (used by the rolling upgrades feature)
- read() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- read() - Method in class org.infinispan.commons.time.TimeServiceTicker
- read() - Method in class org.infinispan.commons.util.Base64.InputStream
-
Deprecated.Reads enough of the input stream to convert to/from Base64 and returns the next byte.
- read() - Method in class org.infinispan.io.GridInputStream
- read() - Method in class org.infinispan.io.UnclosableObjectInputStream
- read(byte[]) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- read(byte[]) - Method in class org.infinispan.io.GridInputStream
- read(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
- read(byte[], int, int) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- read(byte[], int, int) - Method in class org.infinispan.commons.util.Base64.InputStream
-
Deprecated.Calls
Base64.InputStream.read()
repeatedly until the end of stream is reached or len bytes are read. - read(byte[], int, int) - Method in class org.infinispan.io.GridInputStream
- read(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
- 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(ByteBuffer) - Method in class org.infinispan.io.ReadableGridFileChannel
- read(Attribute<T>) - Method in class org.infinispan.commons.configuration.attributes.Attribute
- read(AttributeSet) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Copies all attribute from another AttributeSet
- read(AsyncStoreConfiguration) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
- read(AuthorizationConfiguration) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
- read(BackupConfiguration) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
- read(BackupForConfiguration) - Method in class org.infinispan.configuration.cache.BackupForBuilder
- read(ClusteringConfiguration) - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
- read(ClusterLoaderConfiguration) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
- read(CompatibilityModeConfiguration) - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
- read(Configuration) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- read(ContentTypeConfiguration) - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- read(CustomInterceptorsConfiguration) - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
- read(CustomStoreConfiguration) - Method in class org.infinispan.configuration.cache.CustomStoreConfigurationBuilder
- read(DataContainerConfiguration) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.
- read(DeadlockDetectionConfiguration) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.
- read(EncodingConfiguration) - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- read(EvictionConfiguration) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.
- read(ExpirationConfiguration) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- read(GroupsConfiguration) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- read(HashConfiguration) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
- read(IndexingConfiguration) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
- read(InterceptorConfiguration) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
- read(InvocationBatchingConfiguration) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- read(JMXStatisticsConfiguration) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
- read(L1Configuration) - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
- read(LockingConfiguration) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
- read(MemoryConfiguration) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- read(PartitionHandlingConfiguration) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
- read(PersistenceConfiguration) - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- read(RecoveryConfiguration) - Method in class org.infinispan.configuration.cache.RecoveryConfigurationBuilder
- read(SecurityConfiguration) - Method in class org.infinispan.configuration.cache.SecurityConfigurationBuilder
- read(SingleFileStoreConfiguration) - Method in class org.infinispan.configuration.cache.SingleFileStoreConfigurationBuilder
- read(SingletonStoreConfiguration) - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
-
Deprecated.
- read(SitesConfiguration) - Method in class org.infinispan.configuration.cache.SitesConfigurationBuilder
- read(StateTransferConfiguration) - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
- read(StoreAsBinaryConfiguration) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
-
Deprecated.
- read(SyncConfiguration) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
-
Deprecated.
- read(TakeOfflineConfiguration) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
- read(TransactionConfiguration) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- read(UnsafeConfiguration) - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
- read(VersioningConfiguration) - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
-
Deprecated.
- read(XSiteStateTransferConfiguration) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- read(ExecutorFactoryConfiguration) - Method in class org.infinispan.configuration.global.ExecutorFactoryConfigurationBuilder
- read(GlobalAuthorizationConfiguration) - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfigurationBuilder
- read(GlobalConfiguration) - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
- read(GlobalJmxStatisticsConfiguration) - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
- read(GlobalSecurityConfiguration) - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
- read(GlobalStateConfiguration) - Method in class org.infinispan.configuration.global.GlobalStateConfigurationBuilder
- read(ScheduledExecutorFactoryConfiguration) - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- read(SerializationConfiguration) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
- read(ShutdownConfiguration) - Method in class org.infinispan.configuration.global.ShutdownConfigurationBuilder
- read(SiteConfiguration) - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
- read(ThreadPoolConfiguration) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- read(TransportConfiguration) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- read(PrivateGlobalConfiguration) - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
- read(CounterManagerConfiguration) - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
- read(StrongCounterConfiguration) - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- read(WeakCounterConfiguration) - Method in class org.infinispan.counter.configuration.WeakCounterConfigurationBuilder
- read(ClusteredLockConfiguration) - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
- read(ClusteredLockManagerConfiguration) - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
- read(LuceneLoaderConfiguration) - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
- read(JdbcStringBasedStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
- read(ManagedConnectionFactoryConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
- read(PooledConnectionFactoryConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- read(SimpleConnectionFactoryConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
- read(TableManipulationConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
- read(JpaStoreConfiguration) - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationBuilder
- read(LevelDBStoreConfiguration) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- read(AuthenticationConfiguration) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
- read(ConnectionPoolConfiguration) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
- read(ExecutorFactoryConfiguration) - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
- read(RemoteServerConfiguration) - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
- read(RemoteStoreConfiguration) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- read(SecurityConfiguration) - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
- read(SslConfiguration) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
- read(ConnectionPoolConfiguration) - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfigurationBuilder
- read(RestStoreConfiguration) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- read(RestServerConfiguration) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- read(Role) - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
- read(SslConfiguration) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
- read(SslEngineConfiguration) - Method in class org.infinispan.server.core.configuration.SslEngineConfigurationBuilder
- read(AuthenticationConfiguration) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- read(HotRodServerConfiguration) - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfigurationBuilder
- read(MemcachedServerConfiguration) - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfigurationBuilder
- read(T) - Method in interface org.infinispan.commons.configuration.Builder
-
Reads the configuration from an already created configuration bean into this builder.
- read(T) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- read(T) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- read(T) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- READ - org.infinispan.container.entries.ReadCommittedEntry.Flags
- READ - org.infinispan.security.AuthorizationPermission
-
Allows reading data from a cache
- READ_ALL_WRITE_ALL - org.infinispan.topology.CacheTopology.Phase
-
Used after state transfer completes: readCH == writeCH = unionCH
- READ_COMMITTED - org.infinispan.util.concurrent.IsolationLevel
- READ_NEW_WRITE_ALL - org.infinispan.topology.CacheTopology.Phase
-
Intermediate state that prevents ISPN-5021: readCH == pendingCH, writeCH = unionCH
- READ_OLD_WRITE_ALL - org.infinispan.topology.CacheTopology.Phase
-
Used during state transfer: readCH == currentCH, writeCH = unionCH
- READ_ONLY - org.infinispan.configuration.parsing.Attribute
- READ_ONLY_SNAPSHOT_VIEW - Static variable in interface org.infinispan.commons.marshall.Ids
- READ_UNCOMMITTED - org.infinispan.util.concurrent.IsolationLevel
- READ_WRITE_SNAPSHOT_VIEW - Static variable in interface org.infinispan.commons.marshall.Ids
- readable(ByteBuf, int) - Static method in class org.infinispan.server.hotrod.Intrinsics
- ReadableGridFileChannel - Class in org.infinispan.io
- readBoolean() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readBoolean() - Method in class org.infinispan.io.UnclosableObjectInputStream
- readBooleanAttributeElement(XMLStreamReader, 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
- readChar() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readChar() - Method in class org.infinispan.io.UnclosableObjectInputStream
- ReadCommittedEntry - 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(Object, Object, Metadata) - Constructor for class org.infinispan.container.entries.ReadCommittedEntry
- ReadCommittedEntry.Flags - Enum in org.infinispan.container.entries
- readDouble() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readDouble() - Method in class org.infinispan.io.UnclosableObjectInputStream
- readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in interface org.infinispan.configuration.parsing.ConfigurationParser
-
The entry point of a configuration parser which gets passed a
XMLExtendedStreamReader
positioned at a root element associated with the parser itself according to the registered mapping. - readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.configuration.parsing.Parser
- readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.counter.configuration.CounterConfigurationParser
- readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationParser
- readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationParser
- readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationParser
- readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationParser
-
Deprecated.
- readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationParser
- readElement(XMLExtendedStreamReader, ConfigurationBuilderHolder) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationParser
- readExternal(ObjectInput) - Method in class org.infinispan.commons.util.ImmutableListCopy
-
See
ImmutableListCopy.writeExternal(java.io.ObjectOutput)
for serialization format - readExternal(ObjectInput) - Method in class org.infinispan.io.GridFile.Metadata
- readFloat() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readFloat() - Method in class org.infinispan.io.UnclosableObjectInputStream
- 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.encoding.DataConversion
- readFrom(ObjectInput) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
- readFrom(ObjectInput) - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- readFrom(ObjectInput) - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- readFrom(ObjectInput) - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
- 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.statetransfer.StateRequestCommand
- readFrom(ObjectInput) - Method in class org.infinispan.statetransfer.StateResponseCommand
- readFrom(ObjectInput) - Method in class org.infinispan.topology.CacheTopologyControlCommand
- readFrom(ObjectInput) - Method in class org.infinispan.topology.HeartBeatCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- readFrom(ObjectInput) - Method in class org.infinispan.xsite.XSiteAdminCommand
- readFully(byte[]) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readFully(byte[]) - Method in class org.infinispan.io.UnclosableObjectInputStream
- readFully(byte[], int, int) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readFully(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectInputStream
- readInt() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readInt() - Method in class org.infinispan.io.UnclosableObjectInputStream
- readLine() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readLine() - Method in class org.infinispan.io.UnclosableObjectInputStream
- readLong() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readLong() - Method in class org.infinispan.io.UnclosableObjectInputStream
- 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.
- readMetadata(URL) - Method in class org.infinispan.factories.components.ComponentMetadataRepo
- readNeedsRemoteValue(FlagAffectedCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- readObject() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readObject() - Method in class org.infinispan.io.UnclosableObjectInputStream
- readObject(ObjectInput) - Method in class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
-
Deprecated.
- 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
-
Read an instance from the stream.
- readObject(ObjectInput) - Method in class org.infinispan.commons.marshall.exts.EquivalenceExternalizer
- 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.Immutables.ImmutableMapWrapperExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.util.Immutables.ImmutableSetWrapperExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.commons.util.KeyValueWithPrevious.KeyValueWithPreviousExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.compat.BiFunctionMapper.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.compat.FunctionMapper.Externalizer
- 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.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.CollectionKeyFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.filter.CompositeKeyFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter.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.interceptors.distribution.VersionedResult.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.lucene.ChunkCacheKey.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.lucene.FileMetadata.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.lucene.FileReadLockKey.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.core.MarshalledEntryImpl.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.marshall.exts.CacheRpcCommandExternalizer
- 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.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.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.notifications.cachelistener.cluster.ClusterEvent.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.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.cluster.MultiClusterEventCallable.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.KeyFilterAsCacheEventFilter.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.MigrationTask.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.persistence.remote.upgrade.RemovedFilter.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.query.clustered.NodeTopDocs.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.query.clustered.QueryResponse.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.query.remote.client.Externalizers.NamedParameterExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.query.remote.client.Externalizers.QueryRequestExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.query.remote.client.Externalizers.QueryResponseExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.remoting.MIMECacheEntry.Externalizer
- 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.rest.operations.mime.MimeMetadata.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.server.core.security.InetAddressPrincipal.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.core.security.simple.SimpleUserPrincipal.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.server.memcached.MemcachedMetadataExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.statetransfer.StateChunk.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
- 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.DldGlobalTransaction.Externalizer
-
Deprecated.
- readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
- readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
-
Deprecated.
- readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
- readObject(ObjectInput) - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
-
Deprecated.
- 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.statetransfer.XSiteState.XSiteStateExternalizer
- ReadOnlyCollectionAsSet<T> - Class in org.infinispan.util
-
Assumes that the delegate collection already contains unique elements.
- ReadOnlyCollectionAsSet(Collection<? extends T>) - Constructor for class org.infinispan.util.ReadOnlyCollectionAsSet
- ReadOnlyDataContainerBackedKeySet - Class in org.infinispan.util
-
Deprecated.DataContainer keySet method will be removed in the future. See
DataContainer.keySet()
- ReadOnlyDataContainerBackedKeySet(DataContainer) - Constructor for class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- ReadOnlyManyHelper() - Constructor for class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
- 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>, ConsistentHash, 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>>, ConsistentHash, 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>>, ConsistentHash, 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>, ConsistentHash, 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>, ConsistentHash, IntSet) - Constructor for class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- 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
- 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
- readScopedState(String) - Method in interface org.infinispan.globalstate.GlobalStateManager
-
Reads the persistent state for the specified scope.
- readShort() - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- readShort() - Method in class org.infinispan.io.UnclosableObjectInputStream
- readSignedInt(InputStream) - Static method in class org.infinispan.commons.io.SignedNumeric
- readSignedInt(ObjectInput) - Static method in class org.infinispan.commons.io.SignedNumeric
- readStream(InputStream) - Static method in class org.infinispan.commons.util.Util
-
Reads the given InputStream fully, closes the stream and returns the result as a byte array.
- 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.hotrod.transport.ExtendedByteBuf
-
Reads length of String and then returns an UTF-8 formatted String of such length.
- readStringAttributeElement(XMLStreamReader, 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
- 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(InputStream) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- readUnsignedInt(ObjectInput) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Reads an int stored in variable-length format.
- 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(InputStream) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- readUnsignedLong(ObjectInput) - Static method in class org.infinispan.commons.io.UnsignedNumeric
-
Reads a long stored in variable-length format.
- 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
- 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
- READY - org.infinispan.remoting.inboundhandler.action.ActionStatus
-
The action is completed successfully.
- READY - org.infinispan.remoting.inboundhandler.action.BaseLockingAction.InternalState
- READY_TOPOLOGY - org.infinispan.remoting.inboundhandler.TopologyMode
- READY_TX_DATA - org.infinispan.remoting.inboundhandler.TopologyMode
- 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.CacheCollectionMapper
-
Deprecated.
- 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(String) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Specifies the realm to be used for authentication.
- REALM - 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 - 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
-
Create a new consistent hash instance, based on an existing instance, but balanced according to the implementation's rules.
- rebalance(CacheTopology) - Method in interface org.infinispan.topology.CacheTopologyHandler
-
Invoked when state transfer has to be started.
- REBALANCE_PHASE_CONFIRM - org.infinispan.topology.CacheTopologyControlCommand.Type
-
A member is confirming that it has finished a topology change during rebalance.
- REBALANCE_START - org.infinispan.topology.CacheTopologyControlCommand.Type
- RebalanceType - Enum in org.infinispan.statetransfer
- REBALANCING - org.infinispan.health.HealthStatus
-
Given entity is healthy but a rebalance is in progress.
- REBALANCING_GET_STATUS - org.infinispan.topology.CacheTopologyControlCommand.Type
- RebalancingStatus - Enum in org.infinispan.topology
-
RebalancingStatus.
- receiveClusterView(View) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- 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
- record(long) - Method in class org.infinispan.commons.stat.DefaultSimpleStat
- record(long) - Method in interface org.infinispan.commons.stat.SimpleStat
- 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.
- recover(int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- RecoverableTransactionIdentifier - Interface in org.infinispan.transaction.xa.recovery
-
Interface that adds recovery required information to a
GlobalTransaction
. - RECOVERING_CLUSTER - 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 - org.infinispan.configuration.parsing.Element
- RECOVERY_INFO_CACHE_NAME - 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
- RecoveryAwareDldGlobalTransaction - Class in org.infinispan.transaction.xa.recovery
-
Deprecated.Since 9.0, no longer used.
- RecoveryAwareDldGlobalTransaction() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
-
Deprecated.
- RecoveryAwareDldGlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
-
Deprecated.
- RecoveryAwareDldGlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa.recovery
-
Deprecated.
- RecoveryAwareGlobalTransaction - Class in org.infinispan.transaction.xa.recovery
-
GlobalTransaction that also holds xid information, required for recovery.
- RecoveryAwareGlobalTransaction() - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
- RecoveryAwareGlobalTransaction(Address, boolean) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
- RecoveryAwareGlobalTransaction.Externalizer - Class in org.infinispan.transaction.xa.recovery
- 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(WriteCommand[], GlobalTransaction, int, long) - Constructor for class org.infinispan.transaction.xa.recovery.RecoveryAwareRemoteTransaction
- RecoveryAwareRemoteTransaction(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(Xid, 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.InDoubtTxInfo - Interface in org.infinispan.transaction.xa.recovery
-
An object describing in doubt transaction's state.
- 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, ByteBufAllocator, Collection<Xid>) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- recoveryResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Collection<Xid>) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- 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.
- 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
- reduce(double, SerializableDoubleBinaryOperator) - Method in interface org.infinispan.DoubleCacheStream
-
Same as
DoubleStream.reduce(double, DoubleBinaryOperator)
except that the DoubleBinaryOperator must also implementSerializable
- reduce(int, SerializableIntBinaryOperator) - Method in interface org.infinispan.IntCacheStream
-
Same as
IntStream.reduce(int, IntBinaryOperator)
except that the IntBinaryOperator must also implementSerializable
- reduce(long, SerializableLongBinaryOperator) - Method in interface org.infinispan.LongCacheStream
-
Same as
LongStream.reduce(long, LongBinaryOperator)
except that the LongBinaryOperator must also implement Serializable. - 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(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.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.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
- 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 class org.infinispan.query.indexmanager.LocalOnlyBackend
- refresh() - Method in interface org.infinispan.query.indexmanager.SwitchingBackend
- REGISTER - org.infinispan.configuration.global.ShutdownHookBehavior
-
Forces the cache to register a shutdown hook even if an MBean server is detected.
- registerChannel(Channel) - Method in class org.infinispan.server.hotrod.iteration.IterationReaper
- 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.
- 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
- registerEncoder(Encoder) - Method in interface org.infinispan.marshall.core.EncoderRegistry
- registerEncoder(Encoder) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
- 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
- registerInternalCache(String, Configuration) - Method in interface org.infinispan.registry.InternalCacheRegistry
-
Registers an internal cache.
- registerInternalCache(String, Configuration, EnumSet<InternalCacheRegistry.Flag>) - Method in interface org.infinispan.registry.InternalCacheRegistry
-
Registers an internal cache with the specified flags.
- registerKeyTransformer(Class<?>, Class<? extends Transformer>) - Method in interface org.infinispan.query.spi.SearchManagerImplementor
-
Registers a
Transformer
for the supplied key class. - 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.CompositeAction
- registerListener() - Method in class org.infinispan.remoting.inboundhandler.action.DefaultReadyAction
- registerListener() - Method in class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- registerListener() - Method in class org.infinispan.spring.session.EmbeddedApplicationPublishedBridge
- registerListener() - Method in class org.infinispan.spring.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
- registerMarshaller(BaseMarshaller<?>) - Method in interface org.infinispan.query.remote.ProtobufMetadataManager
- registerMarshallers(SerializationContext) - Static method in class org.infinispan.query.remote.client.MarshallerRegistration
-
Registers proto files and marshallers.
- registerMBean(Object) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
- registerMBean(Object, ObjectName, MBeanServer) - Static method in class org.infinispan.commons.jmx.JmxUtil
-
Register the given dynamic JMX MBean.
- registerMBeans(Collection<ResourceDMBean>) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
-
Performs the MBean registration.
- registerNamedComponentRegistry(ComponentRegistry, String) - Method in class org.infinispan.factories.GlobalComponentRegistry
- registerNonVolatileComponent(Object, Class<?>) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- registerNonVolatileComponent(Object, String) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- registerNullComponent(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.registers a special "null" component that has no dependencies.
- 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.
- 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
- registerSynchronization(Synchronization) - Method in class org.infinispan.commons.tx.TransactionImpl
-
Register a
Synchronization
callback with this transaction. - registerSynchronization(Synchronization) - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.Register a
Synchronization
callback with this transaction. - registerTaskEngine(TaskEngine) - Method in interface org.infinispan.tasks.TaskManager
-
Registers a new
TaskEngine
- 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
- registerWrapper(Wrapper) - Method in class org.infinispan.marshall.core.EncoderRegistryImpl
- registerWriteIncoming(K) - Method in interface org.infinispan.expiration.ExpirationManager
-
Deprecated.since 9.3 There is no reason for this method and is implementation specific
- registerXSiteActionSequencer(ActionSequencer) - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- registerXSiteActionSequencer(ActionSequencer) - Method in interface org.infinispan.remoting.inboundhandler.PerCacheInboundInvocationHandler
-
Registers the
ActionSequencer
used by async cross-site requests to expose some internals metrics. - registerXSiteCommandReceiver(boolean) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
- registerXSiteCommandReceiver(boolean) - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- registerXSiteCommandReceiver(boolean) - Method in interface org.infinispan.remoting.inboundhandler.PerCacheInboundInvocationHandler
- registrar - Variable in class org.infinispan.jmx.AbstractJmxRegistration
- REGULAR_MEMBER - org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
- rehashDisabled() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Deprecated.
- rehashEnabled() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Deprecated.Use
StateTransferConfiguration.fetchInMemoryState()
instead. - rehashEnabled() - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Deprecated.
- rehashEnabled(boolean) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Deprecated.
- rehashRpcTimeout() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Deprecated.Use
StateTransferConfiguration.timeout()
instead. - rehashRpcTimeout(long) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Deprecated.Use
StateTransferConfigurationBuilder.timeout(long)
instead. - rehashWait() - Method in class org.infinispan.configuration.cache.HashConfiguration
-
Deprecated.Use
StateTransferConfiguration.timeout()
instead. - rehashWait(long) - Method in class org.infinispan.configuration.cache.HashConfigurationBuilder
-
Deprecated.No longer used.
- reincarnate() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- reincarnate() - Method in interface org.infinispan.container.entries.InternalCacheEntry
-
Deprecated.
- reincarnate() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- reincarnate() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- reincarnate() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- reincarnate() - Method in class org.infinispan.container.entries.MortalCacheEntry
- reincarnate() - Method in class org.infinispan.container.entries.TransientCacheEntry
- reincarnate() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- 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(Object...) - Method in interface org.infinispan.query.MassIndexer
- RELATIVE_TO - org.infinispan.configuration.parsing.Attribute
- RELATIVE_TO - org.infinispan.persistence.leveldb.configuration.Attribute
- release(TotalOrderRemoteTransactionState) - Method in class org.infinispan.transaction.totalorder.TotalOrderManager
-
Release the locked key possibly unblock waiting prepares.
- releaseAllLocks(List<Object>) - Method in class org.infinispan.util.concurrent.locks.StripedLock
-
Releases locks on all keys passed in.
- releaseConnection(Connection) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
-
Destroys a connection.
- RELEASED - org.infinispan.util.concurrent.locks.LockState
-
The lock owner released the lock.
- releaseExclusiveTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
- releaseExclusiveTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- releaseGlobalLock(boolean) - Method in class org.infinispan.util.concurrent.locks.StripedLock
- releaseLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
-
Releases a lock the caller may be holding.
- releaseSharedTopologyLock() - Method in interface org.infinispan.statetransfer.StateTransferLock
- releaseSharedTopologyLock() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- 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 - org.infinispan.counter.configuration.Attribute
- RELIABILITY - org.infinispan.lock.configuration.Attribute
- 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
. - REMOTE_CACHE - org.infinispan.configuration.parsing.Attribute
- REMOTE_CACHE - Static variable in class org.infinispan.configuration.cache.BackupForConfiguration
- REMOTE_CACHE_NAME - org.infinispan.persistence.remote.configuration.Attribute
- REMOTE_CALL_TIMEOUT - Static variable in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
- REMOTE_COMMAND_EXECUTOR - org.infinispan.configuration.parsing.Attribute
- REMOTE_COMMAND_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
- REMOTE_COMMIT_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- REMOTE_GET - org.infinispan.stats.topK.StreamSummaryContainer.Stat
- REMOTE_GET_EXECUTION - org.infinispan.stats.container.ExtendedStatistic
- REMOTE_ITERATION - org.infinispan.context.Flag
-
Flag to identify that this iteration is done on a remote node and thus no additional wrappings are required
- REMOTE_PREPARE_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- REMOTE_PUT - org.infinispan.stats.topK.StreamSummaryContainer.Stat
- REMOTE_PUT_EXECUTION - org.infinispan.stats.container.ExtendedStatistic
- REMOTE_ROLLBACK_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- REMOTE_SITE - org.infinispan.configuration.parsing.Attribute
- REMOTE_SITE - Static variable in class org.infinispan.configuration.cache.BackupForConfiguration
- REMOTE_STORE - org.infinispan.persistence.remote.configuration.Element
- REMOTE_TIMEOUT - org.infinispan.configuration.parsing.Attribute
- REMOTE_TIMEOUT - Static variable in class org.infinispan.configuration.cache.ClusteringConfiguration
- RemoteApplicationPublishedBridge - Class in org.infinispan.spring.session
-
A bridge between Infinispan Remote events and Spring.
- RemoteApplicationPublishedBridge(SpringCache) - Constructor for class org.infinispan.spring.session.RemoteApplicationPublishedBridge
- remoteCache() - Method in class org.infinispan.configuration.cache.BackupForConfiguration
- remoteCache(String) - Method in class org.infinispan.configuration.cache.BackupForBuilder
- 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.
- remoteCallTimeout() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
- remoteCallTimeout(long) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
- remoteCallTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
- 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, DistributedExecutorService, CacheNotifier, CacheManagerNotifier, ClusterEventManager, boolean) - Constructor for class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
- remoteCommandsExecutor - Variable in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- remoteCommandsExecutor - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- remoteCommandsExecutor() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated.This method always returns null now. Look for a thread pool named as
TransportConfiguration.remoteCommandThreadPool()
instead. - remoteCommandThreadPool() - Method in class org.infinispan.configuration.global.TransportConfiguration
- remoteCommandThreadPool() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- 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 - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- RemoteExtendedStatisticsContainer - Class in org.infinispan.stats.container
-
Container for the statistics corresponding to remote originated transactions.
- RemoteExtendedStatisticsContainer() - Constructor for class org.infinispan.stats.container.RemoteExtendedStatisticsContainer
- remoteGetMany(InvocationContext, C, Collection<?>) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- remoteGetSingleKey(InvocationContext, C, Object, boolean) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
-
Fetch a key from its remote owners and store it in the context.
- remoteGetSingleKey(InvocationContext, C, Object, boolean) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- RemoteGetSingleKeyCollector - Class in org.infinispan.interceptors.distribution
-
Return the first successful response for a staggered remote get, used in dist mode.
- RemoteGetSingleKeyCollector() - Constructor for class org.infinispan.interceptors.distribution.RemoteGetSingleKeyCollector
- RemoteLockCommand - Interface in org.infinispan.util.concurrent.locks
-
Simple interface to extract all the keys that may need to be locked.
- 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
- remoteNodeSuspected(Address) - Static method in class org.infinispan.remoting.transport.ResponseCollectors
- remoteReadOnlyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- remoteReadOnlyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- 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
- 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
- RemoteStoreConfiguration - Class in org.infinispan.persistence.remote.configuration
- RemoteStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration, ExecutorFactoryConfiguration, ConnectionPoolConfiguration, SecurityConfiguration) - 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
- 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.
- remoteTransactionCommitted(GlobalTransaction, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- remoteTransactionPrepared(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
-
Marks the transaction as prepared.
- remoteTransactionRollback(GlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- RemoteTransactionStatistics - Class in org.infinispan.stats
-
Represents the statistic collected for a remote transaction
- RemoteTransactionStatistics(TimeService) - Constructor for class org.infinispan.stats.RemoteTransactionStatistics
- remoteValueFound(InternalCacheEntry) - Method in interface org.infinispan.distribution.RemoteValueRetrievedListener
-
Invoked when a remote value is found from a remote source
- 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
- 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(CloseableIterator<C>, Consumer<? super C>) - Constructor for class org.infinispan.commons.util.RemovableCloseableIterator
- RemovableFunction<T,R> - Interface in org.infinispan.util.function
-
Deprecated.since 9.2.1 this interface is no longer supported as we don't support remove operation on iterators produced from a Stream
- 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(Iterator<C>, Consumer<? super C>) - Constructor for class org.infinispan.commons.util.RemovableIterator
- 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.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 class org.infinispan.server.memcached.MemcachedDecoder
- 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.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.offheap.BoundedOffHeapDataContainer
- 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.equivalence.EquivalentHashMap
-
Deprecated.
- remove(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
-
Deprecated.
- remove(Object) - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Removes the specified element from this set if it is present.
- remove(Object) - Method in class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
-
Deprecated.
- 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.ArrayMap
- remove(Object) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- remove(Object) - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- remove(Object) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Removes the key (and its corresponding value) from this map.
- 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.offheap.BoundedOffHeapDataContainer
- remove(Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- remove(Object) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
- remove(Object) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
- remove(Object) - Method in class org.infinispan.util.CollectionMapper
- remove(Object) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- remove(Object) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- remove(Object) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- remove(Object, Object) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- remove(Object, Object) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
- remove(Object, Object) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- 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(String, Object, MediaType, boolean, Subject) - Method in class org.infinispan.rest.cachemanager.RestCacheManager
- remove(Predicate<? super V>) - Method in interface org.infinispan.multimap.api.embedded.MultimapCache
-
Asynchronous method.
- 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, V) - Method in interface org.infinispan.multimap.api.BasicMultimapCache
-
Removes a key-value pair from this multimap cache, if such exists.
- 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
remove(Predicate)
withSerializablePredicate
. - remove(T) - Method in class org.infinispan.util.DependencyGraph
-
Remove element from the graph
- 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 - org.infinispan.eviction.EvictionStrategy
-
Strategy where the cache will remove entries to make room for new ones while staying under the configured size
- REMOVE - org.infinispan.persistence.modifications.Modification.Type
- REMOVE - org.infinispan.server.hotrod.HotRodOperation
- REMOVE_ALL - org.infinispan.conflict.MergePolicy
- REMOVE_ALL - Static variable in class org.infinispan.conflict.MergePolicies
-
Deprecated.
- REMOVE_CLIENT_LISTENER - org.infinispan.server.hotrod.HotRodOperation
- REMOVE_CLIENT_LISTENER_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- REMOVE_DATA_ON_STOP - org.infinispan.context.Flag
-
Deprecated.No longer in use.
- REMOVE_ENTRY_MULTIMAP - org.infinispan.server.hotrod.HotRodOperation
- REMOVE_ENTRY_MULTIMAP_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- REMOVE_IF_UNMODIFIED - 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_MULTIMAP - org.infinispan.server.hotrod.HotRodOperation
- REMOVE_OP - org.infinispan.server.hotrod.tx.ControlByte
- REMOVE_REQUEST - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- removeAll(Collection<?>) - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- 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.util.CollectionMapper
- removeAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- removeAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- removeAll(Collection<?>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- 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 interface org.infinispan.query.api.continuous.ContinuousQuery
-
Unregisters all listeners.
- removeAsync(Object) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.remove(Object)
. - removeAsync(Object, Object) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
ConcurrentMap.remove(Object, Object)
. - removeAtomicMap(Cache<MK, ?>, MK) - Static method in class org.infinispan.atomic.AtomicMapLookup
-
Removes the atomic map associated with the given key from the underlying cache.
- removeBackupLock(Object) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
It cleans up the backup for
key
. - removeBackupLocks(Collection<?>) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
It cleans up the backup lock for the
keys
. - 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.Since 9.2, obtain a
CacheContainerAdmin
instance usingEmbeddedCacheManager.administration()
and invoke theCacheContainerAdmin.removeCache(String)
method - 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 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
- removeConfiguration(String) - Method in class org.infinispan.configuration.ConfigurationManager
- removeConsumer() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- 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 - 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
- removeDependency(T, T) - Method in class org.infinispan.util.DependencyGraph
-
Remove a dependency
- 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
- removeEldestEntry(Map.Entry<K, V>) - Method in class org.infinispan.commons.equivalence.EquivalentLinkedHashMap
-
Deprecated.
- removeEntry(Object) - Method in class org.infinispan.persistence.support.BatchModification
- removeGroup(String) - Method in interface org.infinispan.AdvancedCache
-
It removes all the key which belongs to a group.
- 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.commons.util.AbstractDelegatingCollection
- removeIf(Predicate<? super E>) - Method in class org.infinispan.commons.util.ImmutableHopscotchHashSet
- removeIf(Predicate<? super R>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- removeIfValueEqualsReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- removeInterceptor(int) - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 9.0, use
AdvancedCache.getAsyncInterceptorChain()
instead. - 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(int) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Removes the interceptor at the given postion.
- 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
- removeInterceptor(Class<? extends CommandInterceptor>) - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 9.0, use
AdvancedCache.getAsyncInterceptorChain()
instead. - removeInterceptor(Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Removes all the occurences of supplied interceptor type from the chain.
- 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.
- removeListener() - Method in class org.infinispan.notifications.cachelistener.cluster.RemoteClusterListener
- removeListener() - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
- removeListener(Object) - Method in class org.infinispan.manager.DefaultCacheManager
- removeListener(Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- 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
- RemoveListenerAction - Class in org.infinispan.security.actions
-
RemoveListenerAction
- RemoveListenerAction(Listenable, Object) - Constructor for class org.infinispan.security.actions.RemoveListenerAction
- removeListenerInvocation(Class<? extends Annotation>, Object) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- removeLocalTransaction(LocalTransaction) - Method in class org.infinispan.transaction.xa.XaTransactionTable
- removeLocalTx(Xid) - 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.SingleKeyNonTxInvocationContext
-
Deprecated.
- 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.
- removeMember(Principal) - Method in class org.infinispan.server.core.security.simple.SimpleGroupPrincipal
- 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
- 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(javax.transaction.xa.Xid)
but identifies the tx by its internal id. - removeRecoveryInformation(Long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- removeRecoveryInformation(Collection<Address>, Xid, boolean, 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>, Xid, boolean, GlobalTransaction, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- removeRecoveryInformation(Xid) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
Remove recovery information stored on this node (doesn't involve rpc).
- removeRecoveryInformation(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- removeRecoveryInformationFromCluster(Collection<Address>, long, boolean) - Method in interface org.infinispan.transaction.xa.recovery.RecoveryManager
-
Same as
RecoveryManager.removeRecoveryInformation(java.util.Collection, javax.transaction.xa.Xid, boolean, org.infinispan.transaction.xa.GlobalTransaction, boolean)
but the transaction is identified by its internal id, and not by its xid. - removeRecoveryInformationFromCluster(Collection<Address>, long, boolean) - Method in class org.infinispan.transaction.xa.recovery.RecoveryManagerImpl
- removeRemoteTransaction(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareTransactionTable
- removeRemovalListener(Object) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- RemoveRequest - org.infinispan.server.memcached.MemcachedOperation
- removeReturnBoolean() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- removeReturnPrevOrNull() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- removeScript(String) - Method in interface org.infinispan.scripting.ScriptingManager
-
Removes a script.
- removeSegments(IntSet) - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- removeSegments(IntSet) - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- removeSegments(IntSet) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Notifies any underlying segmented stores that a given segment is no longer owned by this cache and allowing it to remove the given segments and release resources related to it.
- removeSegments(IntSet) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- removeSegments(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Invoked when a node loses ownership of a segment.
- removeSegments(IntSet) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- removeShutdownHook() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- removeShutdownHook() - Method in class org.infinispan.factories.GlobalComponentRegistry
- removeStaleData(IntSet) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- removeTransfer(InboundTransferTask) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- renameTempFile(File, File, File) - Static method in class org.infinispan.commons.util.Util
- renameTo(File) - Method in class org.infinispan.io.GridFile
- 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.
- REPEATABLE_READ - org.infinispan.util.concurrent.IsolationLevel
- RepeatableReadEntry - Class in org.infinispan.container.entries
-
An extension of
ReadCommittedEntry
that provides Repeatable Read semantics - RepeatableReadEntry(Object, Object, Metadata) - Constructor for class org.infinispan.container.entries.RepeatableReadEntry
- REPL - org.infinispan.configuration.parsing.ParsedCacheMode
- REPL_ASYNC - org.infinispan.configuration.cache.CacheMode
-
Data replicated asynchronously.
- REPL_SYNC - org.infinispan.configuration.cache.CacheMode
-
Data replicated synchronously.
- REPL_TIMEOUT - Static variable in class org.infinispan.configuration.cache.SyncConfiguration
-
Deprecated.Since 9.0, replaced with
ClusteringConfiguration.REMOTE_TIMEOUT
- replace() - Method in class org.infinispan.server.memcached.MemcachedDecoder
- replace(String, String, BackupReceiver) - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
- replace(K, V) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- replace(K, V) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
- 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, 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, 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, V) - Method in class org.infinispan.commons.util.AbstractDelegatingMap
- replace(K, V, V) - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
- 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, 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, 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(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 - org.infinispan.server.hotrod.HotRodOperation
- REPLACE_IF_UNMODIFIED - 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.commons.util.AbstractDelegatingMap
- replaceAsync(K, V) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
ConcurrentMap.replace(Object, Object)
. - 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, long, TimeUnit) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
BasicCache.replace(Object, Object, long, TimeUnit, long, TimeUnit)
. - 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, V) - Method in interface org.infinispan.commons.api.AsyncCache
-
Asynchronous version of
ConcurrentMap.replace(Object, Object, Object)
. - 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, 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, Metadata) - Method in interface org.infinispan.AdvancedCache
- replaceIfUnmodified() - Method in class org.infinispan.server.memcached.MemcachedDecoder
- ReplaceIfUnmodifiedRequest - 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
- replaceInterceptor(CommandInterceptor, Class<? extends CommandInterceptor>) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Replaces an existing interceptor of the given type in the interceptor chain with a new interceptor instance passed as parameter.
- 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) - 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.
- ReplaceRequest - org.infinispan.server.memcached.MemcachedOperation
- replaceValue(Object, InternalCacheEntry) - Method in interface org.infinispan.context.InvocationContext
-
Deprecated.Since 8.1, use
EntryFactory.wrapExternalEntry(InvocationContext, Object, CacheEntry, boolean, boolean)
instead. - replaceVersionRead(Object, EntryVersion) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.since 9.0
- REPLICABLE_COMMAND - Static variable in interface org.infinispan.commons.marshall.Ids
- ReplicableCommandExternalizer - Class in org.infinispan.marshall.exts
-
ReplicableCommandExternalizer.
- ReplicableCommandExternalizer(RemoteCommandsFactory, GlobalComponentRegistry) - Constructor for class org.infinispan.marshall.exts.ReplicableCommandExternalizer
- REPLICATED_CACHE - org.infinispan.configuration.parsing.Element
- REPLICATED_CACHE_CONFIGURATION - 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
- REPLICATION_MODE_ID - Static variable in class org.infinispan.functional.ParamIds
- REPLICATION_QUEUE_EXECUTOR - org.infinispan.configuration.parsing.Attribute
-
Deprecated.
- REPLICATION_TIMEOUT - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
- ReplicationLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.ReplicationLogic
- replicationQueueThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
-
Deprecated.Since 9.0, no longer used.
- replicationQueueThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfigurationBuilder
-
Deprecated.
- replicationQueueThreadPool() - Method in interface org.infinispan.configuration.global.GlobalConfigurationChildBuilder
-
Deprecated.Since 9.0, no longer used.
- replicationTimeout() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- replicationTimeout(long) - Method in class org.infinispan.configuration.cache.BackupConfiguration
- replicationTimeout(long) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
-
Timeout(millis) used for replicating calls to other sites.
- replTimeout() - Method in class org.infinispan.configuration.cache.SyncConfiguration
-
Deprecated.Since 9.0, please use
ClusteringConfiguration.remoteTimeout()
instead. - replTimeout(long) - Method in class org.infinispan.configuration.cache.SyncConfiguration
-
Deprecated.Since 9.0, please use
ClusteringConfiguration.remoteTimeout(long)
instead. - replTimeout(long) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
-
Deprecated.Since 9.0, please use
ClusteringConfigurationBuilder.remoteTimeout(long)
. - replTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
-
Deprecated.Since 9.0, please use
ClusteringConfigurationBuilder.remoteTimeout(long, TimeUnit)
. - reply - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- reply(Response) - Method in interface org.infinispan.remoting.inboundhandler.Reply
-
Sends back the return value to the sender.
- Reply - Interface in org.infinispan.remoting.inboundhandler
-
Interface responsible to send back the return value to the sender.
- REPLY_FLAGS - Static variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- repository - Variable in class org.infinispan.remoting.transport.AbstractRequest
- request - Variable in class org.infinispan.rest.InfinispanRequest
- requestBytes - Variable in class org.infinispan.server.hotrod.AccessLoggingHeader
- requestBytes() - Method in class org.infinispan.server.hotrod.HotRodDecoder
- requestId - Variable in class org.infinispan.remoting.transport.AbstractRequest
- requestKeys() - Method in class org.infinispan.statetransfer.InboundTransferTask
- requestSegments() - Method in class org.infinispan.statetransfer.InboundTransferTask
-
Send START_STATE_TRANSFER request to source node.
- requestStart - Variable in class org.infinispan.server.hotrod.AccessLoggingHeader
- require(Map<String, String>) - Method in enum org.infinispan.server.core.admin.AdminOperationParameter
- requireAttributes(XMLStreamReader, boolean, String...) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Require all the named attributes, returning their values in order.
- requireAttributes(XMLStreamReader, String...) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- requireClientAuth() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- requireClientAuth(boolean) - Method in class org.infinispan.server.core.configuration.SslConfigurationBuilder
-
Enables client certificate authentication
- requireNoAttributes(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Checks that the current element has no attributes, throwing an
XMLStreamException
if one is found. - requireNoContent(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Consumes the remainder of the current element, throwing an
XMLStreamException
if it contains any child elements. - requireNoNamespaceAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
- requireParameter(Map<String, String>, String) - Method in class org.infinispan.server.core.admin.AdminServerTask
- requireSingleAttribute(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Require that the current element have only a single attribute with the given name.
- ReservoirSampler - Class in org.infinispan.stats.percentiles
-
Keeps the sample for percentile calculations.
- ReservoirSampler() - Constructor for class org.infinispan.stats.percentiles.ReservoirSampler
- ReservoirSampler(int) - Constructor for class org.infinispan.stats.percentiles.ReservoirSampler
- reset() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- reset() - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
- reset() - Method in class org.infinispan.configuration.cache.BackupForBuilder
- 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.stats.CacheStatisticCollector
-
reset all the statistics collected so far.
- reset() - Method in class org.infinispan.stats.CacheStatisticManager
-
Resets the cache statistics collected so far.
- reset() - Method in class org.infinispan.stats.container.ConcurrentGlobalContainer
- reset() - Method in class org.infinispan.stats.percentiles.ReservoirSampler
- reset() - Method in interface org.infinispan.stats.Stats
-
Reset statistics
- reset() - Method in class org.infinispan.xsite.OfflineStatus
- reset(AtomicLongFieldUpdater<T>) - Method in class org.infinispan.commons.util.concurrent.StripedCounters
- resetAll() - Method in class org.infinispan.stats.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 commmand was executed the first time.
- resetCurrentValue() - Method in class org.infinispan.container.entries.ReadCommittedEntry
- resetCurrentValue() - Method in class org.infinispan.container.entries.RepeatableReadEntry
- resetState() - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- resetStatistics() - Method in interface org.infinispan.eviction.PassivationManager
- resetStatistics() - Method in interface org.infinispan.jmx.JmxStatisticsExposer
-
Resets an interceptor's cache statistics
- resetStatistics() - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
- resetStatistics() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- resetStatistics() - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
- resetStatistics() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- resetStatistics() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- resetStatistics() - Method in class org.infinispan.util.concurrent.ActionSequencer
- resetVolatileComponents() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Removes any components not annotated as @SurvivesRestarts.
- RESIN_3 - org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- RESIN_ORION_JONAS - org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- resize(long) - Method in interface org.infinispan.container.DataContainer
-
Resizes the capacity of the underlying container.
- resolveClass(ObjectStreamClass) - Method in class org.infinispan.commons.marshall.CheckedInputStream
- resolveClass(Unmarshaller, String, long) - Method in class org.infinispan.commons.marshall.jboss.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 class org.infinispan.topology.ClusterCacheStatus
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.infinispan.spring.config.InfinispanContainerCacheManagerBeanDefinitionParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.infinispan.spring.config.InfinispanEmbeddedCacheManagerBeanDefinitionParser
- resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.infinispan.spring.config.InfinispanRemoteCacheManagerBeanDefinitionParser
- resolveModuleLifecycles(ClassLoader) - Static method in class org.infinispan.util.ModuleProperties
- resolvePrincipal(Session) - Method in class org.infinispan.spring.session.PrincipalNameResolver
-
Resolves Principal Name (e.g.
- ResourceDMBean - Class in org.infinispan.jmx
-
This class was entirely copied from JGroups 2.7 (same name there).
- ResourceDMBean(Object, ManageableComponentMetadata) - Constructor for class org.infinispan.jmx.ResourceDMBean
- ResourceDMBean(Object, ManageableComponentMetadata, String) - Constructor for class org.infinispan.jmx.ResourceDMBean
- response - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- Response - Interface in org.infinispan.remoting.responses
-
A response to be sent back to a remote caller
- RESPONSE_TIME - org.infinispan.stats.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() - Method in class org.infinispan.remoting.rpc.RpcOptions
-
Deprecated.Since 9.2, ignored by
RpcManager.invokeCommand*()
. - responseFilter(ResponseFilter) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
-
Deprecated.Since 9.2, ignored by
RpcManager.invokeCommand*()
. - 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
- responseMode() - Method in class org.infinispan.remoting.rpc.RpcOptions
-
Deprecated.Since 9.2, ignored by
RpcManager.invokeCommand*()
. - responseMode(ResponseMode) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
-
Deprecated.Since 9.2, ignored by
RpcManager.invokeCommand*()
. - ResponseMode - Enum in org.infinispan.remoting.rpc
-
Represents different handling mechanisms when dealing with remote command responses.
- REST_STORE - org.infinispan.persistence.rest.configuration.Element
- RESTART_SEND - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
- restartComponent(Lifecycle) - Method in class org.infinispan.util.concurrent.SynchronizedRestarter
- restartConflictResolution(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
- RestCacheManager<V> - Class in org.infinispan.rest.cachemanager
-
Manages caches instances used during rest requests.
- RestCacheManager(EmbeddedCacheManager, Predicate<? super String>) - Constructor for class org.infinispan.rest.cachemanager.RestCacheManager
- 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
. - restoreCacheTopology(ScopedPersistentState) - Method in class org.infinispan.topology.ClusterCacheStatus
- RestResponseException - Exception in org.infinispan.rest
-
An exception representing non-critical HTTP processing errors which will be translated into
InfinispanResponse
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 new
RestResponseException
. - restServer - Variable in class org.infinispan.rest.Http11To2UpgradeHandler
- restServer - Variable in class org.infinispan.rest.Http20RequestHandler
- 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
- RestStore<K,V> - Class in org.infinispan.persistence.rest
-
Deprecated.This cache store will be changed to only implement
CacheLoader
- RestStore() - Constructor for class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- RestStoreConfiguration - Class in org.infinispan.persistence.rest.configuration
-
RestStoreConfiguration.
- RestStoreConfiguration(AttributeSet, AsyncStoreConfiguration, SingletonStoreConfiguration, ConnectionPoolConfiguration) - Constructor for class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- RestStoreConfigurationBuilder - Class in org.infinispan.persistence.rest.configuration
-
RestStoreConfigurationBuilder.
- RestStoreConfigurationBuilder(PersistenceConfigurationBuilder) - Constructor for class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- RestStoreConfigurationChildBuilder<S> - Interface in org.infinispan.persistence.rest.configuration
-
RestStoreConfigurationChildBuilder.
- RestStoreConfigurationParser - Class in org.infinispan.persistence.rest.configuration
-
Rest store configuration parser
- RestStoreConfigurationParser() - Constructor for class org.infinispan.persistence.rest.configuration.RestStoreConfigurationParser
- RestStoreConfigurationSerializer - Class in org.infinispan.persistence.rest.configuration
-
RestStoreConfigurationSerializer.
- RestStoreConfigurationSerializer() - Constructor for class org.infinispan.persistence.rest.configuration.RestStoreConfigurationSerializer
- RestTargetMigrator - Class in org.infinispan.persistence.rest.upgrade
-
Deprecated.
- RestTargetMigrator() - Constructor for class org.infinispan.persistence.rest.upgrade.RestTargetMigrator
-
Deprecated.
- result - Variable in class org.infinispan.distexec.RunnableAdapter
- result - Variable in class org.infinispan.interceptors.distribution.VersionedResult
- ResultIterator<E> - Interface in org.infinispan.query
-
Iterates over query results.
- 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.
- 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(Transaction) - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- resume(Transaction) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.Resume the association of the calling thread with the given transaction.
- resumeEncoding() - Method in class org.infinispan.commons.util.Base64.OutputStream
-
Deprecated.Resumes encoding of the stream.
- resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- resumeIfNeeded(Transaction) - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.AbstractDelegatingCollection
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- retainAll(Collection<?>) - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- 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.util.CollectionMapper
- retainAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- retainAll(Collection<?>) - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- retainAll(Collection<?>) - Method in class org.infinispan.util.WriteableCacheCollectionMapper
- 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.
- rethrowException(Throwable) - Static method in class org.infinispan.util.concurrent.CompletableFutures
- retrievalEncounteredException(Throwable) - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
- 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.
- retrieveDistributionInfo(LocalizedCacheTopology, ReplicableCommand, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- retry(Throwable, RpcManager) - Method in class org.infinispan.remoting.transport.RetryOnFailureXSiteCommand.MaxRetriesPolicy
- retry(Throwable, RpcManager) - Method in interface org.infinispan.remoting.transport.RetryOnFailureXSiteCommand.RetryPolicy
- RETRY_NEXT_TOPOLOGY - Static variable in exception org.infinispan.statetransfer.OutdatedTopologyException
-
A cached instance that requests the command's topology id + 1.
- RETRY_SAME_TOPOLOGY - Static variable in exception org.infinispan.statetransfer.OutdatedTopologyException
-
A cached instance, used for read commands that need to be retried in the same topology.
- RetryOnFailureXSiteCommand - Class in org.infinispan.remoting.transport
-
Invokes a command in a remote site.
- RetryOnFailureXSiteCommand.MaxRetriesPolicy - Class in org.infinispan.remoting.transport
- RetryOnFailureXSiteCommand.RetryPolicy - Interface in org.infinispan.remoting.transport
- 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
- 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. - revokeLocalBias(Object) - Method in interface org.infinispan.scattered.BiasManager
-
Stop reading local data.
- revokeLocalBiasForSegments(IntSet) - Method in interface org.infinispan.scattered.BiasManager
-
Stop reading local data from this segment.
- rewind() - Method in interface org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap.ReusableIterator
- rewire() - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.Rewires components.
- rewireNamedRegistries() - Method in class org.infinispan.factories.GlobalComponentRegistry
- rewrapAsCacheException(Throwable) - Static method in class org.infinispan.commons.util.Util
- right() - Method in class org.infinispan.commons.util.Either
- right(byte, int) - Static method in class org.infinispan.server.hotrod.BitShift
- RIGHT - org.infinispan.commons.util.Either.Type
- RiverCloseListener - Interface in org.infinispan.commons.marshall.jboss
-
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.
- RO_LOCAL_EXECUTION - org.infinispan.stats.percentiles.PercentileStatistic
- RO_REMOTE_EXECUTION - org.infinispan.stats.percentiles.PercentileStatistic
- RO_TX_ABORTED_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- RO_TX_SUCCESSFUL_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- role(String) - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
- 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 - org.infinispan.configuration.parsing.Element
- roles() - Method in class org.infinispan.configuration.cache.AuthorizationConfiguration
- roles() - Method in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- ROLES - org.infinispan.configuration.parsing.Attribute
- ROLES - Static variable in class org.infinispan.configuration.cache.AuthorizationConfiguration
- ROLES - Static variable in class org.infinispan.configuration.global.GlobalAuthorizationConfiguration
- 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 interface org.infinispan.container.entries.CacheEntry
-
Deprecated.since 9.0
- 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.DummyBaseTransactionManager
-
Deprecated.Rolls back the transaction associated with the calling thread.
- rollback() - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.Rolls back this transaction.
- rollback() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
-
Deprecated.Rolls back this transaction.
- rollback() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
- rollback(Transaction) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- rollback(Transaction) - Method in interface org.infinispan.persistence.spi.TransactionalCacheWriter
-
Rollback the provided transaction's changes to the underlying store.
- rollback(Xid) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
-
Same comment as for
TransactionXaAdapter.prepare(javax.transaction.xa.Xid)
applies for commit. - ROLLBACK_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- ROLLBACK_TX - org.infinispan.server.hotrod.HotRodOperation
- ROLLBACK_TX - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- rollbackAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Perform the rollback operation for the provided transaction on all Tx stores.
- rollbackAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- rollbackAllTxStores(Transaction, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- 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 - org.infinispan.server.hotrod.tx.table.Status
-
The client transaction is rolled back.
- ROLLING_UPGRADE - org.infinispan.context.Flag
-
Flag to identity that data is being written as part of a Rolling Upgrade.
- RollingUpgradeManager - Class in org.infinispan.upgrade
-
This component handles the control hooks to handle migrating from one version of Infinispan to another.
- RollingUpgradeManager() - Constructor for class org.infinispan.upgrade.RollingUpgradeManager
- root() - Method in annotation type org.infinispan.configuration.parsing.Namespace
-
The root element of this namespace.
- ROOT - org.infinispan.configuration.parsing.Element
- roundUpToNearest8(long) - Method in class org.infinispan.commons.util.AbstractEntrySizeCalculatorHelper
- rpc - Variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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.statetransfer.StateConsumerImpl
- rpcManager - Variable in class org.infinispan.statetransfer.StateProviderImpl
- 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.statetransfer.StateConsumerImpl
- RpcOptions - Class in org.infinispan.remoting.rpc
-
Classes that wraps all the configuration parameters to configure a remote invocation.
- RpcOptions(long, TimeUnit, ResponseFilter, ResponseMode, boolean, DeliverOrder) - Constructor for class org.infinispan.remoting.rpc.RpcOptions
-
Deprecated.Since 9.0, use
RpcOptions(long, TimeUnit, ResponseFilter, ResponseMode, DeliverOrder)
instead. - RpcOptions(long, TimeUnit, ResponseFilter, ResponseMode, DeliverOrder) - Constructor for class org.infinispan.remoting.rpc.RpcOptions
-
Deprecated.Since 9.2, use
RpcOptions(DeliverOrder, long, TimeUnit)
instead. - RpcOptions(DeliverOrder, long, TimeUnit) - Constructor for class org.infinispan.remoting.rpc.RpcOptions
- RpcOptionsBuilder - Class in org.infinispan.remoting.rpc
-
Deprecated.Since 9.2, please use
RpcOptions
directly. - RpcOptionsBuilder(long, TimeUnit, ResponseMode, DeliverOrder) - Constructor for class org.infinispan.remoting.rpc.RpcOptionsBuilder
-
Deprecated.
- RpcOptionsBuilder(RpcOptions) - Constructor for class org.infinispan.remoting.rpc.RpcOptionsBuilder
-
Deprecated.Constructor based on existing
RpcOptions
- run() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- 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.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.GetCacheGlobalComponentRegistryAction
- 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.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.GetClusterExecutorAction
- run() - Method in class org.infinispan.security.actions.GetDefaultExecutorServiceAction
- run() - Method in class org.infinispan.security.actions.GetGlobalComponentRegistryAction
- 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.RemoveListenerAction
- 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.statetransfer.OutboundTransferTask
- run(int) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl.ArgRunnable
- runCommit(boolean) - Method in class org.infinispan.commons.tx.TransactionImpl
-
Runs the second phase of two-phase-commit protocol.
- runCommit(boolean) - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.Runs the second phase of two-phase-commit protocol.
- runL1UpdateIfPossible(InternalCacheEntry) - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
-
Attempts to the L1 update and set the value.
- RunnableAdapter<T> - Class in org.infinispan.distexec
-
Runnable adapter for distributed executor service Any RunnableAdapter refactoring might break CDI
- RunnableAdapter() - Constructor for class org.infinispan.distexec.RunnableAdapter
- RunnableAdapter(Runnable, T) - Constructor for class org.infinispan.distexec.RunnableAdapter
- RUNNING - org.infinispan.lifecycle.ComponentStatus
-
The
start()
method has been completed and the component is running. - runPrepare() - Method in class org.infinispan.commons.tx.TransactionImpl
- runPrepare() - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.
- 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) - Method in interface org.infinispan.tasks.TaskManager
-
Executes the named task, passing an optional cache and a map of named parameters.
- runTask(String, TaskContext, Executor) - Method in class org.infinispan.server.core.admin.AdminOperationsHandler
- runTask(String, TaskContext, Executor) - Method in interface org.infinispan.tasks.spi.TaskEngine
-
Executes the named task on the specified cache, passing a map of named parameters.
- rvrl - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
S
- safeClose(Connection) - Static method in class org.infinispan.persistence.jdbc.JdbcUtil
- safeClose(ResultSet) - Static method in class org.infinispan.persistence.jdbc.JdbcUtil
- safeClose(Statement) - Static method in class org.infinispan.persistence.jdbc.JdbcUtil
- safeEquals(Object, Object) - Static method in class org.infinispan.commons.util.Util
-
Null-safe equality test.
- SAME_MACHINE - org.infinispan.distexec.DistributedTaskExecutionPolicy
- SAME_MACHINE - org.infinispan.manager.ClusterExecutionPolicy
-
The command can be executed only on the same machine from where it was initiated.
- SAME_RACK - org.infinispan.distexec.DistributedTaskExecutionPolicy
- SAME_RACK - org.infinispan.manager.ClusterExecutionPolicy
-
The command will be executed on a machine on the same rack.
- SAME_SITE - org.infinispan.distexec.DistributedTaskExecutionPolicy
- SAME_SITE - org.infinispan.manager.ClusterExecutionPolicy
-
The command will be executed on a machine on the same site.
- sameCacheName(String) - Method in class org.infinispan.transaction.xa.recovery.RecoveryInfoKey
- sameXid(Xid) - Method in class org.infinispan.server.hotrod.tx.table.CacheXid
- SASL_MECHANISM - org.infinispan.persistence.remote.configuration.Attribute
- saslMechanism() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- saslMechanism(String) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Selects the SASL mechanism to use for the connection to the server
- saslProperties() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- saslProperties(Map<String, String>) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Sets the SASL properties
- 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
- SaslUtils - Class in org.infinispan.commons.util
-
Utility methods for handling SASL authentication
- SaslUtils() - Constructor for class org.infinispan.commons.util.SaslUtils
- save(MapSession) - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- SCATTERED_CACHE - org.infinispan.configuration.parsing.Element
- SCATTERED_CACHE_CONFIGURATION - org.infinispan.configuration.parsing.Element
- 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 - org.infinispan.configuration.cache.CacheMode
-
Synchronous scattered cache
- ScatteredDistributionInterceptor - Class in org.infinispan.interceptors.distribution
-
This interceptor mixes several functions: A) replicates changes to other nodes B) commits the entry C) schedules invalidation On primary owner, the commit is executed before the change is replicated to other node.
- ScatteredDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- ScatteredDistributionInterceptor.PrimaryResponseGenerator - Class in org.infinispan.interceptors.distribution
- ScatteredDistributionInterceptor.PrimaryResponseHandler - Class in org.infinispan.interceptors.distribution
- ScatteredLogic() - Constructor for class org.infinispan.interceptors.locking.ClusteringDependentLogic.ScatteredLogic
- scatteredLostDataCheck(ConsistentHash, List<Address>) - Static method in class org.infinispan.topology.ClusterTopologyManagerImpl
- ScatteredStateProvider - Interface in org.infinispan.scattered
- ScatteredVersionManager<K> - Interface in org.infinispan.scattered
-
Manages versions of entries and states of segments.
- ScatteredVersionManager.SegmentState - Enum in org.infinispan.scattered
- schedule(Runnable, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- 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
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- SCHEDULED_THREAD_POOL - 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.
- ScheduledThreadPoolExecutorFactory - Enum in org.infinispan.commons.executors
- scheduleKeyInvalidation(Object, EntryVersion, boolean) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- 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
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.infinispan.executors.LazyInitializingScheduledExecutorService
- Schema - Class in org.infinispan.configuration.parsing
-
Schema.
- Schema(int, int) - Constructor for class org.infinispan.configuration.parsing.Schema
- SCHEMA_MANAGER_ROLE - Static variable in interface org.infinispan.query.remote.ProtobufMetadataManager
- scheme() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
-
Deprecated.
- scheme(VersioningScheme) - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
-
Deprecated.
- SCHEME - Static variable in class org.infinispan.configuration.cache.VersioningConfiguration
-
Deprecated.
- Scope - Annotation Type in org.infinispan.factories.scopes
-
Defines the scope of a component in a cache system.
- SCOPED_STATE - Static variable in interface org.infinispan.commons.marshall.Ids
- SCOPED_STATE_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- ScopeDetector - Class in org.infinispan.factories.scopes
-
Retrieves the declared scope of a component
- ScopeDetector() - Constructor for class org.infinispan.factories.scopes.ScopeDetector
- ScopedPersistentState - Interface in org.infinispan.globalstate
-
ScopedPersistentState represents state which needs to be persisted, scoped by name (e.g.
- 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.scopes
-
The different scopes that can be declared for a component in the cache system.
- SCRIPT_CACHE - Static variable in interface org.infinispan.scripting.ScriptingManager
- SCRIPT_MANAGER_ROLE - Static variable in interface org.infinispan.scripting.ScriptingManager
- ScriptConversions - Class in org.infinispan.scripting.utils
- ScriptConversions(EncoderRegistry) - Constructor for class org.infinispan.scripting.utils.ScriptConversions
- ScriptingManager - Interface in org.infinispan.scripting
-
ScriptingManager.
- search(String, JsonQueryRequest, InfinispanSearchRequest) - Method in class org.infinispan.rest.operations.SearchOperations
- Search - Class in org.infinispan.query
-
This is the entry point for the Infinispan query API.
- searchFactory - Variable in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- SearchManager - Interface in org.infinispan.query
-
The SearchManager is the entry point to create full text queries on top of an indexed cache.
- SearchManagerImplementor - Interface in org.infinispan.query.spi
- SearchOperations - Class in org.infinispan.rest.operations
-
Handle search related operations via Rest.
- SearchOperations(RestServerConfiguration, RestCacheManager<Object>) - Constructor for class org.infinispan.rest.operations.SearchOperations
- SECONDS - org.infinispan.jmx.annotations.Units
- SECONDS - org.infinispan.server.hotrod.TimeUnitValue
- SecureCache<K,V> - Interface in org.infinispan.security
-
SecureCache.
- SecureTypeIdResolver - Class in org.infinispan.server.core.dataconversion.json
-
Jackson TypeIdResolver that checks the serialization whitelist before deserializing JSON types.
- SecureTypeResolverBuilder - Class in org.infinispan.server.core.dataconversion.json
-
Builder that can produce
SecureTypeIdResolver
from an existing TypeIdResolver. - SecureTypeResolverBuilder(ObjectMapper.DefaultTyping, ClassWhiteList) - Constructor for class org.infinispan.server.core.dataconversion.json.SecureTypeResolverBuilder
- 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.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 - org.infinispan.configuration.parsing.Element
- SECURITY - org.infinispan.persistence.remote.configuration.Element
- 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
- securityCacheTimeout() - Method in class org.infinispan.configuration.global.GlobalSecurityConfiguration
- securityCacheTimeout(long) - Method in class org.infinispan.configuration.global.GlobalSecurityConfigurationBuilder
- securityCacheTimeout(long) - Method in interface org.infinispan.configuration.global.GlobalSecurityConfigurationChildBuilder
-
Deprecated.
- 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.configuration.cache
-
SecurityConfiguration.
- SecurityConfiguration - Class in org.infinispan.persistence.remote.configuration
-
SecurityConfiguration.
- 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. - SEGMENT_COLUMN - org.infinispan.persistence.jdbc.configuration.Element
- SEGMENT_COLUMN_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- SEGMENT_COLUMN_TYPE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- SEGMENTATION_FEATURE - Static variable in class org.infinispan.factories.DataContainerFactory
- segmentAwareEntrySet - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- segmentAwareKeySet - Variable in class org.infinispan.distribution.util.ReadOnlySegmentAwareMap
- 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.TableManipulationConfiguration
- segmentColumnType(String) - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
-
The type of the database column used to store the segments
- segmentCompleted(Set<Integer>) - Method in interface org.infinispan.BaseCacheStream.SegmentCompletionListener
-
Deprecated.This method requires boxing for each segment. Please use
BaseCacheStream.SegmentCompletionListener.accept(Supplier)
instead - 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.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 - org.infinispan.configuration.parsing.Attribute
- SEGMENTED - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- SegmentedAdvancedLoadWriteStore<K,V> - Interface in org.infinispan.persistence.spi
-
An interface implementing both
AdvancedCacheWriter
andAdvancedCacheLoader
as well as overrides of those methods that can be optimized when a segment is already known for the key or a subset of segments are to be used instead of the entire store. - SegmentedBoundedOffHeapDataContainer - Class in org.infinispan.container.offheap
- SegmentedBoundedOffHeapDataContainer(int, int, long, EvictionType) - Constructor for class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- segmentId() - Method in class org.infinispan.distribution.DistributionInfo
- SegmentReadLocker - Interface in org.infinispan.lucene.readlocks
-
SegmentReadLocker implementations have to make sure that segments are not deleted while they are being used by an IndexReader.
- SEGMENTS - org.infinispan.configuration.parsing.Attribute
- segmentsToBytes() - Method in class org.infinispan.server.hotrod.iteration.IterableIterationResult
- select(String...) - Method in interface org.infinispan.query.dsl.QueryBuilder
- select(Expression...) - Method in interface org.infinispan.query.dsl.QueryBuilder
- selectExecutionNode(List<Address>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- selectExecutionNode(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- self() - Method in interface org.infinispan.commons.configuration.Self
- self() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfigurationBuilder
- 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.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
- 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.jpa.configuration.JpaStoreConfigurationBuilder
- self() - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- self() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- self() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- self() - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- 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
- 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
- sendEvents() - Method in interface org.infinispan.notifications.cachelistener.cluster.ClusterEventManager
-
Sends all previously added events on this thread
- sendResponse(ChannelHandlerContext, FullHttpRequest, FullHttpResponse) - Method in class org.infinispan.rest.Http11RequestHandler
- sendResponse(ChannelHandlerContext, FullHttpRequest, FullHttpResponse) - Method in class org.infinispan.rest.Http20RequestHandler
- 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
. - sendTo(Address, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.stats.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. - sendToAll(ReplicableCommand, DeliverOrder) - Method in class org.infinispan.stats.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
. - sendToMany(Collection<Address>, ReplicableCommand, DeliverOrder) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticRpcManager
- sequence(List<CompletableFuture<T>>) - Static method in class org.infinispan.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.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.util.AbstractDelegatingCacheStream
- sequentialInterceptorClass() - Method in class org.infinispan.configuration.cache.InterceptorConfiguration
- SERIALIZABLE - 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
- SerializableXid - Class in org.infinispan.transaction.xa.recovery
-
Deprecated.use
XidImpl
instead. - SerializableXid(byte[], byte[], int) - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid
-
Deprecated.
- SerializableXid(Xid) - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid
-
Deprecated.
- SerializableXid.XidExternalizer - Class in org.infinispan.transaction.xa.recovery
-
Deprecated.
- 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 - org.infinispan.configuration.parsing.Element
- SerializationConfiguration - Class in org.infinispan.configuration.global
- SerializationConfigurationBuilder - Class in org.infinispan.configuration.global
-
Configures serialization and marshalling settings.
- serialize(OutputStream, String, Configuration) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Serializes a single configuration to an OutputStream
- serialize(OutputStream, GlobalConfiguration, Map<String, Configuration>) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Serializes a full configuration to an
OutputStream
- serialize(Object, JsonGenerator, SerializerProvider) - Method in class org.infinispan.query.remote.json.HitSerializer
- serialize(String, Configuration) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Serializes a single configuration to a String
- serialize(XMLExtendedStreamWriter, GlobalConfiguration, Map<String, Configuration>) - Method in class org.infinispan.configuration.parsing.ParserRegistry
-
Serializes a full configuration to an
XMLExtendedStreamWriter
- serialize(XMLExtendedStreamWriter, PrivateGlobalConfiguration) - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationSerializer
- serialize(XMLExtendedStreamWriter, ConfigurationHolder) - Method in class org.infinispan.configuration.serializing.Serializer
- serialize(XMLExtendedStreamWriter, CounterManagerConfiguration) - Method in class org.infinispan.counter.configuration.CounterConfigurationSerializer
- serialize(XMLExtendedStreamWriter, JdbcStringBasedStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.JdbcStringBasedStoreConfigurationSerializer
- serialize(XMLExtendedStreamWriter, JpaStoreConfiguration) - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationSerializer
- serialize(XMLExtendedStreamWriter, RemoteStoreConfiguration) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationSerializer
- serialize(XMLExtendedStreamWriter, RestStoreConfiguration) - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationSerializer
- serialize(XMLExtendedStreamWriter, T) - Method in interface org.infinispan.configuration.serializing.ConfigurationSerializer
- serializeConfigurations(OutputStream, List<AbstractCounterConfiguration>) - Method in class org.infinispan.counter.configuration.CounterConfigurationSerializer
- serializedModel - Variable in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- 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 - Class in org.infinispan.configuration.serializing
-
Serializes an Infinispan configuration to an
XMLExtendedStreamWriter
- Serializer() - Constructor for class org.infinispan.configuration.serializing.Serializer
- SerializeUtils - Class in org.infinispan.configuration.serializing
- SerializeWith - Annotation Type in org.infinispan.commons.marshall
-
Indicate that this class should be serialized with an instance of the given
Externalizer
class. - SerializeWithExtFactory - Class in org.infinispan.commons.marshall.jboss
-
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.commons.marshall.jboss.SerializeWithExtFactory
- serveBannerFile(InfinispanRequest) - Method in class org.infinispan.rest.operations.StaticContent
- serveHtmlFile(InfinispanRequest) - Method in class org.infinispan.rest.operations.StaticContent
- server - Variable in class org.infinispan.server.core.transport.NettyChannelInitializer
- server - Variable in class org.infinispan.server.hotrod.BaseRequestProcessor
- SERVER - org.infinispan.persistence.remote.configuration.Element
- SERVER - org.infinispan.persistence.rest.configuration.Element
- SERVER_ADDRESS - Static variable in class org.infinispan.server.core.ExternalizerIds
- SERVER_ENTRY_VERSION - Static variable in class org.infinispan.server.core.ExternalizerIds
- SERVER_ERROR - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- SERVER_NAME - org.infinispan.persistence.remote.configuration.Attribute
- ServerAddress - Class in org.infinispan.server.hotrod
-
A Hot Rod server address
- ServerAddress(String, int) - Constructor for class org.infinispan.server.hotrod.ServerAddress
- serverAuthenticationProvider() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- serverAuthenticationProvider(ServerAuthenticationProvider) - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfigurationBuilder
- ServerAuthenticationProvider - Interface in org.infinispan.server.core.security
- ServerConstants - Class in org.infinispan.server.core
-
Server Constant values
- ServerCoreMetadataFileFinder - Class in org.infinispan.server.core
- ServerCoreMetadataFileFinder() - Constructor for class org.infinispan.server.core.ServerCoreMetadataFileFinder
- ServerError - org.infinispan.server.hotrod.OperationStatus
- ServerInternalException - Exception in org.infinispan.rest.operations.exceptions
- ServerInternalException(Exception) - Constructor for exception org.infinispan.rest.operations.exceptions.ServerInternalException
- ServerMetadataFileFinder - Class in org.infinispan.server.hotrod
- ServerMetadataFileFinder() - Constructor for class org.infinispan.server.hotrod.ServerMetadataFileFinder
- serverMode(boolean) - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
- serverName() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- serverName() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- 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
- servers() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- SERVERS - org.infinispan.persistence.remote.configuration.Element
- SERVERS - org.infinispan.persistence.rest.configuration.Element
- 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 for deployed server tasks.
- 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
- sessionRepository(SpringEmbeddedCacheManager, ApplicationEventPublisher) - Method in class org.infinispan.spring.session.configuration.InfinispanEmbeddedHttpSessionConfiguration
- sessionRepository(SpringRemoteCacheManager, ApplicationEventPublisher) - Method in class org.infinispan.spring.session.configuration.InfinispanRemoteHttpSessionConfiguration
- 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.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(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 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
- setAddress(Address) - Method in class org.infinispan.transaction.xa.GlobalTransaction
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- setAsyncExecutorFactory(String) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setAsyncExecutorFactory(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setAttribute(Attribute) - Method in class org.infinispan.jmx.ResourceDMBean
- setAttributes(AttributeList) - Method in class org.infinispan.jmx.ResourceDMBean
- setAttributes(AttributeSet, Map<?, ?>, boolean, boolean) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
- setAuthenticator(Authenticator) - Method in class org.infinispan.rest.RestServer
-
Sets Authentication mechanism.
- setAvailability(AvailabilityMode) - Method in interface org.infinispan.AdvancedCache
-
Manually change the availability of the cache.
- setBeanName(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
- setBeanName(String) - Method in class org.infinispan.spring.support.remote.InfinispanNamedRemoteCacheFactoryBean
- 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
- setCacheAvailability(String, AvailabilityMode) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- 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.query.clustered.ClusteredQueryCommand
- setCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
-
This is invoked only on the receiving node, before
ReplicableCommand.perform(org.infinispan.context.InvocationContext)
. - setCacheName(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
-
Sets the
name
of the
to be created.org.infinispan.Cache
- setCacheName(String) - Method in class org.infinispan.spring.support.remote.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
- setCacheRebalancingEnabled(String, boolean) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- setCacheTopology(CacheTopology) - Method in interface org.infinispan.distribution.DistributionManager
-
Deprecated.Internal only.
- setCapacity(int) - Method in class org.infinispan.stats.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
- setClassLoader(ClassLoader) - Method in interface org.infinispan.context.InvocationContext
-
Deprecated.Not in use any more.
- setClassLoader(ClassLoader) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- setClearOnStop(boolean) - Method in interface org.infinispan.persistence.manager.PersistenceManager
- setClearOnStop(boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- setClearOnStop(boolean) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- setClustered(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setCoinToss(long) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.Sets the random number that defines the coin toss.
- 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
- setComponentClass(Class<?>) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- setConfigurationFileLocation(Resource) - Method in class org.infinispan.spring.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.AbstractRemoteCacheManagerFactory
- setConfigurationPropertiesFileLocation(Resource) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setConfigurationTemplateMode(String) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
- setConnectionFactoryClass(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- setConnectionUrl(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- setContext(PrincipalRoleMapperContext) - Method in interface org.infinispan.security.PrincipalRoleMapper
-
Sets the context for this
PrincipalRoleMapper
- 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(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
- setDatasourceJndiLocation(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- 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
- setDefaultNamespace(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- setDriverClass(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- setEnabled(boolean) - Method in class org.infinispan.stats.topK.StreamSummaryContainer
-
Enables or disables the top-key collection
- setEnlisted(boolean) - Method in class org.infinispan.transaction.synchronization.SyncLocalTransaction
- 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
- setEnvironment(Cache<Object, Object>, Set<Object>) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask
- setEnvironment(Cache<K, V>, Set<K>) - Method in interface org.infinispan.distexec.DistributedCallable
-
Invoked by execution environment after DistributedCallable has been migrated for execution to a specific Infinispan node.
- setEnvironment(Cache<K, V>, Set<K>) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable
- setEnvironment(Cache<K, V>, Set<K>) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerRemoveCallable
- setEnvironment(Cache<K, V>, Set<K>) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterListenerReplicateCallable
- setEnvironment(Cache<K, V>, Set<K>) - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable
- 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
- setException(Exception) - Method in class org.infinispan.remoting.responses.ExceptionResponse
- setExecutable(boolean) - Method in class org.infinispan.io.GridFile
- setExecutable(boolean, boolean) - Method in class org.infinispan.io.GridFile
- 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
- setField(Object, Field, Object) - Static method in class org.infinispan.commons.util.ReflectionUtil
- setField(Field) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- 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
- setFirstInChain(CommandInterceptor) - Method in class org.infinispan.interceptors.InterceptorChain
-
Deprecated.Mainly used by unit tests to replace the interceptor chain with the starting point passed in.
- setFirstTopologyAsMember(int) - Method in class org.infinispan.remoting.inboundhandler.AbstractDelegatingHandler
- setFirstTopologyAsMember(int) - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- setFirstTopologyAsMember(int) - Method in interface org.infinispan.remoting.inboundhandler.PerCacheInboundInvocationHandler
- setFlag(ReadCommittedEntry.Flags) - Method in class org.infinispan.container.entries.ReadCommittedEntry
-
Utility method that sets the value of the given flag to true.
- setForceReturnValues(boolean) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setForceReturnValues(boolean) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setId(long) - Method in class org.infinispan.transaction.xa.GlobalTransaction
- setIdentifier(UUID) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setIgnoredCaches(Set<String>) - Method in class org.infinispan.server.core.AbstractCacheIgnoreAware
- setIgnoredCaches(Set<String>) - Method in interface org.infinispan.server.core.CacheIgnoreAware
-
Replaces all ignored caches with the set provided
- setImportMetadata(AnnotationMetadata) - Method in class org.infinispan.spring.session.configuration.InfinispanEmbeddedHttpSessionConfiguration
- setImportMetadata(AnnotationMetadata) - Method in class org.infinispan.spring.session.configuration.InfinispanRemoteHttpSessionConfiguration
- setIncludeCurrentState(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setIndexedQueryMode(String) - Method in class org.infinispan.query.remote.client.QueryRequest
- setIndexName(String) - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- setInfinispanCacheContainer(CacheContainer) - Method in class org.infinispan.spring.InfinispanDefaultCacheFactoryBean
-
Sets the
to be used for creating ourorg.infinispan.manager.CacheContainer
instance.Cache
- setInfinispanEmbeddedCacheManager(EmbeddedCacheManager) - Method in class org.infinispan.spring.support.embedded.InfinispanNamedEmbeddedCacheFactoryBean
-
Sets the
to be used for creating ourorg.infinispan.manager.EmbeddedCacheManager
instance.Cache
- setInfinispanRemoteCacheManager(RemoteCacheManager) - Method in class org.infinispan.spring.support.remote.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
- setInternalCacheEntryFactory(InternalEntryFactory) - Method in class org.infinispan.persistence.remote.RemoteStore
- setInternalCacheEntryFactory(InternalEntryFactory) - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- setInternalCacheValueConsumer() - Static method in class org.infinispan.marshall.core.MarshallableFunctions
- setInternalId(long) - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
- setInternalId(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
-
Deprecated.
- setInternalId(long) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
- setJmxDomain(String) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
- setKeepAliveTime(long) - Method in class org.infinispan.executors.ManageableExecutorService
- setKeyDataConversion(DataConversion) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setKeyInvalidationListener(StateConsumerImpl.KeyInvalidationListener) - Method in class org.infinispan.statetransfer.StateConsumerImpl
- setKeySizeEstimate(int) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setKeySizeEstimate(int) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setLastModified(long) - Method in class org.infinispan.io.GridFile
- 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
- 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.CacheEntry
-
Deprecated.since 8.1
- 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.InDoubtTxInfoImpl
- setLockIntention(Collection<Object>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- setLockOwner(Object) - Method in interface org.infinispan.context.InvocationContext
-
Sets the object to be used by lock owner.
- setLockOwner(Object) - Method in class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- setLocksHeldAtOrigin(Collection<?>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- 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.spring.AbstractRemoteCacheManagerFactory
- setMarshaller(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setMarshaller(Marshaller) - Method in class org.infinispan.server.hotrod.HotRodServer
- setMarshaller(StreamingMarshaller) - Method in interface org.infinispan.persistence.keymappers.MarshallingTwoWayKey2StringMapper
- 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
- setMaxResults(Integer) - Method in class org.infinispan.query.remote.client.QueryRequest
- 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
- setMethod(Method) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- setMethod(Method) - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
- setModificationTime(long) - Method in class org.infinispan.io.GridFile.Metadata
- setNamedParameters(List<QueryRequest.NamedParameter>) - Method in class org.infinispan.query.remote.client.QueryRequest
- setNamespaceContext(NamespaceContext) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- setNearCacheMaxEntries(int) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setNearCacheMaxEntries(int) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setNearCacheMode(String) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setNearCacheMode(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setNearCacheNamePattern(String) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setNearCacheNamePattern(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- 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
- setNext(CommandInterceptor) - Method in class org.infinispan.interceptors.base.CommandInterceptor
-
Deprecated.Does nothing since 9.0.
- setNextInterceptor(AsyncInterceptor) - Method in interface org.infinispan.interceptors.AsyncInterceptor
-
Sets up the interceptor.
- setNextInterceptor(AsyncInterceptor) - Method in class org.infinispan.interceptors.base.CommandInterceptor
-
Deprecated.
- 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
- setNumResults(int) - Method in class org.infinispan.query.remote.client.QueryResponse
- setObservation(Listener.Observation) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setOnlyPrimary(boolean) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- setOriginSite(String) - Method in class org.infinispan.xsite.XSiteReplicateCommand
- setOutcome(boolean) - Method in class org.infinispan.stats.TransactionStatistics
-
Sets the transaction outcome.
- 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
-
Sets the value of a named parameter.
- setParameterClasses(Class<?>[]) - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- setParameters(Map<String, Object>) - Method in interface org.infinispan.query.dsl.ParameterContext
-
Sets multiple named parameters at once.
- setParserContext(Class<? extends ConfigurationParser>, ParserContext) - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- setPassword(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- setPrefix(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- 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
- setProjectionSize(int) - Method in class org.infinispan.query.remote.client.QueryResponse
- setProperty(String, boolean) - Method in class org.infinispan.commons.util.TypedProperties
- 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 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.configuration.cache.IndexingConfigurationBuilder
-
Defines a single value.
- setProperty(String, String) - Method in class org.infinispan.commons.util.TypedProperties
- setProperty(String, String) - Method in interface org.infinispan.globalstate.ScopedPersistentState
-
Sets a state property.
- setQueryString(String) - Method in class org.infinispan.query.remote.client.QueryRequest
- 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
- setReadable(boolean, boolean) - Method in class org.infinispan.io.GridFile
- setReadOnly() - Method in class org.infinispan.io.GridFile
- setReadTimeout(long) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setReadTimeout(long) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setReadTimeout(long) - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
- setRebalanceEnabled(boolean) - Method in class org.infinispan.topology.ClusterCacheStatus
- 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(boolean) - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- 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
- setRemoteLockIntention(Collection<?>) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- 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.AbstractRemoteCacheManagerFactory
- setRequestBalancingStrategy(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setResults(List<WrappedMessage>) - Method in class org.infinispan.query.remote.client.QueryResponse
- 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.DummyBaseTransactionManager
-
Deprecated.Mark the transaction associated with the calling thread for rollback only.
- setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.Mark the transaction so that the only possible outcome is a rollback.
- setRollbackOnly() - Method in class org.infinispan.transaction.tm.DummyUserTransaction
-
Deprecated.Mark the transaction so that the only possible outcome is a rollback.
- setRollbackOnly() - Method in class org.infinispan.transaction.tm.EmbeddedUserTransaction
- setSchema(Schema) - Method in interface org.infinispan.configuration.parsing.XMLExtendedStreamReader
-
Sets the current schema
- setSerializedWorkList(byte[]) - Method in class org.infinispan.query.affinity.AffinityUpdateCommand
- setSerializedWorkList(byte[]) - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- setServerList(Collection<InetSocketAddress>) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setServerList(Collection<InetSocketAddress>) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setSiteName(String) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- setSize(long) - Method in class org.infinispan.lucene.FileMetadata
- 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
- setStackTrace(StackTraceElement[]) - Method in exception org.infinispan.commons.marshall.NotSerializableException
- setStartAutomatically(boolean) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setStartOffset(Long) - Method in class org.infinispan.query.remote.client.QueryRequest
- setStatisticEnabled(boolean) - Method in class org.infinispan.util.concurrent.ActionSequencer
- 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.inboundhandler.AbstractDelegatingHandler
- setStatisticsEnabled(boolean) - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- setStatisticsEnabled(boolean) - Method in class org.infinispan.remoting.rpc.RpcManagerImpl
-
Deprecated.We already have an attribute, we shouldn't have an operation for the same thing.
- setStatisticsEnabled(boolean) - Method in interface org.infinispan.stats.Stats
-
Enables or disables statistics at runtime.
- setStatisticsEnabled(boolean) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- setStatus(Status, boolean, TimeService) - Method in class org.infinispan.server.hotrod.tx.table.TxState
- setStatusOk(boolean) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- setSubject(Subject) - Method in class org.infinispan.rest.InfinispanRequest
- setTakeOfflineAfterFailures(String, int) - Method in class org.infinispan.xsite.XSiteAdminOperations
- setTakeOfflineMinTimeToWait(String, long) - Method in class org.infinispan.xsite.XSiteAdminOperations
- 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
- setTcpKeepAlive(boolean) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setTcpKeepAlive(boolean) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setTcpNoDelay(boolean) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setTcpNoDelay(boolean) - Method in class org.infinispan.spring.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
- setThreadLocal(InvocationContext) - Method in interface org.infinispan.context.InvocationContextContainer
-
Deprecated.Associate the InvocationContext parameter with the calling thread.
- SetThreadNameAction - Class in org.infinispan.security.actions
-
SetThreadNameAction.
- SetThreadNameAction(String) - Constructor for class org.infinispan.security.actions.SetThreadNameAction
- 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
- setTimeoutExceptionFactory(TimeoutExceptionFactory) - Method in interface org.infinispan.query.spi.SearchManagerImplementor
-
Define the timeout exception factory to customize the exception thrown when the query timeout is exceeded.
- setTopKValue(int) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- setTopologyId(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
-
Set current topology id.
- setTopologyId(int) - Method in class org.infinispan.statetransfer.StateRequestCommand
- setTopologyId(int) - Method in class org.infinispan.statetransfer.StateResponseCommand
- setTopologyId(int) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- setTotalResults(long) - Method in class org.infinispan.query.remote.client.QueryResponse
- setTransaction(Transaction) - Static method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.Just used for unit tests
- setTransactionOutcome(boolean, GlobalTransaction, boolean) - Method in class org.infinispan.stats.CacheStatisticManager
-
Sets the transaction outcome to commit or rollback, depending if the transaction has commit successfully or not respectively.
- setTransactionTimeout(int) - Method in class org.infinispan.commons.tx.TransactionManagerImpl
- setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.Change the transaction timeout for transactions started by the calling thread with the
DummyBaseTransactionManager.begin()
method. - setTransactionTimeout(int) - Method in class org.infinispan.transaction.tm.DummyUserTransaction
-
Deprecated.Change the transaction timeout for transactions started by the calling thread with the
DummyUserTransaction.begin()
method. - 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(String) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
-
Deprecated.
- setTransportFactory(String) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setUnregisterCacheMBean(boolean) - Method in class org.infinispan.jmx.CacheJmxRegistration
- setUnspecifiedElementNamespace(String) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- setUnspecifiedElementNamespace(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- setUpdatedEntryVersions(EntryVersionsMap) - Method in interface org.infinispan.transaction.xa.CacheTransaction
- setUserName(String) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactoryConfig
- setUseXaXid(boolean) - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.
- setValid(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
-
Deprecated.since 9.2
- setValue(Object) - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- setValue(Object) - Method in class org.infinispan.container.entries.ImmortalCacheValue
- setValue(Object) - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- setValue(Object) - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- setValue(Object) - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- setValue(Object) - Method in class org.infinispan.container.entries.MortalCacheEntry
- setValue(Object) - Method in class org.infinispan.container.entries.NullCacheEntry
- setValue(Object) - Method in class org.infinispan.container.entries.ReadCommittedEntry
- setValue(Object) - Method in class org.infinispan.container.entries.RepeatableReadEntry
- setValue(Object) - Method in class org.infinispan.container.entries.TransientCacheEntry
- setValue(Object) - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- setValue(V) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Node
-
Deprecated.
- 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.util.EntryWrapper
- setValue(V, EquivalentHashMap<K, V>) - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Node
-
Deprecated.
- 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
- setValues(Object, Map<?, ?>, boolean, boolean) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
- setValueSizeEstimate(int) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setValueSizeEstimate(int) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setValuesTransferTopology(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
- setVersion(EntryVersion) - Method in interface org.infinispan.container.entries.versioned.Versioned
-
Sets the version on this entry.
- setVersion(EntryVersion) - Method in class org.infinispan.container.entries.VersionedRepeatableReadEntry
- setWritable(boolean) - Method in class org.infinispan.io.GridFile
- setWritable(boolean, boolean) - Method in class org.infinispan.io.GridFile
- setWriteTimeout(long) - Method in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- setWriteTimeout(long) - Method in class org.infinispan.spring.ConfigurationPropertiesOverrides
- setWriteTimeout(long) - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
- setXid(Xid) - Method in class org.infinispan.commons.tx.TransactionImpl
- setXid(Xid) - Method in class org.infinispan.transaction.xa.LocalXaTransaction
- setXid(Xid) - Method in interface org.infinispan.transaction.xa.recovery.RecoverableTransactionIdentifier
- setXid(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
-
Deprecated.
- setXid(Xid) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
- ShardAllocationManagerImpl - Class in org.infinispan.query.affinity
- ShardAllocationManagerImpl() - Constructor for class org.infinispan.query.affinity.ShardAllocationManagerImpl
- ShardAllocatorManager - Interface in org.infinispan.query.affinity
-
ShardAllocatorManager is responsible for the mapping between index shards and Infinispan segments for all indexes in a cache.
- shared - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
Deprecated.
- shared() - Method in annotation type org.infinispan.commons.persistence.Store
-
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 - org.infinispan.configuration.parsing.Attribute
- SHARED - org.infinispan.persistence.manager.PersistenceManager.AccessMode
-
The operation is performed only in shared configured
CacheWriter
orCacheLoader
- SHARED - Static variable in class org.infinispan.configuration.cache.AbstractStoreConfiguration
- SHARED_PERSISTENT_LOCATION - org.infinispan.configuration.parsing.Element
- SHARED_PERSISTENT_LOCATION - Static variable 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.
- SHORT - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- shortened(String) - Static method in class org.infinispan.factories.KnownComponentNames
- shouldClose() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
- shouldConnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
- shouldDisconnect() - Method in interface org.infinispan.remoting.transport.jgroups.JGroupsChannelLookup
- 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
- shouldInvokeRemoteTxCommand(TxInvocationContext) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- shouldRevoke() - Method in interface org.infinispan.scattered.BiasManager.Revocation
- shouldWrite(long) - Method in class org.infinispan.persistence.remote.RemoteStore
- shouldWrite(long) - Method in interface org.infinispan.persistence.spi.FlagAffectedStore
- showInDoubtTransactions() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAdminOperations
- showUnrecognizedAttributes(Map<Object, Object>) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
- shutdown() - Method in interface org.infinispan.Cache
-
Performs a controlled, clustered shutdown of the cache.
- 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.distexec.DefaultExecutorService
-
Deprecated.
- 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.query.indexmanager.LocalOnlyBackend
- shutdown() - Method in interface org.infinispan.query.indexmanager.SwitchingBackend
- shutdown() - Method in class org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- shutdown() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
- SHUTDOWN - org.infinispan.configuration.parsing.Element
- SHUTDOWN_HOOK - org.infinispan.configuration.parsing.Attribute
- SHUTDOWN_PERFORM - org.infinispan.topology.CacheTopologyControlCommand.Type
- SHUTDOWN_REQUEST - org.infinispan.topology.CacheTopologyControlCommand.Type
- SHUTDOWN_TIMEOUT - org.infinispan.configuration.parsing.Attribute
-
Deprecated.
- shutdownCache() - Method in class org.infinispan.topology.ClusterCacheStatus
- ShutdownConfiguration - Class in org.infinispan.configuration.global
- ShutdownConfigurationBuilder - Class in org.infinispan.configuration.global
- ShutdownHookBehavior - Enum in org.infinispan.configuration.global
-
Behavior of the JVM shutdown hook registered by the cache
- shutdownNow() - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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.util.concurrent.BlockingTaskAwareExecutorServiceImpl
- shutdownNow() - Method in class org.infinispan.util.concurrent.WithinThreadExecutor
- shutdownTimeout() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
-
Deprecated.
- shutdownTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
-
Deprecated.
- shutdownTimeout(long) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
-
Deprecated.
- shutdownTimeout(long, TimeUnit) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
-
Deprecated.
- 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 - org.infinispan.configuration.cache.VersioningScheme
- SIMPLE_CACHE - 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_COLLECTION_KEY_FILTER - Static variable in interface org.infinispan.commons.marshall.Ids
- SIMPLE_CONNECTION - org.infinispan.persistence.jdbc.configuration.Element
- 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.ConfigurationBuilder
- simpleCache(boolean) - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- 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
- 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.configuration.AbstractJdbcStoreConfigurationBuilder
- simpleConnection() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationChildBuilder
- simpleConnection() - Method in interface org.infinispan.persistence.jdbc.configuration.JdbcStoreConfigurationChildBuilder
-
Configures this JDBC Cache Store to use a single connection to the database
- SimpleConnectionFactoryConfiguration - Class in org.infinispan.persistence.jdbc.configuration
-
SimpleConnectionFactoryConfiguration.
- SimpleConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> - Class in org.infinispan.persistence.jdbc.configuration
-
SimpleConnectionFactoryBuilder.
- SimpleConnectionFactoryConfigurationBuilder(AbstractJdbcStoreConfigurationBuilder<?, S>) - Constructor for class org.infinispan.persistence.jdbc.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.
- 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.
- 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
- SimpleUserPrincipal.Externalizer - Class in org.infinispan.server.core.security.simple
- since() - Method in annotation type org.infinispan.configuration.parsing.Namespace
-
The first version of the schema where this is supported.
- since(int, int) - Method in class org.infinispan.configuration.parsing.Schema
- singleChar() - Method in enum org.infinispan.scattered.ScatteredVersionManager.SegmentState
- SingleFileStore<K,V> - Class in org.infinispan.persistence.file
-
A filesystem-based implementation of a
AdvancedLoadWriteStore
. - 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, SingletonStoreConfiguration) - 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
- SingleKeyNonTxInvocationContext - Class in org.infinispan.context
-
Deprecated.Since 9.0, this class is going to be moved to an internal package.
- SingleKeyNonTxInvocationContext(Address) - Constructor for class org.infinispan.context.SingleKeyNonTxInvocationContext
-
Deprecated.
- 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.
- SingleSiteRequest<T> - Class in org.infinispan.remoting.transport.jgroups
-
Request implementation that waits for a response from a single target site.
- singleton() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
-
SingletonStore is a delegating cache store used for situations when only one instance in a cluster should interact with the underlying store.
- singleton() - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationChildBuilder
- singleton() - Method in interface org.infinispan.configuration.cache.StoreConfigurationChildBuilder
-
Deprecated.Singleton writers will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
- SINGLETON - org.infinispan.configuration.parsing.Attribute
-
Deprecated.
- SINGLETON_STORE - org.infinispan.configuration.parsing.Element
-
Deprecated.
- SingletonCacheWriter - Class in org.infinispan.persistence.support
-
Deprecated.this writer will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
- SingletonCacheWriter(CacheWriter, SingletonStoreConfiguration) - Constructor for class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.
- SingletonCacheWriter.PushStateException - Exception in org.infinispan.persistence.support
-
Deprecated.Exception representing any issues that arise from pushing the in-memory state to the cache loader.
- SingletonCacheWriter.SingletonStoreListener - Class in org.infinispan.persistence.support
-
Deprecated.Cache listener that reacts to cluster topology changes to find out whether a new coordinator is elected.
- SingletonExternalizer<T> - Class in org.infinispan.commons.marshall
- SingletonExternalizer(Integer, T) - Constructor for class org.infinispan.commons.marshall.SingletonExternalizer
- singletonStore - Variable in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- singletonStore() - Method in class org.infinispan.configuration.cache.AbstractStoreConfiguration
-
SingletonStore is a delegating store used for situations when only one instance in a cluster should interact with the underlying store.
- singletonStore() - Method in interface org.infinispan.configuration.cache.StoreConfiguration
-
Deprecated.Singleton writers will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
- SingletonStoreConfiguration - Class in org.infinispan.configuration.cache
-
Deprecated.Singleton writers will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
- SingletonStoreConfigurationBuilder<S> - Class in org.infinispan.configuration.cache
-
Deprecated.Singleton writers will be removed in 10.0. If it is desirable that all nodes don't write to the underlying store then a shared store should be used instead, as this only performs store writes at a key's primary owner.
- SingletonStoreListener() - Constructor for class org.infinispan.persistence.support.SingletonCacheWriter.SingletonStoreListener
-
Deprecated.
- singleWriteOnRemotePrimary(Address, DataWriteCommand) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- singleWriteOnRemotePrimary(Address, DataWriteCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
-
This method is called by a non-owner sending write request to the primary owner
- singleWriteResponse(InvocationContext, DataWriteCommand, Object) - Method in class org.infinispan.interceptors.distribution.BiasedScatteredDistributionInterceptor
- singleWriteResponse(InvocationContext, DataWriteCommand, Object) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
-
This method is called by primary owner responding to the originator after write has been completed
- SingleXSiteRpcCommand - Class in org.infinispan.xsite
-
RPC command to replicate cache operations (such as put, remove, replace, etc.) to the backup site.
- SingleXSiteRpcCommand() - Constructor for class org.infinispan.xsite.SingleXSiteRpcCommand
- SingleXSiteRpcCommand(ByteString) - Constructor for class org.infinispan.xsite.SingleXSiteRpcCommand
- SingleXSiteRpcCommand(ByteString, VisitableCommand) - Constructor for class org.infinispan.xsite.SingleXSiteRpcCommand
- 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.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 - org.infinispan.configuration.parsing.Attribute
- SITE - org.infinispan.configuration.parsing.Element
- SITE - org.infinispan.distribution.topologyaware.TopologyLevel
- SITE - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
- SITE_ID - Static variable in class org.infinispan.configuration.global.TransportConfiguration
- SITE_STATUS - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
- SiteConfiguration - Class in org.infinispan.configuration.global
- SiteConfigurationBuilder - Class in org.infinispan.configuration.global
- 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.
- SiteMasterPickerImpl - Class in org.infinispan.remoting.transport.jgroups
-
A
SiteMasterPicker
implementation that picks the first route. - SiteMasterPickerImpl() - Constructor for class org.infinispan.remoting.transport.jgroups.SiteMasterPickerImpl
- siteOffline() - Method in interface org.infinispan.xsite.notification.SiteStatusListener
- siteOnline() - Method in interface org.infinispan.xsite.notification.SiteStatusListener
- 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 - org.infinispan.configuration.parsing.Element
- 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
- siteStatus(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
- 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
- size - Variable in class org.infinispan.commons.util.ArrayMap
- 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.commons.equivalence.EquivalentHashMap.EntrySet
-
Deprecated.
- size() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- size() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap.Values
-
Deprecated.
- size() - Method in class org.infinispan.commons.equivalence.EquivalentHashSet
-
Deprecated.Returns the number of elements in this set.
- size() - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
-
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.concurrent.ConcurrentHashSet
- size() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Returns the number of key-value mappings in this map.
- 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.EvictionConfiguration
-
Deprecated.use
MemoryConfiguration.size()
instead - size() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
-
Size of the eviction, -1 if disabled
- size() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
The configured eviction size, please see
MemoryConfigurationBuilder.size(long)
. - size() - Method in interface org.infinispan.container.DataContainer
- size() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- 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 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.interceptors.InterceptorChain
-
Deprecated.Returns the number of interceptors in the chain.
- size() - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
-
Overriden only to avoid unneeded synchronization
- size() - Method in class org.infinispan.io.ExposedByteArrayOutputStream
-
Deprecated.Overriden only to avoid unneeded synchronization
- size() - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
- size() - Method in class org.infinispan.io.MarshalledValueByteStream
- size() - Method in class org.infinispan.io.ReadableGridFileChannel
- size() - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
- 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.persistence.async.AdvancedAsyncCacheLoader
- size() - Method in class org.infinispan.persistence.file.SingleFileStore
- size() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- size() - Method in class org.infinispan.persistence.jpa.JpaStore
- size() - Method in interface org.infinispan.persistence.manager.PersistenceManager
- size() - Method in class org.infinispan.persistence.remote.RemoteStore
- size() - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- size() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader
-
Returns the number of elements in the store.
- size() - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- size() - Method in class org.infinispan.util.CollectionMapper
- size() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- size() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- size(long) - Method in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- size(long) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.Defines the maximum size before eviction occurs.
- size(long) - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- size(long) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
Defines the maximum size before eviction occurs.
- size(Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Returns the count of how many entries are persisted.
- size(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- size(Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- size(IntSet) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- size(IntSet) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Returns the count of how many entries are persisted within the given segments.
- size(IntSet) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- size(IntSet) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- size(IntSet) - Method in class org.infinispan.persistence.remote.RemoteStore
- size(IntSet) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
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 - org.infinispan.configuration.parsing.Attribute
- SIZE - org.infinispan.server.hotrod.HotRodOperation
- SIZE - Static variable in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- SIZE - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
- SIZE_MULTIMAP - 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
- 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
- sizeIncludingExpired() - Method in interface org.infinispan.container.DataContainer
- sizeIncludingExpired() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- sizeUnsignedInt(int) - Static method in class org.infinispan.commons.io.UnsignedNumeric
- 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
- skip(long) - Method in class org.infinispan.io.UnclosableObjectInputStream
- skip(long) - Method in interface org.infinispan.LongCacheStream
- skip(long) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- SKIP - org.infinispan.functional.Param.LockingMode
- SKIP - org.infinispan.functional.Param.PersistenceMode
- SKIP - org.infinispan.functional.Param.StatisticsMode
-
Statistics from this command are not recorded
- SKIP_CACHE_LOAD - org.infinispan.context.Flag
-
Skips loading an entry from any configured
CacheLoader
s. - SKIP_CACHE_STATUS_CHECK - org.infinispan.context.Flag
-
Deprecated.This flag is no longer in use.
- SKIP_CACHE_STORE - org.infinispan.context.Flag
-
Skips storing an entry to any configured
CacheLoader
s. - SKIP_INDEX_CLEANUP - 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_INDEXING - 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_LISTENER_NOTIFICATION - org.infinispan.context.Flag
-
This flag skips listener notifications as a result of a cache operation.
- SKIP_LOAD - org.infinispan.functional.Param.PersistenceMode
- SKIP_LOCKING - org.infinispan.context.Flag
-
Bypasses lock acquisition for this invocation altogether.
- SKIP_LOOKUP - org.infinispan.container.entries.ReadCommittedEntry.Flags
- SKIP_OWNERSHIP_CHECK - 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_PERSIST - org.infinispan.functional.Param.PersistenceMode
- SKIP_REMOTE_LOOKUP - 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_SHARED_CACHE_STORE - org.infinispan.context.Flag
-
If this flag is enabled, if a cache store is shared, then storage to the store is skipped.
- SKIP_SIZE_OPTIMIZATION - org.infinispan.context.Flag
-
Flag that can be used to skip any size optimizations - forcing iteration of entries to count.
- SKIP_STATISTICS - org.infinispan.context.Flag
-
This flag skips statistics updates as a result of a cache operation.
- SKIP_XSITE_BACKUP - org.infinispan.context.Flag
-
If cross-site replication is enabled, this would skip the replication to any remote site.
- skipBytes(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectInput
- skipBytes(int) - Method in class org.infinispan.io.UnclosableObjectInputStream
- SkipCacheLoader - org.infinispan.server.hotrod.ProtocolFlag
- SkipIndexing - org.infinispan.server.hotrod.ProtocolFlag
- skipL1Lookup(FlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- skipL1Lookup(FlagAffectedCommand, Object) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
- SkipListenerNotification - 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.PassivationManager
-
Skips the passivation when the cache is stopped.
- skipReplicationQueue() - Method in class org.infinispan.remoting.rpc.RpcOptions
-
Deprecated.Since 9.0, always returns
false
. - skipReplicationQueue(boolean) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
-
Deprecated.Since 9.0, it no longer does anything.
- skipXSiteBackup(FlagAffectedCommand) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- SmallIntSet - Class in org.infinispan.commons.util
-
Deprecated.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.
- SNAPPY - org.infinispan.persistence.leveldb.configuration.CompressionType
- SNI_HOSTNAME - org.infinispan.persistence.remote.configuration.Attribute
- sniDomainsConfiguration() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- sniHostName() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- 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
- SOCKET_TIMEOUT - org.infinispan.persistence.remote.configuration.Attribute
- SOCKET_TIMEOUT - org.infinispan.persistence.rest.configuration.Attribute
- SOCKET_TIMEOUT - Static variable in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- socketTimeout() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- socketTimeout() - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- socketTimeout(int) - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfigurationBuilder
- 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.
- sort(Sort) - Method in interface org.infinispan.query.CacheQuery
-
Allows lucene to sort the results.
- 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.util.AbstractDelegatingCacheStream
- sorted(Comparator<? super R>) - Method in interface org.infinispan.CacheStream
- 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
-
Enumeration of the available sort directions.
- SP - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- SPIN_DURATION - org.infinispan.configuration.parsing.Attribute
-
Deprecated.
- SPIN_DURATION - Static variable in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
-
Deprecated.
- spinDuration() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
-
Deprecated.Since 9.0, always returns
-1
. - spinDuration(long) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.Since 9.0, deadlock detection is always disabled.
- spinDuration(long, TimeUnit) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.Since 9.0, deadlock detection is always disabled.
- split(CacheTopologyInfo) - Method in interface org.infinispan.persistence.remote.upgrade.DataPartitioner
-
Same as
DataPartitioner.split(CacheTopologyInfo, int)
but will create a single partition per server - split(CacheTopologyInfo, int) - Method in interface org.infinispan.persistence.remote.upgrade.DataPartitioner
- spliterator - Variable in class org.infinispan.commons.util.SpliteratorMapper
- 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.offheap.OffHeapDataContainer
- spliterator() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
- spliterator() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
- spliterator() - Method in interface org.infinispan.LockedStream
-
This method is not supported when using a
LockedStream
- spliterator() - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- spliterator() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorCollection
- spliterator() - Method in class org.infinispan.util.AbstractDelegatingCloseableIteratorSet
- spliterator() - Method in class org.infinispan.util.CacheCollectionMapper
-
Deprecated.
- 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.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.offheap.OffHeapDataContainer
- 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
- SpringCache - Class in org.infinispan.spring.provider
-
A
implementation that delegates to aCache
instance supplied at construction time.org.infinispan.Cache
- SpringCache(BasicCache) - Constructor for class org.infinispan.spring.provider.SpringCache
- SpringCache(BasicCache, long, long) - Constructor for class org.infinispan.spring.provider.SpringCache
- SpringEmbeddedCacheManager - Class in org.infinispan.spring.provider
-
A
implementation that is backed by anCacheManager
instance.Infinispan EmbeddedCacheManager
- SpringEmbeddedCacheManager(EmbeddedCacheManager) - Constructor for class org.infinispan.spring.provider.SpringEmbeddedCacheManager
- SpringEmbeddedCacheManagerFactoryBean - Class in org.infinispan.spring.provider
-
A
for creating anFactoryBean
instance.SpringEmbeddedCacheManager
- SpringEmbeddedCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.provider.SpringEmbeddedCacheManagerFactoryBean
- springEventsPublisher - Variable in class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- SpringRemoteCacheManager - Class in org.infinispan.spring.provider
-
A
implementation that is backed by anCacheManager
instance.Infinispan RemoteCacheManager
- SpringRemoteCacheManager(RemoteCacheManager) - Constructor for class org.infinispan.spring.provider.SpringRemoteCacheManager
- SpringRemoteCacheManager(RemoteCacheManager, long, long) - Constructor for class org.infinispan.spring.provider.SpringRemoteCacheManager
- SpringRemoteCacheManagerFactoryBean - Class in org.infinispan.spring.provider
-
A
for creating anFactoryBean
instance.SpringRemoteCacheManager
- SpringRemoteCacheManagerFactoryBean() - Constructor for class org.infinispan.spring.provider.SpringRemoteCacheManagerFactoryBean
- SQL_SERVER - org.infinispan.persistence.jdbc.DatabaseType
- SQLITE - org.infinispan.persistence.jdbc.DatabaseType
- 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.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
- SslConfiguration - Class in org.infinispan.persistence.remote.configuration
-
SslConfiguration.
- SslConfiguration - Class in org.infinispan.server.core.configuration
-
SslConfiguration.
- 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.persistence.remote.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.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(SSLContext) - Method in class org.infinispan.persistence.remote.configuration.SslConfigurationBuilder
- 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.
- SslUtils - Class in org.infinispan.server.core.utils
-
SSL utils mainly for Netty.
- SslUtils() - Constructor for class org.infinispan.server.core.utils.SslUtils
- STABLE_TOPOLOGY_UPDATE - org.infinispan.topology.CacheTopologyControlCommand.Type
- STACK - org.infinispan.configuration.parsing.Attribute
- STACK_FILE - org.infinispan.configuration.parsing.Element
- StaggeredRequest<T> - Class in org.infinispan.remoting.transport.jgroups
- 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 interface org.infinispan.commons.api.Lifecycle
-
Invoked on component start
- start() - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- start() - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
- start() - Method in class org.infinispan.container.offheap.BoundedOffHeapDataContainer
- start() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- 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.NumericVersionGenerator
- start() - Method in class org.infinispan.container.versioning.SimpleClusteredVersionGenerator
- start() - Method in class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- 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.interceptors.base.BaseCustomInterceptor
-
Deprecated.
- start() - Method in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
- start() - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- start() - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- start() - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- start() - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- start() - Method in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- start() - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
- start() - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
- start() - Method in class org.infinispan.jmx.CacheJmxRegistration
-
Here is where the registration is being performed.
- start() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
-
On start, the mbeans are registered.
- start() - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
- start() - Method in class org.infinispan.manager.DefaultCacheManager
- start() - Method in class org.infinispan.marshall.core.GlobalMarshaller
- start() - Method in class org.infinispan.marshall.core.JBossMarshaller
- start() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- start() - Method in interface org.infinispan.notifications.cachelistener.filter.FilterIndexingServiceProvider
-
Start the provider.
- start() - Method in class org.infinispan.persistence.async.AsyncCacheLoader
- start() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- start() - Method in class org.infinispan.persistence.cluster.ClusterLoader
- start() - Method in class org.infinispan.persistence.file.SingleFileStore
- start() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- start() - Method in class org.infinispan.persistence.jpa.JpaStore
- start() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- start() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- start() - Method in class org.infinispan.persistence.manager.PreloadManager
- start() - Method in class org.infinispan.persistence.remote.RemoteStore
- start() - Method in class org.infinispan.persistence.rest.RestStore
-
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.SingletonCacheWriter
-
Deprecated.
- start() - Method in interface org.infinispan.query.MassIndexer
- start() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- start() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderPerCacheInboundInvocationHandler
- start() - Method in class org.infinispan.remoting.inboundhandler.NonTotalOrderTxPerCacheInboundInvocationHandler
- start() - Method in class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- start() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- 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.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.provider.SpringRemoteCacheManager
-
Start the
that backs thisorg.infinispan.client.hotrod.RemoteCacheManager
SpringRemoteCacheManager
. - start() - Method in class org.infinispan.statetransfer.StateConsumerImpl
- start() - Method in interface org.infinispan.statetransfer.StateProvider
- start() - Method in class org.infinispan.statetransfer.StateProviderImpl
- start() - Method in interface org.infinispan.statetransfer.StateTransferManager
- start() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- start() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- start() - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- start() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- start() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- 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.BackupReceiverRepositoryImpl
- start() - Method in class org.infinispan.xsite.BackupSenderImpl
- start(A, 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 and with the corresponding configuration.
- start(Xid, int) - Method in class org.infinispan.transaction.xa.TransactionXaAdapter
- start(Cache, BitSet, String, List<byte[]>, MediaType, int, boolean) - Method in class org.infinispan.server.hotrod.iteration.DefaultIterationManager
- start(Cache, BitSet, String, List<byte[]>, MediaType, int, boolean) - Method in interface org.infinispan.server.hotrod.iteration.IterationManager
- start(ConnectionFactoryConfiguration, ClassLoader) - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
-
Starts the connection factory.
- 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 - org.infinispan.configuration.parsing.Attribute
- START_CONSISTENCY_CHECK - org.infinispan.statetransfer.StateRequestCommand.Type
- START_KEYS_TRANSFER - org.infinispan.statetransfer.StateRequestCommand.Type
- START_RECEIVE - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
- START_SEND - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
- START_STATE_TRANSFER - org.infinispan.statetransfer.StateRequestCommand.Type
- START_TRANSPORT - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- startAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
- startAsync() - Method in interface org.infinispan.query.MassIndexer
- startAtomic() - Method in class org.infinispan.batch.AutoBatchSupport
- startAutomatically - Variable in class org.infinispan.spring.AbstractRemoteCacheManagerFactory
- startBatch() - Method in class org.infinispan.batch.BatchContainer
-
Starts a batch
- startBatch() - Method in interface org.infinispan.commons.api.BatchingCache
-
Starts a batch.
- 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(String...) - Method in class org.infinispan.manager.DefaultCacheManager
- startCaches(String...) - Method in interface org.infinispan.manager.EmbeddedCacheManager
-
Starts a set of caches in parallel.
- startDefaultCache() - Method in class org.infinispan.server.core.AbstractProtocolServer
- startDefaultCache() - Method in class org.infinispan.server.hotrod.HotRodServer
- startDefaultExternalMarshaller(GlobalConfiguration) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- startDelegate() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- startingUp() - Method in enum org.infinispan.lifecycle.ComponentStatus
- startInternal(A, EmbeddedCacheManager) - Method in class org.infinispan.server.core.AbstractProtocolServer
- startInternal(RestServerConfiguration, EmbeddedCacheManager) - Method in class org.infinispan.rest.RestServer
- startInternal(HotRodServerConfiguration, EmbeddedCacheManager) - Method in class org.infinispan.server.hotrod.HotRodServer
- startInternal(MemcachedServerConfiguration, EmbeddedCacheManager) - Method in class org.infinispan.server.memcached.MemcachedServer
- startKeysTransfer(IntSet, Address) - Method in interface org.infinispan.scattered.ScatteredStateProvider
- 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 class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- startObjectInput(InputStream, boolean) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- startObjectInput(InputStream, boolean) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Create and open a new ObjectInput for the given input stream.
- startObjectInput(InputStream, boolean) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- startObjectOutput(OutputStream, boolean, int) - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Create and open an ObjectOutput instance for the given output stream.
- startObjectOutput(OutputStream, boolean, int) - Method in class org.infinispan.marshall.core.GlobalMarshaller
- startOffset(long) - Method in interface org.infinispan.query.dsl.PaginationContext
- startOutboundTransfer(Address, int, IntSet, boolean) - Method in interface org.infinispan.statetransfer.StateProvider
-
Start to send cache entries that belong to the given set of segments.
- startOutboundTransfer(Address, int, IntSet, boolean) - Method in class org.infinispan.statetransfer.StateProviderImpl
- 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.
- 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 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
- startTrack(Flag) - Method in class org.infinispan.statetransfer.CommitManager
-
It starts tracking keys committed.
- 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.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.
- startXidMapping() - Method in class org.infinispan.transaction.xa.XaTransactionTable
- state - Variable in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- state - Variable in class org.infinispan.persistence.async.AsyncCacheLoader
- state - Variable in class org.infinispan.persistence.async.AsyncCacheWriter
- State - Class in org.infinispan.persistence.async
- State(boolean, ConcurrentMap<Object, Modification>, State) - Constructor for class org.infinispan.persistence.async.State
- STATE_CHUNK - Static variable in interface org.infinispan.commons.marshall.Ids
- STATE_TRANSFER - org.infinispan.configuration.parsing.Element
- STATE_TRANSFER_EXECUTOR - org.infinispan.configuration.parsing.Attribute
- STATE_TRANSFER_EXECUTOR - Static variable in class org.infinispan.factories.KnownComponentNames
- STATE_TRANSFER_FLAGS - Static variable in class org.infinispan.statetransfer.StateConsumerImpl
- StateChangingEntry - Interface in org.infinispan.container.entries
-
Deprecated.since 9.0
- StateChunk - Class in org.infinispan.statetransfer
-
Encapsulates a chunk of cache entries that belong to the same segment.
- StateChunk(int, Collection<InternalCacheEntry>, boolean) - Constructor for class org.infinispan.statetransfer.StateChunk
- StateChunk.Externalizer - Class in org.infinispan.statetransfer
- StateConsumer - Interface in org.infinispan.statetransfer
-
Handles inbound state transfers.
- StateConsumerImpl - Class in org.infinispan.statetransfer
-
StateConsumer
implementation. - StateConsumerImpl() - Constructor for class org.infinispan.statetransfer.StateConsumerImpl
- StateConsumerImpl.KeyInvalidationListener - Interface in org.infinispan.statetransfer
- stateLock - Variable in class org.infinispan.persistence.async.AsyncCacheWriter
- StateProvider - Interface in org.infinispan.statetransfer
-
Handles outbound state transfers.
- StateProviderImpl - Class in org.infinispan.statetransfer
-
StateProvider
implementation. - StateProviderImpl() - Constructor for class org.infinispan.statetransfer.StateProviderImpl
- StateRequestCommand - Class in org.infinispan.statetransfer
-
This command is used by a StateConsumer to request transactions and cache entries from a StateProvider.
- StateRequestCommand(ByteString) - Constructor for class org.infinispan.statetransfer.StateRequestCommand
- StateRequestCommand(ByteString, StateRequestCommand.Type, Address, int, IntSet) - Constructor for class org.infinispan.statetransfer.StateRequestCommand
- StateRequestCommand.Type - Enum in org.infinispan.statetransfer
- stateRequestExecutor - Variable in class org.infinispan.statetransfer.StateConsumerImpl
-
Push RPCs on a background thread
- StateResponseCommand - Class in org.infinispan.statetransfer
-
This command is used by a StateProvider to push cache entries to a StateConsumer.
- StateResponseCommand(ByteString) - Constructor for class org.infinispan.statetransfer.StateResponseCommand
- StateResponseCommand(ByteString, Address, int, Collection<StateChunk>, boolean, boolean) - Constructor for class org.infinispan.statetransfer.StateResponseCommand
- 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
- 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 - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- stateTransferFuture - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- StateTransferInterceptor - Class in org.infinispan.statetransfer
-
This interceptor has two tasks: If the command's topology id is higher than the current topology id, wait for the node to receive transaction data for the new topology id. If the topology id changed during a command's execution, retry the command, but only on the originator (which replicates it to the new owners). If the cache is configured with asynchronous replication, owners cannot signal to the originator that they saw a new topology, so instead each owner forwards the command to all the other owners in the new topology.
- StateTransferInterceptor() - Constructor for class org.infinispan.statetransfer.StateTransferInterceptor
- stateTransferLock - Variable in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- stateTransferLock - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- stateTransferLock - Variable in class org.infinispan.statetransfer.StateProviderImpl
- StateTransferLock - Interface in org.infinispan.statetransfer
-
We use the state transfer lock for three different things: We don't want to execute a command until we have the transaction table for that topology id.
- StateTransferLockImpl - Class in org.infinispan.statetransfer
-
StateTransferLock
implementation. - StateTransferLockImpl() - Constructor for class org.infinispan.statetransfer.StateTransferLockImpl
- StateTransferManager - Interface in org.infinispan.statetransfer
-
A component that manages the state transfer when the topology of the cluster changes.
- StateTransferManagerImpl - Class in org.infinispan.statetransfer
-
StateTransferManager
implementation. - StateTransferManagerImpl() - Constructor for class org.infinispan.statetransfer.StateTransferManagerImpl
- stateTransferThreadPool() - Method in class org.infinispan.configuration.global.GlobalConfiguration
- 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
- stateTransferTopologyId - Variable in class org.infinispan.statetransfer.StateConsumerImpl
-
Indicates if there is a state transfer in progress.
- StaticContent - Class in org.infinispan.rest.operations
-
Class responsible for serving static content
- STATISTICS - org.infinispan.configuration.parsing.Attribute
- STATISTICS_AVAILABLE - org.infinispan.configuration.parsing.Attribute
- StatisticsSnapshot - Class in org.infinispan.stats.container
-
A Statistic Snapshot;
- StatisticsSnapshot(double[]) - Constructor for class org.infinispan.stats.container.StatisticsSnapshot
- stats - Variable in class org.infinispan.stats.container.BaseExtendedStatisticsContainer
- Stats - Interface in org.infinispan.stats
-
Stats.
- STATS - 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
- 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
- StatsRequest - org.infinispan.server.memcached.MemcachedOperation
- statsResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Stats, NettyTransport, ComponentRegistry) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- statsResponse(HotRodHeader, HotRodServer, ByteBufAllocator, Stats, NettyTransport, ComponentRegistry) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- status() - Method in interface org.infinispan.xsite.BackupSender
-
Returns a Map having as entries the site names and as value Boolean.TRUE if the site is online and Boolean.FALSE if it is offline.
- status() - Method in class org.infinispan.xsite.BackupSenderImpl
- status() - Method in class org.infinispan.xsite.XSiteAdminOperations
- status(HttpResponseStatus) - Method in class org.infinispan.rest.InfinispanResponse
-
Adds status code.
- Status - Enum in org.infinispan.server.hotrod.tx.table
-
Internal server status for the client's transactions.
- STATUS - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
- 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_REQUEST - org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
- STATUS_SENDING - Static variable in interface org.infinispan.xsite.statetransfer.XSiteStateTransferManager
- stop() - Method in interface org.infinispan.Cache
-
Stops a cache.
- stop() - Method in interface org.infinispan.commons.api.Lifecycle
-
Invoked on component stop
- stop() - Method in class org.infinispan.commons.marshall.AbstractDelegatingMarshaller
- stop() - Method in class org.infinispan.commons.marshall.jboss.AbstractJBossMarshaller
- stop() - Method in interface org.infinispan.commons.marshall.StreamingMarshaller
-
Stop the marshaller.
- stop() - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- stop() - Method in class org.infinispan.container.offheap.OffHeapDataContainer
- stop() - Method in class org.infinispan.container.offheap.SegmentedBoundedOffHeapDataContainer
- 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 class org.infinispan.interceptors.base.BaseCustomInterceptor
-
Deprecated.
- stop() - Method in class org.infinispan.interceptors.BaseCustomAsyncInterceptor
- stop() - Method in class org.infinispan.jmx.CacheJmxRegistration
-
Unregister when the cache is being stopped.
- stop() - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
-
On stop, the mbeans are unregistered.
- stop() - Method in class org.infinispan.lucene.cacheloader.LuceneCacheLoader
- stop() - Method in class org.infinispan.manager.DefaultCacheManager
- stop() - Method in class org.infinispan.marshall.core.GlobalMarshaller
- stop() - Method in class org.infinispan.marshall.core.JBossMarshaller
- 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.persistence.async.AsyncCacheLoader
- stop() - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- stop() - Method in class org.infinispan.persistence.cluster.ClusterLoader
- stop() - Method in class org.infinispan.persistence.file.SingleFileStore
- stop() - Method in class org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory
-
Closes the connection factory, including all allocated connections etc.
- stop() - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- stop() - Method in class org.infinispan.persistence.jpa.JpaStore
- stop() - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- stop() - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- stop() - Method in class org.infinispan.persistence.remote.RemoteStore
- stop() - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- stop() - Method in interface org.infinispan.persistence.spi.AdvancedCacheLoader.TaskContext
-
Deprecated.Invoked from within the CacheLoaderTask, in order to signal the AdvancedCacheLoader implementation that iteration should be stopped early (before iteration is finished).
- 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.SingletonCacheWriter
-
Deprecated.
- stop() - Method in class org.infinispan.persistence.TaskContextImpl
- stop() - Method in class org.infinispan.remoting.inboundhandler.BasePerCacheInboundInvocationHandler
- stop() - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- 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.cachemanager.RestCacheManager
- stop() - Method in class org.infinispan.rest.RestServer
- 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.provider.SpringEmbeddedCacheManager
-
Stop the
thisEmbeddedCacheManager
CacheManager
delegates to. - stop() - Method in class org.infinispan.spring.provider.SpringRemoteCacheManager
-
Stop the
that backs thisorg.infinispan.client.hotrod.RemoteCacheManager
SpringRemoteCacheManager
. - stop() - Method in interface org.infinispan.statetransfer.StateConsumer
-
Cancels all incoming state transfers.
- stop() - Method in class org.infinispan.statetransfer.StateConsumerImpl
- stop() - Method in interface org.infinispan.statetransfer.StateProvider
-
Cancels all outbound state transfers.
- stop() - Method in class org.infinispan.statetransfer.StateProviderImpl
- stop() - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- stop() - Method in interface org.infinispan.statetransfer.StateTransferManager
- stop() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- stop() - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- stop() - Method in class org.infinispan.topology.ClusterTopologyManagerImpl
- stop() - Method in class org.infinispan.topology.LocalTopologyManagerImpl
- stop() - Method in class org.infinispan.xsite.BackupReceiverRepositoryImpl
- 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 - org.infinispan.configuration.parsing.Attribute
- stopAllowed() - Method in enum org.infinispan.lifecycle.ComponentStatus
- stopApplyingState(int) - Method in interface org.infinispan.statetransfer.StateConsumer
-
Stops applying incoming state.
- stopApplyingState(int) - Method in class org.infinispan.statetransfer.StateConsumerImpl
-
Stops applying incoming state.
- stopDefaultExternalMarshaller() - Method in class org.infinispan.marshall.core.GlobalMarshaller
- stopDelegate() - Method in class org.infinispan.util.AbstractControlledLocalTopologyManager
- STOPPING - org.infinispan.lifecycle.ComponentStatus
-
The
stop()
method has been called but has not yet completed. - STOPPING - org.infinispan.topology.ClusterTopologyManager.ClusterManagerStatus
- stopTrack(Flag) - Method in class org.infinispan.statetransfer.CommitManager
-
It stops tracking keys committed.
- stopTransport() - Method in class org.infinispan.server.core.AbstractProtocolServer
- storage() - Method in class org.infinispan.counter.api.CounterConfiguration
- storage() - Method in class org.infinispan.counter.configuration.AbstractCounterConfiguration
- storage(Storage) - Method in class org.infinispan.counter.api.CounterConfiguration.Builder
-
Sets the storage mode of the counter.
- 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 - org.infinispan.counter.configuration.Attribute
- STORAGE_TYPE - Static variable in class org.infinispan.configuration.cache.MemoryConfiguration
- storageType() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
-
Storage type to use for the data container
- storageType() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
The underlying storage type for this configuration
- storageType(StorageType) - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
-
Set the
StorageType
to determine how the data is stored in the data container. - 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(org.infinispan.marshall.core.MarshalledEntry)
. - Store - Annotation Type in org.infinispan.commons.persistence
-
Store.
- Store(Object, MarshalledEntry) - Constructor for class org.infinispan.persistence.modifications.Store
- STORE - org.infinispan.configuration.parsing.Element
- STORE - org.infinispan.persistence.modifications.Modification.Type
- STORE_AS_BINARY - org.infinispan.configuration.parsing.Element
- STORE_KEYS_AS_BINARY - org.infinispan.configuration.parsing.Attribute
- STORE_KEYS_AS_BINARY - Static variable in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.
- STORE_METADATA - org.infinispan.persistence.jpa.configuration.Attribute
- STORE_VALUES_AS_BINARY - org.infinispan.configuration.parsing.Attribute
- STORE_VALUES_AS_BINARY - Static variable in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.
- storeAsBinary() - Method in class org.infinispan.configuration.cache.Configuration
-
Deprecated.please use
Configuration.memory()
- storeAsBinary() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
-
Deprecated.
- storeAsBinary() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- StoreAsBinaryConfiguration - Class in org.infinispan.configuration.cache
-
Deprecated.Use
MemoryConfiguration
instead - StoreAsBinaryConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Deprecated.Please use
MemoryConfigurationBuilder.storageType(StorageType)
method instead - 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
- storeKeysAsBinary() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.when store as binary is enabled, keys are always stored as binary
- storeKeysAsBinary(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
-
Deprecated.No longer supported, keys and values are both enabled if store as binary is
- storeMetadata() - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfiguration
- storeMetadata(boolean) - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationBuilder
- stores() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- stores() - Method in class org.infinispan.configuration.cache.PersistenceConfigurationBuilder
- 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
- storeValuesAsBinary() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.when store as binary is enabled, values are always stored as binary
- storeValuesAsBinary(boolean) - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
-
Deprecated.No longer supported, keys and values are both enabled if store as binary is
- 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() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.use
MemoryConfiguration.evictionType()
instead - strategy(BackupConfiguration.BackupStrategy) - Method in class org.infinispan.configuration.cache.BackupConfigurationBuilder
-
Sets the strategy used for backing up data: sync or async.
- strategy(EvictionStrategy) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.Eviction strategy.
- STRATEGY - org.infinispan.configuration.parsing.Attribute
- STRATEGY - Static variable in class org.infinispan.configuration.cache.BackupConfiguration
- STRATEGY - Static variable in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- 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.interceptors.distribution.DistributionBulkInterceptor.BackingEntrySet
- stream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.BackingKeySet
- stream() - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor.TxBackingEntrySet
- stream() - Method in class org.infinispan.util.AbstractDelegatingCacheCollection
- stream() - Method in class org.infinispan.util.CacheCollectionMapper
-
Deprecated.
- 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
- StreamingMarshaller - Interface in org.infinispan.commons.marshall
-
A specialization of
Marshaller
that supports streams. - StreamManagerFactory - Class in org.infinispan.factories
-
Factory that allows creation of a
LocalStreamManager
orClusterStreamManager
based on the provided configuration. - StreamManagerFactory() - Constructor for class org.infinispan.factories.StreamManagerFactory
- 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
-
A collection of stream related utility methods.
- Streams() - Constructor for class org.infinispan.util.stream.Streams
- StreamSummaryContainer - Class in org.infinispan.stats.topK
-
This contains all the stream lib top keys.
- StreamSummaryContainer(String, String) - Constructor for class org.infinispan.stats.topK.StreamSummaryContainer
- StreamSummaryContainer.Stat - Enum in org.infinispan.stats.topK
- strictPeerToPeer() - Method in class org.infinispan.configuration.global.TransportConfiguration
-
Deprecated.Since 6.0, strictPeerToPeer is ignored and asymmetric clusters are always allowed.
- strictPeerToPeer(Boolean) - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
-
Deprecated.Since 6.0, strictPeerToPeer is ignored and asymmetric clusters are always allowed.
- string(ByteBuf) - Static method in class org.infinispan.server.hotrod.Intrinsics
- STRING - Static variable in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- STRING_KEYED_JDBC_STORE - org.infinispan.persistence.jdbc.configuration.Element
- STRING_KEYED_TABLE - org.infinispan.persistence.jdbc.configuration.Element
- stringArray(int) - Static method in class org.infinispan.commons.util.Util
- 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
- stringToElement(String) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
-
Converts a String representing an XML snippet into an
Element
. - 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 read write locks that provides ability to retrieve them by offset and hashCode Note that locks protect entries
- StripedLock - Class in org.infinispan.util.concurrent.locks
-
A simple implementation of lock striping, using cache entry keys to lock on, primarily used to help make
CacheLoader
implemtations thread safe. - StripedLock() - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
-
This constructor just calls
StripedLock(int)
with a default concurrency value of 20. - StripedLock(int) - Constructor for class org.infinispan.util.concurrent.locks.StripedLock
-
Creates a new StripedLock which uses a certain number of shared locks across all elements that need to be locked.
- StripedLock(int, OffsetCalculator) - Constructor for class org.infinispan.container.offheap.StripedLock
- stripeForCurrentThread() - Method in class org.infinispan.commons.util.concurrent.StripedCounters
- STRIPING - org.infinispan.configuration.parsing.Attribute
- STRONG_COUNTER - org.infinispan.counter.configuration.Element
- 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. - subject(Subject) - Method in class org.infinispan.tasks.TaskContext
-
The subject to impersonate when running this task.
- 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, Void) - Method in class org.infinispan.executors.ExecutorAllCompletionService
- submit(Runnable, T) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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, V) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
-
{@inheritDoc CompletionService}
- submit(Callable<Void>) - Method in class org.infinispan.executors.ExecutorAllCompletionService
- submit(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- 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>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- submit(Callable<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
-
Deprecated.Submits the given Callable task for execution on a single Infinispan node.
- submit(Callable<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
-
{@inheritDoc CompletionService}
- submit(Callable<V>, K...) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
- submit(DistributedTask<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- submit(DistributedTask<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
-
Deprecated.Submits the given DistributedTask for execution on a single Infinispan node.
- submit(Address, Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- submit(Address, Callable<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
-
Deprecated.Submits the given Callable task for execution on the specified target Infinispan node.
- submit(Address, Callable<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
- submit(Address, DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- submit(Address, DistributedTask<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
-
Deprecated.Submits the given DistributedTask for execution on the specified target Infinispan node.
- 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. - submitEverywhere(Callable<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- submitEverywhere(Callable<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
-
Deprecated.Submits the given Callable task for execution on all available Infinispan nodes.
- submitEverywhere(Callable<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- submitEverywhere(Callable<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
-
Deprecated.Submits the given Callable task for execution on all available Infinispan nodes using input keys specified by K input.
- submitEverywhere(Callable<V>) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
- submitEverywhere(Callable<V>, K...) - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
- submitEverywhere(DistributedTask<T>) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- submitEverywhere(DistributedTask<T>) - Method in interface org.infinispan.distexec.DistributedExecutorService
-
Deprecated.Submits the given DistributedTask for execution on all available Infinispan nodes.
- submitEverywhere(DistributedTask<T>, K...) - Method in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- submitEverywhere(DistributedTask<T>, K...) - Method in interface org.infinispan.distexec.DistributedExecutorService
-
Deprecated.Submits the given DistributedTask for execution on all available Infinispan nodes using input keys specified by K input.
- subscribe(Subscriber<? super T>, PrimitiveIterator.OfInt, IntFunction<T>) - Static method in class org.infinispan.util.rxjava.FlowableFromIntSetFunction
- subscribeActual(Subscriber<? super T>) - Method in class org.infinispan.util.rxjava.FlowableFromIntSetFunction
- Success - org.infinispan.server.hotrod.OperationStatus
- SUCCESS - Static variable in class org.infinispan.xsite.XSiteAdminOperations
- 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 - org.infinispan.stats.container.ExtendedStatistic
- SuccessfulResponse - Class in org.infinispan.remoting.responses
-
A successful response
- SuccessfulResponse(Object) - Constructor for class org.infinispan.remoting.responses.SuccessfulResponse
- SuccessfulResponse.Externalizer - Class in org.infinispan.remoting.responses
- SuccessObjStorage - org.infinispan.server.hotrod.OperationStatus
- successResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[]) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- successResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[]) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- SuccessWithPrevious - org.infinispan.server.hotrod.OperationStatus
- SuccessWithPreviousObjStorage - org.infinispan.server.hotrod.OperationStatus
- sum(String) - Static method in interface org.infinispan.query.dsl.Expression
- SUMMARY - org.infinispan.jmx.annotations.DisplayType
- SuppliedExternalizer<T> - Class in org.infinispan.commons.marshall
- SuppliedExternalizer(Integer, Class<T>, Supplier<T>) - Constructor for class org.infinispan.commons.marshall.SuppliedExternalizer
- supplier() - Method in class org.infinispan.commons.util.ArrayCollector
- supplierBuilder(String, Class<T>) - Static method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- supportedTypes - Variable in class org.infinispan.commons.dataconversion.OneToManyTranscoder
- supports(MediaType) - Method in interface org.infinispan.commons.dataconversion.Transcoder
- supportsConcurrentUpdates() - Method in class org.infinispan.configuration.cache.LockingConfiguration
-
Deprecated.this option is always
true
and cannot be modified since version 5.3 - supportsConcurrentUpdates(boolean) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
-
Deprecated.
- 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
- 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.
- supportsExtendedHeaders(RestServerConfiguration, String) - Static method in class org.infinispan.rest.operations.CacheOperationsHelper
- 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
- suspend() - Method in class org.infinispan.transaction.tm.DummyBaseTransactionManager
-
Deprecated.Suspend the association the calling thread has to a transaction, and return the suspended transaction.
- SUSPENDED - org.infinispan.topology.RebalancingStatus
- suspendEncoding() - Method in class org.infinispan.commons.util.Base64.OutputStream
-
Deprecated.Suspends encoding of the stream.
- suspendIfNeeded() - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl
- suspendIfNeeded() - Method in class org.infinispan.notifications.cachemanagerlistener.CacheManagerNotifierImpl
- svm - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- SwitchingBackend - Interface in org.infinispan.query.indexmanager
-
Defines the strategy contract to be plugging into an InfinispanBackendQueueProcessor
- SYBASE - org.infinispan.persistence.jdbc.DatabaseType
- sync - Variable in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.BaseCacheEntryListenerInvocation
- sync - Variable in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- sync() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
-
Deprecated.Since 9.0, the
replTimeout
attribute is now inClusteringConfiguration
. - sync() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
- sync() - Method in interface org.infinispan.configuration.cache.ClusteringConfigurationChildBuilder
-
Deprecated.Since 9.0, the
replTimeout
attribute is now inClusteringConfigurationBuilder
. - 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() - Method in annotation type org.infinispan.notifications.Listener
-
Specifies whether callbacks on any class annotated with this annotation happens synchronously (in the caller's thread) or asynchronously (using a separate thread).
- SYNC - org.infinispan.configuration.cache.BackupConfiguration.BackupStrategy
- SYNC - org.infinispan.configuration.parsing.Element
- SYNC - org.infinispan.configuration.parsing.Parser.Mode
- SYNC - org.infinispan.functional.Param.ReplicationMode
-
Command is completed when all owners are updated.
- SYNC_COMMIT_TIME - org.infinispan.stats.container.ExtendedStatistic
- SYNC_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.commons.marshall.Ids
- SYNC_GET_TIME - org.infinispan.stats.container.ExtendedStatistic
- SYNC_PREPARE_TIME - org.infinispan.stats.container.ExtendedStatistic
- SYNC_REPLICATED_CONSISTENT_HASH_FACTORY - Static variable in interface org.infinispan.commons.marshall.Ids
- SYNC_ROLLBACK_TIME - org.infinispan.stats.container.ExtendedStatistic
- syncCommitPhase() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
Deprecated.since 9.0. no longer supported
- syncCommitPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
Deprecated.The syncRollbackPhase setting can no longer be modified at runtime. It must be the same on all nodes.
- syncCommitPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
Deprecated.since 9.0. no longer supported
- SyncConfiguration - Class in org.infinispan.configuration.cache
-
Deprecated.Since 9.0, the
replTimeout
attribute is nowClusteringConfiguration.remoteTimeout
. - SyncConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Deprecated.Since 9.0, the
replTimeout
attribute is nowClusteringConfigurationBuilder.remoteTimeout
. - SyncConfigurationBuilder(ClusteringConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.SyncConfigurationBuilder
-
Deprecated.
- 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 class org.infinispan.persistence.rest.upgrade.RestTargetMigrator
-
Deprecated.
- 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 class org.infinispan.persistence.rest.upgrade.RestTargetMigrator
-
Deprecated.
- synchronizeData(Cache<Object, Object>, int, int) - Method in interface org.infinispan.upgrade.TargetMigrator
-
Performs the synchronization of data between source and target
- 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 - org.infinispan.remoting.rpc.ResponseMode
- SYNCHRONOUS_IGNORE_LEAVERS - 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
- syncRollbackPhase() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
Deprecated.since 9.0. no longer supported
- syncRollbackPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfiguration
-
Deprecated.The syncRollbackPhase setting can no longer be modified at runtime. It must be the same on all nodes.
- syncRollbackPhase(boolean) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
-
Deprecated.since 9.0. no longer supported
- SyncStrongCounter - Class in org.infinispan.counter
-
Deprecated.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.
- SyncWeakCounter - Class in org.infinispan.counter
-
Deprecated.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.
T
- 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_NAME_PREFIX - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- 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.
- 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.
- take() - Method in class org.infinispan.distexec.DistributedExecutionCompletionService
-
{@inheritDoc CompletionService}
- take() - Method in class org.infinispan.executors.ExecutorAllCompletionService
- take() - Method in class org.infinispan.executors.SemaphoreCompletionService
- TAKE_BACKUP_OFFLINE_AFTER_FAILURES - org.infinispan.configuration.parsing.Attribute
- TAKE_BACKUP_OFFLINE_MIN_WAIT - org.infinispan.configuration.parsing.Attribute
- TAKE_OFFLINE - org.infinispan.configuration.parsing.Element
- TAKE_OFFLINE - org.infinispan.xsite.XSiteAdminCommand.AdminOperation
- takeExecutorOwnership - Variable in class org.infinispan.distexec.DefaultExecutorService
-
Deprecated.
- TAKEN_OFFLINE - org.infinispan.xsite.BackupSender.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
- takeSiteOffline(String) - Method in interface org.infinispan.xsite.BackupSender
- takeSiteOffline(String) - Method in class org.infinispan.xsite.BackupSenderImpl
- takeSiteOffline(String) - Method in class org.infinispan.xsite.GlobalXSiteAdminOperations
- takeSiteOffline(String) - Method in class org.infinispan.xsite.XSiteAdminOperations
- 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.ValidSingleResponseCollector
- task - Variable in class org.infinispan.distexec.RunnableAdapter
- Task - Interface in org.infinispan.tasks
- TaskContext - Class in org.infinispan.tasks
-
TaskContext.
- TaskContext() - Constructor for class org.infinispan.tasks.TaskContext
- TaskContextImpl - Class in org.infinispan.persistence
- TaskContextImpl() - Constructor for class org.infinispan.persistence.TaskContextImpl
- TaskEngine - Interface in org.infinispan.tasks.spi
-
TaskEngine.
- TaskExecution - Interface in org.infinispan.tasks
-
TaskExecution.
- TaskExecutionMode - Enum in org.infinispan.tasks
- TaskManager - Interface in org.infinispan.tasks
-
TaskManager.
- TaskRequestProcessor - Class in org.infinispan.server.hotrod
- TCP_KEEPALIVE - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- TCP_NO_DELAY - org.infinispan.persistence.remote.configuration.Attribute
- TCP_NO_DELAY - org.infinispan.persistence.rest.configuration.Attribute
- TCP_NO_DELAY - Static variable in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- TCP_NODELAY - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- tcpKeepAlive() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- 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.persistence.remote.configuration.RemoteStoreConfiguration
- tcpNoDelay() - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- tcpNoDelay() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- 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.persistence.rest.configuration.ConnectionPoolConfigurationBuilder
- 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 - org.infinispan.commons.util.MemoryUnit
- template() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- template(boolean) - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- template(boolean) - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- TEMPORARY_LOCATION - org.infinispan.configuration.parsing.Element
- TEMPORARY_LOCATION - Static variable in class org.infinispan.configuration.global.GlobalStateConfiguration
- 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.
- TERABYTES - org.infinispan.commons.util.MemoryUnit
- TERMINAL_OPERATIONS - Static variable in interface org.infinispan.commons.marshall.Ids
- terminate() - Method in class org.infinispan.statetransfer.InboundTransferTask
-
Terminate abruptly regardless if the segments were received or not.
- terminate() - Method in class org.infinispan.stats.LocalTransactionStatistics
- terminate() - Method in class org.infinispan.stats.RemoteTransactionStatistics
- terminate() - Method in class org.infinispan.stats.TransactionStatistics
-
Signals this transaction as completed and updates the statistics to the final values ready to be merged in the cache statistics.
- TERMINATED - org.infinispan.lifecycle.ComponentStatus
-
The
stop()
method has completed and the component has terminated. - terminateTransaction() - Method in class org.infinispan.stats.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.stats.CacheStatisticManager
-
Signals the ending of a transaction.
- test(K) - Method in interface org.infinispan.filter.KeyFilter
-
Deprecated.
- test(ScopedState) - Method in class org.infinispan.globalstate.ScopeFilter
- test(CacheXid) - Method in class org.infinispan.server.hotrod.tx.table.functions.XidPredicate
- TEST_WHILE_IDLE - org.infinispan.persistence.remote.configuration.Attribute
- testWhileIdle() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- testWhileIdle(boolean) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
-
Indicates whether or not idle connections should be validated by sending an TCP packet to the server, during idle connection eviction runs.
- 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_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, VisitableCommand, InvocationSuccessAction) - Method in class org.infinispan.interceptors.InvocationStage
- thenApply(InvocationContext, VisitableCommand, InvocationSuccessFunction) - Method in class org.infinispan.interceptors.InvocationStage
-
After the current stage completes successfully, invoke
function
and return its result. - THREAD_FACTORY - org.infinispan.configuration.parsing.Attribute
- THREAD_FACTORY - org.infinispan.configuration.parsing.Element
- THREAD_NAME_PATTERN - org.infinispan.configuration.parsing.Attribute
- THREAD_POLICY - org.infinispan.configuration.parsing.Attribute
- THREAD_POLICY - Static variable in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- THREAD_POOL_SIZE - org.infinispan.configuration.parsing.Attribute
- THREAD_POOL_SIZE - Static variable in class org.infinispan.configuration.cache.AsyncStoreConfiguration
- threadDump() - Static method in class org.infinispan.commons.util.Util
- threadFactory() - Method in class org.infinispan.configuration.global.ThreadPoolConfiguration
- threadFactory(ThreadFactory) - Method in class org.infinispan.configuration.global.ThreadPoolConfigurationBuilder
- threadGroup() - Method in class org.infinispan.factories.threads.DefaultThreadFactory
- 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.factories.threads.DefaultThreadFactory
- threadPolicy() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- threadPolicy(EvictionThreadPolicy) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.Threading policy for eviction.
- ThreadPoolConfiguration - Class in org.infinispan.configuration.global
- ThreadPoolConfiguration(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
- threadPoolSize() - Method in class org.infinispan.configuration.cache.AsyncStoreConfiguration
-
Size of the thread pool whose threads are responsible for applying the modifications.
- threadPoolSize(int) - Method in class org.infinispan.configuration.cache.AsyncStoreConfigurationBuilder
-
Configures the number of threads in the thread pool that is responsible for applying modifications.
- THREADS - org.infinispan.configuration.parsing.Element
- THROUGHPUT - org.infinispan.stats.container.ExtendedStatistic
- throwStackAwareConfigurationException(String) - Method in class org.infinispan.factories.AbstractComponentRegistry
-
Deprecated.
- time() - Method in class org.infinispan.commons.time.DefaultTimeService
- time() - Method in interface org.infinispan.commons.time.TimeService
- TIME_BETWEEN_EVICTION_RUNS - org.infinispan.persistence.remote.configuration.Attribute
- timeBetweenEvictionRuns() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfiguration
- timeBetweenEvictionRuns(long) - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
-
Indicates how long the eviction thread should sleep before "runs" of examining idle connections.
- TIMED_OUT - 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)
. - timeout - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- timeout - Variable in class org.infinispan.statetransfer.StateProviderImpl
- 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 interface org.infinispan.distexec.DistributedTask
-
Returns timeout for the execution of this task
- timeout() - Method in class org.infinispan.remoting.rpc.RpcOptions
- timeout(long) - 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(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.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.distexec.DistributedTaskBuilder
-
Provide
DistributedTask
task timeout - 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.CacheQuery
-
Set the timeout for this query.
- timeout(long, TimeUnit) - Method in class org.infinispan.query.clustered.ClusteredCacheQueryImpl
- timeout(long, TimeUnit) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
-
Deprecated.Sets the timeout value and its
TimeUnit
. - timeout(long, TimeUnit) - Method in class org.infinispan.util.AbstractDelegatingCacheStream
- timeout(TimeUnit) - Method in class org.infinispan.remoting.rpc.RpcOptionsBuilder
-
Deprecated.
- TIMEOUT - 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
- timeService - Variable in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- timeService - Variable in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- timeService - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- timeService - Variable in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- timeService - Variable in class org.infinispan.server.hotrod.tx.table.functions.TxFunction
- timeService - Variable in class org.infinispan.stats.TransactionStatistics
- timeService - Variable in class org.infinispan.xsite.BaseBackupReceiver
- 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_COLUMN - org.infinispan.persistence.jdbc.configuration.Element
- TIMESTAMP_COLUMN_NAME - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- TIMESTAMP_COLUMN_TYPE - Static variable in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfiguration
- 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.InfinispanCacheResponse
- timeUnit() - Method in class org.infinispan.remoting.rpc.RpcOptions
- TimeUnitValue - Enum in org.infinispan.server.hotrod
- 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.concurrent.ConcurrentHashSet
- 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.util.AbstractDelegatingCacheStream
- toArray() - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- toArray() - Method in class org.infinispan.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- 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.commons.util.AbstractDelegatingCollection
- toArray(T[]) - Method in class org.infinispan.commons.util.CloseableIteratorCollectionAdapter
- toArray(T[]) - Method in class org.infinispan.commons.util.concurrent.ConcurrentHashSet
- 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.util.ReadOnlyDataContainerBackedKeySet
-
Deprecated.
- toArray(T1[]) - Method in class org.infinispan.util.ReadOnlyCollectionAsSet
- toAsync() - Method in enum org.infinispan.configuration.cache.CacheMode
- toAttribute() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- toBuilder() - Method in interface org.infinispan.query.dsl.FilterConditionContext
-
Deprecated.To be removed in Infinispan 10.0 without replacement.
- toBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
- 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.InvocationStage
-
CompletableFuture
conversion. - toCompletableFuture() - Method in class org.infinispan.interceptors.SyncInvocationStage
- toCompletionStage() - Method in interface org.infinispan.scattered.BiasManager.Revocation
- toEntrySet(AdvancedCacheLoader<K, V>, Predicate<? super K>, InternalEntryFactory) - Static method in class org.infinispan.persistence.PersistenceUtil
- toEntrySet(AdvancedCacheLoader<K, V>, KeyFilter<? super K>, InternalEntryFactory) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Deprecated.
- toGibiBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
- toGigaBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
- 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(Supplier<TimeoutException>) - Method in interface org.infinispan.util.concurrent.locks.ExtendedLockPromise
- toJdkAccessOrder() - Method in enum org.infinispan.commons.equivalence.EquivalentLinkedHashMap.IterationOrder
-
Deprecated.
- toJDKByteBuffer() - Method in class org.infinispan.commons.io.ByteBufferImpl
- toKeySet(AdvancedCacheLoader<K, V>, Predicate<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
- toKeySet(AdvancedCacheLoader<K, V>, KeyFilter<? super K>) - Static method in class org.infinispan.persistence.PersistenceUtil
-
Deprecated.Please use
PersistenceUtil.toKeySet(AdvancedCacheLoader, Predicate)
instead - toKibiBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
- toKiloBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
- toManageableComponentMetadata() - Method in class org.infinispan.factories.components.ComponentMetadata
- toManageableComponentMetadata() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
- toMebiBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
- toMegaBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
- toNettyHttpResponse() - Method in class org.infinispan.rest.InfinispanResponse
-
Renders
FullHttpResponse
object. - toNewTypeIteratorFunction - Variable in class org.infinispan.util.WriteableCacheCollectionMapper
- toNullFunction() - Static method in class org.infinispan.util.concurrent.CompletableFutures
- toObjectSet(Collection<?>) - Static method in class org.infinispan.commons.util.InfinispanCollections
- topDocs - Variable in class org.infinispan.query.clustered.NodeTopDocs
- TopKeyLockManager - Class in org.infinispan.stats.wrappers
-
Top-key stats about locks.
- TopKeyLockManager(LockManager, StreamSummaryContainer) - Constructor for class org.infinispan.stats.wrappers.TopKeyLockManager
- topologicalSort() - Method in class org.infinispan.util.DependencyGraph
-
Calculates a topological sort of the graph, in linear time
- TOPOLOGY_ADDRESS - Static variable in class org.infinispan.server.core.ExternalizerIds
- TOPOLOGY_AWAIT_INITIAL_TRANSFER - Static variable in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- 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 - org.infinispan.notifications.cachelistener.event.Event.Type
- TOPOLOGY_LOCK_TIMEOUT - Static variable in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- TOPOLOGY_REPL_TIMEOUT - Static variable in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- TOPOLOGY_STATE_TRANSFER - Static variable in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- TOPOLOGY_VIEW - Static variable in class org.infinispan.server.core.ExternalizerIds
- 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
- 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
. - topologyFuture(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
- topologyFuture(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- topologyId - Variable in class org.infinispan.container.versioning.SimpleClusteredVersion
-
The cache topology id in which it was first created.
- topologyIdDelta - Variable in exception org.infinispan.statetransfer.OutdatedTopologyException
- TopologyIdUpdater() - Constructor for class org.infinispan.container.versioning.SimpleClusteredVersionGenerator.TopologyIdUpdater
- 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(ConsistentHash) - Constructor for class org.infinispan.distribution.topologyaware.TopologyInfo
- 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.
- TopologyMode - Enum in org.infinispan.remoting.inboundhandler
-
It checks or waits until the required topology is installed.
- topologyReceived(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
- topologyReceived(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- 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
- 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
-
Configures whether to enable state transfer for the topology cache.
- toResponse(InfinispanRequest) - Method in exception org.infinispan.rest.authentication.AuthenticationException
- toResponse(InfinispanRequest) - Method in exception org.infinispan.rest.RestResponseException
-
Creates Netty response based on error.
- toScopedState(ScopedPersistentState) - Method in interface org.infinispan.distribution.ch.ConsistentHash
-
Writes this ConsistentHash to the specified scoped state.
- toSerialSupplierCollect(SerializableSupplier) - Static method in class org.infinispan.util.Casting
- toStorage(Object) - Method in class org.infinispan.commons.dataconversion.BinaryEncoder
- toStorage(Object) - Method in interface org.infinispan.commons.dataconversion.Encoder
-
Convert data in the read/write format to the storage format.
- toStorage(Object) - Method in class org.infinispan.commons.dataconversion.IdentityEncoder
- toStorage(Object) - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
- toStorage(Object) - Method in class org.infinispan.commons.dataconversion.UTF8Encoder
- 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
- toStreamRemoved() - Method in class org.infinispan.container.offheap.MemoryAddressHash
-
Same as
MemoryAddressHash.toStream()
except that the memory addresses are also cleared out (set to 0) - toString() - Method in class org.infinispan.atomic.DeltaCompositeKey
-
Deprecated.
- 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.dataconversion.MediaType
- toString() - Method in class org.infinispan.commons.executors.BlockingThreadPoolExecutorFactory
- 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.marshall.WrappedByteArray
- 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.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.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.AuthorizationConfiguration
- toString() - Method in class org.infinispan.configuration.cache.AuthorizationConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.BackupConfiguration
- 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.BackupForConfiguration
- toString() - Method in class org.infinispan.configuration.cache.ClusteringConfiguration
- toString() - Method in class org.infinispan.configuration.cache.ClusteringConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.ClusterLoaderConfiguration
- toString() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfiguration
- 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.ContentTypeConfiguration
- toString() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfiguration
- toString() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
- toString() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.ExpirationConfiguration
- toString() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.GroupsConfiguration
- toString() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.HashConfiguration
- 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.InterceptorConfiguration
- toString() - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
- 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.JMXStatisticsConfiguration
- toString() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.L1Configuration
- toString() - Method in class org.infinispan.configuration.cache.L1ConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.LockingConfiguration
- toString() - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.MemoryConfiguration
- toString() - Method in class org.infinispan.configuration.cache.MemoryConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- 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.RecoveryConfiguration
- 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.SingletonStoreConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.SitesConfiguration
- toString() - Method in class org.infinispan.configuration.cache.StateTransferConfiguration
- toString() - Method in class org.infinispan.configuration.cache.StateTransferConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.StoreAsBinaryConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.SyncConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.TakeOfflineConfiguration
- toString() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- toString() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.UnsafeConfiguration
- toString() - Method in class org.infinispan.configuration.cache.UnsafeConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.cache.VersioningConfiguration
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.VersioningConfigurationBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- toString() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- 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.GlobalJmxStatisticsConfiguration
- toString() - Method in class org.infinispan.configuration.global.GlobalJmxStatisticsConfigurationBuilder
- 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.ScheduledExecutorFactoryConfiguration
- toString() - Method in class org.infinispan.configuration.global.ScheduledExecutorFactoryConfigurationBuilder
- 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
- toString() - Method in class org.infinispan.configuration.global.SiteConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.global.ThreadPoolConfiguration
- toString() - Method in class org.infinispan.configuration.global.TransportConfiguration
- toString() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- toString() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfiguration
- toString() - Method in class org.infinispan.configuration.internal.PrivateGlobalConfigurationBuilder
- toString() - Method in enum org.infinispan.configuration.parsing.Attribute
- toString() - Method in enum org.infinispan.configuration.parsing.Element
- 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.ImmortalCacheEntry
- toString() - Method in class org.infinispan.container.entries.ImmortalCacheValue
- toString() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheEntry
- toString() - Method in class org.infinispan.container.entries.metadata.MetadataImmortalCacheValue
- toString() - Method in class org.infinispan.container.entries.MortalCacheEntry
- toString() - Method in class org.infinispan.container.entries.MortalCacheValue
- 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.entries.TransientCacheEntry
- toString() - Method in class org.infinispan.container.entries.TransientCacheValue
- toString() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- toString() - Method in class org.infinispan.container.entries.TransientMortalCacheValue
- 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.SingleKeyNonTxInvocationContext
-
Deprecated.
- 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.distribution.DistributionInfo
- 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.factories.AbstractComponentRegistry.Component
-
Deprecated.
- toString() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectFieldMetadata
- toString() - Method in class org.infinispan.factories.components.ComponentMetadata.InjectMethodMetadata
- toString() - Method in class org.infinispan.factories.components.ComponentMetadata.PrioritizedMethodMetadata
- toString() - Method in class org.infinispan.factories.components.ComponentMetadata
- toString() - Method in class org.infinispan.factories.components.JmxAttributeMetadata
- toString() - Method in class org.infinispan.factories.components.JmxOperationMetadata
- toString() - Method in class org.infinispan.factories.components.JmxOperationParameter
- toString() - Method in class org.infinispan.factories.components.ManageableComponentMetadata
- 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.distribution.VersionedResult
- toString() - Method in class org.infinispan.interceptors.distribution.VersionedResults
- toString() - Method in class org.infinispan.interceptors.SyncInvocationStage
- toString() - Method in class org.infinispan.io.GridFile.Metadata
- toString() - Method in class org.infinispan.io.GridFile
- toString() - Method in enum org.infinispan.jmx.annotations.DataType
- toString() - Method in enum org.infinispan.jmx.annotations.DisplayType
- toString() - Method in enum org.infinispan.jmx.annotations.Units
- 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.lucene.cacheloader.configuration.LuceneLoaderConfiguration
- toString() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
- toString() - Method in class org.infinispan.lucene.ChunkCacheKey
-
Changing the encoding could break backwards compatibility
- toString() - Method in class org.infinispan.lucene.FileCacheKey
-
Changing the encoding could break backwards compatibility
- toString() - Method in class org.infinispan.lucene.FileListCacheKey
-
Changing the encoding could break backwards compatibility
- toString() - Method in class org.infinispan.lucene.FileMetadata
- toString() - Method in class org.infinispan.lucene.FileReadLockKey
- toString() - Method in class org.infinispan.manager.DefaultCacheManager
- toString() - Method in class org.infinispan.marshall.core.MarshalledEntryImpl
- toString() - Method in class org.infinispan.metadata.EmbeddedMetadata
- toString() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent
- toString() - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfiguration
- toString() - Method in enum org.infinispan.persistence.jdbc.configuration.Attribute
- toString() - Method in enum org.infinispan.persistence.jdbc.configuration.Element
- 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.ManagedConnectionFactoryConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
- toString() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
- 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.connectionfactory.ConnectionFactoryConfig
- toString() - Method in enum org.infinispan.persistence.jpa.configuration.Attribute
- toString() - Method in enum org.infinispan.persistence.jpa.configuration.Element
- toString() - Method in enum org.infinispan.persistence.leveldb.configuration.Attribute
- toString() - Method in enum org.infinispan.persistence.leveldb.configuration.Element
- 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.RemoteServerConfiguration
- toString() - Method in class org.infinispan.persistence.remote.configuration.SecurityConfigurationBuilder
- toString() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- toString() - Method in enum org.infinispan.persistence.rest.configuration.Attribute
- toString() - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfiguration
- toString() - Method in enum org.infinispan.persistence.rest.configuration.Element
- toString() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfiguration
- toString() - Method in class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.
- toString() - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
- toString() - Method in class org.infinispan.query.indexmanager.LazyInitializingBackend
- toString() - Method in class org.infinispan.query.indexmanager.LockAcquiringBackend
- toString() - Method in class org.infinispan.query.remote.client.ContinuousQueryResult
- toString() - Method in class org.infinispan.query.remote.client.FilterResult
- toString() - Method in class org.infinispan.remoting.inboundhandler.BaseBlockingRunnable
- toString() - Method in class org.infinispan.remoting.inboundhandler.DefaultTopologyRunnable
- 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.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.rpc.RpcOptionsBuilder
-
Deprecated.
- toString() - Method in class org.infinispan.remoting.transport.AggregateBackupResponse
- toString() - Method in class org.infinispan.remoting.transport.jgroups.ClusterView
- 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.RetryOnFailureXSiteCommand
- toString() - Method in class org.infinispan.rest.CacheControl
- toString() - Method in class org.infinispan.rest.configuration.RestServerConfiguration
- toString() - Method in class org.infinispan.rest.operations.mediatypes.Charset
- toString() - Method in class org.infinispan.rest.operations.mime.MimeMetadata
- toString() - Method in enum org.infinispan.security.AuditContext
- toString() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- toString() - Method in class org.infinispan.server.core.configuration.SslConfiguration
- 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.hotrod.command.tx.ForwardCommitCommand
- toString() - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
- toString() - Method in class org.infinispan.server.hotrod.configuration.AuthenticationConfiguration
- toString() - Method in class org.infinispan.server.hotrod.configuration.HotRodServerConfiguration
- toString() - Method in class org.infinispan.server.hotrod.counter.listener.ClientCounterEvent
- toString() - Method in class org.infinispan.server.hotrod.HotRodHeader
- 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.ServerAddress
- 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.TxState
- toString() - Method in class org.infinispan.server.memcached.configuration.MemcachedServerConfiguration
- toString() - Method in class org.infinispan.server.memcached.MemcachedMetadata
- toString() - Method in class org.infinispan.spring.provider.SpringCache
- toString() - Method in class org.infinispan.statetransfer.CommitManager
- toString() - Method in class org.infinispan.statetransfer.InboundTransferTask
- toString() - Method in class org.infinispan.statetransfer.OutboundTransferTask
- toString() - Method in class org.infinispan.statetransfer.StateChunk
- toString() - Method in class org.infinispan.statetransfer.StateRequestCommand
- toString() - Method in class org.infinispan.statetransfer.StateResponseCommand
- toString() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- toString() - Method in class org.infinispan.statetransfer.TransactionInfo
- toString() - Method in class org.infinispan.stats.container.LocalExtendedStatisticsContainer
- toString() - Method in class org.infinispan.stats.LocalTransactionStatistics
- toString() - Method in class org.infinispan.stats.RemoteTransactionStatistics
- toString() - Method in class org.infinispan.stats.topK.StreamSummaryContainer
- toString() - Method in class org.infinispan.stats.TransactionStatistics
- 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.CacheTopologyControlCommand
- 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.lookup.DummyTransactionManagerLookup
-
Deprecated.
- 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.tm.DummyNoXaXid
-
Deprecated.
- toString() - Method in class org.infinispan.transaction.tm.DummyTransaction
-
Deprecated.
- toString() - Method in class org.infinispan.transaction.tm.DummyXid
-
Deprecated.
- toString() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
- toString() - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- 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.InDoubtTxInfoImpl
- toString() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction
-
Deprecated.
- toString() - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction
- 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.recovery.SerializableXid
-
Deprecated.
- 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.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.OfflineStatus
- toString() - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
- 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.statetransfer.XSiteStateTransferControlCommand
- toString() - Method in class org.infinispan.xsite.XSiteAdminCommand
- toString() - Method in class org.infinispan.xsite.XSiteBackup
- toString(Object) - Method in class org.infinispan.commons.equivalence.AnyEquivalence
-
Deprecated.
- toString(Object) - Method in class org.infinispan.commons.equivalence.AnyServerEquivalence
-
Deprecated.
- toString(Object) - Method in class org.infinispan.commons.equivalence.ByteArrayEquivalence
-
Deprecated.
- toString(Object) - Method in interface org.infinispan.commons.equivalence.Equivalence
-
Deprecated.Returns a string representation of the given object.
- toString(Object) - Method in class org.infinispan.commons.equivalence.IdentityEquivalence
-
Deprecated.
- 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(Element) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
- toStringArray(Class<?>[]) - Static method in class org.infinispan.commons.util.ReflectionUtil
- toStringExcludingParam(String...) - Method in class org.infinispan.commons.dataconversion.MediaType
- toSupplierCollect(Supplier) - Static method in class org.infinispan.util.Casting
- toSync() - Method in enum org.infinispan.configuration.cache.CacheMode
- TOTAL - org.infinispan.remoting.inboundhandler.DeliverOrder
-
The message is delivered in the same order in all the destinations.
- TOTAL_ORDER - org.infinispan.transaction.TransactionProtocol
-
uses the total order protocol
- TOTAL_ORDER_EXECUTOR - org.infinispan.configuration.parsing.Attribute
- TOTAL_RESULTS - Static variable in interface org.infinispan.query.remote.json.JSONConstants
- totalOrder - Variable in class org.infinispan.interceptors.locking.ClusteringDependentLogic.AbstractClusteringDependentLogic
- TotalOrderDistributionInterceptor - Class in org.infinispan.interceptors.totalorder
-
This interceptor handles distribution of entries across a cluster, as well as transparent lookup, when the total order based protocol is enabled
- TotalOrderDistributionInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
- TotalOrderInterceptor - Class in org.infinispan.interceptors.totalorder
-
Created to control the total order validation.
- TotalOrderInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderInterceptor
- TotalOrderLatch - Interface in org.infinispan.transaction.totalorder
-
Behaves as a latch between
org.infinispan.commands.tx.PrepareCommand
delivered in total order to coordinate conflicting transactions and betweenorg.infinispan.commands.tx.PrepareCommand
and state transfer (blocking the prepare until the state transfer is finished and blocking the state transfer until all the prepared transactions has finished) - TotalOrderLatchImpl - Class in org.infinispan.transaction.totalorder
-
Implementation of
TotalOrderLatch
- TotalOrderLatchImpl(String) - Constructor for class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
- totalOrderManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- TotalOrderManager - Class in org.infinispan.transaction.totalorder
-
This class behaves as a synchronization point between incoming transactions (totally ordered) and between incoming transactions and state transfer.
- TotalOrderManager() - Constructor for class org.infinispan.transaction.totalorder.TotalOrderManager
- TotalOrderStateTransferInterceptor - Class in org.infinispan.interceptors.totalorder
-
Synchronizes the incoming totally ordered transactions with the state transfer.
- TotalOrderStateTransferInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderStateTransferInterceptor
- TotalOrderTxPerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
-
A
PerCacheInboundInvocationHandler
implementation for total order caches. - TotalOrderTxPerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.TotalOrderTxPerCacheInboundInvocationHandler
- TotalOrderVersionedDistributionInterceptor - Class in org.infinispan.interceptors.totalorder
-
This interceptor is used in total order in distributed mode when the write skew check is enabled.
- TotalOrderVersionedDistributionInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
- TotalOrderVersionedEntryWrappingInterceptor - Class in org.infinispan.interceptors.totalorder
-
Wrapping Interceptor for Total Order protocol when versions are needed
- TotalOrderVersionedEntryWrappingInterceptor() - Constructor for class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
- toTebiBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
- toTeraBytes(long) - Method in enum org.infinispan.commons.util.MemoryUnit
- toTimeUnit() - Method in enum org.infinispan.server.hotrod.TimeUnitValue
- toTypedProperties(Properties) - Static method in class org.infinispan.commons.util.TypedProperties
-
Factory method that converts a JDK
Properties
instance to an instance of TypedProperties, if needed. - toTypedProperties(Properties) - Static method in class org.infinispan.util.TypedProperties
-
Deprecated.Factory method that converts a JDK
Properties
instance to an instance of TypedProperties, if needed. - touch() - Method in class org.infinispan.container.entries.ImmortalCacheEntry
- touch() - Method in interface org.infinispan.container.entries.InternalCacheEntry
-
Deprecated.
- touch() - Method in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- touch() - Method in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- touch() - Method in class org.infinispan.container.entries.metadata.MetadataTransientMortalCacheEntry
- touch() - Method in class org.infinispan.container.entries.MortalCacheEntry
- touch() - Method in class org.infinispan.container.entries.TransientCacheEntry
- touch() - Method in class org.infinispan.container.entries.TransientMortalCacheEntry
- 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
- touchKey(Object, long) - Method in class org.infinispan.container.offheap.OffHeapConcurrentMap
- toURI() - Method in class org.infinispan.io.GridFile
- toURL() - Method in class org.infinispan.io.GridFile
- toXMLString() - Method in interface org.infinispan.commons.configuration.BasicConfiguration
-
Deprecated.
- toXMLString(String) - Method in interface org.infinispan.commons.configuration.BasicConfiguration
-
Converts this configuration to its XML representation.
- toXMLString(String) - Method in class org.infinispan.commons.configuration.XMLStringConfiguration
- toXMLString(String) - Method in class org.infinispan.configuration.cache.Configuration
- trace - Static variable in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- trace - Variable in class org.infinispan.server.hotrod.AbstractEncoder1x
- trace - Variable in class org.infinispan.stats.TransactionStatistics
- TRAIT - org.infinispan.jmx.annotations.DataType
- 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 - org.infinispan.configuration.parsing.Element
- TRANSACTION_COMPLETED - org.infinispan.notifications.cachelistener.event.Event.Type
- TRANSACTION_INFO - Static variable in interface org.infinispan.commons.marshall.Ids
- TRANSACTION_MANAGER_LOOKUP - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- TRANSACTION_MANAGER_LOOKUP_CLASS - org.infinispan.configuration.parsing.Attribute
- TRANSACTION_MODE - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- TRANSACTION_PROTOCOL - org.infinispan.configuration.parsing.Attribute
- TRANSACTION_PROTOCOL - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- TRANSACTION_REGISTERED - org.infinispan.notifications.cachelistener.event.Event.Type
- TRANSACTION_SYNCHRONIZATION_REGISTRY_LOOKUP - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- 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 - org.infinispan.configuration.parsing.Attribute
- TRANSACTIONAL - 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
-
Defines the functionality of a transactional store.
- 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
-
Deprecated.Since 9.0, this class is going to be moved to an internal package.
- TransactionalInvocationContextFactory() - Constructor for class org.infinispan.context.TransactionalInvocationContextFactory
-
Deprecated.
- TransactionalRemoteLockCommand - Interface in org.infinispan.util.concurrent.locks
-
Simple interface to extract all the keys that may need to be locked for transactional commands.
- 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.configuration.cache
-
Defines transactional (JTA) characteristics of the cache.
- TransactionConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Defines transactional (JTA) characteristics of the cache.
- TransactionConfigurationChildBuilder - Interface in org.infinispan.configuration.cache
- transactionDataFuture(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
- transactionDataFuture(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- transactionDataReceived(int) - Method in interface org.infinispan.statetransfer.StateTransferLock
- transactionDataReceived(int) - Method in class org.infinispan.statetransfer.StateTransferLockImpl
- TransactionFactory - Class in org.infinispan.transaction.xa
-
Factory for transaction related sate.
- 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
- TransactionInfo - Class in org.infinispan.statetransfer
-
A representation of a transaction that is suitable for transferring between a StateProvider and a StateConsumer running on different members of the same cache.
- TransactionInfo(GlobalTransaction, int, WriteCommand[], Set<Object>) - Constructor for class org.infinispan.statetransfer.TransactionInfo
- TransactionInfo.Externalizer - Class in org.infinispan.statetransfer
- transactionManager - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- 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.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.configuration.cache.TransactionConfiguration
-
Deprecated.since 9.0. The transaction manager is only looked up once, during cache startup.
- 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.
- TransactionManagerLookup - Interface in org.infinispan.transaction.lookup
-
Deprecated.Use
TransactionManagerLookup
instead. - 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.configuration.cache.TransactionConfigurationBuilder
- TransactionMode - Enum in org.infinispan.configuration.cache
-
Transaction mode
- TransactionMode - Enum in org.infinispan.transaction
-
Enumeration containing the available transaction modes for a cache.
- transactionProtocol() - Method in class org.infinispan.configuration.cache.TransactionConfiguration
- transactionProtocol() - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- transactionProtocol(TransactionProtocol) - Method in class org.infinispan.configuration.cache.TransactionConfigurationBuilder
- TransactionProtocol - Enum in org.infinispan.transaction
-
Enumerate with the possible commits protocols.
- 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
. - transactionResponse(HotRodHeader, HotRodServer, ByteBufAllocator, int) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- transactionResponse(HotRodHeader, HotRodServer, ByteBufAllocator, int) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- TransactionStatistics - Class in org.infinispan.stats
-
Keeps the temporary statistics for a transaction.
- TransactionStatistics(ExtendedStatisticsContainer, TimeService) - Constructor for class org.infinispan.stats.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
- TransactionSynchronizerInterceptor - Class in org.infinispan.statetransfer
-
With the Non-Blocking State Transfer (NBST) in place it is possible for a transactional command to be forwarded multiple times, concurrently to the same node.
- TransactionSynchronizerInterceptor() - Constructor for class org.infinispan.statetransfer.TransactionSynchronizerInterceptor
- transactionTable - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- TransactionTable - Interface in org.infinispan.transaction
-
Interface that allows to fetch the
GlobalTransaction
associated to local or remote transactions. - TransactionTableFactory - Class in org.infinispan.factories
-
Factory for
TransactionTable
objects. - TransactionTableFactory() - Constructor for class org.infinispan.factories.TransactionTableFactory
- 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.DefaultTranscoder
- transcode(Object, MediaType, MediaType) - Method in interface org.infinispan.commons.dataconversion.Transcoder
-
Transcodes content between two different
MediaType
. - transcode(Object, MediaType, MediaType) - Method in class org.infinispan.commons.dataconversion.TranscoderMarshallerAdapter
- transcode(Object, MediaType, MediaType) - Method in class org.infinispan.server.core.dataconversion.JBossMarshallingTranscoder
- transcode(Object, MediaType, MediaType) - Method in class org.infinispan.server.core.dataconversion.JsonTranscoder
- transcode(Object, MediaType, MediaType) - Method in class org.infinispan.server.core.dataconversion.XMLTranscoder
- 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
- transferComplete() - Method in interface org.infinispan.notifications.cachelistener.QueueingSegmentListener
-
This is needed to tell the handler when the complete iteration is done.
- transferMapsLock - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- transfersBySegment - Variable in class org.infinispan.statetransfer.StateConsumerImpl
-
A map that keeps track of current inbound state transfers by segment id.
- 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. - Transformable - Annotation Type in org.infinispan.query
-
If you annotate your object with this, it can be used as a valid key for Infinispan to index (unless your key type is a boxed primitive, a String or a byte array in which case it can be used without a transformer).
- 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() - Method in annotation type org.infinispan.query.Transformable
-
The
Transformer
to use. - Transformer - Interface in org.infinispan.query
-
Convert objects (cache keys only) from their original Java types to a String representation (which is suitable to be used in a Lucene index) and vice versa.
- transformKeysToString(Collection<LuceneWork>, KeyTransformationHandler) - Static method in class org.infinispan.query.indexmanager.LuceneWorkConverter
- 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.
- transformResult(Object[]) - Method in interface org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadManyCommandHelper
- transformResult(Object[]) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor.ReadOnlyManyHelper
- 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.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.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.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) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
- TransientMortalCacheValue(Object, long, long, long, long) - Constructor for class org.infinispan.container.entries.TransientMortalCacheValue
- TransientMortalCacheValue.Externalizer - Class in org.infinispan.container.entries
- TRANSITORY - 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.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.TransportConfiguration
- 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 - org.infinispan.configuration.parsing.Attribute
- TRANSPORT - org.infinispan.configuration.parsing.Element
- TRANSPORT_FACTORY - org.infinispan.persistence.remote.configuration.Attribute
- TransportConfiguration - Class in org.infinispan.configuration.global
- TransportConfigurationBuilder - Class in org.infinispan.configuration.global
-
Configures the transport used for network communications across the cluster.
- transportFactory() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- 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
-
Controls which transport to use.
- 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
-
Controls which transport to use.
- TransportFactory - Class in org.infinispan.factories
-
Factory for Transport implementations
- TransportFactory() - Constructor for class org.infinispan.factories.TransportFactory
- transportThreadPool() - Method in class org.infinispan.configuration.global.TransportConfiguration
- transportThreadPool() - Method in class org.infinispan.configuration.global.TransportConfigurationBuilder
- Traversable<T> - Interface in org.infinispan.functional
-
Unsorted traversable stream for sequential and aggregating operations.
- TRENDSDOWN - org.infinispan.jmx.annotations.MeasurementType
- TRENDSUP - org.infinispan.jmx.annotations.MeasurementType
- 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
- TriangleDistributionInterceptor - Class in org.infinispan.interceptors.distribution
-
Non-transactional interceptor used by distributed caches that supports concurrent writes.
- TriangleDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- 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 - Variable in class org.infinispan.statetransfer.StateConsumerImpl
- 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
- TrianglePerCacheInboundInvocationHandler - Class in org.infinispan.remoting.inboundhandler
-
A
PerCacheInboundInvocationHandler
implementation for non-transactional and distributed caches that uses the triangle algorithm. - TrianglePerCacheInboundInvocationHandler() - Constructor for class org.infinispan.remoting.inboundhandler.TrianglePerCacheInboundInvocationHandler
- TriConsumer<T,U,V> - Interface in org.infinispan.util.function
-
Represents an operation that accepts three input arguments and returns no result.
- 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. - TRUSTSTORE - org.infinispan.persistence.remote.configuration.Element
- trustStoreFileName() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- 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.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.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.persistence.remote.configuration.SslConfiguration
- 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.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.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)
. - trustStoreType() - Method in class org.infinispan.persistence.remote.configuration.SslConfiguration
- trustStoreType() - Method in class org.infinispan.server.core.configuration.SslEngineConfiguration
- 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.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 - 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.stats.topK.StreamSummaryContainer
-
Tries to flush all the enqueue offers to be visible globally.
- 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
- trySkipL1Update() - Method in class org.infinispan.interceptors.distribution.L1WriteSynchronizer
-
Attempts to mark the L1 update to only retrieve the value and not to actually update the L1 cache.
- trySplit() - Method in class org.infinispan.commons.util.CloseableSpliteratorMapper
-
Deprecated.
- 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
- TWO_PHASE - org.infinispan.statetransfer.RebalanceType
-
Used by scattered cache.
- TwoWayKey2StringMapper - Interface in org.infinispan.persistence.keymappers
-
Extends
Key2StringMapper
and allows a bidirectional transformation between keys and Strings. - TX_STATE - Static variable in class org.infinispan.server.core.ExternalizerIds
- TxDistributionInterceptor - Class in org.infinispan.interceptors.distribution
-
Handles the distribution of the transactional caches.
- TxDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- TxFunction - Class in org.infinispan.server.hotrod.tx.table.functions
- TxFunction() - Constructor for class org.infinispan.server.hotrod.tx.table.functions.TxFunction
- 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
- txTable - Variable in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- type() - Method in class org.infinispan.commons.util.Either
- type() - Method in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.use
MemoryConfiguration.evictionType()
instead - type() - Method in class org.infinispan.counter.api.CounterConfiguration
- type() - Method in annotation type org.infinispan.jmx.annotations.Parameter
- type(EvictionType) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.Sets the eviction type which can either be COUNT - entries will be evicted when the number of entries exceeds the
EvictionConfigurationBuilder.size(long)
MEMORY - entries will be evicted when the approximate combined size of all values exceeds theEvictionConfigurationBuilder.size(long)
Cache size is guaranteed not to exceed upper limit specified by max entries. - TYPE - org.infinispan.configuration.parsing.Attribute
- TYPE - org.infinispan.persistence.jdbc.configuration.Attribute
- TYPE - org.infinispan.persistence.leveldb.configuration.Attribute
- TYPE - org.infinispan.persistence.remote.configuration.Attribute
- TYPE - Static variable in class org.infinispan.configuration.cache.EvictionConfiguration
-
Deprecated.
- 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 - Class in org.infinispan.util
-
Deprecated.
- TypedProperties() - Constructor for class org.infinispan.commons.util.TypedProperties
-
Default constructor that returns an empty instance
- TypedProperties() - Constructor for class org.infinispan.util.TypedProperties
-
Deprecated.
- TypedProperties(Properties) - Constructor for class org.infinispan.commons.util.TypedProperties
-
Copy constructor
- TypedProperties(Properties) - Constructor for class org.infinispan.util.TypedProperties
-
Deprecated.
- 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
U
- UberJarDuplicatedJarsWarner - Interface in org.infinispan.commons.util.uberjar
-
Checks if classpath contains proper configuration for Uber Jars and warns if it does not.
- 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
- unauthorized(String) - Static method in class org.infinispan.rest.InfinispanErrorResponse
- unBlock() - Method in interface org.infinispan.transaction.totalorder.TotalOrderLatch
-
Unblocks this synchronization block
- unBlock() - Method in class org.infinispan.transaction.totalorder.TotalOrderLatchImpl
- 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 - org.infinispan.counter.api.CounterType
-
A strong consistent and unbounded counter.
- UnclosableObjectInputStream - Class in org.infinispan.io
-
A delegating
ObjectInput
that delegates all methods exceptObjectInput.close()
. - UnclosableObjectInputStream(ObjectInput) - Constructor for class org.infinispan.io.UnclosableObjectInputStream
- UnclosableObjectOutputStream - Class in org.infinispan.io
-
An unclosable version of an
ObjectOutput
. - UnclosableObjectOutputStream(ObjectOutput) - Constructor for class org.infinispan.io.UnclosableObjectOutputStream
- 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.
- UndefineConfigurationAction - Class in org.infinispan.security.actions
-
UndefineConfigurationAction.
- UndefineConfigurationAction(EmbeddedCacheManager, String) - Constructor for class org.infinispan.security.actions.UndefineConfigurationAction
- undelegate() - Method in class org.infinispan.persistence.support.DelegatingCacheLoader
- undelegate() - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
- undelete(boolean) - Method in interface org.infinispan.container.entries.CacheEntry
-
Deprecated.
- underlyingStream - Variable in class org.infinispan.util.AbstractDelegatingCacheStream
- unexpectedAttribute(XMLStreamReader, int) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an unexpected XML attribute.
- unexpectedAttribute(XMLStreamReader, String) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an unexpected XML attribute.
- unexpectedElement(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an unexpected XML element.
- unexpectedEndElement(XMLStreamReader) - Static method in class org.infinispan.configuration.parsing.ParseUtils
-
Get an exception reporting an unexpected end tag for an XML element.
- unexpectedResponse(Response) - Static method in class org.infinispan.remoting.transport.ResponseCollectors
- UNHEALTHY - org.infinispan.health.HealthStatus
-
Given entity is unhealthy.
- unicodeEscapeString(String) - Static method in class org.infinispan.commons.util.Util
- unicodeUnescapeString(String) - Static method in class org.infinispan.commons.util.Util
- unignore(String) - Method in class org.infinispan.server.core.AbstractCacheIgnoreAware
- unignore(String) - Method in interface org.infinispan.server.core.CacheIgnoreAware
-
No longer ignore the given cache if it was before
- union(CH, CH) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
-
Creates a union of two compatible ConsistentHashes (use the same hashing function and have the same configuration parameters).
- units() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
- Units - Enum in org.infinispan.jmx.annotations
- UNKNOWN - org.infinispan.configuration.parsing.Attribute
- UNKNOWN - org.infinispan.configuration.parsing.Element
- UNKNOWN - org.infinispan.counter.configuration.Attribute
- UNKNOWN - org.infinispan.counter.configuration.Element
- UNKNOWN - org.infinispan.lock.configuration.Attribute
- UNKNOWN - org.infinispan.lock.configuration.Element
- UNKNOWN - org.infinispan.persistence.jdbc.configuration.Attribute
- UNKNOWN - org.infinispan.persistence.jdbc.configuration.Element
- UNKNOWN - org.infinispan.persistence.jpa.configuration.Attribute
- UNKNOWN - org.infinispan.persistence.jpa.configuration.Element
- UNKNOWN - org.infinispan.persistence.leveldb.configuration.Attribute
- UNKNOWN - org.infinispan.persistence.leveldb.configuration.Element
- UNKNOWN - org.infinispan.persistence.remote.configuration.Attribute
- UNKNOWN - org.infinispan.persistence.remote.configuration.Element
- UNKNOWN - org.infinispan.persistence.rest.configuration.Attribute
- UNKNOWN - org.infinispan.persistence.rest.configuration.Element
- UNKNOWN - org.infinispan.server.hotrod.HotRodVersion
- UnknownOperation - org.infinispan.server.hotrod.OperationStatus
- UnknownVersion - 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.stats.wrappers.ExtendedStatisticLockManager
- unlock(Object, Object) - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- unlock(Object, Object) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Releases the lock for the
key
if thelockOwner
is the lock owner. - unlockAll(Collection<?>, Object) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticLockManager
- unlockAll(Collection<?>, Object) - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- 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.stats.wrappers.ExtendedStatisticLockManager
- unlockAll(InvocationContext) - Method in class org.infinispan.stats.wrappers.TopKeyLockManager
- unlockAll(InvocationContext) - Method in interface org.infinispan.util.concurrent.locks.LockManager
-
Same as
unlockAll(context.getLockedKeys(), context.getKeyLockOwner();
. - unmarshall(byte[]) - Method in class org.infinispan.commons.dataconversion.BinaryEncoder
- unmarshall(byte[]) - Method in class org.infinispan.commons.dataconversion.MarshallerEncoder
- 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(ObjectInput) - 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
. - 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.util.AbstractDelegatingCacheStream
- UNORDERED - org.infinispan.eviction.EvictionStrategy
-
Deprecated.
- 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
- unregister() - Method in class org.infinispan.notifications.cachelistener.filter.DelegatingCacheEntryListenerInvocation
-
Stops handling the invocation.
- unregisterCacheMBean(String, String) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
- unregisterFilter(FilterSubscription) - Method in interface org.infinispan.objectfilter.Matcher
- unregisterInternalCache(String) - Method in interface org.infinispan.registry.InternalCacheRegistry
-
Unregisters an internal cache
- unregisterL1WriteSynchronizer(Object, L1WriteSynchronizer) - Method in interface org.infinispan.distribution.L1Manager
-
Unregister the given write synchronizer if present.
- unregisterListener() - Method in class org.infinispan.spring.session.AbstractApplicationPublisherBridge
- unregisterListener() - Method in class org.infinispan.spring.session.EmbeddedApplicationPublishedBridge
- unregisterListener() - Method in class org.infinispan.spring.session.RemoteApplicationPublishedBridge
- unregisterMarshaller(BaseMarshaller<?>) - Method in interface org.infinispan.query.remote.ProtobufMetadataManager
- unregisterMBean(ObjectName, MBeanServer) - Static method in class org.infinispan.commons.jmx.JmxUtil
-
Unregister the MBean located under the given
ObjectName
- unregisterMBeans(String, MBeanServer) - Static method in class org.infinispan.commons.jmx.JmxUtil
-
Unregister all mbeans whose object names match a given filter.
- unregisterMBeans(Collection<ResourceDMBean>) - Method in class org.infinispan.jmx.AbstractJmxRegistration
- unregisterMBeans(Collection<ResourceDMBean>) - Method in class org.infinispan.jmx.ComponentsJmxRegistration
-
Unregisters all the MBeans registered through
ComponentsJmxRegistration.registerMBeans(Collection)
. - 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 interface org.infinispan.scattered.ScatteredVersionManager
-
Move the segment to
ScatteredVersionManager.SegmentState.NOT_OWNED
state. - unregisterServerMBeans() - Method in class org.infinispan.server.core.AbstractProtocolServer
- unregisterWrite(K) - Method in interface org.infinispan.expiration.ExpirationManager
-
Deprecated.since 9.3 There is no reason for this method and is implementation specific
- UNRELIABLE_RETURN_VALUES - 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.Configuration
- unsafe() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- unsafe() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
- UNSAFE - 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, ByteBufAllocator, long) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- unsignedLongResponse(HotRodHeader, HotRodServer, ByteBufAllocator, 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
- 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
- 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
- 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() - Method in annotation type org.infinispan.configuration.parsing.Namespace
-
The last version of the schema where this is supported.
- unwrap(Class<T>) - Method in interface org.infinispan.query.SearchManager
-
This method gives access to internal Infinispan implementation details, and should not be normally needed.
- 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
- unwrapFunctionalManyResultOnOrigin(InvocationContext, List<Object>, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- unwrapFunctionalManyResultOnOrigin(InvocationContext, List<Object>, Object) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
- unwrapFunctionalResultOnOrigin(InvocationContext, Object, Object) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- unwrapFunctionalResultOnOrigin(InvocationContext, Object, Object) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
- update(CacheXid, TxFunction, long) - Method in class org.infinispan.server.hotrod.tx.table.GlobalTxTable
- updateAvailabilityMode(List<Address>, AvailabilityMode, boolean) - Method in class org.infinispan.topology.ClusterCacheStatus
- 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).
- updateCurrentTopology(List<Address>) - Method in class org.infinispan.topology.ClusterCacheStatus
- UPDATED - org.infinispan.query.remote.client.ContinuousQueryResult.ResultType
- updateDomain(ComponentsJmxRegistration, MBeanServer, String) - Method in class org.infinispan.jmx.CacheManagerJmxRegistration
- updateDomain(ComponentsJmxRegistration, MBeanServer, String, CacheManagerJmxRegistration) - Method in class org.infinispan.jmx.CacheJmxRegistration
- updateFilteredKeys(List<Object>) - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
- updateMembers(CH, List<Address>, Map<Address, Float>) - Method in interface org.infinispan.distribution.ch.ConsistentHashFactory
-
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
- updateMetadata(CacheEntry, Metadata) - Static method in class org.infinispan.metadata.Metadatas
-
Set the
providedMetadata
on the cache entry. - updateOnCommunicationFailure(long) - Method in class org.infinispan.xsite.OfflineStatus
- 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
- updatePreviousValue() - Method in class org.infinispan.container.entries.RepeatableReadEntry
- updateTimeout(long) - Method in class org.infinispan.remoting.inboundhandler.action.ActionState
- 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
- updateTTL(MapSession, boolean) - Method in class org.infinispan.spring.session.AbstractInfinispanSessionRepository
- upgradeLock(Object) - Method in class org.infinispan.util.concurrent.locks.StripedLock
- UPPER_BOUND - org.infinispan.counter.configuration.Element
- UPPER_BOUND - Static variable in exception org.infinispan.counter.exception.CounterOutOfBoundsException
- UPPER_BOUND_REACHED - 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.
- uri() - Method in annotation type org.infinispan.configuration.parsing.Namespace
-
The URI of the namespace.
- uri() - Method in class org.infinispan.rest.InfinispanRequest
- urlDecode(Object) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
- urlEncode(Object, MediaType) - Static method in class org.infinispan.commons.dataconversion.StandardConversions
- USE_1_PC_FOR_AUTO_COMMIT_TRANSACTIONS - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- USE_LOCK_STRIPING - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
- USE_SYNCHRONIZATION - Static variable in class org.infinispan.configuration.cache.TransactionConfiguration
- USE_TWO_PHASE_COMMIT - 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
- 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.
- USER - org.infinispan.registry.InternalCacheRegistry.Flag
-
means that this cache is visible to users
- useRequestFormat() - Method in interface org.infinispan.notifications.cachelistener.filter.CacheEventConverter
- userEventTriggered(ChannelHandlerContext, Object) - Method in class org.infinispan.server.core.transport.IdleStateHandlerProvider
- username() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfiguration
- username() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfiguration
- username() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfiguration
- username(String) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- username(String) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
- username(String) - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
-
Specifies the username to be used for authentication.
- USERNAME - org.infinispan.persistence.jdbc.configuration.Attribute
- USERNAME - org.infinispan.persistence.remote.configuration.Attribute
- 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
-
Configures whether the replication happens in a 1PC or 2PC for sync backups.
- usingAsyncStore() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- usingStores() - Method in class org.infinispan.configuration.cache.PersistenceConfiguration
- UTF8 - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- UTF8 - Static variable in class org.infinispan.rest.operations.mediatypes.Charset
-
Default
Charset
- UTF8. - UTF8_COMPAT - Static variable in interface org.infinispan.commons.dataconversion.EncoderIds
- UTF8Encoder - Class in org.infinispan.commons.dataconversion
-
Encoder to/from UTF-8 content using the java string encoding mechanism.
- UTF8Encoder() - Constructor for class org.infinispan.commons.dataconversion.UTF8Encoder
- UTF8StringMarshaller - Class in org.infinispan.commons.marshall
- UTF8StringMarshaller() - Constructor for class org.infinispan.commons.marshall.UTF8StringMarshaller
- 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.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
- Utils - Class in org.infinispan.counter.util
-
Utility methods.
- UUID - Static variable in interface org.infinispan.commons.marshall.Ids
- UuidExternalizer - Class in org.infinispan.marshall.exts
- UuidExternalizer() - Constructor for class org.infinispan.marshall.exts.UuidExternalizer
V
- VALID - org.infinispan.counter.api.CounterState
-
The counter value is valid.
- validate() - Method in class org.infinispan.commons.configuration.attributes.Attribute
- 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
- 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.AuthorizationConfigurationBuilder
- 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.ClusterLoaderConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.CompatibilityModeConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.ContentTypeConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.CustomInterceptorsConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- 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
- validate() - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
- 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.SecurityConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.cache.SingletonStoreConfigurationBuilder
-
Deprecated.
- 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.StoreAsBinaryConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
- 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.VersioningConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- 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.GlobalJmxStatisticsConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.global.GlobalRoleConfigurationBuilder
- 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.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
- 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.internal.PrivateGlobalConfigurationBuilder
- validate() - Method in class org.infinispan.configuration.parsing.ConfigurationBuilderHolder
- validate() - Method in class org.infinispan.counter.configuration.CounterManagerConfigurationBuilder
- validate() - Method in class org.infinispan.counter.configuration.StrongCounterConfigurationBuilder
- validate() - Method in class org.infinispan.lock.configuration.ClusteredLockConfigurationBuilder
- validate() - Method in class org.infinispan.lock.configuration.ClusteredLockManagerConfigurationBuilder
- validate() - Method in class org.infinispan.lucene.cacheloader.configuration.LuceneLoaderConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jdbc.configuration.TableManipulationConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.jpa.configuration.JpaStoreConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfigurationBuilder
-
Deprecated.
- validate() - Method in class org.infinispan.persistence.remote.configuration.AuthenticationConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.remote.configuration.ConnectionPoolConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.remote.configuration.ExecutorFactoryConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.remote.configuration.RemoteServerConfigurationBuilder
- 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.rest.configuration.ConnectionPoolConfigurationBuilder
- validate() - Method in class org.infinispan.persistence.rest.configuration.RestStoreConfigurationBuilder
- 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(boolean) - Method in class org.infinispan.configuration.cache.AbstractStoreConfigurationBuilder
- 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.CompatibilityModeConfigurationBuilder
- 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
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.DeadlockDetectionConfigurationBuilder
-
Deprecated.
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.EvictionConfigurationBuilder
-
Deprecated.
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.ExpirationConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.GroupsConfigurationBuilder
- 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
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.InvocationBatchingConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.JMXStatisticsConfigurationBuilder
- 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.SingletonStoreConfigurationBuilder
-
Deprecated.
- 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.StoreAsBinaryConfigurationBuilder
-
Deprecated.
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.SyncConfigurationBuilder
-
Deprecated.
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.TakeOfflineConfigurationBuilder
- 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.VersioningConfigurationBuilder
-
Deprecated.
- validate(GlobalConfiguration) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.ManagedConnectionFactoryConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.PooledConnectionFactoryConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.SimpleConnectionFactoryConfigurationBuilder
- 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.remote.configuration.RemoteServerConfigurationBuilder
- validate(GlobalConfiguration) - Method in class org.infinispan.persistence.rest.configuration.ConnectionPoolConfigurationBuilder
- validate(T) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- validate(T) - Method in interface org.infinispan.commons.configuration.attributes.AttributeValidator
- validateFlags(EnumSet<CacheContainerAdmin.AdminFlag>) - Method in interface org.infinispan.globalstate.LocalConfigurationStorage
-
Checks whether this
LocalConfigurationStorage
supports the supplied flags. - validateStrongCounterBounds(long, long, long) - Static method in class org.infinispan.counter.util.Utils
-
Validates the lower and upper bound for a strong counter.
- validator(AttributeValidator<? super T>) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- 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.commons.configuration.attributes.Attribute
- value - Variable in class org.infinispan.container.entries.ImmortalCacheEntry
- value - Variable in class org.infinispan.container.entries.ImmortalCacheValue
- value - Variable in class org.infinispan.container.entries.metadata.MetadataMortalCacheEntry
- value - Variable in class org.infinispan.container.entries.metadata.MetadataTransientCacheEntry
- value - Variable in class org.infinispan.container.entries.MortalCacheEntry
- value - Variable in class org.infinispan.container.entries.ReadCommittedEntry
- value - Variable in class org.infinispan.container.entries.TransientCacheEntry
- value - Variable in class org.infinispan.container.entries.TransientMortalCacheEntry
- value - Variable in class org.infinispan.functional.MetaParam.MetaLong
- value - Variable in enum org.infinispan.server.hotrod.tx.table.Status
- value() - Method in annotation type org.infinispan.commons.configuration.BuiltBy
- value() - Method in annotation type org.infinispan.commons.configuration.ConfigurationFor
- value() - Method in annotation type org.infinispan.commons.configuration.ConfiguredBy
- value() - Method in annotation type org.infinispan.commons.marshall.SerializeFunctionWith
-
Specify the externalizer class to be used by the annotated class.
- value() - Method in annotation type org.infinispan.commons.marshall.SerializeWith
-
Specify the externalizer class to be used by the annotated class.
- value() - Method in class org.infinispan.configuration.cache.EncodingConfigurationBuilder
- value() - Method in annotation type org.infinispan.configuration.parsing.Namespaces
- value() - Method in annotation type org.infinispan.configuration.serializing.SerializedWith
- value() - Method in annotation type org.infinispan.factories.annotations.ComponentName
- value() - Method in annotation type org.infinispan.factories.scopes.Scope
- value() - Method in class org.infinispan.xsite.statetransfer.XSiteState
- VALUE - org.infinispan.configuration.parsing.Attribute
- VALUE - org.infinispan.counter.configuration.Attribute
- VALUE - Static variable in interface org.infinispan.query.ProjectionConstants
- VALUE - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- VALUE_DATA_TYPE - org.infinispan.configuration.parsing.Element
- VALUE_EQUIVALENCE - org.infinispan.configuration.parsing.Attribute
- VALUE_SIZE - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- VALUE_SIZE_ESTIMATE - org.infinispan.persistence.remote.configuration.Attribute
- VALUE_TRANSFER - 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
- valueConverter(Class, String) - Static method in class org.infinispan.configuration.parsing.XmlConfigHelper
- valueDataType() - Method in class org.infinispan.configuration.cache.EncodingConfiguration
- valueEquivalence() - Method in class org.infinispan.configuration.cache.DataContainerConfiguration
-
Deprecated.Equivalence is no longer used. This will be removed in the future. Only returns
AnyEquivalence
- valueEquivalence(Equivalence<V>) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.Equivalence is to be removed (byte[] are directly supported)
- valueMatcher() - Method 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.
- 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.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.query.clustered.commandworkers.CQCommandType
-
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.commons.api.CacheContainerAdmin.AdminFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.commons.equivalence.EquivalentLinkedHashMap.IterationOrder
-
Deprecated.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.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
-
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.Index
-
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.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.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.Parser.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.configuration.parsing.Parser.TransactionMode
-
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.distexec.DistributedTaskExecutionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.distribution.DataLocality
-
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.EvictionThreadPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.eviction.EvictionType
-
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.interceptors.locking.ClusteringDependentLogic.Commit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.jmx.annotations.DataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.jmx.annotations.DisplayType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.jmx.annotations.MeasurementType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.jmx.annotations.Units
-
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.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.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.jdbc.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.jdbc.DatabaseType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.jpa.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.jpa.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.leveldb.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.leveldb.configuration.CompressionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.leveldb.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.leveldb.configuration.LevelDBStoreConfiguration.ImplementationType
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.manager.PersistenceManager.AccessMode
-
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.rest.configuration.Attribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.persistence.rest.configuration.Element
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.query.clustered.commandworkers.CQCommandType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.query.dsl.IndexedQueryMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.query.dsl.SortOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.query.FetchOptions.FetchMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.query.remote.client.ContinuousQueryResult.ResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.registry.InternalCacheRegistry.Flag
-
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.inboundhandler.action.BaseLockingAction.InternalState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.remoting.inboundhandler.DeliverOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.remoting.inboundhandler.TopologyMode
-
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.rest.configuration.ExtendedHeaders
-
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.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.statetransfer.RebalanceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.statetransfer.StateRequestCommand.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.stats.container.ExtendedStatistic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.stats.percentiles.PercentileStatistic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.stats.topK.StreamSummaryContainer.Stat
-
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.topology.CacheTopology.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.topology.CacheTopologyControlCommand.Type
-
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.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.TransactionProtocol
-
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.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.BackupSender.BringSiteOnlineResponse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.BackupSender.TakeSiteOfflineResponse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand.StateTransferControl
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.XSiteAdminCommand.AdminOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.xsite.XSiteAdminCommand.Status
-
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. - valueResponse(HotRodHeader, HotRodServer, ByteBufAllocator, OperationStatus, byte[]) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- valueResponse(HotRodHeader, HotRodServer, ByteBufAllocator, OperationStatus, 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 - Variable in class org.infinispan.interceptors.distribution.VersionedResults
- 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.commons.api.CacheContainerAdmin.AdminFlag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.infinispan.commons.equivalence.EquivalentHashMap
-
Deprecated.
- values() - Static method in enum org.infinispan.commons.equivalence.EquivalentLinkedHashMap.IterationOrder
-
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.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.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() - Method in class org.infinispan.commons.util.concurrent.ConcurrentWeakKeyHashMap
-
Returns a
Collection
view of the values contained in this map. - 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
-
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.Index
-
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.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.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.Parser.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.Parser.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.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() - Method in interface org.infinispan.container.DataContainer
-
Deprecated.Please use iterator method if bulk operations are required.
- 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.distexec.DistributedTaskExecutionPolicy
-
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
-
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.EvictionThreadPolicy
-
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
-
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.interceptors.locking.ClusteringDependentLogic.Commit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.jmx.annotations.DataType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.jmx.annotations.DisplayType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.jmx.annotations.MeasurementType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.jmx.annotations.Units
-
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.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.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.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.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.jpa.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.jpa.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.leveldb.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.leveldb.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.leveldb.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.leveldb.configuration.LevelDBStoreConfiguration.ImplementationType
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.persistence.manager.PersistenceManager.AccessMode
-
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.rest.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.rest.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.query.clustered.commandworkers.CQCommandType
-
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.IndexedQueryMode
-
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
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.query.FetchOptions.FetchMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.query.remote.client.ContinuousQueryResult.ResultType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.registry.InternalCacheRegistry.Flag
-
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.inboundhandler.action.BaseLockingAction.InternalState
-
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.DeliverOrder
-
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.TopologyMode
-
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.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.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() - 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.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.statetransfer.RebalanceType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.statetransfer.StateRequestCommand.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.stats.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.stats.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.stats.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.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.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.CacheTopologyControlCommand.Type
-
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.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.TransactionProtocol
-
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.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.BackupSender.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.BackupSender.TakeSiteOfflineResponse
-
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.XSiteStateTransferControlCommand.StateTransferControl
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.xsite.XSiteAdminCommand.AdminOperation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.infinispan.xsite.XSiteAdminCommand.Status
-
Returns an array containing the constants of this enum type, in the order they are declared.
- Values() - Constructor for class org.infinispan.commons.equivalence.EquivalentHashMap.Values
-
Deprecated.
- Values() - Constructor for class org.infinispan.commons.util.FastCopyHashMap.Values
- valuesFuture(int) - Method in interface org.infinispan.scattered.ScatteredVersionManager
- valueSizeEstimate() - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfiguration
- valueSizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.AbstractRemoteStoreConfigurationChildBuilder
- valueSizeEstimate(int) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- valueSizeEstimate(int) - Method in interface org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationChildBuilder
-
This hint allows sizing of byte buffers when serializing and deserializing values, to minimize array resizing.
- valueWithVersionResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[], long) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- valueWithVersionResponse(HotRodHeader, HotRodServer, ByteBufAllocator, byte[], long) - Method in interface org.infinispan.server.hotrod.VersionedEncoder
- VerbosityRequest - org.infinispan.server.memcached.MemcachedOperation
- version - Variable in class org.infinispan.container.versioning.SimpleClusteredVersion
- version - Variable in class org.infinispan.interceptors.distribution.VersionedResult
- version - Variable in class org.infinispan.metadata.EmbeddedMetadata.Builder
- version - Variable in class org.infinispan.server.memcached.MemcachedMetadata
- version() - Method in class org.infinispan.configuration.global.SerializationConfiguration
- version() - Method in class org.infinispan.container.entries.RemoteMetadata
- version() - Method in class org.infinispan.metadata.EmbeddedMetadata
- version() - Method in interface org.infinispan.metadata.Metadata
-
Returns the version of the cache entry with which this metadata object is associated.
- version() - Method in class org.infinispan.rest.operations.mime.MimeMetadata
- version() - Method in class org.infinispan.server.memcached.MemcachedMetadata
- version(short) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
-
Largest allowable version to use when marshalling internal state.
- version(String) - Method in class org.infinispan.configuration.global.SerializationConfigurationBuilder
-
Largest allowable version to use when marshalling internal state.
- 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
-
Contains version information about this release of Infinispan.
- VERSION - org.infinispan.configuration.parsing.Attribute
- VERSION - Static variable in class org.infinispan.configuration.global.SerializationConfiguration
- VERSION_10 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_11 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_12 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_13 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- 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_23 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_24 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_25 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_26 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_27 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_28 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- VERSION_29 - Static variable in interface org.infinispan.server.hotrod.HotRodConstants
- Versioned - Interface in org.infinispan.container.entries.versioned
-
An interface that marks the ability to handle versions
- VERSIONED_RESULT - Static variable in interface org.infinispan.commons.marshall.Ids
- VERSIONED_RESULTS - Static variable in interface org.infinispan.commons.marshall.Ids
- VersionedDistributionInterceptor - Class in org.infinispan.interceptors.distribution
-
A version of the
TxDistributionInterceptor
that adds logic to handling prepares when entries are versioned. - VersionedDistributionInterceptor() - Constructor for class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
- 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.
- VersionedRepeatableReadEntry - Class in org.infinispan.container.entries
-
A version of RepeatableReadEntry that can perform write-skew checks during prepare.
- VersionedRepeatableReadEntry(Object, Object, Metadata) - Constructor for class org.infinispan.container.entries.VersionedRepeatableReadEntry
- VersionedResult - Class in org.infinispan.interceptors.distribution
- VersionedResult(Object, EntryVersion) - Constructor for class org.infinispan.interceptors.distribution.VersionedResult
- VersionedResult.Externalizer - Class in org.infinispan.interceptors.distribution
- VersionedResults - Class in org.infinispan.interceptors.distribution
- VersionedResults(Object[], EntryVersion[]) - Constructor for class org.infinispan.interceptors.distribution.VersionedResults
- VersionedResults.Externalizer - Class in org.infinispan.interceptors.distribution
- 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() - Method in class org.infinispan.configuration.cache.Configuration
-
Deprecated.since 9.0. Infinispan automatically enables versioning when needed.
- versioning() - Method in class org.infinispan.configuration.cache.ConfigurationBuilder
- versioning() - Method in interface org.infinispan.configuration.cache.ConfigurationChildBuilder
-
Deprecated.since 9.0. Infinispan automatically enables versioning when needed.
- VERSIONING - org.infinispan.configuration.parsing.Element
- VERSIONING_SCHEME - org.infinispan.configuration.parsing.Attribute
- VersioningConfiguration - Class in org.infinispan.configuration.cache
-
Deprecated.since 9.0. Infinispan automatically enable versioning when needed.
- VersioningConfigurationBuilder - Class in org.infinispan.configuration.cache
-
Deprecated.since 9.0. Infinispan automatically enable versioning when needed.
- VersioningConfigurationBuilder(ConfigurationBuilder) - Constructor for class org.infinispan.configuration.cache.VersioningConfigurationBuilder
-
Deprecated.
- VersioningScheme - Enum in org.infinispan.configuration.cache
-
The various versioning schemes supported
- VersionRequest - org.infinispan.server.memcached.MemcachedOperation
- versions - Variable in class org.infinispan.interceptors.distribution.VersionedResults
- VIEW_CHANGED - 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.persistence.support.SingletonCacheWriter.SingletonStoreListener
-
Deprecated.The cluster formation changed, so determine whether the current cache stopped being the coordinator or became the coordinator.
- 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
- visit(ChunkCacheKey) - Method in interface org.infinispan.lucene.KeyVisitor
- visit(FileCacheKey) - Method in interface org.infinispan.lucene.KeyVisitor
- visit(FileListCacheKey) - Method in interface org.infinispan.lucene.KeyVisitor
- visit(FileReadLockKey) - Method in interface org.infinispan.lucene.KeyVisitor
- visitAddWork(AddLuceneWork, KeyTransformationHandler) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitClearCommand(InvocationContext, ClearCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- 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.base.CommandInterceptor
-
Deprecated.
- visitCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.statetransfer.TransactionSynchronizerInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.xsite.OptimisticBackupInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.interceptors.xsite.PessimisticBackupInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitCommitCommand(TxInvocationContext, CommitCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitComputeCommand(InvocationContext, ComputeCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitComputeIfAbsentCommand(InvocationContext, ComputeIfAbsentCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitDataReadCommand(InvocationContext, DataCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitDataReadCommand(InvocationContext, DataCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
- visitDataReadCommand(InvocationContext, DataCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
- visitDataReadCommand(InvocationContext, DataCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
- visitDataWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitDataWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.locking.NonTransactionalLockingInterceptor
- visitDataWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
- visitDataWriteCommand(InvocationContext, DataWriteCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
- visitDataWriteCommand(InvocationContext, DataWriteCommand, boolean) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitDeleteByQueryWork(DeleteByQueryLuceneWork, KeyTransformationHandler) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
- visitDeleteWork(DeleteLuceneWork, KeyTransformationHandler) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
- visitDistributedExecuteCommand(InvocationContext, DistributedExecuteCommand<V>) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitEntrySetCommand(InvocationContext, EntrySetCommand) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor
- visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitEvictCommand(InvocationContext, EvictCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitFlushWork(FlushLuceneWork, KeyTransformationHandler) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- visitGetAllCommand(InvocationContext, GetAllCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitGetCacheEntryCommand(InvocationContext, GetCacheEntryCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- visitGetKeysInGroupCommand(InvocationContext, GetKeysInGroupCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- visitGetKeyValueCommand(InvocationContext, GetKeyValueCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitInvalidateCommand(InvocationContext, InvalidateCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitInvalidateL1Command(InvocationContext, InvalidateL1Command) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitKeySetCommand(InvocationContext, KeySetCommand) - Method in class org.infinispan.interceptors.distribution.DistributionBulkInterceptor
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderInterceptor
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitLockControlCommand(TxInvocationContext, LockControlCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitOptimizeWork(OptimizeLuceneWork, KeyTransformationHandler) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.locking.OptimisticLockingInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.locking.PessimisticLockingInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderStateTransferInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedEntryWrappingInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.interceptors.xsite.BaseBackupInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- visitPrepareCommand(TxInvocationContext, PrepareCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitPurgeAllWork(PurgeAllLuceneWork, KeyTransformationHandler) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.stats.topK.CacheUsageInterceptor
- visitPutKeyValueCommand(InvocationContext, PutKeyValueCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitPutMapCommand(InvocationContext, PutMapCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitReadOnlyKeyCommand(InvocationContext, ReadOnlyKeyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitReadOnlyManyCommand(InvocationContext, ReadOnlyManyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitReadWriteKeyCommand(InvocationContext, ReadWriteKeyCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitReadWriteKeyValueCommand(InvocationContext, ReadWriteKeyValueCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitReadWriteManyCommand(InvocationContext, ReadWriteManyCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitReadWriteManyEntriesCommand(InvocationContext, ReadWriteManyEntriesCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitRemoveCommand(InvocationContext, RemoveCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.L1TxInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitReplaceCommand(InvocationContext, ReplaceCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.locking.AbstractTxLockingInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderDistributionInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.totalorder.TotalOrderVersionedDistributionInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.interceptors.xsite.OptimisticBackupInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.statetransfer.AffectedKeysVisitor
-
Deprecated.
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitRollbackCommand(TxInvocationContext, RollbackCommand) - Method in class org.infinispan.stats.wrappers.ExtendedStatisticInterceptor
- visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.base.PrePostProcessingCommandInterceptor
-
Deprecated.
- visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitSizeCommand(InvocationContext, SizeCommand) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- visitUnknownCommand(InvocationContext, VisitableCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitUpdateWork(UpdateLuceneWork, KeyTransformationHandler) - Method in class org.infinispan.query.indexmanager.LuceneWorkTransformationVisitor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitWriteOnlyKeyCommand(InvocationContext, WriteOnlyKeyCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseGenerator
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor.PrimaryResponseHandler
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitWriteOnlyKeyValueCommand(InvocationContext, WriteOnlyKeyValueCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitWriteOnlyManyCommand(InvocationContext, WriteOnlyManyCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.DDAsyncInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.L1LastChanceInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.L1NonTxInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.NonTxDistributionInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.ScatteredDistributionInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.TriangleDistributionInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.distribution.TxDistributionInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.locking.AbstractLockingInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.interceptors.xsite.NonTransactionalBackupInterceptor
- visitWriteOnlyManyEntriesCommand(InvocationContext, WriteOnlyManyEntriesCommand) - Method in class org.infinispan.statetransfer.StateTransferInterceptor
- 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
- voidMerge(ValidResponse, Void) - Static method in class org.infinispan.util.TriangleFunctionsUtil
- VOLATILE - org.infinispan.counter.api.Storage
-
The counter value is lost when the cluster is restarted/stopped.
- VOLATILE - org.infinispan.globalstate.ConfigurationStorage
-
Stores cache configurations in volatile storage.
- VOLATILE_CONFIGURATION_STORAGE - org.infinispan.configuration.parsing.Element
W
- WAIT - org.infinispan.persistence.remote.configuration.ExhaustedAction
- WAIT_FOR_VALID_RESPONSE - org.infinispan.remoting.rpc.ResponseMode
- WAIT_TIME - org.infinispan.configuration.parsing.Attribute
- WAIT_TIME - Static variable in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- WAIT_TOPOLOGY - org.infinispan.remoting.inboundhandler.TopologyMode
- WAIT_TX_DATA - org.infinispan.remoting.inboundhandler.TopologyMode
- 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
- waitForInitialStateTransferToComplete() - Method in interface org.infinispan.statetransfer.StateTransferManager
- waitForInitialStateTransferToComplete() - Method in class org.infinispan.statetransfer.StateTransferManagerImpl
- waitForLockRelease(long) - Method in interface org.infinispan.transaction.xa.CacheTransaction
-
Deprecated.
- waitForTopology(int, long, TimeUnit) - Method in interface org.infinispan.statetransfer.StateTransferLock
-
Deprecated.
- waitForTransactionData(int, long, TimeUnit) - Method in interface org.infinispan.statetransfer.StateTransferLock
-
Deprecated.
- waitForView(int) - Method in class org.infinispan.remoting.transport.AbstractDelegatingTransport
- waitForView(int) - Method in class org.infinispan.remoting.transport.jgroups.JGroupsTransport
- waitForView(int) - Method in interface org.infinispan.remoting.transport.Transport
-
Deprecated.Since 9.0, please use
Transport.withView(int)
instead. - waitFuture(Object) - Method in interface org.infinispan.persistence.manager.OrderedUpdatesManager
- waitFuture(Object) - Method in class org.infinispan.persistence.manager.OrderedUpdatesManagerImpl
- WAITING - org.infinispan.util.concurrent.locks.LockState
-
The lock owner is in the queue waiting for the lock to be available.
- waitingForState - Variable in class org.infinispan.statetransfer.StateConsumerImpl
-
Indicates if there is a rebalance in progress and there the local node has not yet received all the new segments yet.
- waitTime() - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfiguration
- waitTime(long) - Method in class org.infinispan.configuration.cache.XSiteStateTransferConfigurationBuilder
-
The waiting 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 - org.infinispan.configuration.cache.BackupFailurePolicy
- WEAK - org.infinispan.counter.api.CounterType
-
A weak consistent counter.
- WEAK_COUNTER - org.infinispan.counter.configuration.Element
- 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. - 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 - org.infinispan.commons.tx.lookup.LookupNames.JndiTransactionManager
- WEBSPHERE_4 - org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- WEBSPHERE_51_6 - org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- WEBSPHERE_6 - org.infinispan.commons.tx.lookup.LookupNames.TransactionManagerFactory
- WHEN_SPLIT - org.infinispan.configuration.parsing.Attribute
- WHEN_SPLIT - Static variable in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- whenSplit() - Method in class org.infinispan.configuration.cache.PartitionHandlingConfiguration
- whenSplit(PartitionHandling) - Method in class org.infinispan.configuration.cache.PartitionHandlingConfigurationBuilder
- WILDFLY - 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
- 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(CacheEventFilter<? super K, ? super V>, CacheEventConverter<? super K, ? super V, C>) - Method in class org.infinispan.notifications.cachelistener.CacheNotifierImpl.CacheInvocationBuilder
- with(ClassLoader) - Method in interface org.infinispan.AdvancedCache
-
Deprecated.Since 9.4, the classloader is ignored.
- 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
- withEncoding(Class<? extends Encoder>) - Method in interface org.infinispan.AdvancedCache
-
Performs any cache operations using the specified
Encoder
. - withEncoding(Class<? extends Encoder>) - Method in class org.infinispan.encoding.DataConversion
- withEncoding(Class<? extends Encoder>, Class<? extends Encoder>) - Method in interface org.infinispan.AdvancedCache
-
Performs any cache operations using the specified pair of
Encoder
. - withException(Address, Exception) - Method in class org.infinispan.remoting.transport.ValidSingleResponseCollector
- 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(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(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
-
A method that adds flags to any API call.
- 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
- withMediaType(String, String) - Method in interface org.infinispan.AdvancedCache
-
Perform any cache operations using an alternate
MediaType
. - withoutParameters() - Method in class org.infinispan.commons.dataconversion.MediaType
- 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 based on current one and the given parameters.
- 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. - 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.ClusterLoaderConfigurationBuilder
- withProperties(Properties) - Method in class org.infinispan.configuration.cache.DataContainerConfigurationBuilder
-
Deprecated.Set key/value properties to this
DataContainer
configuration - withProperties(Properties) - Method in class org.infinispan.configuration.cache.IndexingConfigurationBuilder
-
The Query engine relies on properties for configuration.
- withProperties(Properties) - Method in class org.infinispan.configuration.cache.InterceptorConfigurationBuilder
-
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.GlobalJmxStatisticsConfigurationBuilder
-
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.jdbc.configuration.JdbcStringBasedStoreConfigurationBuilder
- withProperties(Properties) - Method in class org.infinispan.persistence.remote.configuration.RemoteStoreConfigurationBuilder
- withRequestMediaType(MediaType) - Method in class org.infinispan.encoding.DataConversion
- withSubject(Subject) - Method in interface org.infinispan.AdvancedCache
-
Performs any cache operations using the specified
Subject
. - 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
-
Performs any cache operations using the specified
Wrapper
. - withWrapping(Class<? extends Wrapper>) - Method in class org.infinispan.encoding.DataConversion
- withWrapping(Class<? extends Wrapper>, Class<? extends Wrapper>) - Method in interface org.infinispan.AdvancedCache
-
Performs any cache operations using the specified pair of
Wrapper
. - WORKER_THREADS - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- workerThreads() - Method in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- workerThreads(int) - Method in class org.infinispan.rest.configuration.RestServerConfigurationBuilder
- workerThreads(int) - Method in class org.infinispan.server.core.configuration.AbstractProtocolServerConfigurationChildBuilder
- workerThreads(int) - Method in class org.infinispan.server.core.configuration.ProtocolServerConfigurationBuilder
- workerThreads(int) - Method in interface org.infinispan.server.core.configuration.ProtocolServerConfigurationChildBuilder
-
Sets the number of worker threads
- wouldLose(DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction
-
Deprecated.
- WR_LOCAL_EXECUTION - org.infinispan.stats.percentiles.PercentileStatistic
- WR_REMOTE_EXECUTION - org.infinispan.stats.percentiles.PercentileStatistic
- WR_TX_ABORTED_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- WR_TX_SUCCESSFUL_EXECUTION_TIME - org.infinispan.stats.container.ExtendedStatistic
- 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
- wrapFunctionalManyResultOnNonOrigin(InvocationContext, Collection<?>, Object[]) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- wrapFunctionalManyResultOnNonOrigin(InvocationContext, Collection<?>, Object[]) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
- wrapFunctionalResultOnNonOriginOnReturn(Object, CacheEntry) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- wrapFunctionalResultOnNonOriginOnReturn(Object, CacheEntry) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
- WRAPPED_BYTE_ARRAY - Static variable in interface org.infinispan.commons.marshall.Ids
- 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
- 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
- wrapRemoteEntry(InvocationContext, Object, CacheEntry, boolean) - Method in class org.infinispan.interceptors.distribution.BaseDistributionInterceptor
- wrapRemoteEntry(InvocationContext, Object, CacheEntry, boolean) - Method in class org.infinispan.interceptors.distribution.VersionedDistributionInterceptor
- wrapRemoteException(Address, Throwable) - Static method in class org.infinispan.remoting.transport.ResponseCollectors
- writable() - Method in annotation type org.infinispan.jmx.annotations.ManagedAttribute
- WritableGridFileChannel - Class in org.infinispan.io
- write(byte[]) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- write(byte[]) - Method in class org.infinispan.io.GridOutputStream
- write(byte[]) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- write(byte[], int, int) - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
- write(byte[], int, int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- write(byte[], int, int) - Method in class org.infinispan.commons.util.Base64.OutputStream
-
Deprecated.Calls
Base64.OutputStream.write(int)
repeatedly until len bytes are written. - write(byte[], int, int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
- write(byte[], int, int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
-
Deprecated.
- write(byte[], int, int) - Method in class org.infinispan.io.GridOutputStream
- write(byte[], int, int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- write(int) - Method in class org.infinispan.commons.io.ExposedByteArrayOutputStream
- write(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- write(int) - Method in class org.infinispan.commons.util.Base64.OutputStream
-
Deprecated.Writes the byte to the output stream after converting to/from Base64 notation.
- write(int) - Method in class org.infinispan.io.ExpandableMarshalledValueByteStream
- write(int) - Method in class org.infinispan.io.ExposedByteArrayOutputStream
-
Deprecated.
- write(int) - Method in class org.infinispan.io.GridOutputStream
- write(int) - Method in class org.infinispan.io.ImmutableMarshalledValueByteStream
- write(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- write(int, MarshalledEntry<? extends K, ? extends V>) - Method in interface org.infinispan.persistence.spi.SegmentedAdvancedLoadWriteStore
-
Persists the entry to the storage with the given segment to optimize further lookups based on
- write(int, MarshalledEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- 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.cors.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(ByteBuffer) - Method in class org.infinispan.io.WritableGridFileChannel
- write(XMLStreamWriter) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writes the attributes of this attributeset as part of the current element
- write(XMLStreamWriter, String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writes this attributeset to the specified XMLStreamWriter as an element
- write(XMLStreamWriter, String, AttributeDefinition<?>...) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writes the specified attributes in this attributeset to the specified XMLStreamWriter as an element
- write(XMLStreamWriter, AttributeDefinition<?>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writer a single attribute to the specified
XMLStreamWriter
using the attribute's xmlName - write(XMLStreamWriter, AttributeDefinition<?>, Enum<?>) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writer a single attribute to the specified
XMLStreamWriter
using the supplied name - write(XMLStreamWriter, AttributeDefinition<?>, String) - Method in class org.infinispan.commons.configuration.attributes.AttributeSet
-
Writer a single attribute to the specified
XMLStreamWriter
using the supplied name - write(MarshalledEntry) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- write(MarshalledEntry) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- write(MarshalledEntry) - Method in class org.infinispan.persistence.jpa.JpaStore
- write(MarshalledEntry) - Method in class org.infinispan.persistence.remote.RemoteStore
- write(MarshalledEntry) - Method in class org.infinispan.persistence.rest.RestStore
-
Deprecated.
- write(MarshalledEntry) - Method in class org.infinispan.persistence.support.DelegatingCacheWriter
- write(MarshalledEntry) - Method in class org.infinispan.persistence.support.SingletonCacheWriter
-
Deprecated.
- write(MarshalledEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.file.SingleFileStore
- write(MarshalledEntry<? extends K, ? extends V>) - Method in interface org.infinispan.persistence.spi.CacheWriter
-
Persists the entry to the storage.
- write(MarshalledEntry<? extends K, ? extends V>) - Method in class org.infinispan.persistence.support.AbstractSegmentedAdvancedLoadWriteStore
- WRITE - org.infinispan.security.AuthorizationPermission
-
Allows writing data to a cache
- WRITE_BEHIND - org.infinispan.configuration.parsing.Element
- WRITE_SKEW_CHECK - org.infinispan.configuration.parsing.Attribute
- WRITE_SKEW_CHECK - Static variable in class org.infinispan.configuration.cache.LockingConfiguration
- WRITE_SKEW_PROBABILITY - org.infinispan.stats.container.ExtendedStatistic
- WRITE_TX_PERCENTAGE - org.infinispan.stats.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
- writeAttribute(Enum<?>, String) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- writeAttribute(Enum<?>, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeAttribute(String, Iterable<String>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- writeAttribute(String, Iterable<String>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeAttribute(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeAttribute(String, String[]) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- writeAttribute(String, String[]) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeAttribute(String, String, Iterable<String>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- writeAttribute(String, String, Iterable<String>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeAttribute(String, String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeAttribute(String, String, String[]) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- writeAttribute(String, String, String[]) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeAttribute(String, String, String, Iterable<String>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- writeAttribute(String, String, String, Iterable<String>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeAttribute(String, String, String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeAttribute(String, String, String, String[]) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- writeAttribute(String, String, String, String[]) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeBackups() - Method in class org.infinispan.distribution.DistributionInfo
- writeBatch(Iterable) - Method in class org.infinispan.persistence.async.AsyncCacheWriter
- writeBatch(Iterable<MarshalledEntry<? extends K, ? extends V>>) - Method in class org.infinispan.persistence.jdbc.stringbased.JdbcStringBasedStore
- writeBatch(Iterable<MarshalledEntry<? extends K, ? extends V>>) - Method in class org.infinispan.persistence.jpa.JpaStore
- writeBatch(Iterable<MarshalledEntry<? extends K, ? extends V>>) - Method in class org.infinispan.persistence.remote.RemoteStore
- writeBatch(Iterable<MarshalledEntry<? extends K, ? extends V>>) - Method in interface org.infinispan.persistence.spi.CacheWriter
-
Persist all provided entries to the store in a single batch update.
- writeBatch(Iterable<MarshalledEntry<? extends K, ? extends V>>) - Method in class org.infinispan.persistence.support.ComposedSegmentedLoadWriteStore
- writeBatchToAllNonTxStores(Iterable<MarshalledEntry>, Predicate<? super StoreConfiguration>, long) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Write all entries to the underlying non-transactional stores as a single batch.
- writeBatchToAllNonTxStores(Iterable<MarshalledEntry>, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- writeBatchToAllNonTxStores(Iterable<MarshalledEntry>, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- writeBoolean(boolean) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeBoolean(boolean) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeByte(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeByte(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeBytes(String) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeBytes(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeCData(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeChar(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeChar(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeCharacters(char[], int, int) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeCharacters(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeChars(String) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeChars(String) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- 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 class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeCommonStoreElements(XMLExtendedStreamWriter, StoreConfiguration) - Method in class org.infinispan.configuration.serializing.AbstractStoreSerializer
- writeCommonStoreSubAttributes(XMLExtendedStreamWriter, AbstractStoreConfiguration) - Method in class org.infinispan.configuration.serializing.AbstractStoreSerializer
- writeCounterEvent(ClientCounterEvent, ByteBuf) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- 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 class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeDouble(double) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeDouble(double) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeDTD(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeEmptyElement(Enum<?>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- writeEmptyElement(Enum<?>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeEmptyElement(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeEmptyElement(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeEmptyElement(String, String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeEndDocument() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeEndElement() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeEntityRef(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeEvent(Events.Event, ByteBuf) - Method in class org.infinispan.server.hotrod.AbstractEncoder1x
- 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.commons.util.ImmutableListCopy
-
Format: - entry array size (int) - elements (Object)
- writeExternal(ObjectOutput) - Method in class org.infinispan.io.GridFile.Metadata
- writeExternal(Object, ObjectOutput) - Method in class org.infinispan.commons.marshall.jboss.JBossExternalizerAdapter
- writeFileListAsynchronously(boolean) - Method in interface org.infinispan.lucene.directory.BuildContext
-
When set to true, the list of files of the Directory is propagated to other nodes asynchronously.
- writeFloat(float) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeFloat(float) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeGlobalState() - Method in interface org.infinispan.globalstate.GlobalStateManager
-
Persists the global state by contacting all registered scope providers
- writeInt(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeInt(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeJdbcStoreAttributes(XMLExtendedStreamWriter, AbstractJdbcStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationSerializer
- writeJDBCStoreConnection(XMLExtendedStreamWriter, AbstractJdbcStoreConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationSerializer
- writeJDBCStoreTable(XMLExtendedStreamWriter, Element, TableManipulationConfiguration) - Method in class org.infinispan.persistence.jdbc.configuration.AbstractJdbcStoreConfigurationSerializer
- writeLong(long) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeLong(long) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeMetadata(int, int, long, long, long, ByteBuf) - Static method in class org.infinispan.server.hotrod.MetadataUtils
- writeNamespace(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- 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.stream.StreamMarshalling.StreamMarshallingExternalizer
- 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, DeltaCompositeKey) - Method in class org.infinispan.atomic.DeltaCompositeKey.DeltaCompositeKeyExternalizer
-
Deprecated.
- 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, Equivalence) - Method in class org.infinispan.commons.marshall.exts.EquivalenceExternalizer
- 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, IntSet) - Method in class org.infinispan.util.IntSetExternalizer
- writeObject(ObjectOutput, KeyValueWithPrevious) - Method in class org.infinispan.commons.util.KeyValueWithPrevious.KeyValueWithPreviousExternalizer
- writeObject(ObjectOutput, BiFunctionMapper) - Method in class org.infinispan.compat.BiFunctionMapper.Externalizer
- writeObject(ObjectOutput, FunctionMapper) - Method in class org.infinispan.compat.FunctionMapper.Externalizer
- 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, DataConversion) - Method in class org.infinispan.encoding.DataConversion.Externalizer
- writeObject(ObjectOutput, AcceptAllKeyValueFilter) - Method in class org.infinispan.filter.AcceptAllKeyValueFilter.Externalizer
- writeObject(ObjectOutput, CollectionKeyFilter) - Method in class org.infinispan.filter.CollectionKeyFilter.Externalizer
- writeObject(ObjectOutput, CompositeKeyFilter) - Method in class org.infinispan.filter.CompositeKeyFilter.Externalizer
- writeObject(ObjectOutput, CompositeKeyValueFilter) - Method in class org.infinispan.filter.CompositeKeyValueFilter.Externalizer
- writeObject(ObjectOutput, KeyFilterAsKeyValueFilter) - Method in class org.infinispan.filter.KeyFilterAsKeyValueFilter.Externalizer
- writeObject(ObjectOutput, KeyValueFilterAsKeyFilter) - Method in class org.infinispan.filter.KeyValueFilterAsKeyFilter.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, ScopedState) - Method in class org.infinispan.globalstate.ScopedState.Externalizer
- writeObject(ObjectOutput, ScopeFilter) - Method in class org.infinispan.globalstate.ScopeFilter.Externalizer
- writeObject(ObjectOutput, VersionedResult) - Method in class org.infinispan.interceptors.distribution.VersionedResult.Externalizer
- writeObject(ObjectOutput, VersionedResults) - Method in class org.infinispan.interceptors.distribution.VersionedResults.Externalizer
- writeObject(ObjectOutput, ChunkCacheKey) - Method in class org.infinispan.lucene.ChunkCacheKey.Externalizer
- writeObject(ObjectOutput, FileCacheKey) - Method in class org.infinispan.lucene.FileCacheKey.Externalizer
- writeObject(ObjectOutput, FileListCacheKey) - Method in class org.infinispan.lucene.FileListCacheKey.Externalizer
- writeObject(ObjectOutput, FileMetadata) - Method in class org.infinispan.lucene.FileMetadata.Externalizer
- writeObject(ObjectOutput, FileReadLockKey) - Method in class org.infinispan.lucene.FileReadLockKey.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, MarshalledEntryImpl) - Method in class org.infinispan.marshall.core.MarshalledEntryImpl.Externalizer
- writeObject(ObjectOutput, EmbeddedMetadata) - Method in class org.infinispan.metadata.EmbeddedMetadata.Externalizer
- writeObject(ObjectOutput, ClusterEvent) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEvent.Externalizer
- writeObject(ObjectOutput, ClusterEventCallable) - Method in class org.infinispan.notifications.cachelistener.cluster.ClusterEventCallable.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, MultiClusterEventCallable) - Method in class org.infinispan.notifications.cachelistener.cluster.MultiClusterEventCallable.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, KeyFilterAsCacheEventFilter) - Method in class org.infinispan.notifications.cachelistener.filter.KeyFilterAsCacheEventFilter.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, MigrationTask) - Method in class org.infinispan.persistence.remote.upgrade.MigrationTask.Externalizer
- writeObject(ObjectOutput, NodeTopDocs) - Method in class org.infinispan.query.clustered.NodeTopDocs.Externalizer
- writeObject(ObjectOutput, QueryResponse) - Method in class org.infinispan.query.clustered.QueryResponse.Externalizer
- writeObject(ObjectOutput, QueryRequest) - Method in class org.infinispan.query.remote.client.Externalizers.QueryRequestExternalizer
- writeObject(ObjectOutput, QueryRequest.NamedParameter) - Method in class org.infinispan.query.remote.client.Externalizers.NamedParameterExternalizer
- writeObject(ObjectOutput, QueryResponse) - Method in class org.infinispan.query.remote.client.Externalizers.QueryResponseExternalizer
- writeObject(ObjectOutput, MIMECacheEntry) - Method in class org.infinispan.remoting.MIMECacheEntry.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, MimeMetadata) - Method in class org.infinispan.rest.operations.mime.MimeMetadata.Externalizer
- writeObject(ObjectOutput, InetAddressPrincipal) - Method in class org.infinispan.server.core.security.InetAddressPrincipal.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, SimpleUserPrincipal) - Method in class org.infinispan.server.core.security.simple.SimpleUserPrincipal.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, MemcachedMetadata) - Method in class org.infinispan.server.memcached.MemcachedMetadataExternalizer
- writeObject(ObjectOutput, StateChunk) - Method in class org.infinispan.statetransfer.StateChunk.Externalizer
- writeObject(ObjectOutput, TransactionInfo) - Method in class org.infinispan.statetransfer.TransactionInfo.Externalizer
- 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, DldGlobalTransaction) - Method in class org.infinispan.transaction.xa.DldGlobalTransaction.Externalizer
-
Deprecated.
- writeObject(ObjectOutput, InDoubtTxInfoImpl) - Method in class org.infinispan.transaction.xa.recovery.InDoubtTxInfoImpl.Externalizer
- writeObject(ObjectOutput, RecoveryAwareDldGlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareDldGlobalTransaction.Externalizer
-
Deprecated.
- writeObject(ObjectOutput, RecoveryAwareGlobalTransaction) - Method in class org.infinispan.transaction.xa.recovery.RecoveryAwareGlobalTransaction.Externalizer
- writeObject(ObjectOutput, SerializableXid) - Method in class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
-
Deprecated.
- writeObject(ObjectOutput, ByteString) - Static method in class org.infinispan.util.ByteString
- writeObject(ObjectOutput, KeyValuePair) - Method in class org.infinispan.util.KeyValuePair.Externalizer
- writeObject(ObjectOutput, XSiteState) - Method in class org.infinispan.xsite.statetransfer.XSiteState.XSiteStateExternalizer
- writeObject(ObjectOutput, T) - Method in interface org.infinispan.commons.marshall.Externalizer
-
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(ObjectOutput, T) - Method in class org.infinispan.transaction.xa.GlobalTransaction.AbstractGlobalTxExternalizer
- writeObject(Object) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeObject(Object) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeOptional(XMLExtendedStreamWriter, 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
- writeProcessingInstruction(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeProcessingInstruction(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- 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
- writeResponse(Channel, Object) - Method in class org.infinispan.server.memcached.MemcachedDecoder
- writeResponse(HotRodHeader, ByteBuf) - Method in class org.infinispan.server.hotrod.BaseRequestProcessor
- writeScopedState(ScopedPersistentState) - Method in interface org.infinispan.globalstate.GlobalStateManager
-
Persists the specified scoped state
- writeShort(int) - Method in class org.infinispan.commons.marshall.DelegatingObjectOutput
- writeShort(int) - Method in class org.infinispan.io.UnclosableObjectOutputStream
- writeSignedInt(ObjectOutput, int) - Static method in class org.infinispan.commons.io.SignedNumeric
- writeSignedInt(OutputStream, int) - Static method in class org.infinispan.commons.io.SignedNumeric
- writeSkewCheck() - Method in class org.infinispan.configuration.cache.LockingConfiguration
-
Deprecated.since 9.0.
- writeSkewCheck(boolean) - Method in class org.infinispan.configuration.cache.LockingConfigurationBuilder
-
Deprecated.since 9.0. It will be automatically enabled for OPTIMISTIC and REPEATABLE_READ transactions
- WriteSkewException - Exception in org.infinispan.transaction
-
Thrown when a write skew is detected
- WriteSkewException() - Constructor for exception org.infinispan.transaction.WriteSkewException
- WriteSkewException(Object) - 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
- writeStartDocument() - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeStartDocument(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeStartDocument(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeStartElement(Enum<?>) - Method in interface org.infinispan.configuration.serializing.XMLExtendedStreamWriter
- writeStartElement(Enum<?>) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeStartElement(String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeStartElement(String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- writeStartElement(String, String, String) - Method in class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- 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.server.hotrod.counter.listener.ClientCounterEvent
- writeTo(ObjectOutput) - Method in class org.infinispan.query.clustered.ClusteredQueryCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.query.indexmanager.AbstractUpdateCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.server.hotrod.command.tx.ForwardCommitCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.server.hotrod.command.tx.ForwardRollbackCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.statetransfer.StateRequestCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.statetransfer.StateResponseCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.topology.CacheTopologyControlCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.topology.HeartBeatCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.SingleXSiteRpcCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- writeTo(ObjectOutput) - Method in class org.infinispan.xsite.XSiteAdminCommand
- writeTo(ObjectOutput, E) - Method in interface org.infinispan.commons.marshall.MarshallUtil.ElementWriter
- 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, DataConversion) - Static method in class org.infinispan.encoding.DataConversion
- 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
- writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>) - Method in interface org.infinispan.persistence.manager.PersistenceManager
-
Write to all stores that are not transactional.
- writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>, long) - Method in interface org.infinispan.persistence.manager.PersistenceManager
- writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerImpl
- writeToAllNonTxStores(MarshalledEntry, int, Predicate<? super StoreConfiguration>, long) - Method in class org.infinispan.persistence.manager.PersistenceManagerStub
- writeTypedProperties(XMLExtendedStreamWriter, TypedProperties) - Static method in class org.infinispan.configuration.serializing.SerializeUtils
- 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(ObjectOutput, 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(ObjectOutput, 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
- writeXid(Xid, ByteBuf) - Static method in class org.infinispan.server.hotrod.transport.ExtendedByteBuf
- WrongContextException - Exception in org.infinispan.rest.context
-
Exception indicating wrong context.
- WrongContextException() - Constructor for exception org.infinispan.rest.context.WrongContextException
- WrongDateFormatException - Exception in org.infinispan.rest.operations.exceptions
- WrongDateFormatException(String) - Constructor for exception org.infinispan.rest.operations.exceptions.WrongDateFormatException
- 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 - 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
- XidExternalizer() - Constructor for class org.infinispan.transaction.xa.recovery.SerializableXid.XidExternalizer
-
Deprecated.
- 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
- XmlConfigHelper - Class in org.infinispan.configuration.parsing
-
A simple XML utility class for reading configuration elements
- XmlConfigHelper() - Constructor for class org.infinispan.configuration.parsing.XmlConfigHelper
- XMLExtendedStreamReader - Interface in org.infinispan.configuration.parsing
-
An XML stream reader that can read nested
<xs:any>
content using a registered set of root elements. - XMLExtendedStreamWriter - Interface in org.infinispan.configuration.serializing
- XMLExtendedStreamWriterImpl - Class in org.infinispan.configuration.serializing
-
XMLExtendedStreamWriterImpl.
- XMLExtendedStreamWriterImpl(XMLStreamWriter) - Constructor for class org.infinispan.configuration.serializing.XMLExtendedStreamWriterImpl
- XMLExtendedStreamWriterImpl.ArgRunnable - Interface in org.infinispan.configuration.serializing
- xmlify(String) - Static method in class org.infinispan.commons.util.Util
- xmlName() - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition
- xmlName(String) - Method in class org.infinispan.commons.configuration.attributes.AttributeDefinition.Builder
- XMLStringConfiguration - Class in org.infinispan.commons.configuration
-
A simple wrapper for an XML configuration represented as a String.
- XMLStringConfiguration(String) - Constructor for class org.infinispan.commons.configuration.XMLStringConfiguration
- 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, ClassWhiteList) - Constructor for class org.infinispan.server.core.dataconversion.XMLTranscoder
- XMLTranscoder(ClassWhiteList) - Constructor for class org.infinispan.server.core.dataconversion.XMLTranscoder
- XSiteAdminCommand - Class in org.infinispan.xsite
-
Command used for handling XSiteReplication administrative operations.
- XSiteAdminCommand() - Constructor for class org.infinispan.xsite.XSiteAdminCommand
- XSiteAdminCommand(ByteString) - Constructor for class org.infinispan.xsite.XSiteAdminCommand
- XSiteAdminCommand(ByteString, String, XSiteAdminCommand.AdminOperation, Integer, Long) - Constructor for class org.infinispan.xsite.XSiteAdminCommand
- XSiteAdminCommand.AdminOperation - Enum in org.infinispan.xsite
- XSiteAdminCommand.Status - Enum in org.infinispan.xsite
- XSiteAdminOperations - Class in org.infinispan.xsite
-
Managed bean exposing sys admin operations for Cross-Site replication functionality.
- XSiteAdminOperations() - Constructor for class org.infinispan.xsite.XSiteAdminOperations
- XSiteAsyncAckListener - Interface in org.infinispan.remoting.transport
-
A listener to be notified when an asynchronous cross-site request is completed.
- XSiteBackup - Class in org.infinispan.xsite
- XSiteBackup(String, boolean, long) - Constructor for class org.infinispan.xsite.XSiteBackup
- XSiteReplicateCommand - Class in org.infinispan.xsite
-
Abstract class to invoke RPC on the remote site.
- XSiteReplicateCommand(ByteString) - Constructor for class org.infinispan.xsite.XSiteReplicateCommand
- 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() - 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() - Constructor for class org.infinispan.xsite.statetransfer.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[], long) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStatePushCommand
- 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
- XSiteStateTransferControlCommand - Class in org.infinispan.xsite.statetransfer
-
Command used to control the state transfer between sites.
- XSiteStateTransferControlCommand() - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- XSiteStateTransferControlCommand(ByteString) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- XSiteStateTransferControlCommand(ByteString, XSiteStateTransferControlCommand.StateTransferControl, String) - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferControlCommand
- XSiteStateTransferControlCommand.StateTransferControl - Enum in org.infinispan.xsite.statetransfer
- XSiteStateTransferManager - Interface in org.infinispan.xsite.statetransfer
-
It manages the state transfer between sites.
- XSiteStateTransferManagerImpl - Class in org.infinispan.xsite.statetransfer
-
XSiteStateTransferManager
implementation. - XSiteStateTransferManagerImpl() - Constructor for class org.infinispan.xsite.statetransfer.XSiteStateTransferManagerImpl
Z
- ZERO - Static variable in class org.infinispan.server.memcached.TextProtocolUtil
- ZERO_CAPACITY_NODE - org.infinispan.configuration.parsing.Attribute
- ZERO_CAPACITY_NODE - Static variable in class org.infinispan.server.core.configuration.ProtocolServerConfiguration
- ZERO_LOCK_ACQUISITION_TIMEOUT - org.infinispan.context.Flag
-
Overrides the
LockingConfiguration.lockAcquisitionTimeout(long)
configuration setting by ensuring lock managers use a 0-millisecond lock acquisition timeout. - 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.
_
- _list(Object) - Method in class org.infinispan.io.GridFile
- _listFiles(Object) - Method in class org.infinispan.io.GridFile
All Classes All Packages