Uses of Interface
org.infinispan.container.entries.CacheEntry
Package
Description
This is the core of Infinispan, a distributed, transactional, highly scalable data grid
platform.
Commands that operate on the cache, either locally or remotely.
This package contains the APIs that enable users to search for, and amend, data inconsistencies within their cache.
Entries which are stored in data containers.
Data containers which store cache entries.
Contexts contain information of a specific invocation on the cache, such as its origins, scope
(transactional or non-transactional), as well as invocation-specific flags.
This package contains different context implementations, selected dynamically based on the type of invocation.
Provides capabilities around filtering and converting entries that are found in the cache or cache store/loader.
Metadata interfaces
Embedded Multimap Cache.
Cache
-specific notifications and eventing.Cache stream processing.
XA transaction support.
General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and
collections and containers designed to supplement the JDK-provided containers.
-
Uses of CacheEntry in org.infinispan
Modifier and TypeMethodDescriptionCacheEntry<K,
V> AdvancedCache.getCacheEntry
(Object key) Retrieves a CacheEntry corresponding to a specific key.Modifier and TypeMethodDescriptionCacheSet<CacheEntry<K,
V>> AdvancedCache.cacheEntrySet()
Identical toCache.entrySet()
but is typed to return CacheEntries instead of Entries.Map<K,
CacheEntry<K, V>> AdvancedCache.getAllCacheEntries
(Set<?> keys) Gets a collection of entries from theAdvancedCache
, returning them asMap
of the cache entries associated with the set of keys requested.default CompletableFuture<CacheEntry<K,
V>> AdvancedCache.getCacheEntryAsync
(Object key) Retrieves a CacheEntry corresponding to a specific key.Iterator<CacheEntry<K,
V>> LockedStream.iterator()
This method is not supported when using aLockedStream
AdvancedCache.putAsyncEntry
(K key, V value, Metadata metadata) Extension ofAdvancedCache.putAsync(K, V, Metadata)
which returns aCacheEntry
instead of only the previous value.default CompletionStage<CacheEntry<K,
V>> AdvancedCache.putAsyncReturnEntry
(K key, V value, Metadata metadata) AdvancedCache.putIfAbsentAsyncEntry
(K key, V value, Metadata metadata) An extension form ofAdvancedCache.putIfAbsentAsync(K, V, Metadata)
, which returns aCacheEntry
instead of only the value.default CompletionStage<CacheEntry<K,
V>> AdvancedCache.putIfAbsentAsyncReturnEntry
(K key, V value, Metadata metadata) AdvancedCache.removeAsyncEntry
(Object key) An extension ofAsyncCache.removeAsync(Object)
, which returns aCacheEntry
instead of only the value.default CompletionStage<CacheEntry<K,
V>> AdvancedCache.removeAsyncReturnEntry
(K key) AdvancedCache.replaceAsyncEntry
(K key, V value, Metadata metadata) An extension ofAdvancedCache.replaceAsync(K, V, Metadata)
, which returns aCacheEntry
instead of only the value.default CompletionStage<CacheEntry<K,
V>> AdvancedCache.replaceAsyncReturnEntry
(K key, V value, Metadata metadata) LockedStream.spliterator()
This method is not supported when using aLockedStream
Modifier and TypeMethodDescriptionLockedStream.filter
(Predicate<? super CacheEntry<K, V>> predicate) Returns a locked stream consisting of the elements of this stream that match the given predicate.default LockedStream<K,
V> LockedStream.filter
(SerializablePredicate<? super CacheEntry<K, V>> predicate) Same asLockedStream.filter(Predicate)
except that the Predicate must also implementSerializable
void
LockedStream.forEach
(BiConsumer<Cache<K, V>, ? super CacheEntry<K, V>> biConsumer) Performs an action for each element of this stream on the primary owner of the given key.default void
LockedStream.forEach
(SerializableBiConsumer<Cache<K, V>, ? super CacheEntry<K, V>> biConsumer) Same asLockedStream.forEach(BiConsumer)
except that the BiConsumer must also implementSerializable
LockedStream.invokeAll
(BiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R> biFunction) Performs a BiFunction for each element of this stream on the primary owner of each entry returning a value.LockedStream.invokeAll
(SerializableBiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R> biFunction) Same asLockedStream.invokeAll(BiFunction)
except that the BiFunction must also implementSerializable
-
Uses of CacheEntry in org.infinispan.cache.impl
Modifier and TypeMethodDescriptionCacheEntry<K,
V> AbstractDelegatingAdvancedCache.getCacheEntry
(Object key) final CacheEntry<K,
V> CacheImpl.getCacheEntry
(Object key) CacheEntry<K,
V> DecoratedCache.getCacheEntry
(Object key) CacheEntry<K,
V> EncoderCache.getCacheEntry
(Object key) CacheEntry<K,
V> SimpleCacheImpl.getCacheEntry
(Object k) CacheEntry<K,
V> StatsCollectingCache.getCacheEntry
(Object k) protected CacheEntry<K,
V> CacheBackedEntrySet.wrapElement
(CacheEntry<K, V> e) Modifier and TypeMethodDescriptionCacheSet<CacheEntry<K,
V>> AbstractDelegatingAdvancedCache.cacheEntrySet()
CacheSet<CacheEntry<K,
V>> CacheImpl.cacheEntrySet()
CacheSet<CacheEntry<K,
V>> DecoratedCache.cacheEntrySet()
CacheSet<CacheEntry<K,
V>> EncoderCache.cacheEntrySet()
CacheSet<CacheEntry<K,
V>> SimpleCacheImpl.cacheEntrySet()
Map<K,
CacheEntry<K, V>> AbstractDelegatingAdvancedCache.getAllCacheEntries
(Set<?> keys) Map<K,
CacheEntry<K, V>> CacheImpl.getAllCacheEntries
(Set<?> keys) final Map<K,
CacheEntry<K, V>> CacheImpl.getAllCacheEntries
(Set<?> keys, long explicitFlags, InvocationContext ctx) Map<K,
CacheEntry<K, V>> DecoratedCache.getAllCacheEntries
(Set<?> keys) Map<K,
CacheEntry<K, V>> EncoderCache.getAllCacheEntries
(Set<?> keys) Map<K,
CacheEntry<K, V>> SimpleCacheImpl.getAllCacheEntries
(Set<?> keys) Map<K,
CacheEntry<K, V>> StatsCollectingCache.getAllCacheEntries
(Set<?> keys) AbstractDelegatingAdvancedCache.getCacheEntryAsync
(Object key) CacheImpl.getCacheEntryAsync
(Object key) DecoratedCache.getCacheEntryAsync
(Object key) EncoderCache.getCacheEntryAsync
(Object key) SimpleCacheImpl.getCacheEntryAsync
(Object key) protected Supplier<Stream<CacheEntry<K,
V>>> SimpleCacheImpl.getStreamSupplier
(boolean parallel) SimpleCacheImpl.CacheEntrySet.iterator()
static <K,
V> EncoderEntryMapper<K, V, CacheEntry<K, V>> EncoderEntryMapper.newCacheEntryMapper
(DataConversion keyDataConversion, DataConversion valueDataConversion, InternalEntryFactory entryFactory) SimpleCacheImpl.CacheEntrySet.parallelStream()
AbstractDelegatingAdvancedCache.putAsyncEntry
(K key, V value, Metadata metadata) CacheImpl.putAsyncEntry
(K key, V value, Metadata metadata) DecoratedCache.putAsyncEntry
(K key, V value, Metadata metadata) EncoderCache.putAsyncEntry
(K key, V value, Metadata metadata) SimpleCacheImpl.putAsyncEntry
(K key, V value, Metadata metadata) EncoderCache.putAsyncReturnEntry
(K key, V value, Metadata metadata) AbstractDelegatingAdvancedCache.putIfAbsentAsyncEntry
(K key, V value, Metadata metadata) CacheImpl.putIfAbsentAsyncEntry
(K key, V value, Metadata metadata) DecoratedCache.putIfAbsentAsyncEntry
(K key, V value, Metadata metadata) EncoderCache.putIfAbsentAsyncEntry
(K key, V value, Metadata metadata) SimpleCacheImpl.putIfAbsentAsyncEntry
(K key, V value, Metadata metadata) EncoderCache.putIfAbsentAsyncReturnEntry
(K key, V value, Metadata metadata) AbstractDelegatingAdvancedCache.removeAsyncEntry
(Object key) CacheImpl.removeAsyncEntry
(Object key) DecoratedCache.removeAsyncEntry
(Object key) EncoderCache.removeAsyncEntry
(Object key) SimpleCacheImpl.removeAsyncEntry
(Object key) EncoderCache.removeAsyncReturnEntry
(K key) AbstractDelegatingAdvancedCache.replaceAsyncEntry
(K key, V value, Metadata metadata) CacheImpl.replaceAsyncEntry
(K key, V value, Metadata metadata) DecoratedCache.replaceAsyncEntry
(K key, V value, Metadata metadata) EncoderCache.replaceAsyncEntry
(K key, V value, Metadata metadata) SimpleCacheImpl.replaceAsyncEntry
(K key, V value, Metadata metadata) EncoderCache.replaceAsyncReturnEntry
(K key, V value, Metadata metadata) SimpleCacheImpl.CacheEntrySet.spliterator()
SimpleCacheImpl.CacheEntrySet.stream()
Modifier and TypeMethodDescriptionboolean
SimpleCacheImpl.CacheEntrySet.add
(CacheEntry<K, V> entry) protected CacheEntry<K,
V> CacheBackedEntrySet.wrapElement
(CacheEntry<K, V> e) Modifier and TypeMethodDescriptionboolean
SimpleCacheImpl.CacheEntrySet.addAll
(Collection<? extends CacheEntry<K, V>> c) -
Uses of CacheEntry in org.infinispan.commands
Modifier and TypeMethodDescription<K,
V, R> org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand<K> CommandsFactory.buildEntryReductionPublisherCommand
(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <K,
V, R> org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand<K> CommandsFactoryImpl.buildEntryReductionPublisherCommand
(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) -
Uses of CacheEntry in org.infinispan.conflict
Modifier and TypeMethodDescriptionCacheEntry<K,
V> EntryMergePolicy.merge
(CacheEntry<K, V> preferredEntry, List<CacheEntry<K, V>> otherEntries) This method is called byConflictManager.resolveConflicts()
for each conflict discovered to determine whichCacheEntry
should be utilised.MergePolicy.merge
(CacheEntry preferredEntry, List otherEntries) MergePolicy.UnsupportedMergePolicy.merge
(CacheEntry preferredEntry, List otherEntries) Modifier and TypeMethodDescriptionConflictManager.getConflicts()
Returns a stream of conflicts detected in the cluster.Modifier and TypeMethodDescriptionCacheEntry<K,
V> EntryMergePolicy.merge
(CacheEntry<K, V> preferredEntry, List<CacheEntry<K, V>> otherEntries) This method is called byConflictManager.resolveConflicts()
for each conflict discovered to determine whichCacheEntry
should be utilised.MergePolicy.merge
(CacheEntry preferredEntry, List otherEntries) MergePolicy.UnsupportedMergePolicy.merge
(CacheEntry preferredEntry, List otherEntries) Modifier and TypeMethodDescriptionCacheEntry<K,
V> EntryMergePolicy.merge
(CacheEntry<K, V> preferredEntry, List<CacheEntry<K, V>> otherEntries) This method is called byConflictManager.resolveConflicts()
for each conflict discovered to determine whichCacheEntry
should be utilised. -
Uses of CacheEntry in org.infinispan.container.entries
Modifier and TypeInterfaceDescriptioninterface
InternalCacheEntry<K,
V> Interface for internal cache entries that expose whether an entry has expired.interface
MVCCEntry<K,
V> An entry that can be safely copied when updates are made, to provide MVCC semanticsModifier and TypeClassDescriptionclass
An abstract internal cache entry that is typically stored in the data containerclass
ClearCacheEntry<K,
V> Used inClearInvocationContext
to process theClearCommand
.class
ForwardingCacheEntry<K,
V> A class designed to forward all method invocations for a CacheEntry to the provided delegate.class
A cache entry that is immortal/cannot expireclass
AInternalCacheEntry
implementation to store a L1 entry.class
A cache entry that is mortal.class
NullCacheEntry<K,
V> class
ReadCommittedEntry<K,
V> A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or rolled back.class
RepeatableReadEntry<K,
V> An extension ofReadCommittedEntry
that provides Repeatable Read semanticsclass
A cache entry that is transient, i.e., it can be considered expired after a period of not being used.class
A cache entry that is both transient and mortal.class
A version of RepeatableReadEntry that can perform write-skew checks during prepare.Modifier and TypeMethodDescriptionCacheEntry<K,
V> CacheEntry.clone()
CacheEntry<K,
V> ClearCacheEntry.clone()
CacheEntry<K,
V> ForwardingCacheEntry.clone()
NullCacheEntry.clone()
protected abstract CacheEntry<K,
V> ForwardingCacheEntry.delegate()
-
Uses of CacheEntry in org.infinispan.container.entries.metadata
Modifier and TypeClassDescriptionclass
AInternalCacheEntry
implementation to store a L1 entry.class
A form ofImmortalCacheEntry
that isMetadataAware
class
A cache entry that is mortal and isMetadataAware
class
A cache entry that is transient, i.e., it can be considered expired after a period of not being used, andMetadataAware
class
A form ofTransientMortalCacheEntry
that storesMetadata
-
Uses of CacheEntry in org.infinispan.container.impl
Modifier and TypeMethodDescription<K,
V> CacheEntry<K, V> InternalEntryFactory.copy
(CacheEntry<K, V> cacheEntry) Creates a copy of this cache entry and synchronizes serializes the copy process with theInternalEntryFactory.update(org.infinispan.container.entries.InternalCacheEntry, org.infinispan.metadata.Metadata)
.InternalEntryFactoryImpl.copy
(CacheEntry cacheEntry) Modifier and TypeMethodDescription<K,
V> CacheEntry<K, V> InternalEntryFactory.copy
(CacheEntry<K, V> cacheEntry) Creates a copy of this cache entry and synchronizes serializes the copy process with theInternalEntryFactory.update(org.infinispan.container.entries.InternalCacheEntry, org.infinispan.metadata.Metadata)
.InternalEntryFactoryImpl.copy
(CacheEntry cacheEntry) <K,
V> InternalCacheEntry<K, V> InternalEntryFactory.create
(CacheEntry<K, V> cacheEntry) Creates a newInternalCacheEntry
instance based on the key, value, version and timestamp/lifespan information reflected in theCacheEntry
instance passed in.InternalEntryFactoryImpl.create
(CacheEntry cacheEntry) <V> InternalCacheValue<V>
InternalEntryFactory.createValue
(CacheEntry<?, V> cacheEntry) Creates anInternalCacheValue
based on theInternalCacheEntry
passed in.InternalEntryFactoryImpl.createValue
(CacheEntry cacheEntry) protected MVCCEntry<?,
?> EntryFactoryImpl.createWrappedEntry
(Object key, CacheEntry<?, ?> cacheEntry) void
EntryFactory.wrapExternalEntry
(InvocationContext ctx, Object key, CacheEntry externalEntry, boolean isRead, boolean isWrite) Insert an external entry (e.g.void
EntryFactoryImpl.wrapExternalEntry
(InvocationContext ctx, Object key, CacheEntry externalEntry, boolean isRead, boolean isWrite) -
Uses of CacheEntry in org.infinispan.context
Modifier and TypeMethodDescriptionEntryLookup.lookupEntry
(Object key) Retrieves an entry from the collection of looked up entries in the current scope.Modifier and TypeMethodDescriptionEntryLookup.getLookedUpEntries()
Retrieves a map of entries looked up within the current scope.<K,
V> org.reactivestreams.Publisher<CacheEntry<K, V>> EntryLookup.publisher()
Returns a Publisher that when subscribed to provide all values that have a value in the given context.Modifier and TypeMethodDescriptionvoid
EntryLookup.putLookedUpEntry
(Object key, CacheEntry e) Puts an entry in the registry of looked up entries in the current scope.Modifier and TypeMethodDescriptiondefault void
EntryLookup.forEachEntry
(BiConsumer<Object, CacheEntry> action) Execute an action for each entry in the context.default void
EntryLookup.forEachValue
(BiConsumer<Object, CacheEntry> action) Execute an action for each value in the context. -
Uses of CacheEntry in org.infinispan.context.impl
Modifier and TypeMethodDescriptionSingleKeyNonTxInvocationContext.getCacheEntry()
final CacheEntry
AbstractTxInvocationContext.lookupEntry
(Object key) ClearInvocationContext.lookupEntry
(Object key) ImmutableContext.lookupEntry
(Object key) NonTxInvocationContext.lookupEntry
(Object k) SingleKeyNonTxInvocationContext.lookupEntry
(Object key) Modifier and TypeMethodDescriptionfinal Map<Object,
CacheEntry> AbstractTxInvocationContext.getLookedUpEntries()
ClearInvocationContext.getLookedUpEntries()
ImmutableContext.getLookedUpEntries()
NonTxInvocationContext.getLookedUpEntries()
SingleKeyNonTxInvocationContext.getLookedUpEntries()
<K,
V> org.reactivestreams.Publisher<CacheEntry<K, V>> AbstractInvocationContext.publisher()
<K,
V> org.reactivestreams.Publisher<CacheEntry<K, V>> ImmutableContext.publisher()
<K,
V> org.reactivestreams.Publisher<CacheEntry<K, V>> SingleKeyNonTxInvocationContext.publisher()
Modifier and TypeMethodDescriptionfinal void
AbstractTxInvocationContext.putLookedUpEntry
(Object key, CacheEntry e) void
ClearInvocationContext.putLookedUpEntry
(Object key, CacheEntry e) void
ImmutableContext.putLookedUpEntry
(Object key, CacheEntry e) void
NonTxInvocationContext.putLookedUpEntry
(Object key, CacheEntry e) void
SingleKeyNonTxInvocationContext.putLookedUpEntry
(Object key, CacheEntry e) Modifier and TypeMethodDescriptionvoid
ImmutableContext.forEachEntry
(BiConsumer<Object, CacheEntry> action) void
NonTxInvocationContext.forEachEntry
(BiConsumer<Object, CacheEntry> action) void
SingleKeyNonTxInvocationContext.forEachEntry
(BiConsumer<Object, CacheEntry> action) void
ImmutableContext.forEachValue
(BiConsumer<Object, CacheEntry> action) void
SingleKeyNonTxInvocationContext.forEachValue
(BiConsumer<Object, CacheEntry> action) -
Uses of CacheEntry in org.infinispan.distribution.group.impl
Modifier and TypeMethodDescription<K,
V> Map<K, V> GroupManager.collect
(CacheStream<? extends CacheEntry<K, V>> stream, InvocationContext ctx, String groupName) Collects all entries belonging to a single group.<K,
V> Map<K, V> GroupManagerImpl.collect
(CacheStream<? extends CacheEntry<K, V>> stream, InvocationContext ctx, String groupName) -
Uses of CacheEntry in org.infinispan.filter
Modifier and TypeMethodDescriptionstatic <K,
V, C> Function<CacheEntry<K, V>, CacheEntry<K, C>> CacheFilters.converterToFunction
(KeyValueFilterConverter<? super K, ? super V, C> filterConverter) Creates a newFunction
using the provided filter convert.static <K,
V, C> Function<CacheEntry<K, V>, CacheEntry<K, C>> CacheFilters.converterToFunction
(KeyValueFilterConverter<? super K, ? super V, C> filterConverter) Creates a newFunction
using the provided filter convert.static <K,
V, C> Stream<CacheEntry<K, C>> CacheFilters.filterAndConvert
(Stream<CacheEntry<K, V>> stream, KeyValueFilterConverter<? super K, ? super V, C> filterConverter) Adds needed intermediate operations to the provided stream, returning a possibly new stream as a result of the operations.static <K,
V, C> CacheStream<CacheEntry<K, C>> CacheFilters.filterAndConvert
(CacheStream<CacheEntry<K, V>> stream, KeyValueFilterConverter<? super K, ? super V, C> filterConverter) static <K,
V, C> Function<CacheEntry<K, V>, CacheEntry<K, C>> Creates a newFunction
using the provided converter as a basis for the operation.static <K,
V, C> Function<CacheEntry<K, V>, CacheEntry<K, C>> Creates a newFunction
using the provided converter as a basis for the operation.static <K,
V> Predicate<CacheEntry<K, V>> CacheFilters.notNullCacheEntryPredicate()
Provides a predicate that can be used to filter out null cache entry objects as well as placeholder "null" entries ofNullCacheEntry
that can be returned from methods such asCacheFilters.converterToFunction(KeyValueFilterConverter)
.static <K,
V> Predicate<CacheEntry<K, V>> CacheFilters.predicate
(KeyValueFilter<? super K, ? super V> filter) Creates a newPredicate
using the provided key value filter as a basis for the operation.Modifier and TypeMethodDescriptionstatic <K,
V, C> Stream<CacheEntry<K, C>> CacheFilters.filterAndConvert
(Stream<CacheEntry<K, V>> stream, KeyValueFilterConverter<? super K, ? super V, C> filterConverter) Adds needed intermediate operations to the provided stream, returning a possibly new stream as a result of the operations.static <K,
V, C> CacheStream<CacheEntry<K, C>> CacheFilters.filterAndConvert
(CacheStream<CacheEntry<K, V>> stream, KeyValueFilterConverter<? super K, ? super V, C> filterConverter) static <K,
V, C> CacheStream<K> CacheFilters.filterAndConvertToKey
(CacheStream<CacheEntry<K, V>> stream, KeyValueFilterConverter<? super K, ? super V, C> filterConverter) static <K,
V, C> CacheStream<C> CacheFilters.filterAndConvertToValue
(CacheStream<CacheEntry<K, V>> stream, KeyValueFilterConverter<? super K, ? super V, C> filterConverter) -
Uses of CacheEntry in org.infinispan.functional.impl
Modifier and TypeMethodDescriptionstatic <T> StatsEnvelope<T>
StatsEnvelope.create
(T returnValue, CacheEntry<?, ?> e, boolean exists, boolean isRead) void
FunctionalNotifier.notifyOnCreate
(CacheEntry<K, V> entry) Notify registeredListeners.ReadWriteListeners.ReadWriteListener
instances of the created entry.void
FunctionalNotifierImpl.notifyOnCreate
(CacheEntry entry) void
FunctionalNotifier.notifyOnModify
(CacheEntry<K, V> entry, V previousValue, Metadata previousMetadata) Notify registeredListeners.ReadWriteListeners.ReadWriteListener
instances of the modified entry passing the previous and new value.void
FunctionalNotifierImpl.notifyOnModify
(CacheEntry<K, V> entry, V previousValue, Metadata previousMetadata) void
FunctionalNotifier.notifyOnWrite
(CacheEntry<K, V> entry) void
FunctionalNotifierImpl.notifyOnWrite
(CacheEntry<K, V> entry) static <K,
V> EntryView.ReadEntryView<K, V> EntryViews.readOnly
(CacheEntry entry) static <K,
V> EntryView.ReadEntryView<K, V> EntryViews.readOnly
(CacheEntry<K, V> entry, DataConversion keyDataConversion, DataConversion valueDataConversion) static <K,
V> EntryView.WriteEntryView<K, V> EntryViews.writeOnly
(CacheEntry entry, DataConversion valueDataConversion) -
Uses of CacheEntry in org.infinispan.metadata
Modifier and TypeMethodDescriptionstatic void
Metadatas.updateMetadata
(CacheEntry entry, Metadata providedMetadata) Set theprovidedMetadata
on the cache entry. -
Uses of CacheEntry in org.infinispan.multimap.api.embedded
Modifier and TypeMethodDescriptionRetrieves a CacheEntry corresponding to a specific key in this multimap cache. -
Uses of CacheEntry in org.infinispan.multimap.impl
Modifier and TypeMethodDescription -
Uses of CacheEntry in org.infinispan.notifications.cachelistener
Modifier and TypeMethodDescriptionorg.reactivestreams.Publisher<CacheEntry<K,
V>> QueueingSegmentListener.apply
(SegmentPublisherSupplier.Notification<CacheEntry<K, V>> cacheEntryNotification) This should be invoked on a notification before actually processing the data.Modifier and TypeMethodDescriptionstatic CompletionStage<Void>
NotifyHelper.entryCommitted
(CacheNotifier notifier, FunctionalNotifier functionalNotifier, boolean created, boolean removed, boolean expired, CacheEntry entry, InvocationContext ctx, FlagAffectedCommand command, Object previousValue, Metadata previousMetadata, EvictionManager evictionManager) Modifier and TypeMethodDescriptionorg.reactivestreams.Publisher<CacheEntry<K,
V>> QueueingSegmentListener.apply
(SegmentPublisherSupplier.Notification<CacheEntry<K, V>> cacheEntryNotification) This should be invoked on a notification before actually processing the data. -
Uses of CacheEntry in org.infinispan.reactive.publisher.impl
Modifier and TypeMethodDescription<R> SegmentPublisherSupplier<R>
ClusterPublisherManager.entryPublisher
(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) Performs the given transformer on data in the cache, resulting in multiple values.<R> SegmentPublisherSupplier<R>
ClusterPublisherManagerImpl.entryPublisher
(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) <R> SegmentPublisherSupplier<R>
LocalClusterPublisherManagerImpl.entryPublisher
(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) LocalPublisherManager.entryPublisher
(IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) Performs the given transformer on data in the cache that is local, resulting in a stream of values of possibly varying size.LocalPublisherManagerImpl.entryPublisher
(IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) <R> SegmentPublisherSupplier<R>
PartitionAwareClusterPublisherManager.entryPublisher
(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) <R> CompletionStage<R>
ClusterPublisherManager.entryReduction
(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) Performs the given transformer and finalizer on data in the cache, resulting in a single value.<R> CompletionStage<R>
ClusterPublisherManagerImpl.entryReduction
(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext ctx, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <R> CompletionStage<R>
LocalClusterPublisherManagerImpl.entryReduction
(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <R> CompletionStage<org.infinispan.reactive.publisher.impl.commands.reduction.PublisherResult<R>>
LocalPublisherManager.entryReduction
(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) Performs the given transformer and finalizer on data in the cache that is local, resulting in a single value.<R> CompletionStage<org.infinispan.reactive.publisher.impl.commands.reduction.PublisherResult<R>>
LocalPublisherManagerImpl.entryReduction
(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> collator, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <R> CompletionStage<R>
PartitionAwareClusterPublisherManager.entryReduction
(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext ctx, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) -
Uses of CacheEntry in org.infinispan.rest.stream
ModifierConstructorDescriptionCacheEntryStreamProcessor
(org.reactivestreams.Publisher<CacheEntry<?, ?>> publisher, boolean keysAreJson, boolean valuesAreJson, boolean includeMetadata) -
Uses of CacheEntry in org.infinispan.security.actions
-
Uses of CacheEntry in org.infinispan.security.impl
Modifier and TypeMethodDescriptionCacheSet<CacheEntry<K,
V>> SecureCacheImpl.cacheEntrySet()
Map<K,
CacheEntry<K, V>> SecureCacheImpl.getAllCacheEntries
(Set<?> keys) SecureCacheImpl.getCacheEntryAsync
(Object key) SecureCacheImpl.putAsyncEntry
(K key, V value, Metadata metadata) SecureCacheImpl.putAsyncReturnEntry
(K key, V value, Metadata metadata) SecureCacheImpl.putIfAbsentAsyncEntry
(K key, V value, Metadata metadata) SecureCacheImpl.putIfAbsentAsyncReturnEntry
(K key, V value, Metadata metadata) SecureCacheImpl.removeAsyncEntry
(Object key) SecureCacheImpl.removeAsyncReturnEntry
(K key) SecureCacheImpl.replaceAsyncEntry
(K key, V value, Metadata metadata) SecureCacheImpl.replaceAsyncReturnEntry
(K key, V value, Metadata metadata) -
Uses of CacheEntry in org.infinispan.server.hotrod
Modifier and TypeMethodDescriptionstatic long
MetadataUtils.extractCreated
(CacheEntry ce) static long
MetadataUtils.extractLastUsed
(CacheEntry ce) static int
MetadataUtils.extractLifespan
(CacheEntry ce) static int
MetadataUtils.extractMaxIdle
(CacheEntry ce) static long
MetadataUtils.extractVersion
(CacheEntry ce) io.netty.buffer.ByteBuf
VersionedEncoder.getStreamResponse
(HotRodHeader header, HotRodServer server, io.netty.channel.Channel channel, int offset, CacheEntry<byte[], byte[]> entry) io.netty.buffer.ByteBuf
VersionedEncoder.getWithMetadataResponse
(HotRodHeader header, HotRodServer server, io.netty.channel.Channel channel, CacheEntry<byte[], byte[]> entry) io.netty.buffer.ByteBuf
VersionedEncoder.multimapEntryResponse
(HotRodHeader header, HotRodServer server, io.netty.channel.Channel channel, OperationStatus status, CacheEntry<byte[], Collection<byte[]>> ce) io.netty.buffer.ByteBuf
VersionedEncoder.notExecutedResponse
(HotRodHeader header, HotRodServer server, io.netty.channel.Channel channel, CacheEntry<byte[], byte[]> prev) io.netty.buffer.ByteBuf
VersionedEncoder.successResponse
(HotRodHeader header, HotRodServer server, io.netty.channel.Channel channel, CacheEntry<byte[], byte[]> result) io.netty.buffer.ByteBuf
Encoder4x.valueResponse
(HotRodHeader header, HotRodServer server, io.netty.channel.Channel channel, OperationStatus status, CacheEntry<byte[], byte[]> prev) io.netty.buffer.ByteBuf
VersionedEncoder.valueResponse
(HotRodHeader header, HotRodServer server, io.netty.channel.Channel channel, OperationStatus status, CacheEntry<byte[], byte[]> prev) -
Uses of CacheEntry in org.infinispan.server.hotrod.iteration
-
Uses of CacheEntry in org.infinispan.stream
Modifier and TypeMethodDescriptionstatic <K,
V> Function<K, CacheEntry<K, V>> StreamMarshalling.keyToEntryFunction()
Provides a function that given a key will return theCacheEntry
that maps to this key. -
Uses of CacheEntry in org.infinispan.stream.impl
Modifier and TypeMethodDescriptionIterator<CacheEntry<K,
V>> LockedStreamImpl.iterator()
LockedStreamImpl.spliterator()
Modifier and TypeMethodDescriptionLockedStreamImpl.filter
(Predicate<? super CacheEntry<K, V>> predicate) void
LockedStreamImpl.forEach
(BiConsumer<Cache<K, V>, ? super CacheEntry<K, V>> biConsumer) void
TxLockedStreamImpl.forEach
(BiConsumer<Cache<K, V>, ? super CacheEntry<K, V>> biConsumer) LockedStreamImpl.invokeAll
(BiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R> biFunction) TxLockedStreamImpl.invokeAll
(BiFunction<Cache<K, V>, ? super CacheEntry<K, V>, R> biFunction) ModifierConstructorDescriptionLockedStreamImpl
(CacheStream<CacheEntry<K, V>> realStream, long time, TimeUnit unit) TxLockedStreamImpl
(javax.transaction.TransactionManager tm, CacheStream<CacheEntry<K, V>> realStream, long time, TimeUnit unit) -
Uses of CacheEntry in org.infinispan.transaction.impl
Modifier and TypeFieldDescriptionprotected Map<Object,
CacheEntry> AbstractCacheTransaction.lookedUpEntries
Modifier and TypeMethodDescriptionAbstractCacheTransaction.getLookedUpEntries()
LocalTransaction.getLookedUpEntries()
Modifier and TypeMethodDescriptionstatic void
WriteSkewHelper.addVersionRead
(TxInvocationContext<?> ctx, CacheEntry<?, ?> entry, Object key, VersionGenerator versionGenerator, org.infinispan.util.logging.Log log) static IncrementableEntryVersion
WriteSkewHelper.incrementVersion
(CacheEntry<?, ?> entry, VersionGenerator versionGenerator) void
LocalTransaction.putLookedUpEntry
(Object key, CacheEntry e) void
RemoteTransaction.putLookedUpEntry
(Object key, CacheEntry e) static IncrementableEntryVersion
WriteSkewHelper.versionFromEntry
(CacheEntry<?, ?> entry) Modifier and TypeMethodDescriptionvoid
LocalTransaction.putLookedUpEntries
(Map<Object, CacheEntry> entries) void
RemoteTransaction.putLookedUpEntries
(Map<Object, CacheEntry> entries) -
Uses of CacheEntry in org.infinispan.transaction.xa
Modifier and TypeMethodDescriptionvoid
CacheTransaction.putLookedUpEntry
(Object key, CacheEntry e) Modifier and TypeMethodDescriptionvoid
CacheTransaction.putLookedUpEntries
(Map<Object, CacheEntry> entries) -
Uses of CacheEntry in org.infinispan.util
Modifier and TypeClassDescriptionclass
EntryWrapper<K,
V> Wrapper for CacheEntry(s) that can be used to update the cache when it's value is set.Modifier and TypeMethodDescriptionprotected CacheEntry<K,
V> EntryWrapper.delegate()
CacheEntry<K,
V> DataContainerRemoveIterator.next()
Modifier and TypeMethodDescriptionstatic Optional<IracMetadata>
IracUtils.findIracMetadataFromCacheEntry
(CacheEntry<?, ?> entry) static IracEntryVersion
IracUtils.getIracVersionFromCacheEntry
(CacheEntry<?, ?> entry) static void
IracUtils.setIracMetadata
(CacheEntry<?, ?> entry, int segment, IracMetadata metadata, IracTombstoneManager versionGenerator, LogSupplier logSupplier) Stores theIracMetadata
intoCacheEntry
.static void
IracUtils.setPrivateMetadata
(CacheEntry<?, ?> entry, int segment, PrivateMetadata metadata, IracTombstoneManager versionGenerator, LogSupplier logSupplier) Same asIracUtils.setIracMetadata(CacheEntry, int, IracMetadata, IracTombstoneManager, LogSupplier)
but it stores a "full"PrivateMetadata
instead ofIracMetadata
.ModifierConstructorDescriptionEntryWrapper
(Cache<K, V> cache, CacheEntry<K, V> entry) Creates a new entry wrapper given the cache and entry.