All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractCacheEventFilterConverter<K,V,C> |
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)
and Converter.convert(Object, Object, org.infinispan.metadata.Metadata) methods so they just call the
CacheEventFilterConverter.filterAndConvert(Object, Object, org.infinispan.metadata.Metadata, Object, org.infinispan.metadata.Metadata, EventType)
method and then do the right thing.
|
AbstractConfigurationChildBuilder |
AbstractConfigurationChildBuilder.
|
AbstractCustomInterceptorsConfigurationChildBuilder |
Deprecated.
|
AbstractDelegatingCollection<E> |
|
AbstractDelegatingConcurrentMap<K,V> |
|
AbstractDelegatingMap<K,V> |
|
AbstractDelegatingSet<E> |
|
AbstractEntrySizeCalculatorHelper<K,V> |
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.
|
AbstractExternalizer<T> |
Base class for AdvancedExternalizer implementations that offers default
implementations for some of its methods.
|
AbstractFileLookup |
|
AbstractHotRodServerChildConfigurationBuilder |
AbstractHotRodServerChildConfigurationBuilder.
|
AbstractIterator<E> |
|
AbstractJBossMarshaller |
Deprecated.
|
AbstractJBossMarshaller.DebuggingExceptionListener |
|
AbstractJdbcStoreConfiguration |
|
AbstractJdbcStoreConfigurationBuilder<T extends AbstractJdbcStoreConfiguration,S extends AbstractJdbcStoreConfigurationBuilder<T,S>> |
|
AbstractJdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> |
AbstractJdbcStoreConfigurationChildBuilder.
|
AbstractJdbcStoreConfigurationParser |
|
AbstractJdbcStoreConfigurationSerializer |
AbstractJdbcStoreConfigurationSerializer.
|
AbstractKeyValueFilterConverter<K,V,C> |
|
AbstractMap<K,V> |
Similar to the JDK's AbstractMap, this provides common functionality for custom map implementations.
|
AbstractMap.SimpleEntry<K,V> |
|
AbstractMarshaller |
Abstract Marshaller implementation containing shared implementations.
|
AbstractModuleConfigurationBuilder |
AbstractModuleConfigurationBuilder.
|
AbstractPersistenceConfigurationChildBuilder |
AbstractPersistenceConfigurationChildBuilder.
|
AbstractProtocolServerConfigurationChildBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>> |
Helper
|
AbstractRemoteStoreConfigurationChildBuilder<S> |
AbstractRemoteStoreConfigurationChildBuilder.
|
AbstractSchemaJdbcStore<K,V,C extends org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration> |
|
AbstractSchemaJdbcStore.Parameter |
|
AbstractSchemaJdbcStore.ProtoSchemaOptions<K,V,C extends org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration> |
|
AbstractSchemaJdbcStore.ProtostreamFieldType |
|
AbstractSchemaJdbcStore.SchemaTableOperations<K,V,C extends org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration> |
|
AbstractSecurityConfigurationChildBuilder |
AbstractSecurityConfigurationChildBuilder.
|
AbstractSecurityConfigurationChildBuilder |
AbstractSecurityConfigurationChildBuilder.
|
AbstractSegmentedStoreConfiguration<T extends AbstractStoreConfiguration> |
Abstract store configuration that should be extended when the store configuration supports being segmented.
|
AbstractStoreConfiguration |
|
AbstractStoreConfigurationBuilder<T extends StoreConfiguration,S extends AbstractStoreConfigurationBuilder<T,S>> |
|
AbstractStoreConfigurationChildBuilder<S> |
|
AbstractTransportConfigurationChildBuilder |
|
AbstractTypedPropertiesConfiguration |
|
AbstractUnmanagedConnectionFactoryConfiguration |
|
AcceptAllKeyValueFilter |
A key value filter that accepts all entries found.
|
AcceptAllKeyValueFilter.Externalizer |
|
AdaptiveBufferSizePredictor |
The BufferSizePredictor that automatically increases and
decreases the predicted buffer size on feed back.
|
AdminFlagExternalizer |
|
AdvancedCache<K,V> |
An advanced interface that exposes additional methods not available on Cache .
|
AdvancedCacheExpirationWriter<K,V> |
Deprecated.
|
AdvancedCacheExpirationWriter.ExpirationPurgeListener<K,V> |
|
AdvancedCacheLoader<K,V> |
Deprecated.
|
AdvancedCacheWriter<K,V> |
Deprecated.
|
AdvancedCacheWriter.PurgeListener<K> |
|
AdvancedExternalizer<T> |
Deprecated.
|
AdvancedLoadWriteStore<K,V> |
Deprecated.
|
AffinityTaggedKey |
|
AggregatedClassLoader |
A ClassLoader that delegates loading of classes and resources to a list of delegate ClassLoaders.
|
AllowListConfiguration |
|
AllowListConfigurationBuilder |
|
ALPNHandler |
Handler responsible for TLS/ALPN negotiation.
|
AlwaysRemoveXSiteEntryMergePolicy<K,V> |
|
ArrayCollector |
|
ArrayMap<K,V> |
Base for classes that implement hash map by storing keys in one array and values in another.
|
AsyncCache<K,V> |
AsyncCache.
|
AsyncStoreConfiguration |
Configuration for the async cache store.
|
AsyncStoreConfigurationBuilder<S> |
Configuration for the async cache store.
|
Attribute |
Enumerates the attributes used by the JDBC cache stores configuration
|
Attribute |
Enumerates the attributes used by the JPA cache stores configuration
|
Attribute |
Enumerates the attributes used by the Remote cache store configuration
|
Attribute |
Enumerates the attributes used by the LevelDB cache stores configuration
|
Attribute |
|
AuditContext |
AuditContext.
|
AuditLogger |
AuditLogger.
|
AuditResponse |
|
AuthenticationConfiguration |
AuthenticationConfiguration.
|
AuthenticationConfiguration |
AuthenticationConfiguration.
|
AuthenticationConfiguration |
AuthenticationConfiguration.
|
AuthenticationConfiguration |
AuthenticationConfiguration.
|
AuthenticationConfigurationBuilder |
AuthenticationConfigurationBuilder.
|
AuthenticationConfigurationBuilder |
AuthenticationConfigurationBuilder.
|
AuthenticationConfigurationBuilder |
AuthenticationConfigurationBuilder.
|
AuthenticationConfigurationBuilder |
AuthenticationConfigurationBuilder.
|
Authenticator |
Authentication mechanism.
|
AuthorizationConfiguration |
AuthorizationConfiguration.
|
AuthorizationConfigurationBuilder |
AuthorizationConfigurationBuilder.
|
AuthorizationManager |
The AuthorizationManager is a cache-scoped component which verifies that the Subject
associated with the current AccessControlContext , or explicitly specified, has the requested permissions.
|
AuthorizationPermission |
AuthorizationPermission.
|
AvailabilityException |
Thrown when a partition happened and the key that an operation tries to access is not available.
|
AvailabilityMode |
|
AvailabilityMode.Externalizer |
|
BackupConfiguration |
|
BackupConfiguration.BackupStrategy |
|
BackupConfigurationBuilder |
|
BackupFailurePolicy |
Defines the possible behaviour in case of failure during x-site.
|
BackupForBuilder |
|
BackupForConfiguration |
Defines the remote caches for which this cache acts as a backup.
|
BaseCacheStream<T,S extends BaseStream<T,S>> |
Interface that defines the base methods of all streams returned from a Cache .
|
BaseCacheStream.SegmentCompletionListener |
Functional interface that is used as a callback when segments are completed.
|
BaseHttpRequestHandler |
|
BasicCache<K,V> |
BasicCache provides the common building block for the two different types of caches that Infinispan provides:
embedded and remote.
|
BasicCacheContainer |
BasicCacheContainer defines the methods used to obtain a BasicCache .
|
BasicConfiguration |
BasicConfiguration provides the basis for concrete configurations.
|
BasicMultimapCache<K,V> |
BasicMultimapCache provides the common API for the two different types of multimap caches that Infinispan
provides: embedded and remote.
|
BatchingCache |
The BatchingCache is implemented by all caches which support batching
|
BeanUtils |
Simple JavaBean manipulation helper methods
|
BiasAcquisition |
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).
|
BlockingRejectedExecutionHandler |
A handler for rejected tasks that runs the task if the current thread is a blocking thread otherwise it
rejects the task.
|
BlockingResource |
Interface to designate the resource is a blocking one.
|
BlockingThreadPoolExecutorFactory |
Deprecated.
|
BloomFilter<E> |
|
BoundedThreadPoolConfigurationBuilder |
|
BufferSizePredictor |
Buffer size predictor
|
Builder<T> |
Builder.
|
BuiltBy |
BuiltBy.
|
ByRef<T> |
This class can be used to pass an argument by reference.
|
ByRef.Boolean |
Implementation for primitive type
|
ByRef.Integer |
|
ByRef.Long |
|
ByteBufContentSource |
|
ByteBuffer |
A byte buffer that exposes the internal byte array with minimal copying.
|
ByteBufferFactory |
|
ByteBufferFactoryImpl |
|
ByteBufferImpl |
A byte buffer that exposes the internal byte array with minimal copying
|
ByteBufferImpl.Externalizer |
|
ByteQuantity |
Parser human-readable quantity of bytes.
|
Cache<K,V> |
The central interface of Infinispan.
|
CacheAware<K,V> |
Interface that describes how a cache can be injected into another object.
|
CacheBackpressureFullException |
A CacheException that is thrown when the backpressure has been filled an unable to process the request.
|
CacheCollection<E> |
A collection type that returns special Cache based streams that have additional options to tweak behavior.
|
CacheCollectors |
|
CacheConfigurationException |
An exception that represents an error in the configuration.
|
CacheContainer |
|
CacheContainerAdmin<C extends CacheContainerAdmin,A extends BasicConfiguration> |
Administrative cache container operations.
|
CacheContainerAdmin.AdminFlag |
Flags which affect only administrative operations
|
CacheContainerConfigurationBuilder |
|
CacheContainerStats |
Deprecated.
|
CacheControl |
A helper class for controlling Cache Control headers.
|
CachedThreadPoolConfigurationBuilder |
|
CachedThreadPoolExecutorFactory |
|
CacheEntriesEvicted |
This annotation should be used on methods that need to be notified when cache entries are evicted.
|
CacheEntriesEvictedEvent<K,V> |
|
CacheEntryActivated |
This annotation should be used on methods that need to be notified when a cache entry is activated.
|
CacheEntryActivatedEvent<K,V> |
|
CacheEntryCreated |
This annotation should be used on methods that need to be notified when a cache entry is created.
|
CacheEntryCreatedEvent<K,V> |
|
CacheEntryEvent<K,V> |
A transactional event subtype that additionally expose a key as such events pertain to a specific cache entry.
|
CacheEntryExpired |
This annotation should be used on methods that need to be notified when a cache entry is expired
|
CacheEntryExpiredEvent<K,V> |
|
CacheEntryInputStream |
|
CacheEntryInvalidated |
This annotation should be used on methods that need to be notified when a cache entry is invalidated.
|
CacheEntryInvalidatedEvent<K,V> |
Notifies a listener of an invalidation event.
|
CacheEntryLoaded |
This annotation should be used on methods that need to be notified when a cache entry is loaded from a CacheLoader .
|
CacheEntryLoadedEvent<K,V> |
|
CacheEntryModified |
This annotation should be used on methods that need to be notified when a cache entry has been modified.
|
CacheEntryModifiedEvent<K,V> |
|
CacheEntryPassivated |
This annotation should be used on methods that need to be notified when cache entries are passivated.
|
CacheEntryPassivatedEvent<K,V> |
|
CacheEntryRemoved |
This annotation should be used on methods that need to be notified when a cache entry is removed from the cache.
|
CacheEntryRemovedEvent<K,V> |
|
CacheEntryVisited |
This annotation should be used on methods that need to be notified when a cache entry is visited.
|
CacheEntryVisitedEvent<K,V> |
|
CacheEventConverter<K,V,C> |
A converter that can be used to convert the value given for an event.
|
CacheEventConverterAsConverter<K,V,C> |
Converter that is implemented by using the provided CacheEventConverter.
|
CacheEventConverterAsConverter.Externalizer |
|
CacheEventConverterFactory |
Factory that can produce CacheEventConverters
|
CacheEventFilter<K,V> |
A filter that can be used to tell if an event should be raised or not.
|
CacheEventFilterAsKeyValueFilter<K,V> |
KeyValueFilter that is implemented by using the provided CacheEventFilter.
|
CacheEventFilterAsKeyValueFilter.Externalizer |
|
CacheEventFilterConverter<K,V,C> |
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> |
|
CacheEventFilterConverterAsKeyValueFilterConverter.Externalizer |
|
CacheEventFilterConverterFactory |
|
CacheEventFilterFactory |
Factory that can produce CacheEventFilters
|
CacheException |
Thrown when operations fail unexpectedly.
|
CacheFilters |
|
CacheFilters.CacheFiltersExternalizer |
|
CacheKeyInputStream |
|
CacheListenerException |
Wraps exceptions produced by listener implementations.
|
CacheLoader<K,V> |
Deprecated.
|
CacheManagerInfo |
|
CacheMode |
Cache replication mode.
|
CacheNotTransactionalException |
When try to create a transactional org.infinispan.client.hotrod.RemoteCache but the cache in the Hot Rod
server isn't transactional, this exception is thrown.
|
CachePermission |
CachePermission.
|
CachePermissionCollection |
CachePermissionCollection.
|
CacheSet<E> |
A set that also must implement the various CacheCollection methods for streams.
|
CacheStarted |
This annotation should be used on methods that need to be notified when a cache is started.
|
CacheStartedEvent |
This event is passed in to any method annotated with CacheStarted .
|
CacheStopped |
This annotation should be used on methods that need to be notified when a cache is stopped.
|
CacheStoppedEvent |
This event is passed in to any method annotated with CacheStopped .
|
CacheStream<R> |
A Stream that has additional operations to monitor or control behavior when used from a Cache .
|
CacheTopologyInfo |
Contains information about cache topology including servers and owned segments.
|
CacheWriter<K,V> |
Deprecated.
|
CallerRunsRejectOnShutdownPolicy |
A handler for rejected tasks that runs the rejected task
directly in the calling thread of the execute method.
|
CheckedClassResolver |
Deprecated. |
CheckedInputStream |
|
ClassAllowList |
The ClassAllowList maintains classes definitions either by name or regular expression and is used for
permissioning.
|
ClassFinder |
Find infinispan classes utility
|
ClassLoaderAwareFilteringListenable<K,V> |
Interface that enhances FilteringListenable with the possibility of specifying the
ClassLoader which should be set as the context class loader for the invoked
listener method
|
ClassLoaderAwareListenable |
Interface that enhances Listenable with the possibility of specifying the
ClassLoader which should be set as the context class loader for the invoked
listener method
|
ClasspathURLStreamHandler |
|
ClassWhiteList |
Deprecated.
|
ClientCacheEntryCreated |
|
ClientCacheEntryCreatedEvent<K> |
Client side cache entry created events provide information on the created
key, and the version of the entry.
|
ClientCacheEntryCustomEvent<T> |
The events generated by default contain just enough information to make the
event relevant but they avoid cramming too much information in order to reduce
the cost of sending them.
|
ClientCacheEntryExpired |
|
ClientCacheEntryExpiredEvent<K> |
Client side cache entry expired events provide information on the expired key.
|
ClientCacheEntryModified |
|
ClientCacheEntryModifiedEvent<K> |
Client side cache entry modified events provide information on the modified
key, and the version of the entry after the modification.
|
ClientCacheEntryRemoved |
|
ClientCacheEntryRemovedEvent<K> |
Client side cache entry removed events provide information on the removed key.
|
ClientCacheFailover |
|
ClientCacheFailoverEvent |
Event received when the registered listener fails over to a different node.
|
ClientEvent |
|
ClientEvent.Type |
|
ClientEvents |
|
ClientIntelligence |
ClientIntelligence specifies the level of intelligence used by the client.
|
ClientListener |
Annotation that marks a class to receive remote events from Hot Rod caches.
|
CloseableIterable<E> |
|
CloseableIterator<E> |
|
CloseableIteratorCollection<E> |
A collection that defines an iterator method that returns a CloseableIterator
instead of a non closeable one.
|
CloseableIteratorCollectionAdapter<E> |
|
CloseableIteratorSet<E> |
A set that defines an iterator method that returns a CloseableIterator
instead of a non closeable one.
|
CloseableIteratorSetAdapter<E> |
|
Closeables |
This class consists exclusively of static methods that operate on or return closeable interfaces.
|
CloseableSpliterator<T> |
|
ClusterCacheStats |
Similar to Stats but cluster wide.
|
ClusterConfiguration |
|
ClusterConfigurationBuilder |
|
ClusterContainerStats |
Cluster wide container statistics.
|
ClusteredLock |
ClusteredLock is a data structure used for concurrent programming between Infinispan instances in cluster mode.
|
ClusteredLockConfiguration |
A Clustered Lock can be reentrant and there are different ownership levels.
|
ClusteredLockException |
Exception used to handle errors on clustered locks
|
ClusteredLockManager |
Provides the API to define, create and remove ClusteredLocks.
|
ClusterExecutionPolicy |
ClusterExecutionPolicy controls how which nodes commands submitted via ClusterExecutor .
|
ClusterExecutor |
A cluster executor that can be used to invoke a given command across the cluster.
|
ClusteringConfiguration |
Defines clustered characteristics of the cache.
|
ClusteringConfigurationBuilder |
Defines clustered characteristics of the cache.
|
ClusteringConfigurationChildBuilder |
|
ClusterLoader |
Deprecated.
|
ClusterLoaderConfiguration |
Deprecated.
|
ClusterLoaderConfigurationBuilder |
Deprecated.
|
CommonNameRoleMapper |
CommonNameRoleMapper.
|
ComponentStatus |
Different states a component may be in.
|
CompositeCacheEventFilter<K,V> |
Allows AND-composing several cache event filters.
|
CompositeKeyValueFilter<K,V> |
Allows AND-composing several key/value filters.
|
CompositeKeyValueFilter.Externalizer |
|
CompressionType |
|
ConcatIterator<E> |
Iterator that concatenates a bunch of iterables into 1 big iterator.
|
Configuration |
Configuration.
|
Configuration |
|
ConfigurationBuilder |
|
ConfigurationBuilder |
|
ConfigurationChanged |
This annotation should be used on methods that need to be notified when a configuration is changed.
|
ConfigurationChangedEvent |
|
ConfigurationChangedEvent.EventType |
|
ConfigurationChildBuilder |
ConfigurationChildBuilder.
|
ConfigurationChildBuilder |
|
ConfigurationFor |
ConfigurationFor.
|
Configurations |
Helper configuration methods.
|
ConfigurationStorage |
Configuration storage
|
ConfigurationUtils |
ConfigurationUtils.
|
ConfiguredBy |
Defines the configuration used to configure the given class instances
|
ConflictManager<K,V> |
|
ConflictManagerFactory |
|
ConnectionFactoryConfiguration |
ConnectionFactoryConfiguration.
|
ConnectionFactoryConfigurationBuilder<T extends ConnectionFactoryConfiguration> |
|
ConnectionPoolConfiguration |
ConnectionPoolConfiguration.
|
ConnectionPoolConfiguration |
|
ConnectionPoolConfigurationBuilder |
ConnectionPoolConfigurationBuilder.
|
ConnectionPoolConfigurationBuilder |
ConnectionPoolConfigurationBuilder.
|
ConsistentHash |
A consistent hash algorithm implementation.
|
ConsistentHashFactory<CH extends ConsistentHash> |
Deprecated.
|
Constants |
Various public constant names, used by Infinispan's microprofile metrics support.
|
ContentTypeConfiguration |
|
ContentTypeConfigurationBuilder |
|
ContinuousQuery<K,V> |
A container of continuous query listeners for a cache.
|
ContinuousQueryListener<K,V> |
Listener for continuous query events.
|
Converter<K,V,C> |
Converter that can be used to transform a given entry to a different value.
|
CorsConfiguration |
|
CorsConfigurationBuilder |
|
CorsHandler |
|
CorsRuleConfiguration |
|
CorsRuleConfigurationBuilder |
|
CounterConfiguration |
|
CounterConfiguration.Builder |
|
CounterConfigurationException |
Signals a missing configuration or an invalid configuration.
|
CounterEvent |
|
CounterException |
|
CounterListener |
|
CounterManager |
|
CounterOutOfBoundsException |
|
CounterState |
The possible states for a counter value.
|
CounterState$___Marshaller_93aa5d27c0d57954ec79247b055254b02d5c87a64e0764e392772b387eb7542d |
|
CounterType |
The counter types.
|
CounterType$___Marshaller_4dd4ef0972bf79fd96da56b8ce9348d84b1c42596acd7df3abf86c5e467887f5 |
|
CustomFailurePolicy<K,V> |
Used for implementing custom policies in case of communication failures with a remote site.
|
CustomInterceptorsConfiguration |
Deprecated.
|
CustomInterceptorsConfigurationBuilder |
Deprecated.
|
CustomStoreConfiguration |
|
CustomStoreConfigurationBuilder |
StoreConfigurationBuilder used for stores/loaders that don't have a configuration builder
|
DatabaseType |
Supported database dialects for the JDBC cache stores
|
DataColumnConfiguration |
|
DataColumnConfigurationBuilder |
|
DataConfiguration |
|
DataConfigurationBuilder |
|
DataContainer<K,V> |
The main internal data structure which stores entries.
|
DataContainer.ComputeAction<K,V> |
|
DataConversionAwareListenable<K,V> |
|
DataFormat |
Defines data format for keys and values during Hot Rod client requests.
|
DataFormat.Builder |
|
DataLocality |
Deprecated.
|
DataRehashed |
This annotation should be used on methods that need to be notified when a rehash starts or ends.
|
DataRehashedEvent<K,V> |
|
DateUtils |
|
DefaultCacheManager |
A CacheManager is the primary mechanism for retrieving a Cache instance, and is often used as a
starting point to using the Cache .
|
DefaultCacheManagerAdmin |
|
DefaultContextClassResolver |
Deprecated.
|
DefaultTemplate |
This enum lists the cache configuration templates names that are available in the server by default.
|
DefaultXSiteEntryMergePolicy<K,V> |
|
DelegatingCacheEntryListenerInvocation<K,V> |
A wrapper around a CacheEntryListenerInvocation that keeps a reference to the FilterIndexingServiceProvider instance that handles this invocation.
|
DelegatingObjectInput |
|
DelegatingObjectOutput |
|
DistributionInfo |
|
DistributionManager |
A component that manages the distribution of elements across a cache cluster
|
DoubleCacheStream |
A DoubleStream that has additional methods to allow for Serializable instances.
|
Either<A,B> |
|
Either.Type |
|
Element |
An enumeration of all the recognized XML element local names for the JDBC cache stores
|
Element |
An enumeration of all the recognized XML element local names for the JPA cache stores
|
Element |
An enumeration of all the recognized XML element local names for the
RemoteStore
|
Element |
An enumeration of all the recognized XML element local names for the RocksDB cache store
|
Element |
|
EmbeddedCacheManager |
EmbeddedCacheManager is an CacheManager that runs in the same JVM as the client.
|
EmbeddedCacheManagerAdmin |
Cache manager operations which affect the whole cluster.
|
EmbeddedCacheManagerStartupException |
An exception to encapsulate an error when starting up a cache manager
|
EmbeddedClusteredLockManagerFactory |
|
EmbeddedMetadata |
Metadata class for embedded caches.
|
EmbeddedMetadata.Builder |
|
EmbeddedMetadata.EmbeddedExpirableMetadata |
|
EmbeddedMetadata.EmbeddedLifespanExpirableMetadata |
|
EmbeddedMetadata.EmbeddedMaxIdleExpirableMetadata |
|
EmbeddedMetadata.Externalizer |
|
EmbeddedMultimapCacheManagerFactory |
|
EncodingConfiguration |
Controls encoding configuration for keys and values in the cache.
|
EncodingConfigurationBuilder |
|
EncryptionConfiguration |
|
EncryptionConfigurationBuilder |
|
EntryHeader |
|
EntryInfo |
|
EntryLookup |
Interface that can look up MVCC wrapped entries.
|
EntryMergePolicy<K,V> |
|
EntryMergePolicyFactory |
|
EntryMergePolicyFactoryRegistry |
|
EntryMetadata |
Object to hold metadata bytes and timestamps.
|
EntryRecord |
Helper for reading/writing entries into file.
|
EntrySizeCalculator<K,V> |
|
EntryView |
Entry views expose cached entry information to the user.
|
EntryView.ReadEntryView<K,V> |
Expose read-only information about a cache entry potentially associated
with a key in the functional map.
|
EntryView.ReadWriteEntryView<K,V> |
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> |
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.
|
EnumerationList<T> |
An Enumeration → List adaptor
|
EnumUtil |
Utilities method to Enums.
|
Event<K,V> |
An interface that defines common characteristics of events
|
Event |
Common characteristics of events that occur on a cache manager
|
Event.Type |
|
Event.Type |
|
EventStream |
|
EventType |
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.
|
EvictionListener<K,V> |
Deprecated.
|
EvictionManager<K,V> |
Central component that deals with eviction of cache entries.
|
EvictionStrategy |
Supported eviction strategies
|
EvictionType |
Deprecated.
|
ExecutorFactory |
Used to configure and create executors
|
ExecutorFactoryConfiguration |
ExecutorFactoryConfiguration.
|
ExecutorFactoryConfiguration |
|
ExecutorFactoryConfiguration |
|
ExecutorFactoryConfigurationBuilder |
Configures executor factory.
|
ExecutorFactoryConfigurationBuilder |
Configures executor factory.
|
ExecutorFactoryConfigurationBuilder |
Configures executor factory.
|
ExhaustedAction |
Enumeration for whenExhaustedAction.
|
ExhaustedAction |
|
ExpandableMarshalledValueByteStream |
Deprecated.
|
Experimental |
An experimental user-facing API.
|
ExpirationConfiguration |
Controls the default expiration settings for entries in the cache.
|
ExpirationConfigurationBuilder |
Controls the default expiration settings for entries in the cache.
|
ExpirationManager<K,V> |
Central component that deals with expiration of cache entries.
|
ExposedByteArrayOutputStream |
Deprecated.
|
Expression |
Deprecated.
|
ExtendedHeaders |
|
ExtendedRiverMarshaller |
Deprecated.
|
ExtendedRiverUnmarshaller |
Deprecated.
|
Externalizer<T> |
Deprecated.
|
ExternalizerIds |
1800 to 1899 range is reserved for this module
|
ExternalStore<K,V> |
Deprecated.
|
FailoverRequestBalancingStrategy |
Defines what servers will be selected when a smart-routed request fails.
|
FastCopyHashMap<K,V> |
A HashMap that is optimized for fast shallow copies.
|
Features |
Features allow conditional enabling/disabling of Infinispan's functionality.
|
FileLookup |
|
FileLookupFactory |
|
FileLookupFactory.DefaultFileLookup |
|
FileProvider |
Provides resource management for files - only limited amount of files may be opened in one moment, and opened file
should not be deleted.
|
FileProvider.Handle |
|
FilterCallback |
A single-method callback that is specified when registering a filter with a Matcher.
|
FilterConditionBeginContext |
Deprecated.
|
FilterConditionContext |
Deprecated.
|
FilterConditionContextQueryBuilder |
Deprecated.
|
FilterConditionEndContext |
Deprecated.
|
FilterIndexingServiceProvider |
A service provider for filter indexing services.
|
FilteringListenable<K,V> |
A Listenable that can also filter events based on key
|
FilterIterator<E> |
Iterator that also filters out entries based on the provided predicate.
|
FilterResult |
When using Ickle based filters with client event listeners you will get the event data (see
org.infinispan.client.hotrod.event.ClientCacheEntryCustomEvent.getEventData) wrapped by this FilterResult.
|
FilterSpliterator<T> |
Spliterator that only returns entries that pass the given predicate.
|
FilterSubscription |
A subscription for match notifications.
|
Flag |
Defines all the flags available in the Hot Rod client that can influence the behavior of operations.
|
Flag |
Available flags, which may be set on a per-invocation basis.
|
Flag.Externalizer |
|
FlagAffectedStore<K,V> |
Implemented by stores that can skip writes based on certain flags present in the invocation.
|
FlattenSpliterator<E> |
Composes an array of Collections into a spliterator.
|
ForwardingList<E> |
A list which forwards all its method calls to another list.
|
FunctionalMap<K,V> |
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> |
Exposes read-only operations that can be executed against the functional map.
|
FunctionalMap.ReadWriteMap<K,V> |
Exposes read-write operations that can be executed against the functional map.
|
FunctionalMap.WriteOnlyMap<K,V> |
Exposes write-only operations that can be executed against the functional map.
|
GenericJBossMarshaller |
A marshaller that makes use of JBoss Marshalling
to serialize and deserialize objects.
|
GlobalAuthorizationConfiguration |
GlobalAuthorizationConfiguration.
|
GlobalAuthorizationConfigurationBuilder |
GlobalAuthorizationConfigurationBuilder.
|
GlobalConfiguration |
Configuration component that exposes the global configuration.
|
GlobalConfigurationBuilder |
|
GlobalConfigurationChildBuilder |
|
GlobalConfigurationManager |
|
GlobalContextInitializer |
Interface used to initialise the global SerializationContext using the specified Pojos,
and the generated proto files and marshallers.
|
GlobalContextInitializerImpl |
WARNING: Generated code! Do not edit!
|
GlobalJmxConfiguration |
|
GlobalJmxConfigurationBuilder |
Configures JMX for the cache manager and its caches.
|
GlobalJmxStatisticsConfiguration |
Deprecated.
|
GlobalJmxStatisticsConfigurationBuilder |
Deprecated.
|
GlobalMetricsConfiguration |
Configuration for microprofile metrics.
|
GlobalMetricsConfigurationBuilder |
Configures the types of metrics gathered and exported via microprofile metrics for all caches owned by this cache
manager.
|
GlobalRoleConfigurationBuilder |
GlobalRoleConfigurationBuilder.
|
GlobalRolesConfigurationChildBuilder |
|
GlobalSecurityConfiguration |
GlobalSecurityConfiguration.
|
GlobalSecurityConfigurationBuilder |
GlobalSecurityConfigurationBuilder.
|
GlobalSecurityConfigurationChildBuilder |
GlobalSecurityConfigurationChildBuilder.
|
GlobalSecurityManager |
GlobalSecurityManager.
|
GlobalStateConfiguration |
GlobalStateConfiguration.
|
GlobalStateConfigurationBuilder |
GlobalStateConfigurationBuilder.
|
GlobalStateManager |
GlobalStateManager.
|
GlobalStatePathConfiguration |
|
GlobalStatePathConfigurationBuilder |
|
GlobalStateProvider |
GlobalStateProvider.
|
GlobalStorageConfiguration |
|
GlobalStorageConfigurationBuilder |
|
GlobUtils |
Utility functions for globs
|
GridFile |
Deprecated.
|
GridFile.Metadata |
|
GridFilesystem |
Deprecated.
|
GridInputStream |
Deprecated.
|
GridOutputStream |
Deprecated.
|
Group |
Identifies the key for a group.
|
Grouper<T> |
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.
|
GroupsConfiguration |
Configuration for various grouper definitions.
|
GroupsConfigurationBuilder |
Configuration for various grouper definitions.
|
Handle<T extends CounterListener> |
|
Hash |
Interface that governs implementations
|
HashConfiguration |
Allows fine-tuning of rehashing characteristics.
|
HashConfigurationBuilder |
Allows fine-tuning of rehashing characteristics.
|
HopscotchHashMap<K,V> |
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).
|
HotRodClientException |
Base class for exceptions reported by the hot rod client.
|
HotRodServerChildConfigurationBuilder |
HotRodServerChildConfigurationBuilder.
|
HotRodServerConfiguration |
|
HotRodServerConfigurationBuilder |
HotRodServerConfigurationBuilder.
|
HotRodTimeoutException |
Signals an remote timeout(due to locking) in the infinispan server.
|
IdColumnConfiguration |
|
IdColumnConfigurationBuilder |
|
IdentityMarshaller |
A marshaller that does not transform the content, only applicable to byte[] payloads.
|
IdentityRoleMapper |
IdentityRoleMapper.
|
Ids |
Internal marshalling identifiers.
|
IllegalLifecycleStateException |
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 |
Deprecated.
|
ImmutableHopscotchHashSet<E> |
|
ImmutableIntSet |
Deprecated.
|
ImmutableListCopy<E> |
A lightweight, read-only copy of a List.
|
ImmutableListCopy.Externalizer |
|
ImmutableMarshalledValueByteStream |
Deprecated.
|
ImmutableProtoStreamMarshaller |
A ProtoStream Marshaller implementation that uses Protobuf encoding.
|
Immutables |
Factory for generating immutable type wrappers.
|
Immutables.Immutable |
|
Immutables.ImmutableIteratorWrapper<E> |
|
Immutables.ImmutableMapWrapperExternalizer |
|
Immutables.ImmutableSetWrapperExternalizer |
|
IncorrectClientListenerException |
|
IncorrectListenerException |
|
Index |
Deprecated.
|
IndexConfiguration |
|
IndexConfigurationBuilder |
|
IndexedFilter<K,V,C> |
|
Indexer |
Interacts directly with cache indexes.
|
IndexingConfiguration |
Configures indexing of entries in the cache for searching.
|
IndexingConfigurationBuilder |
Configures indexing of entries in the cache for searching.
|
IndexingConfigurationChildBuilder |
|
IndexMergeConfiguration |
|
IndexMergeConfigurationBuilder |
|
IndexReaderConfiguration |
|
IndexReaderConfigurationBuilder |
|
IndexStorage |
|
IndexWriterConfiguration |
|
IndexWriterConfigurationBuilder |
|
InfinispanCollections |
Static helpers for Infinispan-specific collections
|
InfinispanCollections.Function<E,T> |
A function that converts a type into another one.
|
InfinispanCollections.MapMakerFunction<K,V,E> |
A function that converts an entry into a key/value pair for use in a map.
|
InitializationContext |
|
InitializationContextImpl |
|
InjectiveFunction<T,R> |
This is a marker interface to be used with Function which signals to some implementors that
the function returns distinct values.
|
InstanceReusingAdvancedExternalizer<T> |
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.
|
InstanceSupplier<T> |
|
IntCacheStream |
A IntStream that has additional methods to allow for Serializable instances.
|
InterceptorConfiguration |
Describes a custom interceptor
|
InterceptorConfiguration.Position |
Positional placing of a new custom interceptor
|
InterceptorConfigurationBuilder |
Deprecated.
|
InternalMetadata |
Deprecated.
|
IntSet |
A set that represents primitive ints.
|
IntSets |
Static utility class for creating various IntSet objects.
|
IntSetsExternalization |
IntSets externalization mechanism
|
InvalidCacheUsageException |
Thrown when client makes cache usage errors.
|
InvalidResponseException |
Signals an internal protocol error.
|
InvocationBatchingConfiguration |
|
InvocationBatchingConfigurationBuilder |
|
InvocationContext |
A context that contains information pertaining to a given invocation.
|
InvocationContextFactory |
|
InvocationHelper |
|
IpFilterConfiguration |
|
IpFilterConfigurationBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>> |
IpFilterConfigurationBuilder.
|
IteratorMapper<E,S> |
A iterator that maps each value to the output of the Function.
|
JavaSerializationMarshaller |
Standard Java serialization marshaller.
|
JBossExternalizerAdapter |
Deprecated.
|
JBossMarshallerFactory |
Deprecated.
|
JdbcStoreConfigurationChildBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> |
JdbcStoreConfigurationChildBuilder.
|
JdbcStoreConfigurationParser |
JDBC cache store configuration parser.
|
JdbcStringBasedStore<K,V> |
|
JdbcStringBasedStoreConfiguration |
|
JdbcStringBasedStoreConfigurationBuilder |
JdbcStringBasedStoreConfigurationBuilder.
|
JdbcStringBasedStoreConfigurationSerializer |
JdbcStringBasedStoreConfigurationSerializer.
|
JdbcUtil |
Contains common methods used by JDBC CacheStores.
|
JGroupsConfiguration |
|
JGroupsConfigurationBuilder |
|
JMXStatisticsConfiguration |
Deprecated.
|
JMXStatisticsConfigurationBuilder |
Deprecated.
|
JpaStore<K,V> |
|
JpaStoreConfiguration |
JpaStoreConfiguration.
|
JpaStoreConfigurationBuilder |
|
JpaStoreConfigurationParser |
|
JpaStoreConfigurationSerializer |
JpaStoreConfigurationSerializer.
|
JpaStoreException |
|
JSONConstants |
|
JVMMemoryInfoInfo |
|
KeyAffinityService<K> |
Defines a service that generates keys to be mapped to specific nodes in a distributed(vs.
|
KeyAffinityServiceFactory |
|
KeyGenerator<K> |
|
KeyPartitioner |
Map keys to segments.
|
KeyStoreConfiguration |
|
KeyStoreConfigurationBuilder |
|
KeyValueFilter<K,V> |
A filter for keys with their values.
|
KeyValueFilterAsCacheEventFilter<K,V> |
CacheEventFilter that implements it's filtering solely on the use of the provided KeyValueFilter
|
KeyValueFilterAsCacheEventFilter.Externalizer |
|
KeyValueFilterConverter<K,V,C> |
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> |
|
KeyValueFilterConverterAsCacheEventFilterConverter.Externalizer |
|
KeyValueFilterConverterFactory<K,V,C> |
|
KeyValueWithPrevious<K,V> |
|
L1Configuration |
Configures the L1 cache behavior in 'distributed' caches instances.
|
L1ConfigurationBuilder |
Configures the L1 cache behavior in 'distributed' caches instances.
|
L1Manager |
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.
|
LambdaExternalizer<T> |
|
LazyByteArrayOutputStream |
ByteArrayOutputStream alternative exposing the internal buffer.
|
LegacyKeySupportSystemProperties |
A wrapper around system properties that supports legacy keys
|
Lifecycle |
Lifecycle interface that defines the lifecycle of components
|
LifecycleCallbacks |
|
LifecycleRejectedExecutionHandler |
|
Listenable |
Interface that denotes that the implementation can have listeners attached to it.
|
Listener |
Class-level annotation used to annotate an object as being a valid cache listener.
|
Listener.Observation |
Enumeration that defines when a listener event can be observed.
|
ListenerRegistration |
Used for registering various cache notifications.
|
Listeners |
Holder class for functional listener definitions.
|
Listeners.ReadWriteListeners<K,V> |
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> |
Read-write listener
|
Listeners.WriteListeners<K,V> |
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> |
Write-only listener.
|
LoaderConfigurationChildBuilder<S> |
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
|
LocalConfigurationStorage |
|
LocalizedCacheTopology |
Extends CacheTopology with information about keys owned by the local node.
|
LocalOnlyCacheLoader |
Deprecated.
|
LockedStream<K,V> |
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.
|
LockingConfiguration |
Defines the local, in-VM locking and concurrency characteristics of the cache.
|
LockingConfigurationBuilder |
Defines the local, in-VM locking and concurrency characteristics of the cache.
|
LockingMode |
Defines the locking modes that are available for transactional caches:
optimistic or pessimistic.
|
Log |
This module reserves range 29001 - 29500
|
LogAppender |
|
LoggingAuditLogger |
LoggingAuditLogger.
|
LongCacheStream |
A LongStream that has additional methods to allow for Serializable instances.
|
ManagedConnectionFactoryConfiguration |
ManagedConnectionFactoryConfiguration.
|
ManagedConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> |
ManagedConnectionFactoryConfigurationBuilder.
|
MarshallableEntry<K,V> |
Defines an externally persisted entry.
|
MarshallableEntryFactory<K,V> |
|
MarshallableTypeHints |
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.
|
MarshalledValue |
A marshallable object containing serialized representations of cache values and metadata, that can be used to store
values, metadata and timestamps as a single entity.
|
MarshalledValueByteStream |
Deprecated.
|
Marshaller |
A marshaller is a class that is able to marshall and unmarshall objects efficiently.
|
MarshallingException |
An exception that can be thrown by a cache if an object cannot be successfully serialized/deserialized.
|
MarshallUtil |
MarshallUtil.
|
MarshallUtil.ArrayBuilder<E> |
|
MarshallUtil.CollectionBuilder<E,T extends Collection<E>> |
|
MarshallUtil.ElementReader<E> |
|
MarshallUtil.ElementWriter<E> |
|
MarshallUtil.EnumBuilder<E extends Enum<E>> |
|
MarshallUtil.MapBuilder<K,V,T extends Map<K,V>> |
|
MarshallUtil.UnboundedCollectionBuilder<E,T extends Collection<E>> |
|
Matcher |
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 ).
|
MBeanServerLookup |
Implementors of this should return an MBeanServer to which MBeans will be registered.
|
MechanismConfiguration |
|
MechanismConfigurationBuilder |
|
MemcachedServerConfiguration |
Deprecated.
|
MemcachedServerConfigurationBuilder |
Deprecated.
|
MemoryConfiguration |
Controls the memory storage configuration for the cache.
|
MemoryConfigurationBuilder |
Controls the data container for the cache.
|
MemoryStorageConfiguration |
Deprecated.
|
MemoryStorageConfigurationBuilder |
Deprecated.
|
MemoryUnit |
Deprecated.
|
Merged |
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.
|
MergeEvent |
This event is passed in to any method annotated with Merged .
|
MergePolicy |
|
MergePolicy.UnsupportedMergePolicy |
|
Metadata |
Represents metadata about an entry, such as creation and access times and expiration information.
|
Metadata |
This interface encapsulates metadata information that can be stored
alongside values in the cache.
|
Metadata.Builder |
Metadata builder
|
Metadatas |
Utility method for Metadata classes.
|
MetadataValue<V> |
Besides the value, also contains a version and expiration information.
|
MetaParam<T> |
An easily extensible metadata parameter that's stored along with the value
in the the functional map.
|
MetaParam.Lookup |
Provides metadata parameter lookup capabilities using Class as
lookup key.
|
MetaParam.MetaBoolean |
|
MetaParam.MetaCreated |
Read only metadata parameter representing a cached entry's created time
in milliseconds.
|
MetaParam.MetaEntryVersion |
Writable metadata parameter representing a cached entry's generic version.
|
MetaParam.MetaLastUsed |
Read only metadata parameter representing a cached entry's last used time
in milliseconds.
|
MetaParam.MetaLifespan |
Writable metadata parameter representing a cached entry's millisecond lifespan.
|
MetaParam.MetaLoadedFromPersistence |
Non-writable parameter telling if the entry was loaded from a persistence tier
( CacheLoader ) or not.
|
MetaParam.MetaLong |
Abstract class for numeric long-based metadata parameter instances.
|
MetaParam.MetaMaxIdle |
Writable metadata parameter representing a cached entry's millisecond
max idle time.
|
MetaParam.MetaUpdateCreationTime |
A parameter to tell if the creation timestamp should be updated for modified entries.
|
MetaParam.Writable<T> |
Writable MetaParam instances are those that the user can provide
to be stored as part of the cache entry.
|
ModularArithmetic |
Deprecated.
|
ModuleLifecycle |
ModuleLifecycle is an API hook for delegating lifecycle events to Infinispan sub-modules.
|
MultimapCache<K,V> |
Embedded version of MultimapCache.
|
MultimapCacheManager<K,V> |
|
MurmurHash3 |
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.Externalizer |
|
MurmurHash3BloomFilter |
BloomFilter implementation that allows for up to 10 hash functions all using MurmurHash3 with different
seeds.
|
MutablePrincipalRoleMapper |
|
NamedFactory |
|
NamedStackConfiguration |
|
NearCacheConfiguration |
|
NearCacheConfigurationBuilder |
|
NearCacheMode |
Decides how client-side near caching should work.
|
NettyRestRequest |
A RestRequest backed by Netty.
|
NettyRestResponse |
A RestResponse backed by Netty.
|
NettyRestResponse.Builder |
|
NonBlockingRejectedExecutionHandler |
A handler for rejected tasks that runs the task if the current thread is a non blocking thread otherwise it
blocks until the task can be added to the underlying queue
|
NonBlockingResource |
Interface to designate the resource is a non blocking one
|
NonBlockingSoftIndexFileStore<K,V> |
Local file-based cache store, optimized for write-through use with strong consistency guarantees
(ability to flush disk operations before returning from the store call).
|
NonBlockingSoftIndexFileStore.EntryCreator<K,V> |
|
NonBlockingStore<K,V> |
The contract for defining how caches interface with external sources of data, such as databases or filesystems.
|
NonBlockingStore.Characteristic |
Enumeration defining the various characteristics of the underlying store to communicate what features it may
or may not support.
|
NonBlockingStore.SegmentedPublisher<Type> |
A Publisher that provides a stream of values and the segments to which those values map.
|
NonReentrantLock |
A simplistic non-reentrant lock that does not use ownership by thread.
|
NoStateExternalizer<T> |
An externalizer that writes no state.
|
NotSerializableException |
An exception that hides inner stacktrace lines for non serializable exceptions.
|
NullAuditLogger |
NullAuditLogger.
|
NullValue |
A placeholder for null in a cache, because caches do not allow null values.
|
ObjectDuplicator |
Deprecated.
|
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 |
|
OS |
Operating system family.
|
Ownership |
|
OwnershipLevel |
|
PaginationContext<Context extends PaginationContext> |
Deprecated.
|
ParallelOperationException |
|
Param<P> |
An easily extensible parameter that allows functional map operations to be
tweaked.
|
Param.ExecutionMode |
Defines where is the command executed.
|
Param.LockingMode |
Normally the cache has to acquire locks during any write operation to guarantee
its correctness.
|
Param.PersistenceMode |
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 |
|
Param.StatisticsMode |
Defines how statistics are gathered for this command.
|
ParameterContext<Context extends ParameterContext> |
Deprecated.
|
ParamIds |
Parameter identifiers.
|
ParamKeyValueFilterConverterFactory<K,V,C> |
|
ParsingException |
Thrown in case of syntax errors during parsing or during the processing of the parse tree.
|
PartitionHandling |
|
PartitionHandlingConfiguration |
Controls how the cache handles partitioning and/or multiple node failures.
|
PartitionHandlingConfigurationBuilder |
Controls how the cache handles partitioning and/or multiple node failures.
|
PartitionStatusChanged |
This annotation should be used on methods that need to be notified when the
AvailabilityMode in use by the
PartitionHandlingManager changes due to a change in cluster topology.
|
PartitionStatusChangedEvent<K,V> |
|
PeekableMap<K,V> |
Deprecated.
|
PersistenceAvailabilityChanged |
Use this annotation on methods that require notification when the availability of the PersistenceManager changes.
|
PersistenceAvailabilityChangedEvent<K,V> |
|
PersistenceConfiguration |
Configuration for stores.
|
PersistenceConfigurationBuilder |
Configuration for cache stores.
|
PersistenceConfigurationChildBuilder |
|
PersistenceContextInitializer |
Interface used to initialise a SerializationContext using the specified Pojos,
Marshaller implementations and provided .proto schemas.
|
PersistenceContextInitializerImpl |
WARNING: Generated code! Do not edit!
|
PersistenceContextInitializerImpl |
WARNING: Generated code! Do not edit!
|
PersistenceException |
An exception thrown by a CacheLoader or a CacheWriter implementation if there are problems
reading from a loader.
|
PersistenceMarshaller |
The marshaller that is responsible serializing/deserializing objects which are to be persisted.
|
PersistenceUtil |
|
PlatformMBeanServerLookup |
|
Policy |
|
PooledConnectionFactoryConfiguration |
|
PooledConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> |
PooledConnectionFactoryConfigurationBuilder.
|
PostCacheEventFilter<K,V> |
A Filter that only allows post events to be accepted.
|
PreferNonNullXSiteEntryMergePolicy<K,V> |
|
PreferNullXSiteEntryMergePolicy<K,V> |
|
PrincipalRoleMapper |
PrincipalRoleMapper.
|
PrincipalRoleMapperConfiguration |
|
PrincipalRoleMapperConfigurationBuilder |
|
PrincipalRoleMapperContext |
PrincipalRoleMapperContext.
|
ProcessorInfo |
Provides general information about the processors on this host.
|
PropertyFormatter |
|
ProtobufMetadataManager |
A clustered persistent and replicated repository of protobuf definition files.
|
ProtobufMetadataManagerConstants |
Useful constants used by the Protobuf metadata cache.
|
ProtobufMetadataManagerMBean |
|
ProtocolServerConfiguration<T extends ProtocolServerConfiguration> |
ServerConfiguration.
|
ProtocolServerConfigurationBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>> |
|
ProtocolServerConfigurationChildBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>> |
ProtocolServerConfigurationChildBuilder.
|
ProtocolVersion |
Enumeration of supported Hot Rod client protocol VERSIONS.
|
ProtoStreamMarshaller |
Provides the starting point for implementing a Marshaller that uses Protobuf
encoding.
|
ProtoStreamTypeIds |
TypeIds used by protostream in place of FQN message/enum names to reduce payload size.
|
Proxies |
Proxies is a collection of useful dynamic profixes.
|
QOP |
|
QueriesJdbcStore<K,V> |
|
Query<T> |
An immutable object representing both the query and the result.
|
QueryBuilder |
Deprecated.
|
QueryFactory |
Factory for query DSL objects.
|
QueryNamedParameterParser |
|
QueryNamedParameterParser.ParserResults |
|
QueryResult<E> |
Represents the result of a Query .
|
RangeConditionContext |
Deprecated.
|
RangeConditionContextQueryBuilder |
Deprecated.
|
RangeSet |
Deprecated.
|
ReadableGridFileChannel |
Deprecated.
|
RecoveryConfiguration |
Defines recovery configuration for the cache.
|
RecoveryConfigurationBuilder |
Defines recovery configuration for the cache.
|
ReflectionUtil |
Basic reflection utilities to enhance what the JDK provides.
|
RemoteCache<K,V> |
Provides remote reference to a Hot Rod server/cluster.
|
RemoteCacheConfiguration |
|
RemoteCacheConfigurationBuilder |
Per-cache configuration.
|
RemoteCacheContainer |
|
RemoteCacheManager |
|
RemoteCacheManagerAdmin |
Remote Administration operations
|
RemoteCacheManagerNotStartedException |
|
RemoteCounterManagerFactory |
|
RemoteIllegalLifecycleStateException |
This exception is thrown when the remote cache or cache manager does not
have the right lifecycle state for operations to be called on it.
|
RemoteNodeSuspectException |
When a remote node is suspected and evicted from the cluster while an
operation is ongoing, the Hot Rod client emits this exception.
|
RemoteServerConfiguration |
|
RemoteServerConfigurationBuilder |
|
RemoteStore<K,V> |
Cache store that delegates the call to a infinispan cluster.
|
RemoteStoreConfiguration |
|
RemoteStoreConfigurationBuilder |
RemoteStoreConfigurationBuilder.
|
RemoteStoreConfigurationChildBuilder<S> |
|
RemoteStoreConfigurationParser |
Remote cache store parser.
|
RemoteStoreConfigurationSerializer |
RemoteStoreConfigurationSerializer.
|
RemoteValueRetrievedListener |
Listener that is notified when a remote value is looked up
|
RemovableCloseableIterator<C> |
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.
|
RemovableIterator<C> |
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.
|
RequestHeader |
|
ResponseHeader |
|
ResponseWriter |
|
RestChannelInitializer |
Creates Netty Channels for this server.
|
RestRequestHandler |
Netty handler for REST requests.
|
RestResponseException |
An exception representing non-critical HTTP processing errors which will be translated
into RestResponse and sent back to the client.
|
RestServer |
REST Protocol Server.
|
RestServerConfiguration |
|
RestServerConfigurationBuilder |
RestServerConfigurationBuilder.
|
ReversibleOrderedSet<E> |
|
RiverCloseListener |
Deprecated.
|
RocksDBExpirationConfiguration |
|
RocksDBExpirationConfigurationBuilder |
since 10.0
|
RocksDBStore<K,V> |
|
RocksDBStoreConfiguration |
|
RocksDBStoreConfigurationBuilder |
|
RocksDBStoreConfigurationParser |
RocksDB XML Parser
|
RocksDBStoreConfigurationSerializer |
RocksDBStoreConfigurationSerializer.
|
Role |
A role to permission mapping.
|
SaslConfiguration |
|
SaslConfigurationBuilder |
|
SaslQop |
SaslQop.
|
SaslStrength |
SaslStrength.
|
SaslUtils |
Utility methods for handling SASL authentication
|
ScheduledExecutorFactoryConfiguration |
|
ScheduledExecutorFactoryConfigurationBuilder |
Configures executor factory.
|
ScheduledThreadPoolConfigurationBuilder |
|
ScheduledThreadPoolExecutorFactory |
|
ScopedPersistentState |
ScopedPersistentState represents state which needs to be persisted, scoped by name (e.g.
|
ScopedState |
Key for scoped entries in the ClusterConfigurationManager state cache
|
ScopedState.Externalizer |
|
ScopeFilter |
A filter for ScopedState that allows listeners of the global state cache to choose events by scope.
|
ScopeFilter.Externalizer |
|
Search |
|
Search |
Entry point for performing Infinispan queries.
|
SearchTimeoutException |
Thrown when a query timeout occurs.
|
SecureCache<K,V> |
SecureCache.
|
Security |
Security.
|
SecurityAwareExecutorFactory |
Used to configure and create executors which are aware of the current security context
|
SecurityConfiguration |
SecurityConfiguration.
|
SecurityConfiguration |
SecurityConfiguration.
|
SecurityConfiguration |
SecurityConfiguration.
|
SecurityConfigurationBuilder |
SecurityConfigurationBuilder.
|
SecurityConfigurationBuilder |
SecurityConfigurationBuilder.
|
SecurityConfigurationBuilder |
SecurityConfigurationBuilder.
|
SecurityConfigurationChildBuilder |
|
SecurityDomain |
Pluggable security domain which could be used as a bridge between Authenticator and
WildFly Security Realms.
|
SegmentAwareKey<K> |
Encapsulates the key and its segment.
|
SegmentColumnConfiguration |
|
SegmentColumnConfigurationBuilder |
|
SegmentedAdvancedLoadWriteStore<K,V> |
Deprecated.
|
Self<S extends Self<S>> |
This interface simplifies the task of writing fluent builders which need to inherit from
other builders (abstract or concrete).
|
SerializationConfiguration |
|
SerializationConfigurationBuilder |
Configures serialization and marshalling settings.
|
SerializeFunctionWith |
Indicate that this function should be serialized with an instance of
the given Externalizer class.
|
SerializeWith |
Deprecated.
|
SerializeWithExtFactory |
Deprecated.
|
ServerConfiguration |
ServerConfiguration.
|
ServerConfigurationBuilder |
ServerConfigurationBuilder.
|
ServerRestBlockHoundIntegration |
|
ServerSentEvent |
|
ServerStatistics |
Defines the possible list of statistics defined by the Hot Rod server.
|
ServerTask<V> |
An interface representing a deployed server task.
|
ServiceFinder |
ServiceFinder is a ServiceLoader replacement which understands multiple classpaths.
|
ShutdownConfiguration |
|
ShutdownConfigurationBuilder |
|
ShutdownHookBehavior |
Behavior of the JVM shutdown hook registered by the cache
|
SignedNumeric |
Variable length encoding for signed numbers, using the ZigZag technique
|
SimpleConnectionFactoryConfiguration |
SimpleConnectionFactoryConfiguration.
|
SimpleConnectionFactoryConfigurationBuilder<S extends AbstractJdbcStoreConfigurationBuilder<?,S>> |
SimpleConnectionFactoryBuilder.
|
SimpleImmutableEntry<K,V> |
Where is Java 1.6?
|
SingleFileStore<K,V> |
|
SingleFileStoreConfiguration |
Defines the configuration for the single file cache store.
|
SingleFileStoreConfigurationBuilder |
Single file cache store configuration builder.
|
SingletonExternalizer<T> |
|
SiteConfiguration |
Deprecated.
|
SiteConfigurationBuilder |
Deprecated.
|
SiteEntry<V> |
It stores the entry value and Metadata for a specific site.
|
SitesConfiguration |
|
SitesConfigurationBuilder |
|
SmallIntSet |
Deprecated.
|
SniConfiguration |
|
SniConfigurationBuilder |
|
SoftIndexFileStoreConfiguration |
|
SoftIndexFileStoreConfigurationBuilder |
|
SortField |
Sort specification for a field.
|
SortOrder |
Deprecated.
|
SpliteratorMapper<E,S> |
A spliterator that has been mapped from another spliterator.
|
SqlManager |
|
SslConfiguration |
SslConfiguration.
|
SslConfiguration |
SslConfiguration.
|
SslConfiguration |
SslConfiguration.
|
SslConfigurationBuilder |
SSLConfigurationBuilder.
|
SslConfigurationBuilder |
SSLConfigurationBuilder.
|
SslConfigurationBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>> |
SSLConfigurationBuilder.
|
SslConfigurationChildBuilder |
ProtocolServerConfigurationChildBuilder.
|
SslContextFactory |
SslContextFactory.
|
SslEngineConfiguration |
SslEngineConfiguration
|
SslEngineConfigurationBuilder |
SSLConfigurationBuilder.
|
StackBuilder<T> |
|
StackConfiguration |
|
StackConfigurationBuilder |
|
StackFileConfiguration |
|
StackFileConfigurationBuilder |
|
StateTransferConfiguration |
Configures how state is retrieved when a new cache joins the cluster.
|
StateTransferConfigurationBuilder |
Configures how state is transferred when a cache joins or leaves the cluster.
|
StatisticsConfiguration |
|
StatisticsConfiguration |
Determines whether cache statistics are gathered.
|
StatisticsConfigurationBuilder |
Configures client-side statistics
|
StatisticsConfigurationBuilder |
Determines whether cache statistics are gathered.
|
Stats |
Stats.
|
Storage |
The storage mode of a counter.
|
Storage$___Marshaller_ed04a8616efd062a7c88e9e578efa97c99224ac3211dd20ca76376455f84a9ae |
|
StorageType |
Enumeration defining the various storage types for the data container.
|
StoreConfiguration |
StoreConfiguration contains generic configuration elements available to all the stores.
|
StoreConfigurationBuilder<T extends StoreConfiguration,S extends StoreConfigurationBuilder<T,S>> |
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
|
StoreConfigurationChildBuilder<S> |
|
StoreUnavailableException |
An exception thrown by the PersistenceManager if one or more
stores are unavailable when a cache operation is attempted.
|
StreamAwareMarshaller |
A minimal interface that facilitates the marshalling/unmarshalling of objects from the provided InputStream / OutputStream .
|
StreamingMarshaller |
Deprecated.
|
StreamingRemoteCache<K> |
StreamingRemoteCache implements streaming versions of most RemoteCache methods
|
StreamMarshalling |
Static factory class containing methods that will provide marshallable instances for very common use cases.
|
StreamMarshalling.StreamMarshallingExternalizer |
|
Strength |
|
StringBuilderWriter |
|
StringMarshaller |
|
StringPropertyReplacer |
A utility class for replacing properties in strings.
|
StripedCounters<T> |
Duplicates a set of counters in a set of stripes, so that multiple threads can increment those counters without too
much contention.
|
StrongCounter |
The strong consistent counter interface.
|
SuppliedExternalizer<T> |
|
SyncStrongCounter |
|
SyncWeakCounter |
|
TableJdbcStore<K,V> |
|
TableManipulationConfiguration |
|
TableManipulationConfigurationBuilder<B extends AbstractJdbcStoreConfigurationBuilder<?,B>,S extends TableManipulationConfigurationBuilder<B,S>> |
TableManipulationConfigurationBuilder.
|
TableOperations<K,V> |
|
TakeOfflineConfiguration |
|
TakeOfflineConfigurationBuilder |
|
Task |
|
TaskContext |
TaskContext.
|
TaskExecutionMode |
|
TemporaryGlobalStatePathConfiguration |
|
TemporaryGlobalStatePathConfigurationBuilder |
|
TemporaryTable |
Table holding the entry positions in log before these are persisted to the index.
|
TemporaryTable.LockedEntry |
|
ThreadFactoryConfigurationBuilder |
|
ThreadPoolBuilderAdapter |
|
ThreadPoolConfiguration |
|
ThreadPoolConfigurationBuilder |
|
ThreadPoolExecutorFactory<T extends ExecutorService> |
|
ThreadsConfiguration |
|
ThreadsConfigurationBuilder |
|
TimestampColumnConfiguration |
|
TimestampColumnConfigurationBuilder |
|
TopologyCacheConfiguration |
|
TopologyCacheConfigurationBuilder |
|
TopologyChanged |
This annotation should be used on methods that need to be notified when the ConsistentHash implementation
in use by the DistributionManager changes due to a change in cluster topology.
|
TopologyChangedEvent<K,V> |
|
TouchMode |
Control how the timestamp of read keys are updated on all the key owners in a cluster.
|
TransactionalCache |
This interface is implemented by caches that support (i.e.
|
TransactionalCacheWriter<K,V> |
Deprecated.
|
TransactionalEvent<K,V> |
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.
|
TransactionCompleted |
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> |
|
TransactionConfiguration |
Deprecated.
|
TransactionConfiguration |
Defines transactional (JTA) characteristics of the cache.
|
TransactionConfigurationBuilder |
Deprecated.
|
TransactionConfigurationBuilder |
Defines transactional (JTA) characteristics of the cache.
|
TransactionConfigurationChildBuilder |
|
TransactionMode |
|
TransactionMode |
Transaction mode
|
TransactionMode |
Enumeration containing the available transaction modes for a cache.
|
TransactionRegistered |
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 registered TransactionManager .
|
TransactionRegisteredEvent<K,V> |
|
TransactionTable |
Interface that allows to fetch the GlobalTransaction associated to local or
remote transactions.
|
Transformable |
Annotate objects to convert them to keys that Infinispan can index.
|
Transformer |
Converts objects (cache keys only) to and from their Java types to String representations so that Infinispan can index them.
|
TransportConfiguration |
|
TransportConfigurationBuilder |
Configures the transport used for network communications across the cluster.
|
TransportException |
Indicates a communication exception with the Hot Rod server: e.g.
|
TransportFactory |
TransportFactory is responsible for creating Netty's SocketChannel s and EventLoopGroup s.
|
Traversable<T> |
Unsorted traversable stream for sequential and aggregating operations.
|
TriangleOrderManager |
It manages the order of updates from the primary owner to backup owner.
|
TrustStoreConfiguration |
|
TrustStoreConfigurationBuilder |
|
TypedProperties |
Type-aware properties.
|
UnclosableObjectInputStream |
Deprecated.
|
UnclosableObjectOutputStream |
Deprecated.
|
UnsafeConfiguration |
Controls certain tuning parameters that may break some of Infinispan's public API contracts in
exchange for better performance in some cases.
|
UnsafeConfigurationBuilder |
Controls certain tuning parameters that may break some of Infinispan's public API contracts in exchange for better
performance in some cases.
|
UnsignedNumeric |
Helper to read and write unsigned numerics
|
UserContextInitializer |
Interface used to initialise a SerializationContext using the specified Pojos,
Marshaller implementations and provided .proto schemas.
|
UserContextInitializerImpl |
WARNING: Generated code! Do not edit!
|
UTF8StringMarshaller |
|
Util |
General utility methods used throughout the Infinispan code base.
|
Util.ByteGetter |
Returns the byte at index .
|
ValueMatcherMode |
Value matcher mode.
|
Version |
Contains version information about this release of Infinispan.
|
Version |
Deprecated.
|
Versioned |
Versioned
|
VersionedMetadata |
VersionedMetadata
|
VersionedValue<V> |
Besides the key and value, also contains an version.
|
VersioningScheme |
The various versioning schemes supported
|
ViewChanged |
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 |
This event is passed in to any method annotated with ViewChanged .
|
WeakCounter |
A weak consistent counter interface.
|
WeakValueHashMap<K,V> |
This Map will remove entries when the value in the map has been cleaned from
garbage collection
|
WeakValueHashMap.ValueRef<K,V> |
|
WhiteListConfiguration |
Deprecated. |
WhiteListConfigurationBuilder |
Deprecated.
|
WrappedByteArray |
Simple wrapper around a byte[] to provide equals and hashCode semantics
|
WrappedByteArray.Externalizer |
|
WrappedBytes |
Interface that describes and object holding onto some bytes
|
WritableGridFileChannel |
Deprecated.
|
WriteSkewException |
Thrown when a write skew is detected
|
XMLStringConfiguration |
A simple wrapper for an XML configuration represented as a String.
|
XSiteEntryMergePolicy<K,V> |
An interface to resolve conflicts for asynchronous cross-site replication.
|
XSiteMergePolicy |
|
XSiteStateTransferConfiguration |
Configuration needed for State Transfer between different sites.
|
XSiteStateTransferConfigurationBuilder |
Configuration Builder to configure the state transfer between sites.
|
XSiteStateTransferMode |
Cross site state transfer mode.
|