All Classes and Interfaces
Class
Description
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.
Deprecated.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
Delegating collection that delegates all calls to the collection returned from
AbstractDelegatingCollection.delegate()
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.
Base class for
AdvancedExternalizer
implementations that offers default
implementations for some of its methods.AbstractHotRodServerChildConfigurationBuilder.
Abstract iterator that allows overriding just the
AbstractIterator.getNext()
method to implement it.Deprecated.
since 11.0.
AbstractJdbcStoreConfigurationBuilder<T extends AbstractJdbcStoreConfiguration,S extends AbstractJdbcStoreConfigurationBuilder<T,S>>
AbstractJdbcStoreConfigurationChildBuilder.
AbstractJdbcStoreConfigurationSerializer.
This is a base class that should be used when implementing a KeyValueFilterConverter that provides default
implementations for the
KeyValueFilter.accept(Object, Object, org.infinispan.metadata.Metadata)
and Converter.convert(Object, Object, org.infinispan.metadata.Metadata)
methods so they just call the
KeyValueFilterConverter.filterAndConvert(Object, Object, org.infinispan.metadata.Metadata)
method and then do the right thing.Similar to the JDK's AbstractMap, this provides common functionality for custom map implementations.
Abstract Marshaller implementation containing shared implementations.
AbstractModuleConfigurationBuilder.
AbstractPersistenceConfigurationChildBuilder.
AbstractProtocolServerConfigurationChildBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>>
Helper
AbstractRemoteStoreConfigurationChildBuilder.
AbstractSchemaJdbcStore<K,V,C extends org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration>
AbstractSchemaJdbcStore.ProtoSchemaOptions<K,V,C extends org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration>
AbstractSchemaJdbcStore.SchemaTableOperations<K,V,C extends org.infinispan.persistence.sql.configuration.AbstractSchemaJdbcConfiguration>
AbstractSecurityConfigurationChildBuilder.
AbstractSecurityConfigurationChildBuilder.
Abstract store configuration that should be extended when the store configuration supports being segmented.
AbstractStoreConfigurationBuilder<T extends StoreConfiguration,S extends AbstractStoreConfigurationBuilder<T,S>>
A key value filter that accepts all entries found.
The
BufferSizePredictor
that automatically increases and
decreases the predicted buffer size on feed back.An advanced interface that exposes additional methods not available on
Cache
.Deprecated.
since 11.0 replaced by
NonBlockingStore
Callback to be notified when an entry is removed by the
AdvancedCacheExpirationWriter.purge(Executor, ExpirationPurgeListener)
method.Deprecated.
since 11.0 replaced by
NonBlockingStore
Deprecated.
since 11.0 replaced by
NonBlockingStore
Callback to be notified when an entry is removed by the
AdvancedCacheWriter.purge(java.util.concurrent.Executor, org.infinispan.persistence.spi.AdvancedCacheWriter.PurgeListener)
method.Deprecated.
since 10.0, will be removed in a future release.
Deprecated.
since 11.0 replaced by
NonBlockingStore
A ClassLoader that delegates loading of classes and resources to a list of delegate ClassLoaders.
Configures the
EmbeddedCacheManager
ClassAllowList
.Handler responsible for TLS/ALPN negotiation.
A
XSiteEntryMergePolicy
that removes the key if a conflict is detected.Base for classes that implement hash map by storing keys in one array and values in another.
AsyncCache.
Configuration for the async cache store.
Configuration for the async cache store.
Enumerates the attributes used by the JDBC cache stores configuration
Enumerates the attributes used by the Remote cache store configuration
Enumerates the attributes used by the LevelDB cache stores configuration
AuditContext.
AuditLogger.
AuthenticationConfiguration.
AuthenticationConfiguration.
AuthenticationConfiguration.
AuthenticationConfiguration.
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder.
AuthenticationConfigurationBuilder.
Authentication mechanism.
AuthorizationConfiguration.
AuthorizationConfigurationBuilder.
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.
Thrown when a partition happened and the key that an operation tries to access is not available.
Defines the possible behaviour in case of failure during x-site.
Defines the remote caches for which this cache acts as a backup.
Interface that defines the base methods of all streams returned from a
Cache
.Functional interface that is used as a callback when segments are completed.
BasicCache provides the common building block for the two different types of caches that Infinispan provides:
embedded and remote.
BasicCacheContainer defines the methods used to obtain a
BasicCache
.BasicConfiguration provides the basis for concrete configurations.
BasicMultimapCache
provides the common API for the two different types of multimap caches that Infinispan
provides: embedded and remote.The BatchingCache is implemented by all caches which support batching
Simple JavaBean manipulation helper methods
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).
A handler for rejected tasks that runs the task if the current thread is a blocking thread otherwise it
rejects the task.
Interface to designate the resource is a blocking one.
Deprecated.
since 12.0 with no replacement
Buffer size predictor
Builder.
BuiltBy.
This class can be used to pass an argument by reference.
Implementation for primitive type
A byte buffer that exposes the internal byte array with minimal copying.
Used for building instances of
ByteBuffer
.A byte buffer that exposes the internal byte array with minimal copying
Parser human-readable quantity of bytes.
The central interface of Infinispan.
Interface that describes how a cache can be injected into another object.
A
CacheException
that is thrown when the backpressure has been filled an unable to process the request.A collection type that returns special Cache based streams that have additional options to tweak behavior.
Helper class designed to be used to create a serializable Collector for use with
CacheStream.collect(Collector)
from a supplier of a collector.An exception that represents an error in the configuration.
Administrative cache container operations.
Flags which affect only administrative operations
Deprecated.
Since 10.1.3.
A helper class for controlling Cache Control headers.
This annotation should be used on methods that need to be notified when cache entries are evicted.
This event subtype is passed in to any method annotated with
CacheEntriesEvicted
.This annotation should be used on methods that need to be notified when a cache entry is activated.
This event subtype is passed in to any method annotated with
CacheEntryActivated
.This annotation should be used on methods that need to be notified when a cache entry is created.
This event subtype is passed in to any method annotated with
CacheEntryCreated
.A transactional event subtype that additionally expose a key as such events pertain to a specific cache entry.
This annotation should be used on methods that need to be notified when a cache entry is expired
This event subtype is passed in to any method annotated with
CacheEntryExpired
.An
InputStream
that reads from a CacheStream
of byte[] and produces a JSON output.This annotation should be used on methods that need to be notified when a cache entry is invalidated.
Notifies a listener of an invalidation event.
This annotation should be used on methods that need to be notified when a cache entry is loaded from a
CacheLoader
.This event subtype is passed in to any method annotated with
CacheEntryLoaded
.This annotation should be used on methods that need to be notified when a cache entry has been modified.
This event subtype is passed in to any method annotated with
CacheEntryModified
This annotation should be used on methods that need to be notified when cache entries are passivated.
This event subtype is passed in to any method annotated with
CacheEntryPassivated
.This annotation should be used on methods that need to be notified when a cache entry is removed from the cache.
This event subtype is passed in to any method annotated with
CacheEntryRemoved
.This annotation should be used on methods that need to be notified when a cache entry is visited.
This event subtype is passed in to any method annotated with
CacheEntryVisited
.A converter that can be used to convert the value given for an event.
Converter that is implemented by using the provided CacheEventConverter.
Factory that can produce CacheEventConverters
A filter that can be used to tell if an event should be raised or not.
KeyValueFilter that is implemented by using the provided CacheEventFilter.
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.
Factory that can produce
CacheEventFilterConverter
instances.Factory that can produce CacheEventFilters
Thrown when operations fail unexpectedly.
Static factory class that contains utility methods that can be used for performing proper transformations from
KeyValueFilter
, Converter
and KeyValueFilterConverter
to appropriate distributed stream
instances.An
InputStream
that reads from a CacheStream
of byte[] and produces a JSON output.Wraps exceptions produced by listener implementations.
Deprecated.
since 11.0 replaced by
NonBlockingStore
Cache replication mode.
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.
CachePermissionCollection.
A set that also must implement the various
CacheCollection
methods for streams.This annotation should be used on methods that need to be notified when a cache is started.
This event is passed in to any method annotated with
CacheStarted
.This annotation should be used on methods that need to be notified when a cache is stopped.
This event is passed in to any method annotated with
CacheStopped
.Contains information about cache topology including servers and owned segments.
Deprecated.
since 11.0 replaced by
NonBlockingStore
A handler for rejected tasks that runs the rejected task
directly in the calling thread of the
execute
method.Deprecated.
The
ClassAllowList
maintains classes definitions either by name or regular expression and is used for
permissioning.Find infinispan classes utility
Interface that enhances
FilteringListenable
with the possibility of specifying the
ClassLoader
which should be set as the context class loader for the invoked
listener methodInterface that enhances
Listenable
with the possibility of specifying the
ClassLoader
which should be set as the context class loader for the invoked
listener methodA
URLStreamHandlerFactory
which can handle classpath: URI schemes.Deprecated.
since 12.0.
Client side cache entry created events provide information on the created
key, and the version of the entry.
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.
Client side cache entry expired events provide information on the expired key.
Client side cache entry modified events provide information on the modified
key, and the version of the entry after the modification.
Client side cache entry removed events provide information on the removed key.
Event received when the registered listener fails over to a different node.
ClientIntelligence specifies the level of intelligence used by the client.
Annotation that marks a class to receive remote events from Hot Rod caches.
Interface that provides semantics of a
Iterable
and AutoCloseable
interfaces.Interface that provides semantics of a
Iterator
and AutoCloseable
interfaces.A collection that defines an iterator method that returns a
CloseableIterator
instead of a non closeable one.Adapts
Collection
to CloseableIteratorCollection
A set that defines an iterator method that returns a
CloseableIterator
instead of a non closeable one.Adapts
Set
to CloseableIteratorSet
This class consists exclusively of static methods that operate on or return closeable interfaces.
Interface that provides semantics of a
Spliterator
and AutoCloseable
interfaces.Similar to
Stats
but cluster wide.Cluster wide container statistics.
ClusteredLock is a data structure used for concurrent programming between Infinispan instances in cluster mode.
A Clustered Lock can be reentrant and there are different ownership levels.
Exception used to handle errors on clustered locks
Provides the API to define, create and remove ClusteredLocks.
ClusterExecutionPolicy controls how which nodes commands submitted via
ClusterExecutor
.A cluster executor that can be used to invoke a given command across the cluster.
Defines clustered characteristics of the cache.
Defines clustered characteristics of the cache.
Deprecated.
since 11.0.
Deprecated.
since 11.0.
Deprecated.
since 11.0.
CommonNameRoleMapper.
Different states a component may be in.
Allows AND-composing several cache event filters.
Allows AND-composing several key/value filters.
Iterator that concatenates a bunch of iterables into 1 big iterator.
Configuration.
ConfigurationBuilder used to generate immutable
Configuration
objects to pass to the
RemoteCacheManager(Configuration)
constructor.This annotation should be used on methods that need to be notified when a configuration is changed.
This event is passed in to any method annotated with
ConfigurationChanged
.ConfigurationChildBuilder.
ConfigurationFor.
Helper configuration methods.
Configuration storage
ConfigurationUtils.
Defines the configuration used to configure the given class instances
A
ConflictManager
factory for cache instances.ConnectionFactoryConfiguration.
ConnectionPoolConfiguration.
ConnectionPoolConfigurationBuilder.
ConnectionPoolConfigurationBuilder.
A consistent hash algorithm implementation.
Deprecated.
Since 11.0.
Various public constant names, used by Infinispan's microprofile metrics support.
A container of continuous query listeners for a cache.
Listener for continuous query events.
Converter that can be used to transform a given entry to a different value.
Handles Cross Origin Resource Sharing (CORS) requests.
A counter configuration used to define counters cluster wide via
CounterManager.defineCounter(String, CounterConfiguration)
.The builder of
CounterConfiguration
.WARNING: Generated code! Do not edit!
Signals a missing configuration or an invalid configuration.
The event used by
CounterListener
.A
RuntimeException
related to counters.A listener interface to listen to
StrongCounter
changes.The
CounterManager
creates, defines and returns counters.A
CounterException
signalling that the StrongCounter
has reached its bounds.The possible states for a counter value.
The counter types.
Used for implementing custom policies in case of communication failures with a remote site.
Deprecated.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
Deprecated.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
StoreConfigurationBuilder used for stores/loaders that don't have a configuration builder
Supported database dialects for the JDBC cache stores
The main internal data structure which stores entries.
Defines data format for keys and values during Hot Rod client requests.
Deprecated.
Since 11.0.
This annotation should be used on methods that need to be notified when a rehash starts or ends.
An event passed in to methods annotated with
DataRehashed
.The default implementation of
EmbeddedCacheManagerAdmin
Deprecated.
since 11.0.
This enum lists the cache configuration templates names that are available in the server by default.
The default
XSiteEntryMergePolicy
implementation.A wrapper around a
CacheEntryListenerInvocation
that keeps a reference to the FilterIndexingServiceProvider
instance that handles this invocation.Class that extends
InputStream
and implements ObjectInput
.Class that extends
OutputStream
and implements ObjectOutput
.A component that manages the distribution of elements across a cache cluster
A
DoubleStream
that has additional methods to allow for Serializable instances.An enumeration of all the recognized XML element local names for the JDBC cache stores
An enumeration of all the recognized XML element local names for the
RemoteStore
An enumeration of all the recognized XML element local names for the RocksDB cache store
EmbeddedCacheManager is an CacheManager that runs in the same JVM as the client.
Cache manager operations which affect the whole cluster.
An exception to encapsulate an error when starting up a cache manager
A
ClusteredLockManager
factory for embedded caches.WARNING: Generated code! Do not edit!
WARNING: Generated code! Do not edit!
WARNING: Generated code! Do not edit!
Metadata class for embedded caches.
WARNING: Generated code! Do not edit!
A
MultimapCache
factory for embedded cached.Controls encoding configuration for keys and values in the cache.
Interface that can look up MVCC wrapped entries.
A registry for
EntryMergePolicyFactory
implementations, which allows EntryMergePolicy
implementations
to be eagerly/lazily loaded across multiple contexts.Object to hold metadata bytes and timestamps.
Helper for reading/writing entries into file.
Entry views expose cached entry information to the user.
Expose read-only information about a cache entry potentially associated
with a key in the functional map.
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.
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.
An Enumeration → List adaptor
Utilities method to Enums.
An interface that defines common characteristics of events
Common characteristics of events that occur on a cache manager
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.
Deprecated.
since 10.0 - This class is not used internally anymore
Central component that deals with eviction of cache entries.
Supported eviction strategies
Deprecated.
Since 11.0,
MemoryConfiguration.maxCount()
and
MemoryConfiguration.maxSize()
should be used to differentiate between
the eviction thresholds.Used to configure and create executors
ExecutorFactoryConfiguration.
Configures executor factory.
Configures executor factory.
Configures executor factory.
Enumeration for whenExhaustedAction.
Deprecated.
since 10.0
An experimental user-facing API.
Controls the default expiration settings for entries in the cache.
Controls the default expiration settings for entries in the cache.
Central component that deals with expiration of cache entries.
WARNING: Generated code! Do not edit!
Deprecated.
Since 13.0, please use
LazyByteArrayOutputStream
instead.Deprecated.
since 10.1.
Deprecated.
since 11.0.
Deprecated.
since 11.0.
Deprecated.
since 10.0, will be removed in a future release.
1800 to 1899 range is reserved for this module
Deprecated.
since 11.0 replaced by
NonBlockingStore
Defines what servers will be selected when a smart-routed request fails.
A HashMap that is optimized for fast shallow copies.
Features allow conditional enabling/disabling of Infinispan's functionality.
Provides resource management for files - only limited amount of files may be opened in one moment, and opened file
should not be deleted.
A single-method callback that is specified when registering a filter with a Matcher.
Deprecated.
since 10.1.
Deprecated.
since 10.1.
Deprecated.
since 10.1.
Deprecated.
since 10.1.
A service provider for filter indexing services.
A Listenable that can also filter events based on key
Iterator that also filters out entries based on the provided predicate.
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.
Spliterator that only returns entries that pass the given predicate.
A subscription for match notifications.
Defines all the flags available in the Hot Rod client that can influence the behavior of operations.
Available flags, which may be set on a per-invocation basis.
Implemented by stores that can skip writes based on certain flags present in the invocation.
Composes an array of Collections into a spliterator.
A list which forwards all its method calls to another list.
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.
Exposes read-only operations that can be executed against the functional map.
Exposes read-write operations that can be executed against the functional map.
Exposes write-only operations that can be executed against the functional map.
A marshaller that makes use of JBoss Marshalling
to serialize and deserialize objects.
GlobalAuthorizationConfiguration.
GlobalAuthorizationConfigurationBuilder.
Configuration component that exposes the global configuration.
The
GlobalConfigurationManager
is the main interface for sharing runtime configuration state across a cluster.Interface used to initialise the global
SerializationContext
using the specified Pojos,
and the generated proto files and marshallers.WARNING: Generated code! Do not edit!
Configures JMX for the cache manager and its caches.
Deprecated.
since 10.1.3 Use
GlobalJmxConfiguration
instead.Deprecated.
since 10.1.3.
Configuration for microprofile metrics.
Configures the types of metrics gathered and exported via microprofile metrics for all caches owned by this cache
manager.
GlobalRoleConfigurationBuilder.
GlobalSecurityConfiguration.
GlobalSecurityConfigurationBuilder.
GlobalSecurityConfigurationChildBuilder.
GlobalSecurityManager.
GlobalStateConfiguration.
GlobalStateConfigurationBuilder.
GlobalStateManager.
GlobalStateProvider.
Utility functions for globs
Deprecated.
since 10.0
Deprecated.
since 10.0
Deprecated.
since 10.0
Deprecated.
since 10.0
Identifies the key for a 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.Configuration for various grouper definitions.
Configuration for various grouper definitions.
As a return of
StrongCounter.addListener(CounterListener)
, it is used to un-register the CounterListener
.Interface that governs implementations
Allows fine-tuning of rehashing characteristics.
Allows fine-tuning of rehashing characteristics.
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).
Base class for exceptions reported by the hot rod client.
HotRodServerChildConfigurationBuilder.
HotRodServerConfigurationBuilder.
Signals an remote timeout(due to locking) in the infinispan server.
A marshaller that does not transform the content, only applicable to byte[] payloads.
IdentityRoleMapper.
Internal marshalling identifiers.
This exception is thrown when the cache or cache manager does not have the
right lifecycle state for operations to be called on it.
Deprecated.
since 10.1 please use
IllegalLifecycleStateException
insteadWrap a
HopscotchHashMap
and allow using it as a Set
.Deprecated.
since 9.3 This class will no longer be public, please use
IntSets.immutableSet(IntSet)
A lightweight, read-only copy of a List.
Deprecated.
since 10.0
A ProtoStream
Marshaller
implementation that uses Protobuf encoding.Factory for generating immutable type wrappers.
Thrown when an incorrectly annotated class is added as a cache listener using the
Listenable.addListener(Object)
API.Deprecated.
since 11.0.
A marker interface for filters that can be handled efficiently by a
FilterIndexingServiceProvider
.Interacts directly with cache indexes.
Configures indexing of entries in the cache for searching.
Configures indexing of entries in the cache for searching.
Static helpers for Infinispan-specific collections
A function that converts a type into another one.
A function that converts an entry into a key/value pair for use in a map.
Aggregates the initialisation state needed by either a
CacheLoader
or a CacheWriter
.This is a marker interface to be used with
Function
which signals to some implementors that
the function returns distinct values.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.
A
IntStream
that has additional methods to allow for Serializable instances.Describes a custom interceptor
Positional placing of a new custom interceptor
Deprecated.
Since 10.0, custom interceptors support will be removed and only modules will be able to define interceptors
Deprecated.
since 10.0
A set that represents primitive ints.
Static utility class for creating various
IntSet
objects.IntSets externalization mechanism
Thrown when client makes cache usage errors.
Signals an internal protocol error.
A context that contains information pertaining to a given invocation.
Factory for
InvocationContext
objects.IpFilterConfigurationBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>>
IpFilterConfigurationBuilder.
A iterator that maps each value to the output of the Function.
Standard Java serialization marshaller.
Deprecated.
since 11.0.
Deprecated.
since 11.0.
JdbcStoreConfigurationChildBuilder.
JDBC cache store configuration parser.
AdvancedCacheLoader
implementation that stores the entries in a database.JdbcStringBasedStoreConfigurationBuilder.
JdbcStringBasedStoreConfigurationSerializer.
Contains common methods used by JDBC CacheStores.
Deprecated.
since 10.1.3.
Deprecated.
since 10.1.3.
Defines a service that generates keys to be mapped to specific nodes in a distributed(vs.
Factory for
KeyAffinityService
.Used for generating keys; used by
KeyAffinityService
to generate the affinity keys.Map keys to segments.
A filter for keys with their values.
CacheEventFilter that implements it's filtering solely on the use of the provided KeyValueFilter
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.
CacheEventFilterConverter
that uses an underlying KeyValueFilterConverter
to do the conversion and
filtering.Factory for
KeyValueFilterConverter
instancesWARNING: Generated code! Do not edit!
Configures the L1 cache behavior in 'distributed' caches instances.
Configures the L1 cache behavior in 'distributed' caches instances.
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.
A lambda
AdvancedExternalizer
.ByteArrayOutputStream alternative exposing the internal buffer.
A wrapper around system properties that supports legacy keys
Lifecycle interface that defines the lifecycle of components
A handler for rejected tasks that always throws a
IllegalLifecycleStateException
.Interface that denotes that the implementation can have listeners attached to it.
Class-level annotation used to annotate an object as being a valid cache listener.
Enumeration that defines when a listener event can be observed.
Used for registering various cache notifications.
Holder class for functional listener definitions.
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.
Read-write listener
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.
Write-only listener.
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
The
LocalConfigurationStorage
is responsible for applying on each node the configuration changes initiated
through the GlobalConfigurationManager
and persist them unless they are
CacheContainerAdmin.AdminFlag.VOLATILE
.Extends
CacheTopology
with information about keys owned by the local node.Deprecated.
since 11.0.
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.Defines the local, in-VM locking and concurrency characteristics of the cache.
Defines the local, in-VM locking and concurrency characteristics of the cache.
This module reserves range 29001 - 29500
LoggingAuditLogger.
A
LongStream
that has additional methods to allow for Serializable instances.ManagedConnectionFactoryConfiguration.
ManagedConnectionFactoryConfigurationBuilder.
Defines an externally persisted entry.
Factory for
MarshallableEntry
.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.
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.
Deprecated.
since 10.0 requires jboss-marshalling-osgi artifact to be provided at runtime.
A marshaller is a class that is able to marshall and unmarshall objects efficiently.
An exception that can be thrown by a cache if an object cannot be successfully serialized/deserialized.
MarshallUtil.
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
).Implementors of this should return an MBeanServer to which MBeans will be registered.
Deprecated.
since 10.1.
Deprecated.
since 10.1.
Controls the memory storage configuration for the cache.
Controls the data container for the cache.
Deprecated.
Since 11.0,
MemoryConfiguration
is used to defined the data container memory
eviction and sizing.Deprecated.
since 11.0, use
MemoryConfigurationBuilder
instead.Deprecated.
since 11.0, use
ByteQuantity
instead.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.
This event is passed in to any method annotated with
Merged
.Represents metadata about an entry, such as creation and access times and expiration information.
This interface encapsulates metadata information that can be stored
alongside values in the cache.
Metadata builder
WARNING: Generated code! Do not edit!
Utility method for Metadata classes.
Besides the value, also contains a version and expiration information.
An easily extensible metadata parameter that's stored along with the value
in the the functional map.
Provides metadata parameter lookup capabilities using
Class
as
lookup key.Read only metadata parameter representing a cached entry's created time
in milliseconds.
Writable metadata parameter representing a cached entry's generic version.
Read only metadata parameter representing a cached entry's last used time
in milliseconds.
Writable metadata parameter representing a cached entry's millisecond lifespan.
Non-writable parameter telling if the entry was loaded from a persistence tier
(
CacheLoader
) or not.Abstract class for numeric long-based metadata parameter instances.
Writable metadata parameter representing a cached entry's millisecond
max idle time.
A parameter to tell if the creation timestamp should be updated for modified entries.
Writable
MetaParam
instances are those that the user can provide
to be stored as part of the cache entry.Deprecated.
since 10.0
ModuleLifecycle is an API hook for delegating lifecycle events to Infinispan sub-modules.
Embedded version of MultimapCache.
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.
BloomFilter implementation that allows for up to 10 hash functions all using MurmurHash3 with different
seeds.
Decides how client-side near caching should work.
A
RestRequest
backed by Netty.A
RestResponse
backed by Netty.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
Interface to designate the resource is a non blocking one
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).
The contract for defining how caches interface with external sources of data, such as databases or filesystems.
Enumeration defining the various characteristics of the underlying store to communicate what features it may
or may not support.
A Publisher that provides a stream of values and the segments to which those values map.
A simplistic non-reentrant lock that does not use ownership by thread.
An externalizer that writes no state.
An exception that hides inner stacktrace lines for non serializable exceptions.
NullAuditLogger.
A placeholder for null in a cache, because caches do not allow null values.
WARNING: Generated code! Do not edit!
Deprecated.
Since 12, will be removed in version 15.0
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.
The output of the
ObjectFilter.filter(java.lang.Object)
method.Operating system family.
Ownership level is a configuration parameter for
ClusteredLock
.Deprecated.
since 10.1.
An easily extensible parameter that allows functional map operations to be
tweaked.
Defines where is the command executed.
Normally the cache has to acquire locks during any write operation to guarantee
its correctness.
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.
Defines how statistics are gathered for this command.
Deprecated.
since 10.1.
Parameter identifiers.
Factory for
KeyValueFilterConverter
instances supporting
parameters.Thrown in case of syntax errors during parsing or during the processing of the parse tree.
Controls how the cache handles partitioning and/or multiple node failures.
Controls how the cache handles partitioning and/or multiple node failures.
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.The event passed in to methods annotated with
PartitionStatusChanged
.Deprecated.
since 11.0 with no replacement - no longer used
Use this annotation on methods that require notification when the availability of the PersistenceManager changes.
Configuration for stores.
Configuration for cache stores.
Interface used to initialise a
SerializationContext
using the specified Pojos,
Marshaller implementations and provided .proto schemas.WARNING: Generated code! Do not edit!
WARNING: Generated code! Do not edit!
An exception thrown by a
CacheLoader
or a CacheWriter
implementation if there are problems
reading from a loader.The marshaller that is responsible serializing/deserializing objects which are to be persisted.
Default implementation for
MBeanServerLookup
, will return the platform MBean server.PooledConnectionFactoryConfigurationBuilder.
A Filter that only allows post events to be accepted.
A
XSiteEntryMergePolicy
implementation that chooses a non-null entry.A
XSiteEntryMergePolicy
implementation that chooses a null entry.PrincipalRoleMapper.
PrincipalRoleMapperContext.
Provides general information about the processors on this host.
A property style format for
CounterConfiguration
.Useful constants used by the Protobuf metadata cache.
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.ServerConfiguration.
ProtocolServerConfigurationBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>>
ProtocolServerConfigurationChildBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>>
ProtocolServerConfigurationChildBuilder.
Enumeration of supported Hot Rod client protocol VERSIONS.
Provides the starting point for implementing a
Marshaller
that uses Protobuf
encoding.TypeIds used by protostream in place of FQN message/enum names to reduce payload size.
Proxies is a collection of useful dynamic profixes.
An immutable object representing both the query and the result.
Deprecated.
since 10.1.
Factory for query DSL objects.
Represents the result of a
Query
.Deprecated.
since 10.1.
Deprecated.
since 10.1.
Deprecated.
since 9.3 This class will no longer be public.
Deprecated.
since 10.0
Defines recovery configuration for the cache.
Defines recovery configuration for the cache.
Basic reflection utilities to enhance what the JDK provides.
Provides remote reference to a Hot Rod server/cluster.
Per-cache configuration.
Factory for
RemoteCache
s.Remote Administration operations
Thrown when trying to use an
RemoteCache
that is associated to an
RemoteCacheManager
that was not started.A
CounterManager
factory for Hot Rod client.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.
When a remote node is suspected and evicted from the cluster while an
operation is ongoing, the Hot Rod client emits this exception.
Cache store that delegates the call to a infinispan cluster.
RemoteStoreConfigurationBuilder.
Remote cache store parser.
RemoteStoreConfigurationSerializer.
Listener that is notified when a remote value is looked up
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.
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.
Creates Netty Channels for this server.
Netty handler for REST requests.
An exception representing non-critical HTTP processing errors which will be translated
into
RestResponse
and sent back to the client.REST Protocol Server.
RestServerConfigurationBuilder.
A set that allows reverse iteration of the set elements, exposed via the
ReversibleOrderedSet.reverseIterator()
method.Deprecated.
since 11.0.
since 10.0
RocksDB XML Parser
RocksDBStoreConfigurationSerializer.
A role to permission mapping.
SaslQop.
SaslStrength.
Utility methods for handling SASL authentication
Configures executor factory.
ScopedPersistentState represents state which needs to be persisted, scoped by name (e.g.
Key for scoped entries in the ClusterConfigurationManager state cache
A filter for
ScopedState
that allows listeners of the global state cache to choose events by scope.Entry point for performing Infinispan queries.
Thrown when a query timeout occurs.
SecureCache.
Security.
Used to configure and create executors which are aware of the current security context
SecurityConfiguration.
SecurityConfiguration.
SecurityConfiguration.
SecurityConfigurationBuilder.
SecurityConfigurationBuilder.
SecurityConfigurationBuilder.
Pluggable security domain which could be used as a bridge between
Authenticator
and
WildFly Security Realms.Encapsulates the key and its segment.
Deprecated.
since 11.0 replaced by
NonBlockingStore
This interface simplifies the task of writing fluent builders which need to inherit from
other builders (abstract or concrete).
Configures serialization and marshalling settings.
Indicate that this function should be serialized with an instance of
the given
Externalizer
class.Deprecated.
since 10.0, will be removed in a future release.
Deprecated.
since 11.0.
ServerConfiguration.
ServerConfigurationBuilder.
Defines the possible list of statistics defined by the Hot Rod server.
An interface representing a deployed server task.
ServiceFinder is a
ServiceLoader
replacement which understands multiple classpaths.Behavior of the JVM shutdown hook registered by the cache
Variable length encoding for signed numbers, using the ZigZag technique
SimpleConnectionFactoryConfiguration.
SimpleConnectionFactoryBuilder.
Where is Java 1.6?
A filesystem-based implementation of a
NonBlockingStore
.Defines the configuration for the single file cache store.
Single file cache store configuration builder.
Deprecated.
since 11.0.
Deprecated.
since 11.0.
It stores the entry value and
Metadata
for a specific site.Deprecated.
since 9.3 This class will no longer be public.
Sort specification for a field.
Deprecated.
since 10.1.
A spliterator that has been mapped from another spliterator.
SslConfiguration.
SslConfiguration.
SslConfiguration.
SSLConfigurationBuilder.
SSLConfigurationBuilder.
SslConfigurationBuilder<T extends ProtocolServerConfiguration,S extends ProtocolServerConfigurationChildBuilder<T,S>>
SSLConfigurationBuilder.
ProtocolServerConfigurationChildBuilder.
SslContextFactory.
SslEngineConfiguration
SSLConfigurationBuilder.
Configures how state is retrieved when a new cache joins the cluster.
Configures how state is transferred when a cache joins or leaves the cluster.
Determines whether cache statistics are gathered.
Configures client-side statistics
Determines whether cache statistics are gathered.
Stats.
The storage mode of a counter.
Enumeration defining the various storage types for the data container.
StoreConfiguration contains generic configuration elements available to all the stores.
LoaderConfigurationBuilder is an interface which should be implemented by all cache loader builders
An exception thrown by the
PersistenceManager
if one or more
stores are unavailable when a cache operation is attempted.A minimal interface that facilitates the marshalling/unmarshalling of objects from the provided
InputStream
/OutputStream
.Deprecated.
for internal use only
StreamingRemoteCache implements streaming versions of most
RemoteCache
methodsStatic factory class containing methods that will provide marshallable instances for very common use cases.
A utility class for replacing properties in strings.
Duplicates a set of counters in a set of stripes, so that multiple threads can increment those counters without too
much contention.
The strong consistent counter interface.
A synchronous
StrongCounter
.A synchronous
WeakCounter
.TableManipulationConfigurationBuilder<B extends AbstractJdbcStoreConfigurationBuilder<?,B>,S extends TableManipulationConfigurationBuilder<B,S>>
TableManipulationConfigurationBuilder.
TaskContext.
Table holding the entry positions in log before these are persisted to the index.
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.The event passed in to methods annotated with
TopologyChanged
.Control how the timestamp of read keys are updated on all the key owners in a cluster.
This interface is implemented by caches that support (i.e.
Deprecated.
since 11.0 replaced by
NonBlockingStore
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.
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.
This event is passed in to any method annotated with
TransactionCompleted
.Deprecated.
since 12.0.
Defines transactional (JTA) characteristics of the cache.
Deprecated.
since 12.0.
Defines transactional (JTA) characteristics of the cache.
Specifies how the
RemoteCache
is enlisted in the Transaction
.Transaction mode
Enumeration containing the available transaction modes for a cache.
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
.This event is passed in to any method annotated with
TransactionRegistered
.Interface that allows to fetch the
GlobalTransaction
associated to local or
remote transactions.Annotate objects to convert them to keys that Infinispan can index.
Converts objects (cache keys only) to and from their Java types to String representations so that Infinispan can index them.
Configures the transport used for network communications across the cluster.
Indicates a communication exception with the Hot Rod server: e.g.
TransportFactory is responsible for creating Netty's
SocketChannel
s and EventLoopGroup
s.Unsorted traversable stream for sequential and aggregating operations.
It manages the order of updates from the primary owner to backup owner.
Type-aware properties.
Deprecated.
since 10.0
Deprecated.
since 10.0
Controls certain tuning parameters that may break some of Infinispan's public API contracts in
exchange for better performance in some cases.
Controls certain tuning parameters that may break some of Infinispan's public API contracts in exchange for better
performance in some cases.
Helper to read and write unsigned numerics
Interface used to initialise a
SerializationContext
using the specified Pojos,
Marshaller implementations and provided .proto schemas.WARNING: Generated code! Do not edit!
General utility methods used throughout the Infinispan code base.
Returns the byte at
index
.Value matcher mode.
Contains version information about this release of Infinispan.
Deprecated.
Use
Version
insteadVersioned
VersionedMetadata
Besides the key and value, also contains an version.
The various versioning schemes supported
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).
This event is passed in to any method annotated with
ViewChanged
.A weak consistent counter interface.
This Map will remove entries when the value in the map has been cleaned from
garbage collection
Deprecated.
Deprecated.
since 12.0.
Simple wrapper around a byte[] to provide equals and hashCode semantics
WARNING: Generated code! Do not edit!
Interface that describes and object holding onto some bytes
Deprecated.
since 10.0
Thrown when a write skew is detected
A simple wrapper for an XML configuration represented as a String.
An interface to resolve conflicts for asynchronous cross-site replication.
An alias with the provided implementation of
XSiteEntryMergePolicy
.Configuration needed for State Transfer between different sites.
Configuration Builder to configure the state transfer between sites.
Cross site state transfer mode.