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.
|
AbstractCacheStream<Original,T,S extends BaseStream<T,S>,S2 extends S> |
Abstract stream that provides all of the common functionality required for all types of Streams including the various
primitive types.
|
AbstractCacheStream.MapOpsExternalizer |
|
AbstractCacheTransaction |
Base class for local and remote transaction.
|
AbstractCloseableIteratorCollection<O,K,V> |
Abstract collection that uses an underlying Cache instance to do various operations.
|
AbstractClusterStats |
|
AbstractComponentFactory |
Factory that creates components used internally within Infinispan, and also wires dependencies into the components.
|
AbstractComponentRegistry |
Deprecated.
|
AbstractConsistentHash |
|
AbstractConsistentHashFactory<CH extends ConsistentHash> |
|
AbstractControlledLocalTopologyManager |
Class to be extended to allow some control over the local topology manager when testing Infinispan.
|
AbstractCustomFailurePolicy<K,V> |
|
AbstractCustomInterceptorsConfigurationChildBuilder |
|
AbstractDataCommand |
|
AbstractDataWriteCommand |
Stuff common to WriteCommands
|
AbstractDelegatingAdvancedCache<K,V> |
Deprecated.
|
AbstractDelegatingAdvancedCache<K,V> |
|
AbstractDelegatingAdvancedCache.AdvancedCacheWrapper<K,V> |
|
AbstractDelegatingCache<K,V> |
Deprecated.
|
AbstractDelegatingCache<K,V> |
This is a convenient base class for implementing a cache delegate.
|
AbstractDelegatingCacheCollection<E> |
|
AbstractDelegatingCacheSet<E> |
|
AbstractDelegatingCacheStream<R> |
Delegate that forwards all the of the method calls to the underlying cache stream.
|
AbstractDelegatingCloseableIteratorCollection<E> |
|
AbstractDelegatingCloseableIteratorSet<E> |
|
AbstractDelegatingDataContainer<K,V> |
|
AbstractDelegatingEmbeddedCacheManager |
Deprecated.
|
AbstractDelegatingEmbeddedCacheManager |
This is a convenient base class for implementing a cache manager delegate.
|
AbstractDelegatingEntryCacheSet<K,V> |
Abstract cache entry set that delegates to the underlying cache for stream usage
|
AbstractDelegatingHandler |
|
AbstractDelegatingInternalDataContainer<K,V> |
|
AbstractDelegatingKeyCacheSet<K,V> |
Abstract cache key set that delegates to the underlying cache for stream usage
|
AbstractDelegatingTransport |
Designed to be overwrite.
|
AbstractEnlistmentAdapter |
Base class for both Sync and XAResource enlistment adapters.
|
AbstractFlagAffectedCommand |
Base class for those commands that can carry flags.
|
AbstractForEachDoubleOperation<Original,K> |
Terminal rehash aware operation that handles for each where no flat map operations are defined on a
DoubleStream .
|
AbstractForEachIntOperation<Original,K> |
Terminal rehash aware operation that handles for each where no flat map operations are defined on a
IntStream .
|
AbstractForEachLongOperation<Original,K> |
Terminal rehash aware operation that handles for each where no flat map operations are defined on a
LongStream .
|
AbstractForEachOperation<Original,K,V,S extends BaseStream<V,S>> |
This is a base operation class for the use of the for each terminal operator.
|
AbstractGlobalModuleConfigurationBuilder |
|
AbstractInternalCacheEntry |
An abstract internal cache entry that is typically stored in the data container
|
AbstractInternalDataContainer<K,V> |
Abstract class implemenation for a segmented data container.
|
AbstractInvocationContext |
Common features of transaction and invocation contexts
|
AbstractInvocationContextFactory |
Deprecated.
|
AbstractJmxRegistration |
Parent class for top level JMX component registration.
|
AbstractKeyValueFilterConverter<K,V,C> |
|
AbstractListenerImpl<T,L extends ListenerInvocation<T>> |
|
AbstractLocalCacheStream<T,S extends BaseStream<T,S>,S2 extends S> |
Implements the base operations required for a local stream.
|
AbstractLocalCacheStream.StreamSupplier<T,S extends BaseStream<T,S>> |
|
AbstractLocalCommand |
Abstract class
|
AbstractLockingInterceptor |
Base class for various locking interceptors in this package.
|
AbstractMixedSiteStatus<E> |
|
AbstractModuleConfigurationBuilder |
AbstractModuleConfigurationBuilder.
|
AbstractModuleLifecycle |
Deprecated.
|
AbstractNamedCacheComponentFactory |
A component factory for creating components scoped per-cache.
|
AbstractParserContext |
|
AbstractPersistenceConfigurationChildBuilder |
AbstractPersistenceConfigurationChildBuilder.
|
AbstractRehashPublisherDecorator<S> |
Abstract publisher decorator that is used to notify segment listener of loss of segments while entries are
being retrieved.
|
AbstractRequest<T> |
A remote invocation request.
|
AbstractSegmentedAdvancedLoadWriteStore<K,V> |
|
AbstractSegmentedStoreConfiguration<T extends AbstractStoreConfiguration> |
Abstract store configuration that should be extended when the store configuration supports being segmented.
|
AbstractSiteStatusBuilder<E> |
A SiteStatus builder based on its online and offline members.
|
AbstractStoreConfiguration |
|
AbstractStoreConfigurationBuilder<T extends StoreConfiguration,S extends AbstractStoreConfigurationBuilder<T,S>> |
|
AbstractStoreConfigurationChildBuilder<S> |
|
AbstractStoreSerializer |
AbstractStoreSerializer.
|
AbstractTopologyAffectedCommand |
Base class for commands that carry topology id.
|
AbstractTransactionBoundaryCommand |
An abstract transaction boundary command that holds a reference to a GlobalTransaction
|
AbstractTransport |
Deprecated.
|
AbstractTransportConfigurationChildBuilder |
|
AbstractTxInvocationContext<T extends AbstractCacheTransaction> |
|
AbstractTxLockingInterceptor |
Base class for transaction based locking interceptors.
|
AbstractVisitor |
An abstract implementation of a Visitor that delegates all visit calls to a default handler which can be overridden.
|
AbstractWriteKeyCommand<K,V> |
|
AbstractWriteManyCommand<K,V> |
|
AcceptAllKeyValueFilter |
A key value filter that accepts all entries found.
|
AcceptAllKeyValueFilter.Externalizer |
|
Action |
|
ActionListener |
A listener that is invoked when an Action is completed.
|
ActionState |
|
ActionStatus |
|
ActivationManager |
Controls activation of cache entries that have been passivated.
|
ActivationManagerImpl |
Concrete implementation of activation logic manager.
|
ActivationManagerStub |
|
AddCacheManagerListenerAction |
CacheManagerAddListenerAction.
|
Address |
A destination for an Infinispan command or operation.
|
AdvancedAsyncCacheLoader<K,V> |
|
AdvancedAsyncCacheWriter |
|
AdvancedCache<K,V> |
An advanced interface that exposes additional methods not available on Cache .
|
AdvancedCacheExpirationWriter<K,V> |
Defines functionality for advanced expiration techniques.
|
AdvancedCacheExpirationWriter.ExpirationPurgeListener<K,V> |
|
AdvancedCacheLoader<K,V> |
A specialised extension of the CacheLoader interface that allows processing parallel iteration over the
existing entries.
|
AdvancedCacheLoader.CacheLoaderTask<K,V> |
Deprecated.
|
AdvancedCacheLoader.TaskContext |
Deprecated.
|
AdvancedCacheWriter<K,V> |
Defines advanced functionality for persisting data to an external storage.
|
AdvancedCacheWriter.PurgeListener<K> |
|
AdvancedLoadWriteStore<K,V> |
Advanced interface for interacting with an external store in a read-write mode.
|
AdvancedSingletonCacheWriter |
Deprecated.
|
AffectedKeysVisitor |
Deprecated.
|
AffinityPartitioner |
Key partitioner that maps keys to segments using information contained in AffinityTaggedKey .
|
AffinityTaggedKey |
|
AggregateBackupResponse |
|
AllOwnersLostException |
Signals that all owners of a key have been lost.
|
ApplyDelta<K> |
|
ApplyDelta.Externalizer |
Deprecated. |
ApplyDeltaCommand |
Deprecated.
|
AsDoubleIntOperation |
|
AsDoubleLongOperation |
|
AsLongIntOperation |
|
AsyncCacheLoader<K,V> |
|
AsyncCacheWriter |
The AsyncCacheWriter is a delegating CacheStore that buffers changes and writes them asynchronously to
the underlying CacheStore.
|
AsyncInterceptor |
Interface for sequential interceptors.
|
AsyncInterceptorChain |
|
AsyncInterceptorChainImpl |
Knows how to build and manage a chain of interceptors.
|
AsyncStoreConfiguration |
Configuration for the async cache store.
|
AsyncStoreConfigurationBuilder<S> |
Configuration for the async cache store.
|
AtomicKeySetImpl<K> |
|
AtomicKeySetImpl.Externalizer |
|
AtomicKeySetImpl.FunctionExternalizer |
|
AtomicMap<K,V> |
This is a special type of Map geared for use in Infinispan.
|
AtomicMapLookup |
A helper that locates or safely constructs and registers atomic maps with a given cache.
|
AtomicMapProxyImpl<K,V,MK> |
This is the proxy class driving access to the entry in cache using functional API.
|
AtomicMapProxyImpl.Externalizer |
|
Attribute |
Enumerates the attributes used in Infinispan
|
AuditContext |
AuditContext.
|
AuditLogger |
AuditLogger.
|
AuditMessages |
AuditMessages.
|
AuditMessages_$logger |
Warning this class consists of generated code.
|
AuditResponse |
|
AuthorizationConfiguration |
AuthorizationConfiguration.
|
AuthorizationConfigurationBuilder |
AuthorizationConfigurationBuilder.
|
AuthorizationHelper |
AuthorizationHelper.
|
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.
|
AuthorizationManagerFactory |
|
AuthorizationManagerImpl |
AuthorizationManagerImpl.
|
AuthorizationPermission |
AuthorizationPermission.
|
AutoBatchSupport |
Enables for automatic batching.
|
AutoInstantiableFactory |
Component factories that implement this interface can be instantiated automatically by component registries when
looking up components.
|
AvailabilityException |
Thrown when a partition happened and the key that an operation tries to access is not available.
|
AvailabilityMode |
|
AvailabilityMode.Externalizer |
|
AvailabilityStrategy |
Implementations decide what to do when the cache membership changes, either because new nodes joined, nodes left,
or there was a merge.
|
AvailabilityStrategyContext |
Contains information about the current state of the cache.
|
AvailablePartitionHandlingManager |
|
BackupAckCommand |
A command that represents an acknowledge sent by a backup owner to the originator.
|
BackupConfiguration |
|
BackupConfiguration.BackupStrategy |
|
BackupConfigurationBuilder |
|
BackupFailureException |
Exception to be used to signal failures to backup to remote sites.
|
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.
|
BackupMultiKeyAckCommand |
A command that represents an acknowledge sent by a backup owner to the originator.
|
BackupReceiver |
Component present on a backup site that manages the backup information and logic.
|
BackupReceiverRepository |
Global component that holds all the BackupReceiver s within this CacheManager.
|
BackupReceiverRepositoryImpl |
|
BackupResponse |
Represents a response from a backup replication call.
|
BackupSender |
Component responsible with sending backup data to remote sites.
|
BackupSender.BringSiteOnlineResponse |
|
BackupSender.TakeSiteOfflineResponse |
|
BackupSenderImpl |
|
BackupWriteCommand |
A write operation sent from the primary owner to the backup owners.
|
BaseAsyncInterceptor |
Base class for an interceptor in the new asynchronous invocation chain.
|
BaseBackupInterceptor |
|
BaseBackupReceiver |
|
BaseBlockingRunnable |
|
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.
|
BaseClusteredReadCommand |
|
BaseCustomAsyncInterceptor |
|
BaseCustomInterceptor |
Deprecated.
|
BaseDistributionInterceptor |
Base class for distribution of entries across a cluster.
|
BaseDistributionInterceptor.ReadManyCommandHelper<C> |
|
BaseDistributionInterceptor.RemoteGetAllHandler |
|
BaseLockingAction |
A base Action implementation for locking.
|
BaseLockingAction.InternalState |
|
BasePerCacheInboundInvocationHandler |
Implementation with the default handling methods and utilities methods.
|
BaseRpcCommand |
|
BaseRpcInterceptor |
Acts as a base for all RPC calls
|
BaseRpcInvokingCommand |
Deprecated.
|
BaseStateTransferInterceptor |
A base class for a state transfer interceptor.
|
BaseStateTransferInterceptor.LostDataVisitor |
|
BaseTerminalOperation<Original> |
Abstract instance that provides common code needed for all terminal operations.
|
BasicComponentRegistry |
Basic dependency injection container.
|
BasicComponentRegistryImpl |
|
BasicEventLogger |
BasicEventLogger.
|
BatchContainer |
A container for holding thread locals for batching, to be used with the BatchingCache.startBatch() and
BatchingCache.endBatch(boolean) calls.
|
BatchingClusterEventManagerImpl<K,V> |
|
BatchingClusterEventManagerImpl.UnicastEventContext<K,V> |
|
BatchingInterceptor |
Interceptor that captures batched calls and attaches contexts.
|
BatchModeTransactionManager |
Not really a transaction manager in the truest sense of the word.
|
BatchModification |
A simple wrapper class, necessary for Transactional stores, which allows MarshalledEntries and Object keys to be passed
to a store implementation in order.
|
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).
|
BiasedCollector |
|
BiasedEntryWrappingInterceptor |
|
BiasedScatteredDistributionInterceptor |
|
BiasManager |
This component tracks if this node can read the data stored locally despite not being an owner
and which nodes will read the local data that is primary-owned by this node.
|
BiasManager.Revocation |
|
BiasManagerImpl |
|
BiasRevocationResponse |
|
BiasRevocationResponse.Externalizer |
|
BiFunctionMapper |
|
BiFunctionMapper.Externalizer |
|
Bits |
Utility method for inserting and retrieving values from to/from a byte[]
|
BlockingRunnable |
A special Runnable (for the particular case of Total Order) that is only sent to a thread when it is ready to be
executed without blocking the thread
|
BlockingTaskAwareExecutorService |
Executor service that is aware of BlockingRunnable and only dispatch the runnable to a thread when it has low
(or no) probability of blocking the thread.
|
BlockingTaskAwareExecutorServiceImpl |
A special executor service that accepts a BlockingRunnable .
|
BoundedExecutors |
Similar to JDK Executors except that the factory methods here allow you to specify the
size of the blocking queue that backs the executor.
|
BoundedOffHeapDataContainer |
|
BoundedSegmentedDataContainer<K,V> |
Bounded implementation of segmented data container.
|
BoxedDoubleOperation |
|
BoxedIntOperation |
|
BoxedLongOperation |
|
ByteBufferImpl |
Deprecated. |
ByteString |
A simple class which encapsulates a byte[] representation of a String using a predefined encoding (currently UTF-8).
|
Cache<K,V> |
The central interface of Infinispan.
|
CacheAware<K,V> |
Interface that describes how a cache can be injected into another object.
|
CacheCollection<E> |
A collection type that returns special Cache based streams that have additional options to tweak behavior.
|
CacheCollectionMapper<E,R> |
Deprecated.
|
CacheCollectors |
|
CacheConfigurationMBean |
CacheConfigurationMBeanImpl.
|
CacheContainer |
|
CacheContainerStats |
Similar to Stats but in the scope of a single per node CacheContainer
|
CacheContainerStatsImpl |
Cache container statistics needed for admin console
|
CacheEntriesEvicted |
This annotation should be used on methods that need to be notified when cache entries are evicted.
|
CacheEntriesEvictedEvent<K,V> |
|
CacheEntry<K,V> |
An entry that is stored in the data container
|
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> |
|
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.
|
CacheEntryListenerInvocation<K,V> |
Additional listener methods specific to caches.
|
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> |
|
CacheEntrySizeCalculator<K,V> |
Implementation of a size calculator that calcultes only the size of the value assuming it is an InternalCacheEntry.
|
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
|
CacheFilters |
|
CacheFilters.CacheFiltersExternalizer |
|
CacheHealth |
Cache health information.
|
CacheHealthImpl |
|
CacheImpl<K,V> |
|
CacheJmxRegistration |
If Configuration.jmxStatistics() is enabled, then class will register all
the MBeans from cache local's ConfigurationRegistry to the MBean server.
|
CacheJoinException |
Thrown when a cache fails to join a cluster
|
CacheJoinInfo |
This class contains the information that a cache needs to supply to the coordinator when starting up.
|
CacheJoinInfo.Externalizer |
|
CacheLoader<K,V> |
Defines the logic for loading data from an external storage.
|
CacheLoaderInterceptor<K,V> |
|
CacheManagerJmxRegistration |
Registers all the components from global component registry to the mbean server.
|
CacheManagerNotifier |
Notifications for the cache manager
|
CacheManagerNotifierImpl |
Global, shared notifications on the cache manager.
|
CacheMgmtInterceptor |
Captures cache management statistics
|
CacheMixedSiteStatus |
|
CacheMode |
Cache replication mode.
|
CacheNotFoundResponse |
A response that signals the named cache is not running on the target node.
|
CacheNotFoundResponse.Externalizer |
|
CacheNotifier<K,V> |
Public interface with all allowed notifications.
|
CacheNotifierImpl<K,V> |
Helper class that handles all notifications to registered listeners.
|
CacheNotifierImpl.BaseCacheEntryListenerInvocation<K,V> |
|
CacheNotifierImpl.ClusteredListenerInvocation<K,V> |
This class is to be used with cluster listener invocations only when they have included current state.
|
CachePermission |
CachePermission.
|
CachePermissionCollection |
CachePermissionCollection.
|
CachePrincipalPair |
CachePrincipalPair.
|
CacheRoleImpl |
CacheRoleImpl.
|
CacheRpcCommand |
|
CacheRpcCommandExternalizer |
Externalizer in charge of marshalling cache specific commands.
|
Caches |
Utility methods for dealing with caches.
|
CacheSet<E> |
A set that also must implement the various CacheCollection methods for streams.
|
CacheSetMapper<E,R> |
A CacheSet that allows for a different set to be mapped as a different instance wtih values replaced on
request.
|
CacheSiteStatusBuilder |
|
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 .
|
CacheState |
Cache State information stored in a cluster-wide cache
|
CacheState.Externalizer |
|
CacheStatusResponse |
|
CacheStatusResponse.Externalizer |
|
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 .
|
CacheStoreFactory |
Creates Cache Store instances.
|
CacheStoreFactoryRegistry |
|
CacheStoreFactoryRegistryFactory |
|
CacheStream<R> |
A Stream that has additional operations to monitor or control behavior when used from a Cache .
|
CacheSupport<K,V> |
|
CacheTopology |
The status of a cache from a distribution/state transfer point of view.
|
CacheTopology.Externalizer |
|
CacheTopology.Phase |
Phase of the rebalance process.
|
CacheTopologyControlCommand |
A control command for all cache membership/rebalance operations.
|
CacheTopologyControlCommand.Type |
|
CacheTopologyHandler |
|
CacheTransaction |
Defines the state a infinispan transaction should have.
|
CacheTransaction.TransactionCompletedListener |
|
CacheUnreachableException |
Signals a backup site was unreachable.
|
CacheWriter<K,V> |
Allows persisting data to an external storage, as opposed to the CacheLoader .
|
CacheWriterInterceptor |
Writes modifications back to the store on the way out: stores modifications back through the CacheLoader, either
after each method call (no TXs), or at TX commit.
|
CallInterceptor |
Always at the end of the chain, directly in front of the cache.
|
CancelCommand |
Command to cancel commands executing in remote VM
|
CancellableCommand |
CancellableCommand is a command whose execution in remote VM can be canceled (if needed)
|
CancellationService |
CancellationService manages association of Thread executing CancellableCommand in a remote VM and
if needed cancels command execution
|
CancellationServiceImpl |
|
Casting |
|
CheckTopologyAction |
An Action implementation that checks if the command topology id is valid.
|
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
|
Clear |
|
ClearCacheEntry<K,V> |
|
ClearCommand |
|
ClearInvocationContext |
|
Closeables |
This class is used solely for the purpose of converting classes only in core to corresponding closeable variants.
|
CloseableSuppliedIterator<E> |
|
CloseableSupplier<T> |
|
ClusterCacheNotifier<K,V> |
This interface describes methods required for a cluster listener to be able to be bootstrapped and properly notified
when a new event has been raised from the cluster.
|
ClusterCacheStats |
Similar to Stats but cluster wide.
|
ClusterCacheStatsFactory |
|
ClusterCacheStatsImpl |
|
ClusterCacheStatus |
Keeps track of a cache's status: members, current/pending consistent hashes, and rebalance status
|
ClusterContainerStats |
Cluster wide container statistics
|
ClusterContainerStatsFactory |
|
ClusterContainerStatsImpl |
|
ClusteredCacheBackupReceiver |
|
ClusteredCacheLoaderInterceptor |
The same as a regular cache loader interceptor, except that it contains additional logic to force loading from the
cache loader if needed on a remote node, in certain conditions.
|
ClusteredGetAllCommand<K,V> |
Issues a remote getAll call.
|
ClusteredGetCommand |
Issues a remote get call.
|
ClusteredGetResponseValidityFilter |
|
ClusteredTransactionOriginatorChecker |
|
ClusterEvent<K,V> |
This is an event designed for use with cluster listeners solely.
|
ClusterEvent.Externalizer |
|
ClusterEventCallable<K,V> |
This DistributedCallable is used to invoke a raised notification on the cluster listener that registered to listen
for this event.
|
ClusterEventCallable.Externalizer |
|
ClusterEventManager<K,V> |
|
ClusterEventManagerFactory |
Constructs the data container
|
ClusterEventManagerStub<K,V> |
|
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.
|
ClusterExecutors |
Static factory methods to construct a ClusterExecutor
|
ClusterExpirationManager<K,V> |
Allows for cluster based expirations to occur.
|
ClusterHealth |
Cluster health information.
|
ClusterHealthImpl |
|
ClusteringConfiguration |
Defines clustered characteristics of the cache.
|
ClusteringConfigurationBuilder |
Defines clustered characteristics of the cache.
|
ClusteringConfigurationChildBuilder |
|
ClusteringDependentLogic |
Abstractization for logic related to different clustering modes: replicated or distributed.
|
ClusteringDependentLogic.AbstractClusteringDependentLogic |
|
ClusteringDependentLogic.Commit |
|
ClusteringDependentLogic.DistributionLogic |
This logic is used in distributed mode caches.
|
ClusteringDependentLogic.InvalidationLogic |
This logic is used in invalidation mode caches.
|
ClusteringDependentLogic.LocalLogic |
This logic is used in local mode caches.
|
ClusteringDependentLogic.ReplicationLogic |
This logic is used in replicated mode caches.
|
ClusteringDependentLogic.ScatteredLogic |
|
ClusteringInterceptor |
Base class for distribution interceptors.
|
ClusterListenerRemoveCallable<K,V> |
This DistributedCallable is used to remove registered RemoteClusterListener on each of the various nodes
when a cluster listener is unregistered from the cache.
|
ClusterListenerRemoveCallable.Externalizer |
|
ClusterListenerReplicateCallable<K,V> |
|
ClusterListenerReplicateCallable.Externalizer |
|
ClusterLoader |
Cache loader that consults other members in the cluster for values.
|
ClusterLoaderConfiguration |
ClusterLoaderConfiguration.
|
ClusterLoaderConfigurationBuilder |
|
ClusterRoleMapper |
ClusterRoleMapper.
|
ClusterStreamManager<Original,K> |
Manages distribution of various stream operations that are sent to remote nodes.
|
ClusterStreamManager.RemoteIteratorPublisher<K> |
ClusterStreamManager.ResultsCallback<R> |
A callback that is used for result processing from the remote nodes.
|
ClusterStreamManagerImpl<Original,K> |
Cluster stream manager that sends all requests using the RpcManager to do the underlying communications.
|
ClusterTopologyManager |
Maintains the topology for all the caches in the cluster.
|
ClusterTopologyManager.ClusterManagerStatus |
|
ClusterTopologyManagerFactory |
Factory for ClusterTopologyManager implementations
|
ClusterTopologyManagerImpl |
The ClusterTopologyManager implementation.
|
ClusterView |
Information about the JGroups cluster.
|
CollectionExternalizer |
|
CollectionKeyFilter<K> |
Filter based on accepting/rejecting the keys that are present in a supplied collection.
|
CollectionKeyFilter.Externalizer |
|
CollectionMapper<E,R> |
A collection that maps another one to a new one of a possibly different type.
|
Collector<T> |
Represents the ack collector for a write operation in triangle algorithm.
|
CommandAckCollector |
An acknowledge collector for Triangle algorithm used in non-transactional caches for write operations.
|
CommandAckCollector.MultiTargetCollector |
|
CommandInterceptor |
Deprecated.
|
CommandInvocationId |
Represents an unique identified for non-transaction write commands.
|
CommandsFactory |
A factory to build commands, initializing and injecting dependencies accordingly.
|
CommandsFactoryImpl |
|
CommitCommand |
Command corresponding to the 2nd phase of 2PC.
|
CommitManager |
Keeps track of the keys updated by normal operation and state transfer.
|
CommonNameRoleMapper |
CommonNameRoleMapper.
|
CompatibilityModeConfiguration |
Compatibility mode configuration
|
CompatibilityModeConfigurationBuilder |
Compatibility mode configuration builder
|
CompletableFutures |
|
CompleteTransactionCommand |
Command used by the recovery tooling for forcing transaction completion .
|
CompletionRehashPublisherDecorator<S> |
PublisherDecorator that only notifies a user listener of segment completion after the last entry for a given
segment has been retrieved from iteration.
|
ComponentAlias |
|
ComponentFactory |
Factory for Infinispan components.
|
ComponentMetadata |
|
ComponentMetadata.InjectMethodMetadata |
This class encapsulates metadata on an inject method, such as one annotated with Inject
|
ComponentMetadata.PrioritizedMethodMetadata |
This class encapsulates metadata on a prioritized method, such as one annotated with Start or {@link @Stop}
|
ComponentMetadataPersister |
A utility class used by the Infinispan build process to scan metadata and persist it.
|
ComponentMetadataRepo |
This is a repository of component metadata, which is populated when the Infinispan core jar is loaded up.
|
ComponentName |
Mechanism for specifying the name of components to retrieve
|
ComponentRef<T> |
Reference to a component.
|
ComponentRegistry |
Named cache specific components
|
ComponentsJmxRegistration |
Registers a set of components on an MBean server.
|
ComponentStatus |
Different states a component may be in.
|
ComposedSegmentedLoadWriteStore<K,V,T extends AbstractSegmentedStoreConfiguration> |
Segmented store that creates multiple inner stores for each segment.
|
CompositeAction |
|
CompositeCacheEventFilter<K,V> |
Allows AND-composing several cache event filters.
|
CompositeKeyFilter<K> |
Allows AND-composing several filters.
|
CompositeKeyFilter.Externalizer |
|
CompositeKeyValueFilter<K,V> |
Allows AND-composing several key/value filters.
|
CompositeKeyValueFilter.Externalizer |
|
ComputeCommand |
|
ComputeIfAbsentCommand |
|
ConcurrentChangeException |
Thrown when the version of entry has changed between loading the entry to the context and committing new value.
|
Configuration |
|
ConfigurationBuilder |
|
ConfigurationBuilderHolder |
|
ConfigurationChildBuilder |
|
ConfigurationForClassExtractor |
|
ConfigurationHolder |
ConfigurationHolder.
|
ConfigurationManager |
It manages all the configuration for a specific container.
|
ConfigurationParser |
ConfigurationParser.
|
Configurations |
Helper configuration methods.
|
ConfigurationSerializer<T> |
|
ConfigurationStorage |
Configuration storage
|
ConflictManager<K,V> |
|
ConflictManagerFactory |
|
ConsistentHash |
A consistent hash algorithm implementation.
|
ConsistentHashFactory<CH extends ConsistentHash> |
|
ConsistentHashPersistenceConstants |
Constants used as keys within a persisted consistent hash
|
ContainerFullException |
Exception that is thrown when exception based eviction is enabled and the cache is full
|
ContainerMixedSiteStatus |
|
ContainerSiteStatusBuilder |
|
ContentTypeConfiguration |
|
ContentTypeConfigurationBuilder |
|
Converter<K,V,C> |
Converter that can be used to transform a given entry to a different value.
|
CopyableDeltaAware |
Deprecated.
|
CoreImmutables |
Factory for generating immutable type wrappers for core types.
|
CreateCacheCommand |
Command to create/start a cache on a subset of Infinispan cluster nodes
|
CustomFailurePolicy<K,V> |
Used for implementing custom policies in case of communication failures with a remote site.
|
CustomInterceptorsConfiguration |
Configures custom interceptors to be added to the cache.
|
CustomInterceptorsConfigurationBuilder |
Configures custom interceptors to be added to the cache.
|
CustomStoreConfiguration |
|
CustomStoreConfigurationBuilder |
StoreConfigurationBuilder used for stores/loaders that don't have a configuration builder
|
CyclicDependencyException |
Thrown when a cyclic dependency exist
|
DataCommand |
Commands of this type manipulate data in the cache.
|
DataContainer<K,V> |
The main internal data structure which stores entries.
|
DataContainer.ComputeAction<K,V> |
|
DataContainerConfiguration |
Deprecated.
|
DataContainerConfigurationBuilder |
Deprecated.
|
DataContainerFactory |
Constructs the data container
|
DataContainerRemoveIterator<K,V> |
This is an iterator that will iterate upon the data container.
|
DataConversion |
Handle conversions for Keys or values.
|
DataConversion.Externalizer |
|
DataConversionAwareListenable<K,V> |
|
DataLocality |
Used to determine whether a key is mapped to a local node.
|
DataRehashed |
This annotation should be used on methods that need to be notified when a rehash starts or ends.
|
DataRehashedEvent<K,V> |
|
DataType |
|
DataWriteCommand |
Mixes features from DataCommand and WriteCommand
|
DDAsyncInterceptor |
Interface for async interceptors using double-dispatch.
|
DeadlockChecker |
An interface to implement the deadlock algorithm.
|
DeadlockDetectedException |
Exception signaling detected deadlocks.
|
DeadlockDetectionConfiguration |
Deprecated.
|
DeadlockDetectionConfigurationBuilder |
Deprecated.
|
DecoratedCache<K,V> |
A decorator to a cache, which can be built with a specific set of Flag s.
|
DecoratedEventLogger |
DecoratedEventLogger.
|
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 |
|
DefaultConflictManager<K,V> |
|
DefaultConsistentHash |
|
DefaultConsistentHash.Externalizer |
|
DefaultConsistentHashFactory |
|
DefaultConsistentHashFactory.Builder |
|
DefaultConsistentHashFactory.Externalizer |
|
DefaultDataContainer<K,V> |
DefaultDataContainer is both eviction and non-eviction based data container.
|
DefaultDistributedTaskLifecycle |
|
DefaultExecutorFactory |
Default executor factory that creates executors using the JDK Executors service.
|
DefaultExecutorService |
Deprecated.
|
DefaultFactoryFor |
An annotation that is used internally, for defining a DEFAULT factory to be used when constructing components.
|
DefaultLockManager |
The default LockManager implementation for transactional and non-transactional caches.
|
DefaultPendingLockManager |
|
DefaultReadyAction |
A list of Action to be executed to check when it is ready.
|
DefaultResponseGenerator |
The default response generator for most cache modes
|
DefaultScheduledExecutorFactory |
Creates scheduled executors using the JDK Executors service
|
DefaultSegmentedDataContainer<K,V> |
DataContainer implementation that internally stores entries in an array of maps.
|
DefaultThreadFactory |
Thread factory based on JBoss Thread's JBossThreadFactory.
|
DefaultTopologyRunnable |
The default Runnable for the remote commands receives.
|
DefaultTwoWayKey2StringMapper |
Default implementation for TwoWayKey2StringMapper that knows how to handle all primitive
wrapper keys and Strings.
|
DefineConfigurationAction |
DefineConfigurationAction.
|
DelegatingCacheEntryListenerInvocation<K,V> |
|
DelegatingCacheLoader<K,V> |
|
DelegatingCacheWriter |
|
DeliverOrder |
Used in RPC, it defines how the messages are delivered to the nodes.
|
Delta |
Deprecated.
|
DeltaAware |
Deprecated.
|
DeltaCompositeKey |
Deprecated.
|
DeltaCompositeKey.DeltaCompositeKeyExternalizer |
Deprecated. |
DependencyGraph<T> |
Graph to track dependencies between objects
|
DisplayType |
|
DistCacheWriterInterceptor |
Cache store interceptor specific for the distribution and replication cache modes.
|
DistinctDoubleOperation |
|
DistinctIntOperation |
|
DistinctLongOperation |
|
DistinctOperation<S> |
Performs distinct operation on a regular Stream
|
DistributedCacheStream<Original,R> |
Implementation of CacheStream that provides support for lazily distributing stream methods to appropriate
nodes
|
DistributedCallable<K,V,T> |
A task that returns a result and may throw an exception capable of being executed in another JVM.
|
DistributedDoubleCacheStream<Original> |
Implementation of DoubleStream that utilizes a lazily evaluated distributed back end execution.
|
DistributedExecuteCommand<V> |
DistributedExecuteCommand is used to migrate Callable and execute it in remote JVM.
|
DistributedExecutionCompletionService<V> |
|
DistributedExecutorService |
Deprecated.
|
DistributedIntCacheStream<Original> |
Implementation of IntStream that utilizes a lazily evaluated distributed back end execution.
|
DistributedLongCacheStream<Original> |
Implementation of LongStream that utilizes a lazily evaluated distributed back end execution.
|
DistributedTask<T> |
DistributedTask describes all relevant attributes of a distributed task, most importantly its
execution policy, fail over policy and its timeout.
|
DistributedTaskBuilder<T> |
DistributedTaskBuilder is a factory interface for DistributedTask
|
DistributedTaskExecutionPolicy |
DistributedTaskExecutionPolicy allows task to specify its custom task execution policy across
Infinispan cluster.
|
DistributedTaskFailoverPolicy |
DistributedTaskFailoverPolicy allows pluggable fail over target selection for a failed remotely
executed distributed task.
|
DistributedTaskLifecycle |
|
DistributedTaskLifecycleService |
|
DistributionBulkInterceptor<K,V> |
Interceptor that handles bulk entrySet and keySet commands when using in a distributed/replicated environment.
|
DistributionBulkInterceptor.BackingEntrySet<K,V> |
|
DistributionBulkInterceptor.BackingKeySet<K,V> |
|
DistributionBulkInterceptor.TxBackingEntrySet<K,V> |
|
DistributionInfo |
|
DistributionManager |
A component that manages the distribution of elements across a cache cluster
|
DistributionManagerFactory |
|
DistributionManagerImpl |
The default distribution manager implementation
|
DldGlobalTransaction |
Deprecated.
|
DldGlobalTransaction.Externalizer |
Deprecated. |
DoubleCacheStream |
A DoubleStream that has additional methods to allow for Serializable instances.
|
DoubleSummaryStatisticsExternalizer |
|
DummyBaseTransactionManager |
Deprecated.
|
DummyNoXaXid |
Deprecated.
|
DummyTransaction |
Deprecated.
|
DummyTransactionManager |
Deprecated.
|
DummyTransactionManagerLookup |
Deprecated.
|
DummyUserTransaction |
Deprecated.
|
DummyXid |
Deprecated.
|
Element |
An enumeration of all the recognized XML element local names, by name.
|
EmbeddedBaseTransactionManager |
|
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
|
EmbeddedMetadata |
Metadata class for embedded caches.
|
EmbeddedMetadata.Builder |
|
EmbeddedMetadata.Externalizer |
|
EmbeddedTimeService |
The default implementation of TimeService .
|
EmbeddedTransaction |
|
EmbeddedTransactionManager |
Simple transaction manager implementation that maintains transaction state in memory only.
|
EmbeddedTransactionManagerLookup |
|
EmbeddedUserTransaction |
|
EmbeddedXid |
|
EmptyAsyncInterceptorChain |
|
EmptyConstructorFactory |
Factory for building global-scope components which have default empty constructors
|
EmptyConstructorNamedCacheFactory |
Simple factory that just uses reflection and an empty constructor of the component type.
|
EncoderCache<K,V> |
Cache decoration that makes use of the Encoder and Wrapper to convert between storage value and
read/write value.
|
EncoderEntryMapper<K,V,T extends Map.Entry<K,V>> |
Function that uses an encoder to converter entries from the configured storage format to
the requested format.
|
EncoderEntryMapper.Externalizer |
|
EncoderKeyMapper<K> |
Function that uses a keyEncoder to converter keys from the configured storage format to
the requested format.
|
EncoderKeyMapper.Externalizer |
|
EncoderRegistry |
Manages existent Encoder , Wrapper and Transcoder instances.
|
EncoderRegistryFactory |
|
EncoderRegistryImpl |
|
EncoderValueMapper<V> |
Function that uses a valueEncoder to converter values from the configured storage format
to the requested format.
|
EncoderValueMapper.Externalizer |
|
EncodingConfiguration |
Controls encoding configuration for keys and values in the cache.
|
EncodingConfigurationBuilder |
|
EndIterator |
Singleton object with no state that is used to signal that an iterator has reached the end.
|
EndIterator.EndIteratorExternalizer |
|
EntryFactory |
|
EntryFactoryImpl |
EntryFactory implementation to be used for optimistic locking scheme.
|
EntryLookup |
Interface that can look up MVCC wrapped entries.
|
EntryMergePolicy<K,V> |
|
EntryMergePolicyFactory |
|
EntryMergePolicyFactoryRegistry |
|
EntryMetaFactory |
|
EntrySetCommand<K,V> |
|
EntryStreamSupplier<K,V> |
Stream supplier that is to be used when the underlying stream is composed by CacheEntry instances.
|
EntryVersion |
A version is used to compare entries against one another.
|
EntryVersionsMap |
|
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.
|
EntryViews |
Entry views implementation class holder.
|
EntryViews.AccessLoggingReadWriteView<K,V> |
|
EntryViews.NoValueReadOnlyViewExternalizer |
|
EntryViews.ReadOnlySnapshotViewExternalizer |
|
EntryViews.ReadWriteSnapshotViewExternalizer |
|
EntryWrapper<K,V> |
Wrapper for CacheEntry(s) that can be used to update the cache when it's value is set.
|
EntryWrappingInterceptor |
Interceptor in charge with wrapping entries and add them in caller's context.
|
EnumSetExternalizer |
|
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 |
|
EventImpl<K,V> |
Basic implementation of an event that covers all event types.
|
EventImpl |
Implementation of cache manager events
|
EventLog |
EventLog describes an event log's attributes.
|
EventLogCategory |
EventLogCategory.
|
EventLogger |
EventLogger provides an interface for logging event messages.
|
EventLogLevel |
EventLogLevel.
|
EventLogManager |
EventLogManager.
|
EventLogManagerImpl |
EventLogManagerImpl.
|
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.
|
EventWrapper<K,V,E extends Event<K,V>> |
Simple wrapper that keeps the original key along with the converted event.
|
EvictCommand |
|
EvictionConfiguration |
Deprecated.
|
EvictionConfigurationBuilder |
Deprecated.
|
EvictionManager<K,V> |
Central component that deals with eviction of cache entries.
|
EvictionManagerImpl<K,V> |
|
EvictionStrategy |
Supported eviction strategies
|
EvictionThreadPolicy |
Supported eviction thread policy
|
EvictionType |
Supported eviction type
|
ExceptionAckCommand |
A command that represents an exception acknowledge sent by any owner.
|
ExceptionResponse |
A response that encapsulates an exception
|
ExceptionResponse.Externalizer |
|
ExecutorAllCompletionService |
Exectues given tasks in provided executor.
|
ExecutorFactoryConfiguration |
|
ExecutorFactoryConfigurationBuilder |
Configures executor factory.
|
ExpandableMarshalledValueByteStream |
|
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.
|
ExpirationManagerFactory |
Constructs the expiration manager
|
ExpirationManagerImpl<K,V> |
|
ExpiryHelper |
Provide utility methods for dealing with expiration of cache entries.
|
ExposedByteArrayOutputStream |
Deprecated. |
ExtendedLockPromise |
An extended LockPromise interface that allows a better control over it.
|
ExternallyMarshallable |
As much as possible, Infinispan consumers should provide
Externalizer or
AdvancedExternalizer instances
for the types being marshalled, so that these types can be marshalled
as efficiently as possible.
|
ExternalPojo |
Marker interface for those pojos that are allowed to be marshalled
externally.
|
ExternalStore<K,V> |
Basic interface for interacting with an external store in a read-write mode.
|
FailoverContext |
As DistributedTask might potentially fail on subset of executing nodes FailureContext
provides details of such task failure.
|
FilterDoubleOperation |
|
FilterIndexingServiceProvider |
A service provider for filter indexing services.
|
FilteringListenable<K,V> |
A Listenable that can also filter events based on key
|
FilterIntOperation<S> |
|
FilterLongOperation<S> |
|
FilterMapResponseCollector |
|
FilterOperation<S> |
Performs filter operation on a regular Stream
|
FineGrainedAtomicMap<K,V> |
FineGrainedAtomicMap is a special type of Map geared for use in Infinispan.
|
FineGrainedAtomicMapProxyImpl<K,V,MK> |
|
Flag |
Available flags, which may be set on a per-invocation basis.
|
Flag.Externalizer |
|
FlagAffectedCommand |
Flags modify behavior of command such as whether or not to invoke certain commands remotely, check cache store etc.
|
FlagAffectedStore<K,V> |
Implemented by stores that can skip writes based on certain flags present in the invocation.
|
FlagBitSets |
Pre-computed bitsets containing each flag.
|
FlatMapDoubleOperation |
|
FlatMapIntOperation |
|
FlatMapLongOperation |
|
FlatMapOperation<I,O> |
Performs flat map operation on a regular Stream
|
FlatMappingOperation<InputType,InputStream extends BaseStream<InputType,InputStream>,OutputType,OutputStream extends BaseStream<OutputType,OutputStream>> |
|
FlatMapToDoubleOperation<I> |
Performs flat map to double operation on a regular Stream
|
FlatMapToIntOperation<I> |
Performs flat map to int operation on a regular Stream
|
FlatMapToLongOperation<I> |
Performs flat map to long operation on a regular Stream
|
FlowableFromIntSetFunction<T> |
Flowable implementation that will produce entries by providing every int in the given set to the provided IntFunction.
|
ForEachBiOperation<Original,K,V> |
Terminal operation that handles for each where no map operations are defined
|
ForEachDoubleOperation<Original,K> |
Terminal rehash aware operation that handles for each where no flat map operations are defined on a
DoubleStream .
|
ForEachFlatMapDoubleOperation<Original,K> |
Terminal rehash aware operation that handles for each where flat map operation is performed on a
DoubleStream .
|
ForEachFlatMapIntOperation<Original,K> |
Terminal rehash aware operation that handles for each where flat map operation is performed on a
IntStream .
|
ForEachFlatMapLongOperation<Original,K> |
Terminal rehash aware operation that handles for each where flat map operation is performed on a
LongStream .
|
ForEachFlatMapObjDoubleOperation<Original,K> |
Terminal rehash aware operation that handles for each where flat map operation is performed on a
DoubleStream .
|
ForEachFlatMapObjIntOperation<Original,K> |
Terminal rehash aware operation that handles for each where flat map operation is performed on a
IntStream .
|
ForEachFlatMapObjLongOperation<Original,K> |
Terminal rehash aware operation that handles for each where flat map operation is performed on a
LongStream .
|
ForEachIntOperation<Original,K> |
Terminal rehash aware operation that handles for each where no flat map operations are defined on a
IntStream .
|
ForEachLongOperation<Original,K> |
Terminal rehash aware operation that handles for each where no flat map operations are defined on a
LongStream .
|
ForEachObjDoubleOperation<Original,K> |
Terminal rehash aware operation that handles for each where no flat map operations are defined on a
DoubleStream .
|
ForEachObjIntOperation<Original,K> |
Terminal rehash aware operation that handles for each where no flat map operations are defined on a
IntStream .
|
ForEachObjLongOperation<Original,K> |
Terminal rehash aware operation that handles for each where no flat map operations are defined on a
LongStream .
|
ForEachOperation<Original,K,V> |
Terminal operation that handles for each where no map operations are defined
|
ForwardingCacheEntry<K,V> |
A class designed to forward all method invocations for a CacheEntry to the provided delegate.
|
FunctionalCommand<K,V> |
A command that carries operation rather than final value.
|
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.
|
FunctionalMapImpl<K,V> |
Functional map implementation.
|
FunctionalNotifier<K,V> |
Listener notifier.
|
FunctionalNotifierImpl<K,V> |
|
FunctionMapper |
|
FunctionMapper.Externalizer |
|
GenericTransactionManagerLookup |
A transaction manager lookup class that attempts to locate a TransactionManager.
|
GetAllCommand |
Retrieves multiple entries at once.
|
GetCacheAction |
GetCacheAction.
|
GetCacheAuthorizationManagerAction |
GetCacheAuthorizationManagerAction.
|
GetCacheAvailabilityAction |
GetCacheAvailabilityAction.
|
GetCacheComponentRegistryAction |
GetCacheComponentRegistryAction.
|
GetCacheConfigurationAction |
GetCacheConfigurationAction.
|
GetCacheDistributionManagerAction |
GetCacheDistributionManagerAction.
|
GetCacheEntryAction<K,V> |
GetCacheEntryAction.
|
GetCacheEntryCommand |
Used to fetch a full CacheEntry rather than just the value.
|
GetCacheGlobalComponentRegistryAction |
GetCacheGlobalComponentRegistryAction.
|
GetCacheInterceptorChainAction |
GetCacheInterceptorChainAction.
|
GetCacheLockManagerAction |
GetCacheLockManagerAction.
|
GetCacheManagerAddress |
GetCacheManagerAddress.
|
GetCacheManagerClusterAvailabilityAction |
GetCacheManagerClusterAvailabilityAction.
|
GetCacheManagerClusterNameAction |
GetCacheManagerClusterNameAction.
|
GetCacheManagerCoordinatorAddress |
GetCacheManagerCoordinatorAddress.
|
GetCacheManagerIsCoordinatorAction |
GetCacheManagerIsCoordinatorAction.
|
GetCacheManagerStatusAction |
GetCacheManagerStatusAction.
|
GetCacheRpcManagerAction |
GetCacheRpcManagerAction.
|
GetCacheStatusAction |
GetCacheStatusAction.
|
GetDefaultExecutorServiceAction |
GetDefaultExecutorServiceAction.
|
GetGlobalComponentRegistryAction |
GetGlobalComponentRegistryAction.
|
GetInDoubtTransactionsCommand |
Rpc to obtain all in-doubt prepared transactions stored on remote nodes.
|
GetInDoubtTxInfoCommand |
Command used by the recovery tooling for obtaining the list of in-doubt transactions from a node.
|
GetKeysInGroupCommand |
|
GetKeyValueCommand |
|
GetSystemPropertyAction |
GetSystemPropertyAction.
|
GetSystemPropertyAsBooleanAction |
Wrapper for Boolean.getBoolean(propertyName)
|
GetSystemPropertyAsIntegerAction |
Wrapper for Integer.getInteger(propertyName, defaultValue) .
|
GlobalAuthorizationConfiguration |
GlobalAuthorizationConfiguration.
|
GlobalAuthorizationConfigurationBuilder |
GlobalAuthorizationConfigurationBuilder.
|
GlobalComponentRegistry |
A global component registry where shared components are stored.
|
GlobalConfiguration |
Configuration component that exposes the global configuration.
|
GlobalConfigurationBuilder |
|
GlobalConfigurationChildBuilder |
|
GlobalConfigurationManager |
|
GlobalConfigurationManagerImpl |
|
GlobalConfigurationManagerPostStart |
|
GlobalConfigurationStateListener |
Listens to events on the global state cache and manages cache configuration creation / removal accordingly
|
GlobalInboundInvocationHandler |
|
GlobalJmxStatisticsConfiguration |
|
GlobalJmxStatisticsConfigurationBuilder |
Configures whether global statistics are gathered and reported via JMX for all caches under this cache manager.
|
GlobalMarshaller |
A globally-scoped marshaller.
|
GlobalRoleConfigurationBuilder |
GlobalRoleConfigurationBuilder.
|
GlobalRolesConfigurationChildBuilder |
|
GlobalSecurityConfiguration |
GlobalSecurityConfiguration.
|
GlobalSecurityConfigurationBuilder |
GlobalSecurityConfigurationBuilder.
|
GlobalSecurityConfigurationChildBuilder |
GlobalSecurityConfigurationChildBuilder.
|
GlobalSecurityManager |
GlobalSecurityManager.
|
GlobalSecurityManagerFactory |
Factory for GlobalSecurityManager implementations
|
GlobalSecurityManagerImpl |
GlobalSecurityManagerImpl.
|
GlobalStateConfiguration |
GlobalStateConfiguration.
|
GlobalStateConfigurationBuilder |
GlobalStateConfigurationBuilder.
|
GlobalStateManager |
GlobalStateManager.
|
GlobalStateManagerImpl |
GlobalStateManagerImpl.
|
GlobalStateProvider |
GlobalStateProvider.
|
GlobalTransaction |
Uniquely identifies a transaction that spans all JVMs in a cluster.
|
GlobalTransaction.AbstractGlobalTxExternalizer<T extends GlobalTransaction> |
|
GlobalTransaction.Externalizer |
|
GlobalXSiteAdminOperations |
A per-container (cache manager) cross-site admin operations.
|
GridFile |
Subclass of File to iterate through directories and files in a grid
|
GridFile.Metadata |
|
GridFilesystem |
Entry point for GridFile and GridInputStream / GridOutputStream
|
GridInputStream |
|
GridOutputStream |
|
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.
|
GroupFilter<K> |
A key filter that accepts keys which belongs to the group.
|
GroupingInterceptor |
An interceptor that keeps track of the keys
added/removed during the processing of a GetKeysInGroupCommand
|
GroupingInterceptor.KeyListener |
|
GroupingPartitioner |
Key partitioner that uses Group annotations to map
grouped keys to the same segment.
|
GroupManager |
Control's key grouping.
|
GroupManagerFactory |
|
GroupManagerImpl |
|
GroupsConfiguration |
Configuration for various grouper definitions.
|
GroupsConfigurationBuilder |
Configuration for various grouper definitions.
|
HashConfiguration |
Allows fine-tuning of rehashing characteristics.
|
HashConfigurationBuilder |
Allows fine-tuning of rehashing characteristics.
|
HashFunctionPartitioner |
Key partitioner that computes a key's segment based on a hash function.
|
Health |
An entry point for checking health status.
|
HealthImpl |
|
HealthJMXExposer |
A Contract for exposing Health API over the JMX.
|
HealthJMXExposerImpl |
A JMX exposer (or adapter) for Health API.
|
HealthStatus |
General Health status.
|
HeartBeatCommand |
|
HostInfo |
Information about the host.
|
HostInfoImpl |
|
IdentityRoleMapper |
IdentityRoleMapper.
|
Ids |
Indexes for object types.
|
IgnoreExtraResponsesValidityFilter |
A filter that only expects responses from an initial set of targets.
|
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.
|
ImmortalCacheEntry |
A cache entry that is immortal/cannot expire
|
ImmortalCacheEntry.Externalizer |
|
ImmortalCacheValue |
|
ImmortalCacheValue.Externalizer |
|
ImmutableContext |
This context is a non-context for operations such as eviction which are not related
to the method invocation which caused them.
|
ImmutableLocalConfigurationStorage |
|
ImmutableMarshalledValueByteStream |
A byte stream that is immutable.
|
InboundInvocationHandler |
Interface to invoke when the Transport receives a command from other node
or site.
|
InboundInvocationHandlerFactory |
|
InboundTransferTask |
Inbound state transfer task.
|
IncorrectListenerException |
|
IncrementableEntryVersion |
An interface indicating that a version of this type can be incremented.
|
Index |
Used to configure indexing of entries in the cache for index-assisted searching.
|
IndexedFilter<K,V,C> |
|
IndexingConfiguration |
Configures indexing of entries in the cache for searching.
|
IndexingConfigurationBuilder |
Configures indexing of entries in the cache for searching.
|
InDoubtTxInfoImpl |
|
InDoubtTxInfoImpl.Externalizer |
|
InequalVersionComparisonResult |
Versions can be compared to each other to result in one version being before, after or at the same time as another
version.
|
InfinispanLock |
A special lock for Infinispan cache.
|
InitializationContext |
|
InitializationContextImpl |
|
Inject |
Used to annotate a method as one that is used to inject a registered component into another component.
|
InjectableComponent |
|
IntCacheStream |
A IntStream that has additional methods to allow for Serializable instances.
|
InterceptorChain |
Deprecated.
|
InterceptorChainFactory |
Factory class that builds an interceptor chain based on cache configuration.
|
InterceptorConfiguration |
Describes a custom interceptor
|
InterceptorConfiguration.Position |
Positional placing of a new custom interceptor
|
InterceptorConfigurationBuilder |
This builder defines details of a specific custom interceptor.
|
IntermediateCacheStream<Original,R> |
An intermediate cache stream used when an intermediate operation that requires both a remote and local portion
|
IntermediateDoubleCacheStream |
An intermediate double cache stream used when an intermediate operation that requires both a remote and local portion
|
IntermediateIntCacheStream |
An intermediate int cache stream used when an intermediate operation that requires both a remote and local portion
|
IntermediateLongCacheStream |
An intermediate long cache stream used when an intermediate operation that requires both a remote and local portion
|
IntermediateOperation<InputType,InputStream extends BaseStream<InputType,InputStream>,OutputType,OutputStream extends BaseStream<OutputType,OutputStream>> |
Intermediate operation that can be applied to a stream to change its processing.
|
IntermediateOperationExternalizer |
Externalizer to be used for serializing the various intermediate operations
|
IntermediateType |
The various intermediate types.
|
InternalCacheEntry<K,V> |
Interface for internal cache entries that expose whether an entry has expired.
|
InternalCacheFactory<K,V> |
An internal factory for constructing Caches.
|
InternalCacheRegistry |
InternalCacheRegistry.
|
InternalCacheRegistry.Flag |
|
InternalCacheRegistryImpl |
InternalCacheRegistryImpl.
|
InternalCacheValue<V> |
A representation of an InternalCacheEntry that does not have a reference to the key.
|
InternalConflictManager<K,V> |
|
InternalDataContainer<K,V> |
Interface describing methods of a data container where operations can be indexed by the segment of the key
stored in the map.
|
InternalDataContainerAdapter<K,V> |
|
InternalEntryFactory |
|
InternalEntryFactoryImpl |
An implementation that generates non-versioned entries
|
InternalExpirationManager<K,V> |
Interface describing the internal operations for the the ExpirationManager.
|
InternalMetadata |
|
InternalMetadataImpl |
|
InternalMetadataImpl.Externalizer |
|
IntSetExternalizer |
Externalizer to be used for IntSet implementations
|
IntSummaryStatisticsExternalizer |
|
InvalidateCommand |
Removes an entry from memory.
|
InvalidateL1Command |
Invalidates an entry in a L1 cache (used with DIST mode)
|
InvalidateVersionsCommand |
|
InvalidationInterceptor |
This interceptor acts as a replacement to the replication interceptor when the CacheImpl is configured with
ClusteredSyncMode as INVALIDATE.
|
InvalidCacheUsageException |
Thrown when client makes cache usage errors.
|
InvalidResponse |
An invalid response
|
InvalidTransactionException |
Thrown if an operation is to be performed on an invalid transaction context.
|
InvocationBatchingConfiguration |
|
InvocationBatchingConfigurationBuilder |
|
InvocationCallback |
|
InvocationContext |
A context that contains information pertaining to a given invocation.
|
InvocationContextContainer |
Deprecated.
|
InvocationContextFactory |
|
InvocationContextInterceptor |
|
InvocationExceptionFunction |
|
InvocationFinallyAction |
|
InvocationFinallyFunction |
|
InvocationStage |
A partial command invocation, either completed or in progress.
|
InvocationSuccessAction |
|
InvocationSuccessFunction |
|
IsMarshallableInterceptor |
Interceptor to verify whether parameters passed into cache are marshallables
or not.
|
IsolationLevel |
Various transaction isolation levels as an enumerated class.
|
IspnMBeanOperationInfo |
Infinispan allows a different JMX operation name than the actual method name that gets invoked
(see ManagedOperation.name() .
|
IteratorAsSpliterator<T> |
A Spliterator using the provided iterator for supplying values.
|
IteratorAsSpliterator.Builder<T> |
|
IteratorHandler |
Handler for storing iterators between invocations so that remote node can request data in chunks.
|
IteratorHandler.OnCloseIterator<E> |
A CloseableIterator that also allows callers to attach Runnable instances to it, so that when
this iterator is closed, those Runnables are also invoked.
|
IteratorResponse<V> |
Iterator response returned when an iterator batch is sent back which contains the iterator, if any segments
were suspected and if the iterator has returned all values (complete).
|
IteratorResponses |
Response object used when an iterator is the response value and it is unknown if the iterator has enough entries
for the given batch size.
|
IteratorResponses.IteratorResponsesExternalizer |
This externalizer is a special breed that converts a given response into others, based on whether or not
an iterator has completed or not.
|
JBossMarshaller |
A JBoss Marshalling based marshaller that is oriented at internal, embedded,
Infinispan usage.
|
JBossMBeanServerLookup |
Deprecated.
|
JBossStandaloneJTAManagerLookup |
JTA standalone TM lookup (JBoss AS 7 and earlier, and WildFly 8, 9, and 10).
|
JGroupsAddress |
An encapsulation of a JGroups Address
|
JGroupsAddress.Externalizer |
|
JGroupsAddressCache |
Cache JGroupsAddress instances
|
JGroupsBackupResponse |
|
JGroupsChannelLookup |
A hook to pass in a JGroups channel.
|
JGroupsTopologyAwareAddress |
An encapsulation of a JGroups ExtendedUUID with a site id, a rack id, and a machine id.
|
JGroupsTopologyAwareAddress.Externalizer |
|
JGroupsTransport |
An encapsulation of a JGroups transport.
|
JmxAttributeMetadata |
Persistable and cacheable metadata for JMX attributes
|
JmxDomainConflictException |
|
JmxOperationMetadata |
Persistable and cacheable metadata for JMX operations
|
JmxOperationParameter |
JmxOperationParameter stores metadata information about MBean operation parameters which
is then used at runtime to build the relevant MBeanParameterInfo
|
JMXStatisticsConfiguration |
Determines whether statistics are gather and reported.
|
JMXStatisticsConfigurationBuilder |
Determines whether statistics are gather and reported.
|
JmxStatisticsExposer |
Interface containing common cache management operations
|
JmxStatsCommandInterceptor |
Base class for all the interceptors exposing management statistics.
|
Key2StringMapper |
Defines the logic of mapping a key object to a String.
|
KeyAffinityService<K> |
Defines a service that generates keys to be mapped to specific nodes in a distributed(vs.
|
KeyAffinityServiceFactory |
|
KeyAffinityServiceImpl<K> |
Implementation of KeyAffinityService.
|
KeyAffinityServiceImpl<K> |
Deprecated.
|
KeyAwareLockListener |
|
KeyAwareLockPromise |
An extension of LockPromise that contains a key associated to the lock.
|
KeyFilter<K> |
Deprecated.
|
KeyFilterAsCacheEventFilter<K> |
CacheEventFilter that implements it's filtering solely on the use of the provided KeyFilter
|
KeyFilterAsCacheEventFilter.Externalizer |
|
KeyFilterAsKeyValueFilter<K,V> |
KeyValueFilter that implements it's filtering solely on the use of the provided KeyFilter
|
KeyFilterAsKeyValueFilter.Externalizer |
|
KeyGenerator<K> |
|
KeyPartitioner |
Map keys to segments.
|
KeyPartitionerFactory |
Key partitioner factory that uses the hash function defined in the configuration.
|
KeySetCommand<K,V> |
|
KeyStreamSupplier<K,V> |
Stream supplier that is to be used when the underlying stream is composed by key instances.
|
KeyTrackingTerminalOperation<Original,K,R> |
A terminal operation for a CacheStream that allows tracking keys during a rehash event.
|
KeyTrackingTerminalOperation.IntermediateCollector<C> |
Collector used to collect items from intermediate responses of operations
|
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 |
|
KeyValueFilterAsKeyFilter<K> |
This is a KeyFilter that utilizes the given KeyValueFilter to determine if to
filter the key.
|
KeyValueFilterAsKeyFilter.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> |
|
KeyValueMetadataSizeCalculator<K,V> |
Size calculator that takes into account not only key and value but also metadata.
|
KeyValuePair<K,V> |
Holds logically related key-value pairs or binary tuples.
|
KeyValuePair.Externalizer |
|
KnownComponentNames |
Holder for known named component names.
|
L1Configuration |
Configures the L1 cache behavior in 'distributed' caches instances.
|
L1ConfigurationBuilder |
Configures the L1 cache behavior in 'distributed' caches instances.
|
L1InternalCacheEntry |
|
L1LastChanceInterceptor |
L1 based interceptor that flushes the L1 cache at the end after a transaction/entry is committed to the data
container but before the lock has been released.
|
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.
|
L1ManagerImpl |
|
L1Metadata |
|
L1MetadataInternalCacheEntry |
|
L1NonTxInterceptor |
Interceptor that handles L1 logic for non-transactional caches.
|
L1SegmentedDataContainer<K,V> |
Segmented data container that also allows for non owned segments to be written to a temporary map (L1).
|
L1TxInterceptor |
Interceptor that handles L1 logic for transactional caches.
|
L1WriteSynchronizer |
A write synchronizer that allows for a single thread to run the L1 update while others can block until it is
completed.
|
LazyConcatIterator<E> |
Iterator implementation that will return all entries from the first iterator.
|
LazyInitializingBlockingTaskAwareExecutorService |
A delegating executor that lazily constructs and initializes the underlying executor.
|
LazyInitializingExecutorService |
A delegating executor that lazily constructs and initializes the underlying executor, since unused JDK executors
are expensive.
|
LazyInitializingScheduledExecutorService |
A delegating scheduled executor that lazily constructs and initializes the underlying scheduled executor, since
unused JDK executors are expensive.
|
Lifecycle |
Deprecated.
|
LimitDoubleOperation |
|
LimitedExecutor |
Executes tasks in the given executor, but never has more than maxConcurrentTasks tasks running at the same
time.
|
LimitIntOperation |
|
LimitLongOperation |
|
LimitOperation<S> |
Performs limit operation on a regular Stream
|
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.
|
ListenerHolder |
|
ListenerInvocation<T> |
Defines simple listener invocation.
|
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
|
LocalCacheBackupReceiver |
|
LocalCacheStream<R> |
CacheStream that is to be used locally.
|
LocalClassLoaderCacheStoreFactory |
Default implementation, which uses Local class loader.
|
LocalCommand |
This is a marker interface to indicate that such commands will never be replicated and hence will not return any
valid command IDs.
|
LocalConfigurationStorage |
|
LocalDoubleCacheStream |
DoubleStream that wraps a given stream to allow for additional functionality such as injection of values into
various operations
|
LocalIntCacheStream |
IntStream that wraps a given stream to allow for additional functionality such as injection of values into
various operations
|
LocalInvocation |
Simulates a remote invocation on the local node.
|
LocalizedCacheTopology |
Extends CacheTopology with information about keys owned by the local node.
|
LocalLongCacheStream |
LongStream that wraps a given stream to allow for additional functionality such as injection of values into
various operations
|
LocalModeAddress |
Represents the local node's address.
|
LocalOnlyCacheLoader |
Marker interface for cache loaders that should only load values on the originating nodes.
|
LocalStreamManager<Original,K> |
Stream manager that is invoked on a local node.
|
LocalStreamManagerImpl<Original,K,V> |
Local stream manager implementation that handles injection of the stream supplier, invoking the operation and
subsequently notifying the operation if a rehash has changed one of its segments.
|
LocalTopologyManager |
|
LocalTopologyManagerFactory |
Factory for ClusterTopologyManager implementations
|
LocalTopologyManagerImpl |
The LocalTopologyManager implementation.
|
LocalTransaction |
Object that holds transaction's state on the node where it originated; as opposed to RemoteTransaction .
|
LocalTxInvocationContext |
Invocation context to be used for locally originated transactions.
|
LocalXaTransaction |
|
LockAction |
An Action implementation that acquire the locks.
|
LockContainer |
A container for locks
|
LockContainerFactory |
|
LockControlCommand |
LockControlCommand is a command that enables distributed locking across infinispan nodes.
|
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.
|
LockedStreamImpl<K,V> |
Lock Stream implementation that locks a key using the LockManager before and after executing the various
code.
|
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.
|
LockListener |
|
LockManager |
An interface to deal with all aspects of acquiring and releasing locks for cache entries.
|
LockManagerFactory |
|
LockPromise |
|
LockState |
|
Log |
Infinispan's log abstraction layer on top of JBoss Logging.
|
Log_$logger |
Warning this class consists of generated code.
|
LogFactory |
Factory that creates Log instances.
|
LoggingAuditLogger |
LoggingAuditLogger.
|
LongCacheStream |
A LongStream that has additional methods to allow for Serializable instances.
|
LongSummaryStatisticsExternalizer |
|
LostDataCheck |
|
ManageableComponentMetadata |
|
ManageableExecutorService<T extends ExecutorService> |
|
ManagedAttribute |
Indicates that a public method or a field (any visibility) in an MBean class defines an MBean attribute.
|
ManagedOperation |
Indicates that a method in an MBean class defines an MBean operation.
|
ManagerStatusResponse |
|
ManagerStatusResponse.Externalizer |
|
MapDoubleOperation |
|
MapExternalizer |
Map externalizer for all map implementations except immutable maps and singleton maps, i.e.
|
MapIntOperation |
|
MapLongOperation |
|
MapOperation<I,O> |
Performs map to operation on a regular Stream
|
MappingOperation<InputType,InputStream extends BaseStream<InputType,InputStream>,OutputType,OutputStream extends BaseStream<OutputType,OutputStream>> |
|
MapResponseCollector |
|
MapToDoubleIntOperation |
Performs map to double operation on a IntStream
|
MapToDoubleLongOperation |
|
MapToDoubleOperation<I> |
Performs map to double operation on a regular Stream
|
MapToIntDoubleOperation |
|
MapToIntLongOperation |
|
MapToIntOperation<I> |
Performs map to int operation on a regular Stream
|
MapToLongDoubleOperation |
|
MapToLongIntOperation |
Performs map to long operation on a IntStream
|
MapToLongOperation<I> |
Performs map to long operation on a regular Stream
|
MapToObjDoubleOperation<R> |
|
MapToObjIntOperation<R> |
Performs map to object operation on a IntStream
|
MapToObjLongOperation<R> |
|
MarshallableFunctionExternalizers |
|
MarshallableFunctionExternalizers.ConstantLambdaExternalizer |
|
MarshallableFunctionExternalizers.LambdaWithMetasExternalizer |
|
MarshallableFunctionExternalizers.SetValueIfEqualsReturnBooleanExternalizer |
|
MarshallableFunctions |
|
MarshalledEntry<K,V> |
Defines an externally persisted entry.
|
MarshalledEntryFactory<K,V> |
|
MarshalledEntryFactoryImpl |
|
MarshalledEntryImpl<K,V> |
|
MarshalledEntryImpl.Externalizer |
|
MarshalledValueByteStream |
A stream of bytes which can be written to, and the underlying byte array can be directly accessed.
|
MarshallerFactory |
MarshallerFactory.
|
MarshallingTwoWayKey2StringMapper |
MarshallingTwoWayKey2StringMapper.
|
MBean |
Classes annotated with this will be exposed as MBeans.
|
MBeanServerLookup |
Deprecated.
|
MeasurementType |
|
MemoryAddressHash |
|
MemoryConfiguration |
Controls the memory storage configuration for the cache.
|
MemoryConfigurationBuilder |
Controls the data container for the cache.
|
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 .
|
MergeFunction<K,V> |
|
MergeFunction.Externalizer |
|
MergeOnStore |
This interface is not a public API.
|
MergePolicies |
Deprecated.
|
MergePolicy |
|
MergePolicy.UnsupportedMergePolicy |
|
Messages |
Messages.
|
Messages_$bundle |
Warning this class consists of generated code.
|
Metadata |
This interface encapsulates metadata information that can be stored
alongside values in the cache.
|
Metadata.Builder |
Metadata builder
|
MetadataAware |
Marker interface for metadata aware cache entry.
|
MetadataAwareCommand |
A command that contains metadata information.
|
MetadataImmortalCacheEntry |
|
MetadataImmortalCacheEntry.Externalizer |
|
MetadataImmortalCacheValue |
|
MetadataImmortalCacheValue.Externalizer |
|
MetadataMortalCacheEntry |
|
MetadataMortalCacheEntry.Externalizer |
|
MetadataMortalCacheValue |
|
MetadataMortalCacheValue.Externalizer |
|
Metadatas |
Utility method for Metadata classes.
|
MetadataTransientCacheEntry |
A cache entry that is transient, i.e., it can be considered expired after
a period of not being used, and MetadataAware
|
MetadataTransientCacheEntry.Externalizer |
|
MetadataTransientCacheValue |
|
MetadataTransientCacheValue.Externalizer |
|
MetadataTransientMortalCacheEntry |
|
MetadataTransientMortalCacheEntry.Externalizer |
|
MetadataTransientMortalCacheValue |
|
MetadataTransientMortalCacheValue.Externalizer |
|
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.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.Writable<T> |
Writable MetaParam instances are those that the user can provide
to be stored as part of the cache entry.
|
MetaParamExternalizers |
|
MetaParamExternalizers.EntryVersionParamExternalizer |
|
MetaParamExternalizers.LifespanExternalizer |
|
MetaParamExternalizers.MaxIdleExternalizer |
|
MetaParamsInternalMetadata |
Metadata parameters backed internal metadata representation.
|
MetaParamsInternalMetadata.Builder |
|
MetaParamsInternalMetadata.Externalizer |
|
MIMECacheEntry |
Wrapper object for entries that arrive via RESTful PUT/POST interface.
|
MIMECacheEntry.Externalizer |
|
Modification |
|
Modification.Type |
|
ModificationsList |
ModificationsList contains a List
|
ModularArithmetic |
For compatibility
|
ModuleCommandExtensions |
Module command extensions.
|
ModuleCommandFactory |
Modules which wish to implement their own commands and visitors must also provide an implementation of this
interface.
|
ModuleCommandInitializer |
Modules which wish to implement their own commands and visitors must also provide an implementation of this
interface.
|
ModuleLifecycle |
ModuleLifecycle is an internal API hook for delegating lifecycle events to Infinispan sub-modules.
|
ModuleMetadataFileFinder |
This interface should be implemented by all Infinispan modules that expect to have components using Inject ,
Start or Stop annotations.
|
ModuleProperties |
The ModuleProperties class represents Infinispan's module service extensions.
|
MortalCacheEntry |
A cache entry that is mortal.
|
MortalCacheEntry.Externalizer |
|
MortalCacheValue |
|
MortalCacheValue.Externalizer |
|
MultiClusterEventCallable<K,V> |
This DistributedCallable is used to invoke a raised notification on the cluster listener that registered to listen
for this event.
|
MultiClusterEventCallable.Externalizer |
|
MultiEntriesFunctionalBackupWriteCommand |
|
MultiKeyFunctionalBackupWriteCommand |
|
MultiSubCommandInvoker |
Invoke a sequence of sub-commands.
|
MultiTargetRequest<T> |
Request implementation that waits for responses from multiple target nodes.
|
Mutation<K,V,R> |
Simplified version of functional command used for read-only operations after transactional modifications.
|
MVCCEntry<K,V> |
An entry that can be safely copied when updates are made, to provide MVCC semantics
|
NamedCacheNotFoundException |
Thrown when a named cache cannot be found.
|
NamedComponentFactory |
Deprecated.
|
NamedExecutorsFactory |
A factory that specifically knows how to create named executors.
|
NamedFactory |
|
Namespace |
Namespace.
|
NamespaceMappingParser |
NamespaceMappingParser.
|
Namespaces |
Namespaces.
|
NonTotalOrderPerCacheInboundInvocationHandler |
|
NonTotalOrderTxPerCacheInboundInvocationHandler |
|
NonTransactionalBackupInterceptor |
Handles x-site data backups for non-transactional caches.
|
NonTransactionalInvocationContextFactory |
Deprecated.
|
NonTransactionalLockingInterceptor |
Locking interceptor to be used for non-transactional caches.
|
NonTxDistributionInterceptor |
Non-transactional interceptor used by distributed caches that support concurrent writes.
|
NonTxInvocationContext |
Context to be used for non transactional calls, both remote and local.
|
NoOpPendingLockManager |
|
NotificationInterceptor |
The interceptor in charge of firing off notifications to cache listeners
|
NotifyHelper |
|
NullAuditLogger |
NullAuditLogger.
|
NullCacheEntry<K,V> |
|
NumericVersion |
Numeric version
|
NumericVersion.Externalizer |
|
NumericVersionGenerator |
Generates unique numeric versions for both local and clustered environments.
|
OffHeapConcurrentMap |
|
OffHeapConcurrentMap.EntryListener |
Listener interface that is notified when certain operations occur for various memory addresses.
|
OffHeapDataContainer |
|
OffHeapEntryFactory |
|
OffHeapEntryFactoryImpl |
Factory that can create CacheEntry instances from off-heap memory.
|
OffHeapMemoryAllocator |
Allows for allocation of memory outside of the heap as well additional functionality surrounding it if
necessary.
|
OfflineSiteStatus |
|
OfflineStatus |
Keeps state needed for knowing when a site needs to be taken offline.
|
OnlineSiteStatus |
|
OptimisticBackupInterceptor |
Handles x-site data backups for optimistic transactional caches.
|
OptimisticLockingInterceptor |
Locking interceptor to be used by optimistic transactional caches.
|
OptionalExternalizer |
|
OrderedUpdatesManager |
|
OrderedUpdatesManagerImpl |
|
OutboundTransferTask |
Outbound state transfer task.
|
OutdatedTopologyException |
An exception signalling that a command should be retried because it was executed with an outdated
topology.
|
OverlayLocalConfigurationStorage |
|
Ownership |
|
OwnershipStatistics |
This class holds statistics about a consistent hash.
|
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.
|
Parameter |
|
ParamIds |
Parameter identifiers.
|
ParamKeyValueFilterConverterFactory<K,V,C> |
|
Params |
Internal class that encapsulates collection of parameters used to tweak
functional map operations.
|
ParsedCacheMode |
|
Parser |
This class implements the parser for Infinispan/AS7/EAP/JDG schema files
|
Parser.Mode |
|
Parser.TransactionMode |
|
Parser72 |
Deprecated. |
ParserContext |
ParserContext.
|
ParserContextListener |
ParserContextListener.
|
ParserRegistry |
ParserRegistry is a namespace-mapping-aware meta-parser which provides a way to delegate the
parsing of multi-namespace XML files to appropriate parsers, defined by the
ConfigurationParser interface.
|
ParserRegistry.NamespaceParserPair |
|
ParserScope |
ParserScope indicates the configuration parser scope.
|
ParseUtils |
|
PartitionAwareClusterStreamManager<Original,K> |
Cluster stream manager that also pays attention to partition status and properly closes iterators and throws
exceptions when the availability mode changes.
|
PartitionerConsistentHash |
|
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.
|
PartitionHandlingInterceptor |
|
PartitionHandlingManager |
|
PartitionHandlingManagerFactory |
|
PartitionHandlingManagerImpl |
|
PartitionStatusChanged |
|
PartitionStatusChangedEvent<K,V> |
|
PassivationManager |
A passivation manager
|
PassivationManagerImpl |
|
PassivationManagerStub |
|
PassivationWriterInterceptor |
Handles store write operations when passivation enabled that don't entail reading the entry first
|
PassthroughMapResponseCollector |
Receive responses from multiple nodes, without checking that the responses are valid.
|
PassthroughSingleResponseCollector |
RPC to a single node, without any validity checks.
|
PeekDoubleOperation |
|
PeekIntOperation |
|
PeekLongOperation |
|
PeekOperation<S> |
Performs peek operation on a regular Stream
|
PendingLockListener |
|
PendingLockManager |
A manager that checks and waits for older topology transaction with conflicting keys.
|
PendingLockPromise |
|
PendingTxAction |
An Action implementation that check for older topology transactions.
|
PerCacheInboundInvocationHandler |
Interface to invoke when a CacheRpcCommand is received from other node in the
local site.
|
PerKeyLockContainer |
A lock container that creates and maintains a new lock per entry.
|
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 |
|
PersistenceEntryStreamSupplier<K,V> |
StreamSupplier that allows for creating streams where they utilize the PersistenceManager to publish entries
using segments if possible.
|
PersistenceException |
An exception thrown by a CacheLoader or a CacheWriter implementation if there are problems
reading from a loader.
|
PersistenceKeyStreamSupplier<K> |
StreamSupplier that allows for creating streams where they utilize the PersistenceManager to publish keys
using segments if possible.
|
PersistenceManager |
Defines the logic for interacting with the chain of external storage.
|
PersistenceManager.AccessMode |
|
PersistenceManagerCloseableSupplier<K,V> |
Deprecated.
|
PersistenceManagerImpl |
|
PersistenceManagerStub |
|
PersistenceUtil |
Persistence Utility that is useful for internal classes.
|
PersistenceUtil |
|
PersistentUUID |
PersistentUUID.
|
PersistentUUID.Externalizer |
|
PersistentUUIDManager |
PersistentUUIDManager maintains a mapping of PersistentUUID s present in the cluster
|
PersistentUUIDManagerImpl |
|
PessimisticBackupInterceptor |
Handles x-site data backups for pessimistic transactional caches.
|
PessimisticLockingInterceptor |
Locking interceptor to be used by pessimistic caches.
|
PlatformMBeanServerLookup |
Deprecated.
|
PostCacheEventFilter<K,V> |
A Filter that only allows post events to be accepted.
|
PostStart |
Deprecated.
|
PreferAvailabilityStrategy |
|
PreferConsistencyStrategy |
|
PrefetchInterceptor<K,V> |
|
PreloadManager |
Separate the preload into its own component
|
PrepareCommand |
Command corresponding to the 1st phase of 2PC.
|
PreparedTxIterator |
Default implementation for RecoveryIterator.
|
PrePostProcessingCommandInterceptor |
Deprecated.
|
PrimaryOwnerFilter<K> |
|
PrimaryOwnerOnlyCollector<T> |
A Collector implementation that only waits for the primary owner.
|
PrimitiveEntrySizeCalculator |
Entry Size calculator that returns an approximation of how much various primitives, primitive wrappers, Strings,
and arrays
|
PrincipalRoleMapper |
PrincipalRoleMapper.
|
PrincipalRoleMapperContext |
PrincipalRoleMapperContext.
|
PrincipalRoleMapperContextImpl |
PrincipalRoleMapperContextImpl.
|
PriorityMergingProcessor<T> |
An iterable that will automatically poll entries from the given publishers.
|
PriorityMergingProcessor.Builder<T> |
|
PrivateGlobalConfiguration |
An internal configuration.
|
PrivateGlobalConfigurationBuilder |
|
PrivateGlobalConfigurationSerializer |
|
PropertyFormatter |
Extracts the configuration into flat key-value property structure by reflection.
|
PutKeyValueCommand |
Implements functionality defined by BasicCache.put(Object, Object)
|
PutMapBackupWriteCommand |
|
PutMapCommand |
|
QueueAsyncInvocationStage |
Invocation stage representing a computation that may or may not be done yet.
|
QueueingSegmentListener<K,V,E extends Event<K,V>> |
This interface describes methods needed for a segment listener that is used when iterating over the current
events and be able to queue them properly
|
RangeSet |
Deprecated.
|
ReadableGridFileChannel |
|
ReadCommittedEntry |
A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or
rolled back.
|
ReadCommittedEntry.Flags |
|
ReadOnlyCollectionAsSet<T> |
Assumes that the delegate collection already contains unique elements.
|
ReadOnlyDataContainerBackedKeySet |
Deprecated.
|
ReadOnlyKeyCommand<K,V,R> |
|
ReadOnlyManyCommand<K,V,R> |
|
ReadOnlyMapImpl<K,V> |
Read-only map implementation.
|
ReadOnlySegmentAwareCollection<E> |
Set implementation that shows a read only view of the provided set by only allowing
entries that map to a given segment using the provided consistent hash.
|
ReadOnlySegmentAwareEntryCollection<K,V> |
Iterator implementation that shows a read only view of the provided iterator by only
allowing values that map to a given segment using the provided consistent hash.
|
ReadOnlySegmentAwareEntryIterator<K,V> |
Iterator implementation that shows a read only view of the provided iterator by only
allowing values that map to a given segment using the provided consistent hash.
|
ReadOnlySegmentAwareIterator<E> |
Iterator implementation that shows a read only view of the provided iterator by only
allowing values that map to a given segment using the provided consistent hash.
|
ReadOnlySegmentAwareMap<K,V> |
Map implementation that shows a read only view of the provided entry by only allowing
entries whose key maps to a given segment using the provided consistent hash.
|
ReadWriteKeyCommand<K,V,R> |
|
ReadWriteKeyValueCommand<K,V,T,R> |
|
ReadWriteManyCommand<K,V,R> |
|
ReadWriteManyEntriesCommand<K,V,T,R> |
|
ReadWriteMapImpl<K,V> |
Read-write map implementation.
|
ReadyAction |
|
RebalanceType |
|
RebalancingStatus |
RebalancingStatus.
|
ReclosableLatch |
|
RecoverableTransactionIdentifier |
|
RecoveryAdminOperations |
Admin utility class for allowing management of in-doubt transactions (e.g.
|
RecoveryAwareDldGlobalTransaction |
Deprecated.
|
RecoveryAwareDldGlobalTransaction.Externalizer |
Deprecated. |
RecoveryAwareGlobalTransaction |
GlobalTransaction that also holds xid information, required for recovery.
|
RecoveryAwareGlobalTransaction.Externalizer |
|
RecoveryAwareLocalTransaction |
|
RecoveryAwareRemoteTransaction |
|
RecoveryAwareTransaction |
Base interface for transactions that are holders of recovery information.
|
RecoveryAwareTransactionTable |
Transaction table that delegates prepared transaction's management to the RecoveryManager .
|
RecoveryCommand |
Base class for recovery-related rpc-commands.
|
RecoveryConfiguration |
Defines recovery configuration for the cache.
|
RecoveryConfigurationBuilder |
Defines recovery configuration for the cache.
|
RecoveryInfoKey |
This makes sure that only xids pertaining to a certain cache are being returned when needed.
|
RecoveryManager |
RecoveryManager is the component responsible with managing recovery related information and the functionality
associated with it.
|
RecoveryManager.InDoubtTxInfo |
An object describing in doubt transaction's state.
|
RecoveryManager.RecoveryIterator |
Stateful structure allowing prepared-tx retrieval in a batch-oriented manner, as required by XAResource.recover(int) .
|
RecoveryManagerFactory |
Factory for RecoveryManager.
|
RecoveryManagerImpl |
|
RemoteClusterListener |
A listener that installed locally on each node when a cluster listener is installed on a given node.
|
RemoteCommandsFactory |
|
RemoteException |
Represents an application-level exception originating in a remote node.
|
RemoteGetResponseCollector |
Return the first response that is either successful or exceptional.
|
RemoteLockCommand |
Simple interface to extract all the keys that may need to be locked.
|
RemoteMetadata |
This is a metadata type used by scattered cache during state transfer.
|
RemoteMetadata.Externalizer |
|
RemoteTransaction |
Defines the state of a remotely originated transaction.
|
RemoteTxInvocationContext |
Context to be used for transaction that originated remotely.
|
RemoteValueRetrievedListener |
Listener that is notified when a remote value is looked up
|
RemovableCloseableIterator<K,C> |
Deprecated.
|
RemovableFunction<T,R> |
Deprecated.
|
RemovableIterator<K,C> |
Deprecated.
|
Remove |
|
RemoveCacheCommand |
Deprecated.
|
RemoveCommand |
|
RemoveExpiredCommand |
Removes an entry that is expired from memory
|
RemoveListenerAction |
RemoveListenerAction
|
RenewBiasCommand |
|
RepeatableReadEntry |
|
ReplaceCommand |
|
ReplicableCommand |
The core of the command-based cache framework.
|
ReplicableCommandExternalizer |
ReplicableCommandExternalizer.
|
ReplicableCommandManagerFunction |
|
ReplicableCommandRunnable |
Replicable Command that runs the given Runnable
|
ReplicatedConsistentHash |
|
ReplicatedConsistentHash.Externalizer |
|
ReplicatedConsistentHashFactory |
Factory for ReplicatedConsistentHash.
|
ReplicatedConsistentHashFactory.Externalizer |
|
Reply |
Interface responsible to send back the return value to the sender.
|
Request<T> |
A remote command invocation request.
|
RequestRepository |
|
ResourceDMBean |
This class was entirely copied from JGroups 2.7 (same name there).
|
Response |
A response to be sent back to a remote caller
|
ResponseCollector<T> |
A representation of a request's responses.
|
ResponseCollectors |
|
ResponseFilter |
A mechanism of filtering RPC responses.
|
ResponseGenerator |
A component that generates responses as is expected by different cache setups
|
ResponseGeneratorFactory |
Creates a ResponseGenerator
|
ResponseMode |
Represents different handling mechanisms when dealing with remote command responses.
|
RetrieveLastAccessCommand |
Command that when invoked will retrieve the last access time from an entry without updating it
|
RetryingEntryWrappingInterceptor |
Used in @{link org.infinispan.configuration.cache.CacheMode#SCATTERED_SYNC scattered cache}
The commit is executed in ScatteredDistributionInterceptor
before replicating the change from primary owner.
|
RetryOnFailureXSiteCommand |
Invokes a command in a remote site.
|
RetryOnFailureXSiteCommand.MaxRetriesPolicy |
|
RetryOnFailureXSiteCommand.RetryPolicy |
|
RevokeBiasCommand |
Informs node that it is not allowed to serve reads from the local record anymore.
|
RndKeyGenerator |
Key provider that relies on Random 's distribution to generate keys.
|
Role |
A role to permission mapping.
|
RollbackCommand |
Command corresponding to a transaction rollback.
|
RollingUpgradeManager |
This component handles the control hooks to handle migrating from one version of Infinispan to
another.
|
RpcException |
Thrown when an RPC problem occurred on the caller.
|
RpcManager |
Provides a mechanism for communicating with other caches in the cluster, by formatting and passing requests down to
the registered Transport .
|
RpcManagerFactory |
A factory for the RpcManager
|
RpcManagerImpl |
This component really is just a wrapper around a Transport implementation,
and is used to set up the transport and provide lifecycle and dependency hooks into external transport
implementations.
|
RpcOptions |
Classes that wraps all the configuration parameters to configure a remote invocation.
|
RpcOptionsBuilder |
Deprecated.
|
RunnableAdapter<T> |
Runnable adapter for distributed executor service
Any RunnableAdapter refactoring might break CDI
|
ScatteredCacheWriterInterceptor |
Similar to DistCacheWriterInterceptor but as commands are not forwarded from primary owner
so we just write to the store all the time (with non-shared interceptors).
|
ScatteredConsistentHash |
CH used by scattered caches.
|
ScatteredConsistentHash.Externalizer |
|
ScatteredConsistentHashFactory |
|
ScatteredConsistentHashFactory.Builder |
|
ScatteredConsistentHashFactory.Externalizer |
|
ScatteredDistributionInterceptor |
This interceptor mixes several functions:
A) replicates changes to other nodes
B) commits the entry
C) schedules invalidation
On primary owner, the commit is executed before the change is replicated to other node.
|
ScatteredDistributionInterceptor.PrimaryResponseGenerator |
|
ScatteredPartitionHandlingManagerImpl |
|
ScatteredStateConsumerImpl |
|
ScatteredStateConsumerImpl.KeyAndVersion |
|
ScatteredStateProvider |
|
ScatteredStateProviderImpl |
|
ScatteredVersionManager<K> |
Manages versions of entries and states of segments.
|
ScatteredVersionManager.SegmentState |
|
ScatteredVersionManagerImpl<K> |
|
ScheduledExecutorFactory |
Used to configure and create scheduled executors
|
ScheduledExecutorFactoryConfiguration |
|
ScheduledExecutorFactoryConfigurationBuilder |
Configures executor factory.
|
Schema |
Schema.
|
Scope |
Defines the scope of a component in a cache system.
|
ScopeDetector |
Retrieves the declared scope of a component
|
ScopedPersistentState |
ScopedPersistentState represents state which needs to be persisted, scoped by name (e.g.
|
ScopedPersistentStateImpl |
ScopedPersistentStateImpl.
|
ScopedState |
Key for scoped entries in the ClusterConfigurationManager state cache
|
ScopedState.Externalizer |
|
ScopeFilter |
|
ScopeFilter.Externalizer |
|
Scopes |
The different scopes that can be declared for a component in the cache system.
|
SecureCache<K,V> |
SecureCache.
|
SecureCacheImpl<K,V> |
SecureCacheImpl.
|
Security |
Security.
|
SecurityAwareScheduledExecutorFactory |
|
SecurityConfiguration |
SecurityConfiguration.
|
SecurityConfigurationBuilder |
SecurityConfigurationBuilder.
|
SecurityConfigurationChildBuilder |
|
SegmentAwareOperation |
Terminal stream operation that is aware of segments being lost.
|
SegmentedAdvancedLoadWriteStore<K,V> |
An interface implementing both AdvancedCacheWriter and AdvancedCacheLoader as well as overrides
of those methods that can be optimized when a segment is already known for the key or a subset of segments are to
be used instead of the entire store.
|
SegmentedBoundedOffHeapDataContainer |
|
SegmentedEntryStreamSupplier<K,V> |
StreamSupplier that allows for creating streams where they utilize a InternalDataContainer so that
the stream only looks at entries in those given segments.
|
SegmentedKeyStreamSupplier<K,V> |
StreamSupplier that allows for creating streams where they utilize a InternalDataContainer so that
the stream only looks at keys in those given segments.
|
SegmentRetryingOperation<Original,E,T,S extends BaseStream<T,S>,S2 extends S> |
A terminal based operation that runs the provided function to evaluate the operation.
|
SegmentSpecificCommand |
Interface to be implemented when the command can define a single segment for its operation.
|
SemaphoreCompletionService<T> |
Executes tasks in the given executor, but never has more than maxConcurrentTasks tasks running at the same time.
|
SerializableBiConsumer<T,U> |
|
SerializableBiFunction<T,U,R> |
|
SerializableBinaryOperator<T> |
|
SerializableCallable<V> |
This is a functional interface that is the same as a Callable except that it must also be
Serializable
|
SerializableComparator<T> |
|
SerializableConsumer<T> |
This is a functional interface that is the same as a Consumer except that it must also be
Serializable
|
SerializableDoubleBinaryOperator |
|
SerializableDoubleConsumer |
|
SerializableDoubleFunction<R> |
|
SerializableDoublePredicate |
|
SerializableDoubleToIntFunction |
|
SerializableDoubleToLongFunction |
|
SerializableDoubleUnaryOperator |
|
SerializableFunction<T,R> |
This is a functional interface that is the same as a Function except that it must also be
Serializable
|
SerializableIntBinaryOperator |
|
SerializableIntConsumer |
|
SerializableIntFunction<R> |
|
SerializableIntPredicate |
|
SerializableIntToDoubleFunction |
|
SerializableIntToLongFunction |
|
SerializableIntUnaryOperator |
|
SerializableLongBinaryOperator |
|
SerializableLongConsumer |
|
SerializableLongFunction<R> |
|
SerializableLongPredicate |
|
SerializableLongToDoubleFunction |
|
SerializableLongToIntFunction |
|
SerializableLongUnaryOperator |
|
SerializableObjDoubleConsumer<T> |
|
SerializableObjIntConsumer<T> |
|
SerializableObjLongConsumer<T> |
|
SerializablePredicate<T> |
|
SerializableRunnable |
This is a functional interface that is the same as a Runnable except that it must also be
Serializable
|
SerializableSupplier<T> |
This is a functional interface that is the same as a Supplier except that it must also be
Serializable
|
SerializableToDoubleFunction<T> |
|
SerializableToIntFunction<T> |
|
SerializableToLongFunction<T> |
|
SerializableXid |
Deprecated.
|
SerializableXid.XidExternalizer |
|
SerializationConfiguration |
|
SerializationConfigurationBuilder |
Configures serialization and marshalling settings.
|
SerializedWith |
|
Serializer |
|
SerializeUtils |
|
SetCacheAvailabilityAction |
SetCacheAvailabilityAction.
|
SetMapper<E,R> |
A set that maps another one to a new one of a possibly different type.
|
SetThreadContextClassLoaderAction |
SetThreadContextClassLoaderAction.
|
ShutdownConfiguration |
|
ShutdownConfigurationBuilder |
|
ShutdownHookBehavior |
Behavior of the JVM shutdown hook registered by the cache
|
SimpleAsyncInvocationStage |
Invocation stage representing a computation that may or may not be done yet.
|
SimpleCacheImpl<K,V> |
Simple local cache without interceptor stack.
|
SimpleCacheImpl.CacheEntryChange<K,V> |
|
SimpleCacheImpl.ValueAndMetadata<V> |
|
SimpleClusteredVersion |
A simple versioning scheme that is cluster-aware
|
SimpleClusteredVersion.Externalizer |
|
SimpleClusteredVersionGenerator |
A version generator implementation for SimpleClusteredVersions
|
SingleFileStore<K,V> |
|
SingleFileStoreConfiguration |
Defines the configuration for the single file cache store.
|
SingleFileStoreConfigurationBuilder |
Single file cache store configuration builder.
|
SingleKeyBackupWriteCommand |
|
SingleKeyFunctionalBackupWriteCommand |
|
SingleKeyNonTxInvocationContext |
Deprecated.
|
SingleResponseCollector |
Response collector for a single response.
|
SingleRpcCommand |
Aggregates a single command for replication.
|
SingleRunOperation<Original,E,R,S extends BaseStream<R,S>,S2 extends S> |
Runs the provided function once only and returns the result.
|
SingleSegmentKeyPartitioner |
KeyPartitioner that always returns 0 for a given segment.
|
SingleSiteRequest<T> |
Request implementation that waits for a response from a single target site.
|
SingleTargetRequest<T> |
Request implementation that waits for a response from a single target node.
|
SingletonCacheWriter |
Deprecated.
|
SingletonCacheWriter.PushStateException |
Exception representing any issues that arise from pushing the in-memory state to the cache loader.
|
SingletonMapResponseCollector |
|
SingletonStoreConfiguration |
Deprecated.
|
SingletonStoreConfigurationBuilder<S> |
Deprecated.
|
SingleXSiteRpcCommand |
RPC command to replicate cache operations (such as put, remove, replace, etc.) to the backup site.
|
SiteConfiguration |
|
SiteConfigurationBuilder |
|
SiteMasterPickerImpl |
A SiteMasterPicker implementation that picks the first route.
|
SitesConfiguration |
|
SitesConfigurationBuilder |
|
SiteStatus |
A site status.
|
SiteStatusListener |
A simple interface that is invoked by OfflineStatus when a particular site changes its
status to online/offline.
|
SizeCalculatorFactory |
Factory for creating size calculator used to estimate size of objects
|
SizeCommand |
Command to calculate the size of the cache
|
SkipDoubleOperation |
|
SkipIntOperation |
|
SkipLongOperation |
|
SkipOperation<S> |
Performs skip operation on a regular Stream
|
SortedComparatorOperation<S> |
Performs sorted operation with a comparator on a regular Stream
|
SortedDoubleOperation |
|
SortedIntOperation |
|
SortedLongOperation |
|
SortedOperation<S> |
Performs sorted operation on a regular Stream
|
SourceMigrator |
Performs migration operations on the source server or cluster of servers
|
StaggeredRequest<T> |
|
Start |
Method level annotation that indicates a (no-param) method to be called on a component registered in the
component registry when the registry starts.
|
State |
|
StateChangingEntry |
Deprecated.
|
StateChunk |
Encapsulates a chunk of cache entries that belong to the same segment.
|
StateChunk.Externalizer |
|
StateConsumer |
Handles inbound state transfers.
|
StateConsumerImpl |
|
StateConsumerImpl.KeyInvalidationListener |
|
StateProvider |
Handles outbound state transfers.
|
StateProviderImpl |
|
StateReceiver<K,V> |
|
StateReceiverImpl<K,V> |
|
StateRequestCommand |
This command is used by a StateConsumer to request transactions and cache entries from a StateProvider.
|
StateRequestCommand.Type |
|
StateResponseCommand |
This command is used by a StateProvider to push cache entries to a StateConsumer.
|
StateTransferComponentFactory |
|
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.
|
StateTransferInterceptor |
This interceptor has two tasks:
If the command's topology id is higher than the current topology id,
wait for the node to receive transaction data for the new topology id.
If the topology id changed during a command's execution, retry the command, but only on the
originator (which replicates it to the new owners).
If the cache is configured with asynchronous replication, owners cannot signal to the originator that they
saw a new topology, so instead each owner forwards the command to all the other owners in the new topology.
|
StateTransferLock |
We use the state transfer lock for three different things:
We don't want to execute a command until we have the transaction table for that topology id.
|
StateTransferLockImpl |
StateTransferLock implementation.
|
StateTransferManager |
A component that manages the state transfer when the topology of the cluster changes.
|
StateTransferManagerImpl |
|
Stats |
Stats.
|
StatsCollectingCache<K,V> |
|
StatsCollector |
|
StatsCollector.Factory |
|
StatsEnvelope<T> |
Responses for functional commands that allow to record statistics.
|
StatsEnvelope.Externalizer |
|
StatsImpl |
StatsImpl.
|
Stop |
Method level annotation that indicates a (no-param) method to be called on a component registered in the
component registry when the registry stops.
|
StorageType |
Enumeration defining the various storage types for the data container.
|
Store |
|
StoreAsBinaryConfiguration |
Deprecated.
|
StoreAsBinaryConfigurationBuilder |
Deprecated.
|
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.
|
StreamIteratorCloseCommand |
Stream iterator command that unregisters an iterator so it doesn't consume memory unnecessarily
|
StreamIteratorNextCommand |
Stream request command that is sent to remote nodes handle execution of remote intermediate and terminal operations.
|
StreamIteratorRequestCommand<K> |
Stream request command that is sent to remote nodes handle execution of remote intermediate and terminal operations.
|
StreamManagerFactory |
|
StreamMarshalling |
Static factory class containing methods that will provide marshallable instances for very common use cases.
|
StreamMarshalling.StreamMarshallingExternalizer |
|
StreamRequestCommand<K> |
Stream request command that is sent to remote nodes handle execution of remote intermediate and terminal operations.
|
StreamRequestCommand.Type |
|
StreamResponseCommand<R> |
Stream response command used to handle returning intermediate or final responses from the remote node
|
Streams |
A collection of stream related utility methods.
|
StripedHashFunction<T> |
An hash function for stripping.
|
StripedLock |
Holder for read write locks that provides ability to retrieve them by offset and hashCode
Note that locks protect entries
|
StripedLock |
A simple implementation of lock striping, using cache entry keys to lock on, primarily used to help make CacheLoader implemtations thread safe.
|
StripedLockContainer |
A lock container used with lock stripping.
|
SubjectACL |
SubjectACL.
|
SuccessfulResponse |
A successful response
|
SuccessfulResponse.Externalizer |
|
SurvivesRestarts |
This annotation is used for components that will be registered in the ComponentRegistry ,
that are meant to be retained in the component registry even after the component registry is stopped.
|
SuspectException |
Thrown when a member is suspected during remote method invocation
|
SyncConfiguration |
Deprecated.
|
SyncConfigurationBuilder |
Deprecated.
|
SyncConsistentHashFactory |
One of the assumptions people made on consistent hashing involves thinking
that given a particular key and same topology, it would produce the same
consistent hash value no matter which cache it was stored in.
|
SyncConsistentHashFactory.Builder |
|
SyncConsistentHashFactory.Externalizer |
|
SynchronizationAdapter |
|
SynchronizedRestarter |
A class that handles restarts of components via multiple threads.
|
SyncInvocationStage |
|
SyncLocalTransaction |
|
SyncReplicatedConsistentHashFactory |
SyncConsistentHashFactory adapted for replicated caches, so that the primary owner of a key
is the same in replicated and distributed caches.
|
SyncReplicatedConsistentHashFactory.Externalizer |
|
TakeOfflineConfiguration |
|
TakeOfflineConfigurationBuilder |
|
TargetMigrator |
Performs migration operations on the target server or cluster of servers
|
TaskContextImpl |
|
TerminalOperation<Original,R> |
Interface describing an operation that is a terminal one that doesn't track keys.
|
TerminalOperationExternalizer |
AdvancedExternalizer that provides functionality required for marshalling all of the various terminal
operations that are used by various distributed streams including the primitive forms.
|
ThreadNameInfo |
|
ThreadPoolConfiguration |
|
ThreadPoolConfigurationBuilder |
|
TimeoutException |
Thrown when a timeout occurred.
|
TopologyAffectedCommand |
Some of the commands sent over the wire can only be honored by the receiver if the topology of the cluster at
delivery time is still 'compatible' with the topology in place at send time (eg.
|
TopologyAwareAddress |
Wraps a TopologyUUID JGroups address
|
TopologyAwareConsistentHashFactory |
Default topology-aware consistent hash factory implementation.
|
TopologyAwareConsistentHashFactory.Externalizer |
|
TopologyAwareSyncConsistentHashFactory |
|
TopologyAwareSyncConsistentHashFactory.Builder |
|
TopologyAwareSyncConsistentHashFactory.Externalizer |
|
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> |
|
TopologyInfo |
This class holds the topology hierarchy of a cache's members.
|
TopologyLevel |
The cluster topology is a tree with five levels: the entire cluster, sites, racks, machines, and
individual nodes.
|
TopologyMode |
It checks or waits until the required topology is installed.
|
TotalOrderCommitCommand |
Commit Command used in the 2nd phase of 2PC.
|
TotalOrderDistributionInterceptor |
This interceptor handles distribution of entries across a cluster, as well as transparent lookup, when the total
order based protocol is enabled
|
TotalOrderInterceptor |
Created to control the total order validation.
|
TotalOrderLatch |
Behaves as a latch between org.infinispan.commands.tx.PrepareCommand delivered in total order to coordinate
conflicting transactions and between org.infinispan.commands.tx.PrepareCommand and state transfer (blocking
the prepare until the state transfer is finished and blocking the state transfer until all the prepared transactions
has finished)
|
TotalOrderLatchImpl |
Implementation of TotalOrderLatch
|
TotalOrderManager |
This class behaves as a synchronization point between incoming transactions (totally ordered) and between incoming
transactions and state transfer.
|
TotalOrderNonVersionedPrepareCommand |
Command corresponding to the 1st phase of 2PC when Total Order based protocol is used.
|
TotalOrderPrepareCommand |
Interface with the utilities methods that the prepare command must have when Total Order based protocol is used
|
TotalOrderRemoteTransactionState |
Represents a state for a Remote Transaction when the Total Order based protocol is used.
|
TotalOrderRollbackCommand |
The 2nd phase command of 2PC, used when a transaction must be aborted.
|
TotalOrderStateTransferInterceptor |
Synchronizes the incoming totally ordered transactions with the state transfer.
|
TotalOrderTxPerCacheInboundInvocationHandler |
|
TotalOrderVersionedCommitCommand |
Command corresponding to the 2nd phase of 2PC.
|
TotalOrderVersionedDistributionInterceptor |
This interceptor is used in total order in distributed mode when the write skew check is enabled.
|
TotalOrderVersionedEntryWrappingInterceptor |
Wrapping Interceptor for Total Order protocol when versions are needed
|
TotalOrderVersionedPrepareCommand |
Command corresponding to the 1st phase of 2PC when Total Order based protocol is used.
|
TraceException |
This exception is used to add stack trace information to exceptions as they move from one thread to another.
|
TransactionalCacheWriter<K,V> |
Defines the functionality of a transactional store.
|
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.
|
TransactionalExceptionEvictionInterceptor |
Interceptor that prevents the cache from inserting too many entries over a configured maximum amount.
|
TransactionalInvocationContextFactory |
Deprecated.
|
TransactionalRemoteLockCommand |
Simple interface to extract all the keys that may need to be locked for transactional commands.
|
TransactionalStoreInterceptor |
An interceptor which ensures that writes to an underlying transactional store are prepared->committed/rolledback as part
of the 2PC, therefore ensuring that the cache and transactional store(s) remain consistent.
|
TransactionBoundaryCommand |
An transaction boundary command that allows the retrieval of an attached
GlobalTransaction
|
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 |
Defines transactional (JTA) characteristics of the cache.
|
TransactionConfigurationBuilder |
Defines transactional (JTA) characteristics of the cache.
|
TransactionConfigurationChildBuilder |
|
TransactionCoordinator |
|
TransactionFactory |
Factory for transaction related sate.
|
TransactionFactory.TxFactoryEnum |
|
TransactionInfo |
A representation of a transaction that is suitable for transferring between a StateProvider and a StateConsumer
running on different members of the same cache.
|
TransactionInfo.Externalizer |
|
TransactionManagerFactory |
Uses a number of mechanisms to retrieve a transaction manager.
|
TransactionManagerLookup |
Deprecated.
|
TransactionMode |
Transaction mode
|
TransactionMode |
Enumeration containing the available transaction modes for a cache.
|
TransactionOriginatorChecker |
An interface to check if the transaction originator is left or not.
|
TransactionProtocol |
Enumerate with the possible commits protocols.
|
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> |
|
TransactionSynchronizationRegistryFactory |
Factory for the TransactionSynchronizationRegistry
|
TransactionSynchronizationRegistryLookup |
|
TransactionSynchronizerInterceptor |
With the Non-Blocking State Transfer (NBST) in place it is possible for a transactional command to be forwarded
multiple times, concurrently to the same node.
|
TransactionTable |
|
TransactionTable |
Interface that allows to fetch the GlobalTransaction associated to local or
remote transactions.
|
TransactionTable.CompletedTransactionStatus |
|
TransactionTableFactory |
|
TransactionXaAdapter |
This acts both as an local CacheTransaction and implementor of an XAResource that will be called by tx manager on various tx stages.
|
TransientCacheEntry |
A cache entry that is transient, i.e., it can be considered expired after a period of not being used.
|
TransientCacheEntry.Externalizer |
|
TransientCacheValue |
|
TransientCacheValue.Externalizer |
|
TransientMortalCacheEntry |
A cache entry that is both transient and mortal.
|
TransientMortalCacheEntry.Externalizer |
|
TransientMortalCacheValue |
|
TransientMortalCacheValue.Externalizer |
|
Transport |
An interface that provides a communication link with remote caches.
|
TransportConfiguration |
|
TransportConfigurationBuilder |
Configures the transport used for network communications across the cluster.
|
TransportFactory |
Factory for Transport implementations
|
Traversable<T> |
Unsorted traversable stream for sequential and aggregating operations.
|
Traversables |
|
TriangleAckExternalizer |
Externalizer for the triangle acknowledges.
|
TriangleDistributionInterceptor |
Non-transactional interceptor used by distributed caches that supports concurrent writes.
|
TriangleFunctionsUtil |
|
TriangleOrderAction |
An Action that checks if the command is the next to be executed.
|
TriangleOrderManager |
It manages the order of updates from the primary owner to backup owner.
|
TrianglePerCacheInboundInvocationHandler |
|
TriConsumer<T,U,V> |
Represents an operation that accepts three input arguments and returns no
result.
|
TwoWayKey2StringMapper |
Extends Key2StringMapper and allows a bidirectional transformation between keys and Strings.
|
TxBatchUpdater |
|
TxClusterExpirationManager<K,V> |
|
TxClusterStreamManager<Original,K> |
This is a delegating cluster stream manager that sends all calls to the underlying cluster stream manager.
|
TxCompletionNotificationCommand |
Command for removing recovery related information from the cluster.
|
TxDistributedCacheStream<Original,R,K,V> |
A distributed cache stream that also utilizes transactional awareness.
|
TxDistributedDoubleCacheStream<Original,K,V> |
Double variant of tx cache stream
|
TxDistributedIntCacheStream<Original,K,V> |
Int variant of tx cache stream
|
TxDistributedLongCacheStream<Original,K,V> |
Long variant of tx cache stream
|
TxDistributionInterceptor |
Handles the distribution of the transactional caches.
|
TxInterceptor<K,V> |
Interceptor in charge with handling transaction related operations, e.g enlisting cache as an transaction
participant, propagating remotely initiated changes.
|
TxInvocationContext<T extends AbstractCacheTransaction> |
Interface defining additional functionality for invocation contexts that propagate within a transaction's scope.
|
TxLockedStreamImpl<K,V> |
Locked Stream that is designed for transactions.
|
TxReadOnlyKeyCommand<K,V,R> |
|
TxReadOnlyManyCommand<K,V,R> |
|
TypedProperties |
Deprecated. |
UnclosableObjectInputStream |
|
UnclosableObjectOutputStream |
|
UndefineConfigurationAction |
UndefineConfigurationAction.
|
Units |
|
UnorderedOperation<Type,Stream extends BaseStream<Type,Stream>> |
|
UnpooledOffHeapMemoryAllocator |
Memory allocator that just allocates memory directly using Unsafe .
|
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.
|
UnsuccessfulResponse |
An unsuccessful response
|
UnsuccessfulResponse.Externalizer |
|
UnsupportedKeyTypeException |
Exception thrown by certain cache stores when one tries to persist an entry with an unsupported key type.
|
UnsureResponse |
An unsure response - used with Dist - essentially asks the caller to check the next response from the next node since
the sender is in a state of flux (probably in the middle of rebalancing)
|
UnsureResponse.Externalizer |
|
UpdateLastAccessCommand |
Command that will update the last access time for an entry given the specific time
|
UserRaisedFunctionalException |
Thrown when client's code passed as a labda expression in commands such as ComputeIfAbsentCommand
raises a exception.
|
UuidExternalizer |
|
ValidResponse |
A valid response
|
ValidResponseCollector<T> |
Base class for response collectors, splitting responses into valid responses, exception responses, and target missing.
|
ValidSingleResponseCollector<T> |
|
ValueCacheCollection<K,V> |
CacheCollection that can be used for the values method of a cache.
|
ValueMatcher |
A policy for determining if a write command should be executed based on the current value in the cache.
|
Version |
Contains version information about this release of Infinispan.
|
Versioned |
An interface that marks the ability to handle versions
|
VersionedCommitCommand |
|
VersionedDistributionInterceptor |
|
VersionedEntryWrappingInterceptor |
Interceptor in charge with wrapping entries and add them in caller's context.
|
VersionedPrepareCommand |
Same as PrepareCommand except that the transaction originator makes evident the versions of entries touched
and stored in a transaction context so that accurate write skew checks may be performed by the lock owner(s).
|
VersionedRepeatableReadEntry |
A version of RepeatableReadEntry that can perform write-skew checks during prepare.
|
VersionedResult |
|
VersionedResult.Externalizer |
|
VersionedResults |
|
VersionedResults.Externalizer |
|
VersionGenerator |
Generates versions
|
VersionGeneratorFactory |
Version generator component factory.
|
VersioningConfiguration |
Deprecated.
|
VersioningConfigurationBuilder |
Deprecated.
|
VersioningScheme |
The various versioning schemes supported
|
VersionInterceptor |
Interceptor installed when compatiblity is enabled.
|
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 .
|
VisitableCommand |
|
VisitableCommand.LoadType |
|
Visitor |
|
VoidResponseCollector |
Response collector that discards successful responses and returns null .
|
VolatileLocalConfigurationStorage |
|
WildflyTransactionManagerLookup |
Wildfly transaction client lookup (WildFly 11 and later).
|
WithinThreadExecutor |
An executor that works within the current thread.
|
WithinThreadExecutorFactory |
Executor factory that creates WithinThreadExecutor.
|
WrappedByteArrayOrPrimitiveMapper |
This class is an implementation for TwoWayKey2StringMapper that supports both primitives
and WrappedByteArray s.
|
WrappedByteArraySizeCalculator<K,V> |
Size calculator that supports a WrappedByteArray by adding its size and the underlying byte[].
|
WritableGridFileChannel |
|
WriteableCacheCollectionMapper<E,R> |
A writeable cache collection mapper that also has constant time operations for things such as
Collection.contains(Object) if the underlying Collection does.
|
WriteableCacheSetMapper<E,R> |
A writeable cache set mapper that also has constant time operations for things such as
Collection.contains(Object) if the underlying Set does.
|
WriteCommand |
A command that modifies the cache in some way
|
WriteOnlyKeyCommand<K,V> |
|
WriteOnlyKeyValueCommand<K,V,T> |
|
WriteOnlyManyCommand<K,V> |
|
WriteOnlyManyEntriesCommand<K,V,T> |
|
WriteOnlyMapImpl<K,V> |
Write-only map implementation.
|
WriteSkewException |
Thrown when a write skew is detected
|
WriteSkewHelper |
Encapsulates write skew logic in maintaining version maps, etc.
|
WriteSkewHelper.KeySpecificLogic |
|
XaTransactionTable |
|
XmlConfigHelper |
A simple XML utility class for reading configuration elements
|
XMLExtendedStreamReader |
An XML stream reader that can read nested <xs:any> content using a registered set of root
elements.
|
XMLExtendedStreamWriter |
|
XMLExtendedStreamWriterImpl |
XMLExtendedStreamWriterImpl.
|
XMLExtendedStreamWriterImpl.ArgRunnable |
|
XSiteAdminCommand |
Command used for handling XSiteReplication administrative operations.
|
XSiteAdminCommand.AdminOperation |
|
XSiteAdminCommand.Status |
|
XSiteAdminOperations |
Managed bean exposing sys admin operations for Cross-Site replication functionality.
|
XSiteBackup |
|
XSiteReplicateCommand |
Abstract class to invoke RPC on the remote site.
|
XSiteState |
Represents the state of a single key to be sent to a backup site.
|
XSiteState.XSiteStateExternalizer |
|
XSiteStateConsumer |
It contains the logic needed to consume the state sent from other site.
|
XSiteStateConsumerImpl |
It contains the logic needed to consume the state sent from other site.
|
XSiteStateProvider |
It contains the logic to send state to another site.
|
XSiteStateProviderImpl |
It contains the logic to send state to another site.
|
XSiteStatePushCommand |
Wraps the state to be sent to another site
|
XSiteStateTransferCollector |
It collects the acknowledgements sent from local site member to signal the ending of the state sent.
|
XSiteStateTransferConfiguration |
Configuration needed for State Transfer between different sites.
|
XSiteStateTransferConfigurationBuilder |
Configuration Builder to configure the state transfer between sites.
|
XSiteStateTransferControlCommand |
Command used to control the state transfer between sites.
|
XSiteStateTransferControlCommand.StateTransferControl |
|
XSiteStateTransferManager |
It manages the state transfer between sites.
|
XSiteStateTransferManagerImpl |
|