Package | Description |
---|---|
org.infinispan |
This is the core of Infinispan, a distributed, transactional, highly scalable data grid
platform.
|
org.infinispan.atomic.impl | |
org.infinispan.cache.impl | |
org.infinispan.commands |
Commands that operate on the cache, either locally or remotely.
|
org.infinispan.commands.functional | |
org.infinispan.commands.read | |
org.infinispan.commands.write |
Commands that alter the state of the cache.
|
org.infinispan.container |
Data containers which store cache entries.
|
org.infinispan.container.entries |
Entries which are stored in data containers.
|
org.infinispan.container.entries.metadata | |
org.infinispan.context |
Contexts contain information of a specific invocation on the cache, such as its origins, scope
(transactional or non-transactional), as well as invocation-specific flags.
|
org.infinispan.context.impl |
This package contains different context implementations, selected dynamically based on the type of invocation.
|
org.infinispan.filter |
Provides capabilities around filtering and converting entries that are found in the cache or cache store/loader.
|
org.infinispan.functional.impl | |
org.infinispan.interceptors |
Infinispan is designed around a set of interceptors around a data container.
|
org.infinispan.interceptors.compat | |
org.infinispan.interceptors.distribution | |
org.infinispan.interceptors.locking | |
org.infinispan.interceptors.totalorder | |
org.infinispan.iteration |
Provides Infinispan-specific utilities for iterating over entries in the cache, specifically optimized for
distributed caches.
|
org.infinispan.iteration.impl |
Provides Infinispan-specific implementation details iterating over entries in the cache, specifically optimized for
distributed caches.
|
org.infinispan.metadata |
Metadata interfaces
|
org.infinispan.notifications.cachelistener |
Cache -specific notifications and eventing. |
org.infinispan.persistence.util | |
org.infinispan.security.actions | |
org.infinispan.security.impl | |
org.infinispan.statetransfer |
Transfer of state to new caches in a cluster.
|
org.infinispan.stream.impl | |
org.infinispan.stream.impl.interceptor | |
org.infinispan.stream.impl.local | |
org.infinispan.stream.impl.termop | |
org.infinispan.stream.impl.termop.object | |
org.infinispan.stream.impl.termop.primitive | |
org.infinispan.stream.impl.tx | |
org.infinispan.transaction.impl | |
org.infinispan.transaction.xa |
XA transaction support.
|
org.infinispan.util |
General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and
collections and containers designed to supplement the JDK-provided containers.
|
Modifier and Type | Method and Description |
---|---|
CacheEntry<K,V> |
AdvancedCache.getCacheEntry(Object key)
Retrieves a CacheEntry corresponding to a specific key.
|
Modifier and Type | Method and Description |
---|---|
CacheSet<CacheEntry<K,V>> |
AdvancedCache.cacheEntrySet()
Identical to
Cache.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 the
AdvancedCache , returning them as
Map of the cache entries associated with the set of keys requested. |
Modifier and Type | Method and Description |
---|---|
protected CacheEntry |
AtomicHashMapProxy.lookupEntryFromCurrentTransaction()
Looks up the CacheEntry stored in transactional context corresponding to this AtomicMap.
|
Modifier and Type | Method and Description |
---|---|
CacheEntry<K,V> |
AbstractDelegatingAdvancedCache.getCacheEntry(Object key) |
CacheEntry<K,V> |
SimpleCacheImpl.getCacheEntry(Object k) |
CacheEntry<K,V> |
StatsCollectingCache.getCacheEntry(Object k) |
CacheEntry |
CacheImpl.getCacheEntry(Object key) |
CacheEntry |
DecoratedCache.getCacheEntry(Object key) |
CacheEntry |
CacheImpl.getCacheEntry(Object key,
EnumSet<Flag> explicitFlags,
ClassLoader explicitClassLoader) |
CacheEntry<K,V> |
SimpleCacheImpl.FilteringIterator.next() |
CacheEntry<K,C> |
SimpleCacheImpl.ConvertingIterator.next() |
Modifier and Type | Method and Description |
---|---|
CacheSet<CacheEntry<K,V>> |
AbstractDelegatingAdvancedCache.cacheEntrySet() |
CacheSet<CacheEntry<K,V>> |
SimpleCacheImpl.cacheEntrySet() |
CacheSet<CacheEntry<K,V>> |
CacheImpl.cacheEntrySet() |
CacheSet<CacheEntry<K,V>> |
DecoratedCache.cacheEntrySet() |
<C> CloseableIterable<CacheEntry<K,C>> |
SimpleCacheImpl.FilteredEntryIterable.converter(Converter<? super K,? super V,C> converter) |
Map<K,CacheEntry<K,V>> |
AbstractDelegatingAdvancedCache.getAllCacheEntries(Set<?> keys) |
Map<K,CacheEntry<K,V>> |
SimpleCacheImpl.getAllCacheEntries(Set<?> keys) |
Map<K,CacheEntry<K,V>> |
StatsCollectingCache.getAllCacheEntries(Set<?> keys) |
Map<K,CacheEntry<K,V>> |
CacheImpl.getAllCacheEntries(Set<?> keys) |
Map<K,CacheEntry<K,V>> |
CacheImpl.getAllCacheEntries(Set<?> keys,
EnumSet<Flag> explicitFlags,
ClassLoader explicitClassLoader) |
protected Supplier<Stream<CacheEntry<K,V>>> |
SimpleCacheImpl.getStreamSupplier(boolean parallel) |
CloseableIterator<CacheEntry<K,V>> |
SimpleCacheImpl.CacheEntrySet.iterator() |
CloseableIterator<CacheEntry<K,V>> |
SimpleCacheImpl.FilteredEntryIterable.iterator() |
CloseableIterator<CacheEntry<K,C>> |
SimpleCacheImpl.ConvertedIterable.iterator() |
CacheStream<CacheEntry<K,V>> |
SimpleCacheImpl.CacheEntrySet.parallelStream() |
CloseableSpliterator<CacheEntry<K,V>> |
SimpleCacheImpl.CacheEntrySet.spliterator() |
CacheStream<CacheEntry<K,V>> |
SimpleCacheImpl.CacheEntrySet.stream() |
Modifier and Type | Method and Description |
---|---|
boolean |
SimpleCacheImpl.CacheEntrySet.add(CacheEntry<K,V> entry) |
Modifier and Type | Method and Description |
---|---|
boolean |
SimpleCacheImpl.CacheEntrySet.addAll(Collection<? extends CacheEntry<K,V>> c) |
Constructor and Description |
---|
ConvertedIterable(Iterator<CacheEntry<K,V>> iterator,
Converter<? super K,? super V,? extends C> converter) |
Modifier and Type | Method and Description |
---|---|
<K,C> EntryResponseCommand<K,C> |
CommandsFactory.buildEntryResponseCommand(UUID identifier,
Set<Integer> completedSegments,
Set<Integer> inDoubtSegments,
Collection<CacheEntry<K,C>> values,
CacheException e)
Builds
EntryResponseCommand use to respond with retrieved entries for
given segments |
<K,C> EntryResponseCommand<K,C> |
CommandsFactoryImpl.buildEntryResponseCommand(UUID identifier,
Set<Integer> completedSegments,
Set<Integer> inDoubtSegments,
Collection<CacheEntry<K,C>> values,
CacheException e) |
Modifier and Type | Method and Description |
---|---|
Object |
ReadOnlyKeyCommand.perform(CacheEntry<K,V> entry) |
Modifier and Type | Method and Description |
---|---|
Set<CacheEntry<K,V>> |
EntrySetCommand.perform(InvocationContext ctx) |
Modifier and Type | Method and Description |
---|---|
protected Object |
RemoveCommand.performRemove(CacheEntry e,
InvocationContext ctx) |
Modifier and Type | Method and Description |
---|---|
CacheEntry |
InternalEntryFactoryImpl.copy(CacheEntry cacheEntry) |
<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 the
InternalEntryFactory.update(org.infinispan.container.entries.InternalCacheEntry, org.infinispan.metadata.Metadata) . |
CacheEntry |
EntryFactory.wrapEntryForDelta(InvocationContext ctx,
Object deltaKey,
Delta delta)
Used for wrapping Delta entry to be applied to DeltaAware object stored in cache.
|
CacheEntry |
EntryFactoryImpl.wrapEntryForDelta(InvocationContext ctx,
Object deltaKey,
Delta delta) |
CacheEntry |
EntryFactory.wrapEntryForReading(InvocationContext ctx,
Object key,
CacheEntry existing)
Wraps an entry for reading.
|
CacheEntry |
EntryFactoryImpl.wrapEntryForReading(InvocationContext ctx,
Object key,
CacheEntry existing) |
Modifier and Type | Method and Description |
---|---|
CacheEntry |
InternalEntryFactoryImpl.copy(CacheEntry cacheEntry) |
<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 the
InternalEntryFactory.update(org.infinispan.container.entries.InternalCacheEntry, org.infinispan.metadata.Metadata) . |
InternalCacheEntry |
InternalEntryFactoryImpl.create(CacheEntry cacheEntry) |
<K,V> InternalCacheEntry<K,V> |
InternalEntryFactory.create(CacheEntry<K,V> cacheEntry)
Creates a new
InternalCacheEntry instance based on the key, value, version and timestamp/lifespan
information reflected in the CacheEntry instance passed in. |
InternalCacheValue |
InternalEntryFactoryImpl.createValue(CacheEntry cacheEntry) |
<V> InternalCacheValue<V> |
InternalEntryFactory.createValue(CacheEntry<?,V> cacheEntry)
Creates an
InternalCacheValue based on the InternalCacheEntry passed in. |
protected MVCCEntry |
IncrementalVersionableEntryFactoryImpl.createWrappedEntry(Object key,
CacheEntry cacheEntry,
InvocationContext context,
boolean skipRead) |
protected MVCCEntry |
EntryFactoryImpl.createWrappedEntry(Object key,
CacheEntry cacheEntry,
InvocationContext context,
boolean skipRead) |
CacheEntry |
EntryFactory.wrapEntryForReading(InvocationContext ctx,
Object key,
CacheEntry existing)
Wraps an entry for reading.
|
CacheEntry |
EntryFactoryImpl.wrapEntryForReading(InvocationContext ctx,
Object key,
CacheEntry existing) |
boolean |
IncrementalVersionableEntryFactoryImpl.wrapExternalEntry(InvocationContext ctx,
Object key,
CacheEntry externalEntry,
EntryFactory.Wrap wrap,
boolean skipRead) |
boolean |
EntryFactory.wrapExternalEntry(InvocationContext ctx,
Object key,
CacheEntry externalEntry,
EntryFactory.Wrap wrap,
boolean skipRead)
Insert an external entry (e.g.
|
boolean |
EntryFactoryImpl.wrapExternalEntry(InvocationContext ctx,
Object key,
CacheEntry externalEntry,
EntryFactory.Wrap wrap,
boolean skipRead) |
Modifier and Type | Interface and Description |
---|---|
interface |
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 semantics
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractInternalCacheEntry
An abstract internal cache entry that is typically stored in the data container
|
class |
ClearCacheEntry<K,V>
Used in
ClearInvocationContext to process the ClearCommand . |
class |
ClusteredRepeatableReadEntry
A version of RepeatableReadEntry that can perform write-skew checks during prepare.
|
class |
DeltaAwareCacheEntry<K>
A wrapper around a cached entry that encapsulates DeltaAware and Delta semantics when writes are
initiated, committed or rolled back.
|
class |
ForwardingCacheEntry<K,V>
A class designed to forward all method invocations for a CacheEntry to the provided delegate.
|
class |
ImmortalCacheEntry
A cache entry that is immortal/cannot expire
|
class |
L1InternalCacheEntry
A
InternalCacheEntry implementation to store a L1 entry. |
class |
MortalCacheEntry
A cache entry that is mortal.
|
class |
NullCacheEntry<K,V> |
class |
ReadCommittedEntry
A wrapper around a cached entry that encapsulates read committed semantics when writes are initiated, committed or
rolled back.
|
class |
RepeatableReadEntry
An extension of
ReadCommittedEntry that provides Repeatable Read semantics |
class |
TransientCacheEntry
A cache entry that is transient, i.e., it can be considered expired after a period of not being used.
|
class |
TransientMortalCacheEntry
A cache entry that is both transient and mortal.
|
Modifier and Type | Field and Description |
---|---|
protected CacheEntry<K,DeltaAware> |
DeltaAwareCacheEntry.wrappedEntry |
Modifier and Type | Method and Description |
---|---|
CacheEntry<K,V> |
ClearCacheEntry.clone() |
CacheEntry<K,V> |
CacheEntry.clone() |
CacheEntry |
NullCacheEntry.clone() |
CacheEntry<K,V> |
ForwardingCacheEntry.clone() |
protected abstract CacheEntry<K,V> |
ForwardingCacheEntry.delegate() |
Constructor and Description |
---|
DeltaAwareCacheEntry(K key,
DeltaAware value,
CacheEntry<K,DeltaAware> wrappedEntry) |
Modifier and Type | Class and Description |
---|---|
class |
L1MetadataInternalCacheEntry
A
InternalCacheEntry implementation to store a L1 entry. |
class |
MetadataImmortalCacheEntry
A form of
ImmortalCacheEntry that
is MetadataAware |
class |
MetadataMortalCacheEntry
A cache entry that is mortal and is
MetadataAware |
class |
MetadataTransientCacheEntry
A cache entry that is transient, i.e., it can be considered expired after
a period of not being used, and
MetadataAware |
class |
MetadataTransientMortalCacheEntry
A form of
TransientMortalCacheEntry
that is Versioned |
Modifier and Type | Method and Description |
---|---|
CacheEntry |
SingleKeyNonTxInvocationContext.getCacheEntry() |
CacheEntry |
SingleKeyNonTxInvocationContext.lookupEntry(Object key) |
CacheEntry |
EntryLookup.lookupEntry(Object key)
Retrieves an entry from the collection of looked up entries in the current scope.
|
Modifier and Type | Method and Description |
---|---|
Map<Object,CacheEntry> |
SingleKeyNonTxInvocationContext.getLookedUpEntries() |
Map<Object,CacheEntry> |
EntryLookup.getLookedUpEntries()
Retrieves a map of entries looked up within the current scope.
|
Modifier and Type | Method and Description |
---|---|
void |
SingleKeyNonTxInvocationContext.putLookedUpEntry(Object key,
CacheEntry e) |
void |
EntryLookup.putLookedUpEntry(Object key,
CacheEntry e)
Puts an entry in the registry of looked up entries in the current scope.
|
Modifier and Type | Method and Description |
---|---|
CacheEntry |
ImmutableContext.lookupEntry(Object key) |
CacheEntry |
ClearInvocationContext.lookupEntry(Object key) |
CacheEntry |
NonTxInvocationContext.lookupEntry(Object k) |
CacheEntry |
AbstractTxInvocationContext.lookupEntry(Object key) |
Modifier and Type | Method and Description |
---|---|
Map<Object,CacheEntry> |
ImmutableContext.getLookedUpEntries() |
Map<Object,CacheEntry> |
ClearInvocationContext.getLookedUpEntries() |
Map<Object,CacheEntry> |
NonTxInvocationContext.getLookedUpEntries() |
Map<Object,CacheEntry> |
AbstractTxInvocationContext.getLookedUpEntries() |
Modifier and Type | Method and Description |
---|---|
void |
ImmutableContext.putLookedUpEntry(Object key,
CacheEntry e) |
void |
ClearInvocationContext.putLookedUpEntry(Object key,
CacheEntry e) |
void |
NonTxInvocationContext.putLookedUpEntry(Object key,
CacheEntry e) |
void |
AbstractTxInvocationContext.putLookedUpEntry(Object key,
CacheEntry e) |
Modifier and Type | Method and Description |
---|---|
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> Function<CacheEntry<K,V>,CacheEntry<K,C>> |
CacheFilters.function(Converter<? super K,? super V,C> converter)
Creates a new
Function using the provided converter as a basis for the operation. |
static <K,V,C> Function<CacheEntry<K,V>,CacheEntry<K,C>> |
CacheFilters.function(Converter<? super K,? super V,C> converter)
Creates a new
Function using the provided converter as a basis for the operation. |
static <K,V> Predicate<CacheEntry<K,V>> |
CacheFilters.predicate(KeyValueFilter<? super K,? super V> filter)
Creates a new
Predicate using the provided key value filter as a basis for the operation. |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
static <K,V> EntryView.ReadEntryView<K,V> |
EntryViews.readOnly(CacheEntry<K,V> entry) |
static <K,V> EntryView.ReadWriteEntryView<K,V> |
EntryViews.readWrite(CacheEntry<K,V> entry) |
static <K,V> EntryView.ReadWriteEntryView<K,V> |
EntryViews.readWrite(CacheEntry<K,V> entry,
V prevValue,
Metadata prevMetadata) |
static <K,V> EntryView.WriteEntryView<V> |
EntryViews.writeOnly(CacheEntry<K,V> entry) |
Modifier and Type | Method and Description |
---|---|
CacheSet<CacheEntry<K,V>> |
CacheLoaderInterceptor.visitEntrySetCommand(InvocationContext ctx,
EntrySetCommand command)
Deprecated.
|
CacheSet<CacheEntry<K,V>> |
TxInterceptor.visitEntrySetCommand(InvocationContext ctx,
EntrySetCommand command)
Deprecated.
|
CacheSet<CacheEntry<K,V>> |
MarshalledValueInterceptor.visitEntrySetCommand(InvocationContext ctx,
EntrySetCommand command)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected void |
EntryWrappingInterceptor.commitContextEntry(CacheEntry entry,
InvocationContext ctx,
FlagAffectedCommand command,
Metadata metadata,
Flag stateTransferFlag,
boolean l1Invalidation)
Deprecated.
|
protected void |
VersionedEntryWrappingInterceptor.commitContextEntry(CacheEntry entry,
InvocationContext ctx,
FlagAffectedCommand command,
Metadata metadata,
Flag stateTransferFlag,
boolean l1Invalidation)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
CacheSet<CacheEntry<K,V>> |
BaseTypeConverterInterceptor.visitEntrySetCommand(InvocationContext ctx,
EntrySetCommand command)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected CacheSet<CacheEntry<K,V>> |
DistributionBulkInterceptor.BackingEntrySet.entrySet |
protected CacheSet<CacheEntry<K,V>> |
DistributionBulkInterceptor.BackingKeySet.entrySet |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<CacheEntry<K,V>> |
DistributionBulkInterceptor.BackingEntrySet.iterator() |
CacheStream<CacheEntry<K,V>> |
DistributionBulkInterceptor.BackingEntrySet.parallelStream() |
CacheStream<CacheEntry<K,V>> |
DistributionBulkInterceptor.TxBackingEntrySet.parallelStream() |
CloseableSpliterator<CacheEntry<K,V>> |
DistributionBulkInterceptor.BackingEntrySet.spliterator() |
CacheStream<CacheEntry<K,V>> |
DistributionBulkInterceptor.BackingEntrySet.stream() |
CacheStream<CacheEntry<K,V>> |
DistributionBulkInterceptor.TxBackingEntrySet.stream() |
CacheSet<CacheEntry<K,V>> |
DistributionBulkInterceptor.visitEntrySetCommand(InvocationContext ctx,
EntrySetCommand command)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
BaseDistributionInterceptor.valueIsMissing(CacheEntry entry)
Deprecated.
|
Constructor and Description |
---|
BackingKeySet(Cache<K,V> cache,
CacheSet<CacheEntry<K,V>> entrySet,
LocalFlagAffectedCommand command) |
Modifier and Type | Method and Description |
---|---|
void |
ClusteringDependentLogic.commitEntry(CacheEntry entry,
Metadata metadata,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
void |
ClusteringDependentLogic.AbstractClusteringDependentLogic.commitEntry(CacheEntry entry,
Metadata metadata,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected abstract void |
ClusteringDependentLogic.AbstractClusteringDependentLogic.commitSingleEntry(CacheEntry entry,
Metadata metadata,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected void |
ClusteringDependentLogic.LocalLogic.commitSingleEntry(CacheEntry entry,
Metadata metadata,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected void |
ClusteringDependentLogic.InvalidationLogic.commitSingleEntry(CacheEntry entry,
Metadata metadata,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected void |
ClusteringDependentLogic.ReplicationLogic.commitSingleEntry(CacheEntry entry,
Metadata metadata,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected void |
ClusteringDependentLogic.DistributionLogic.commitSingleEntry(CacheEntry entry,
Metadata metadata,
FlagAffectedCommand command,
InvocationContext ctx,
Flag trackFlag,
boolean l1Invalidation) |
protected void |
ClusteringDependentLogic.AbstractClusteringDependentLogic.notifyCommitEntry(boolean created,
boolean removed,
boolean expired,
CacheEntry entry,
InvocationContext ctx,
FlagAffectedCommand command,
Object previousValue,
Metadata previousMetadata) |
Modifier and Type | Method and Description |
---|---|
protected void |
TotalOrderVersionedEntryWrappingInterceptor.commitContextEntry(CacheEntry entry,
InvocationContext ctx,
FlagAffectedCommand command,
Metadata metadata,
Flag stateTransferFlag,
boolean l1Invalidation)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
<C> CloseableIterable<CacheEntry<K,C>> |
EntryIterable.converter(Converter<? super K,? super V,C> converter)
This returns a
CloseableIterable that will change the type of the returned
value for the entry using the already provided filter in addition to the converter. |
Modifier and Type | Field and Description |
---|---|
protected CacheEntry<K,C> |
RemovableEntryIterator.currentValue |
protected CacheEntry<K,C> |
RemovableEntryIterator.previousValue |
Modifier and Type | Field and Description |
---|---|
protected CloseableIterable<CacheEntry<K,C>> |
TransactionAwareCloseableIterable.iterable |
protected CloseableIterator<CacheEntry<K,V>> |
RemovableEntryIterator.realIterator |
Modifier and Type | Method and Description |
---|---|
protected CacheEntry<K,V> |
TransactionAwareCloseableIterator.filterEntry(CacheEntry<K,V> entry) |
protected CacheEntry<K,C> |
RemovableEntryIterator.getNextFromIterator() |
protected CacheEntry<K,C> |
TransactionAwareCloseableIterator.getNextFromIterator() |
CacheEntry<K,C> |
RemovableEntryIterator.next() |
CacheEntry<K,C> |
LocalEntryRetriever.DataContainerIterator.next() |
CacheEntry<K,C> |
LocalEntryRetriever.Itr.next() |
CacheEntry<K,C> |
DistributedEntryRetriever.DistributedItr.next() |
Modifier and Type | Method and Description |
---|---|
<C> CloseableIterable<CacheEntry<K,C>> |
TransactionAwareEntryIterable.converter(Converter<? super K,? super V,C> converter) |
<C> CloseableIterable<CacheEntry<K,C>> |
EntryIterableFromStreamImpl.converter(Converter<? super K,? super V,C> converter) |
CloseableIterator<CacheEntry<K,C>> |
TransactionAwareCloseableIterable.iterator() |
CloseableIterator<CacheEntry<K,C>> |
TrackingEntryIterableFromStream.iterator() |
<C> CloseableIterator<CacheEntry<K,C>> |
EntryRetriever.retrieveEntries(KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,? extends C> converter,
Set<Flag> flags,
EntryRetriever.SegmentListener listener)
Deprecated.
This is invoked locally on the node that requested the iteration process.
|
<C> CloseableIterator<CacheEntry<K,C>> |
LocalEntryRetriever.retrieveEntries(KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,? extends C> converter,
Set<Flag> flags,
EntryRetriever.SegmentListener listener) |
<C> CloseableIterator<CacheEntry<K,C>> |
DistributedEntryRetriever.retrieveEntries(KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,? extends C> converter,
Set<Flag> flags,
EntryRetriever.SegmentListener listener) |
Modifier and Type | Method and Description |
---|---|
protected CacheEntry<K,V> |
TransactionAwareCloseableIterator.filterEntry(CacheEntry<K,V> entry) |
Modifier and Type | Method and Description |
---|---|
void |
LocalEntryRetriever.Itr.addEntries(Collection<CacheEntry<K,C>> entries) |
void |
LocalEntryRetriever.BatchHandler.handleBatch(boolean complete,
Collection<CacheEntry<K,C>> entries) |
void |
LocalEntryRetriever.ItrQueuerHandler.handleBatch(boolean complete,
Collection<CacheEntry<K,C>> entries) |
<C> void |
EntryRetriever.receiveResponse(UUID identifier,
Address origin,
Set<Integer> completedSegments,
Set<Integer> inDoubtSegments,
Collection<CacheEntry<K,C>> entries,
CacheException e)
Deprecated.
This method is invoked on the local node who started the iteration process for each batch of values.
|
<C> void |
LocalEntryRetriever.receiveResponse(UUID identifier,
Address origin,
Set<Integer> completedSegments,
Set<Integer> inDoubtSegments,
Collection<CacheEntry<K,C>> entries,
CacheException e) |
<C> void |
DistributedEntryRetriever.receiveResponse(UUID identifier,
Address origin,
Set<Integer> completedSegments,
Set<Integer> inDoubtSegments,
Collection<CacheEntry<K,C>> entries,
CacheException e) |
Constructor and Description |
---|
EntryResponseCommand(Address origin,
String cacheName,
UUID identifier,
Set<Integer> completedSegments,
Set<Integer> inDoubtSegments,
Collection<CacheEntry<K,C>> values,
CacheException e) |
RemovableEntryIterator(CloseableIterator<CacheEntry<K,V>> realIterator,
Cache<K,V> cache,
boolean initIterator) |
TransactionAwareCloseableIterable(CloseableIterable<CacheEntry<K,C>> iterable,
KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,? extends C> converter,
TxInvocationContext<LocalTransaction> ctx,
Cache<K,?> cache) |
TransactionAwareCloseableIterator(CloseableIterator<CacheEntry<K,V>> realIterator,
KeyValueFilter<? super K,? super V> filter,
Converter<? super K,? super V,? extends C> converter,
TxInvocationContext<LocalTransaction> ctx,
Cache<K,V> cache) |
Modifier and Type | Method and Description |
---|---|
static void |
Metadatas.updateMetadata(CacheEntry entry,
Metadata providedMetadata)
Set the
providedMetadata on the cache entry. |
Modifier and Type | Method and Description |
---|---|
Set<CacheEntry<K,V>> |
QueueingSegmentListener.findCreatedEntries()
This method is to be called just before marking the transfer as complete and after all keys have been manually
processed.
|
Modifier and Type | Method and Description |
---|---|
CacheEntry<K,V> |
PersistenceManagerCloseableSupplier.get() |
Modifier and Type | Method and Description |
---|---|
CacheEntry<K,V> |
GetCacheEntryAction.run() |
Modifier and Type | Method and Description |
---|---|
CacheEntry |
SecureCacheImpl.getCacheEntry(Object key) |
Modifier and Type | Method and Description |
---|---|
CacheSet<CacheEntry<K,V>> |
SecureCacheImpl.cacheEntrySet() |
Map<K,CacheEntry<K,V>> |
SecureCacheImpl.getAllCacheEntries(Set<?> keys) |
Modifier and Type | Method and Description |
---|---|
void |
CommitManager.commit(CacheEntry entry,
Metadata metadata,
Flag operation,
boolean l1Invalidation)
It tries to commit the cache entry.
|
Modifier and Type | Field and Description |
---|---|
protected Supplier<CacheStream<CacheEntry>> |
AbstractCacheStream.supplier |
Modifier and Type | Method and Description |
---|---|
Collection<CacheEntry<K,R2>> |
KeyTrackingTerminalOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,R2>>> response)
Invoked when a key and rehash aware operation is desired.
|
protected Supplier<Stream<CacheEntry>> |
AbstractCacheStream.supplierForSegments(ConsistentHash ch,
Set<Integer> targetSegments,
Set<Object> excludedKeys) |
protected Supplier<Stream<CacheEntry>> |
AbstractCacheStream.supplierForSegments(ConsistentHash ch,
Set<Integer> targetSegments,
Set<Object> excludedKeys,
boolean usePrimary)
If
usePrimary is true the segments are the primary segments but only those that exist in
targetSegments. |
protected static Supplier<CacheStream<CacheEntry>> |
DistributedCacheStream.supplierStreamCast(Supplier supplier) |
Modifier and Type | Method and Description |
---|---|
Collection<CacheEntry<K,R2>> |
KeyTrackingTerminalOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,R2>>> response)
Invoked when a key and rehash aware operation is desired.
|
Constructor and Description |
---|
AbstractCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry>> supplier,
ClusterStreamManager<Object> csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry) |
DistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
ClusterStreamManager csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry)
Standard constructor requiring all pertinent information to properly utilize a distributed cache stream
|
DistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
ClusterStreamManager csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super CacheEntry<K,V>,R> function)
Constructor that also allows a simple map method to be inserted first to change to another type.
|
DistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
ClusterStreamManager csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super CacheEntry<K,V>,R> function)
Constructor that also allows a simple map method to be inserted first to change to another type.
|
Modifier and Type | Method and Description |
---|---|
protected CacheSet<CacheEntry<K,V>> |
AbstractDelegatingEntryCacheSet.delegate() |
protected CacheStream<CacheEntry<K,V>> |
AbstractDelegatingEntryCacheSet.getStream(boolean parallel) |
CacheStream<CacheEntry<K,V>> |
AbstractDelegatingEntryCacheSet.parallelStream() |
CacheStream<CacheEntry<K,V>> |
AbstractDelegatingEntryCacheSet.stream() |
Constructor and Description |
---|
AbstractDelegatingEntryCacheSet(Cache<K,V> cache,
CacheSet<CacheEntry<K,V>> set) |
Modifier and Type | Method and Description |
---|---|
Stream<CacheEntry<K,V>> |
EntryStreamSupplier.buildStream(Set<Integer> segmentsToFilter,
Set<?> keysToFilter) |
CloseableIterator<CacheEntry<K,V>> |
EntryStreamSupplier.removableIterator(CloseableIterator<CacheEntry<K,V>> realIterator) |
Modifier and Type | Method and Description |
---|---|
CloseableIterator<CacheEntry<K,V>> |
EntryStreamSupplier.removableIterator(CloseableIterator<CacheEntry<K,V>> realIterator) |
Constructor and Description |
---|
EntryStreamSupplier(Cache<K,V> cache,
ConsistentHash hash,
Supplier<Stream<CacheEntry<K,V>>> supplier) |
ValueCacheCollection(Cache<K,V> cache,
CacheSet<CacheEntry<K,V>> cacheSet) |
Modifier and Type | Method and Description |
---|---|
Collection<CacheEntry<K,K>> |
AbstractForEachOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,K>>> response) |
Modifier and Type | Method and Description |
---|---|
Collection<CacheEntry<K,K>> |
AbstractForEachOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,K>>> response) |
Constructor and Description |
---|
AbstractForEachOperation(Iterable<IntermediateOperation> intermediateOperations,
Supplier<Stream<CacheEntry>> supplier,
int batchSize) |
Modifier and Type | Method and Description |
---|---|
Collection<CacheEntry<K,Collection<V>>> |
FlatMapIteratorOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,Collection<V>>>> response) |
Collection<CacheEntry<K,V>> |
NoMapIteratorOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,V>>> response) |
Collection<CacheEntry<K,V2>> |
MapIteratorOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,V2>>> response) |
Modifier and Type | Method and Description |
---|---|
Collection<CacheEntry<K,Collection<V>>> |
FlatMapIteratorOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,Collection<V>>>> response) |
Collection<CacheEntry<K,V>> |
NoMapIteratorOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,V>>> response) |
Collection<CacheEntry<K,V2>> |
MapIteratorOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,V2>>> response) |
Constructor and Description |
---|
FlatMapIteratorOperation(Iterable<IntermediateOperation> intermediateOperations,
Supplier<Stream<CacheEntry>> supplier,
int batchSize) |
ForEachOperation(Iterable<IntermediateOperation> intermediateOperations,
Supplier<Stream<CacheEntry>> supplier,
int batchSize,
Consumer<? super V> consumer) |
MapIteratorOperation(Iterable<IntermediateOperation> intermediateOperations,
Supplier<Stream<CacheEntry>> supplier,
int batchSize) |
NoMapIteratorOperation(Iterable<IntermediateOperation> intermediateOperations,
Supplier<Stream<CacheEntry>> supplier,
int batchSize) |
Modifier and Type | Method and Description |
---|---|
Collection<CacheEntry<K,K>> |
ForEachIntOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,K>>> response) |
Collection<CacheEntry<K,K>> |
ForEachLongOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,K>>> response) |
Collection<CacheEntry<K,K>> |
ForEachDoubleOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,K>>> response) |
Modifier and Type | Method and Description |
---|---|
Collection<CacheEntry<K,K>> |
ForEachIntOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,K>>> response) |
Collection<CacheEntry<K,K>> |
ForEachLongOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,K>>> response) |
Collection<CacheEntry<K,K>> |
ForEachDoubleOperation.performOperationRehashAware(KeyTrackingTerminalOperation.IntermediateCollector<Collection<CacheEntry<K,K>>> response) |
Modifier and Type | Method and Description |
---|---|
protected Supplier<Stream<CacheEntry>> |
TxDistributedLongCacheStream.supplierForSegments(ConsistentHash ch,
Set<Integer> targetSegments,
Set<Object> excludedKeys,
boolean primaryOnly) |
protected Supplier<Stream<CacheEntry>> |
TxDistributedCacheStream.supplierForSegments(ConsistentHash ch,
Set<Integer> targetSegments,
Set<Object> excludedKeys,
boolean primaryOnly) |
protected Supplier<Stream<CacheEntry>> |
TxDistributedIntCacheStream.supplierForSegments(ConsistentHash ch,
Set<Integer> targetSegments,
Set<Object> excludedKeys,
boolean primaryOnly) |
protected Supplier<Stream<CacheEntry>> |
TxDistributedDoubleCacheStream.supplierForSegments(ConsistentHash ch,
Set<Integer> targetSegments,
Set<Object> excludedKeys,
boolean primaryOnly) |
Constructor and Description |
---|
TxDistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
TxClusterStreamManager<?> csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super CacheEntry<K,V>,R> function,
LocalTxInvocationContext ctx) |
TxDistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
TxClusterStreamManager<?> csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
Function<? super CacheEntry<K,V>,R> function,
LocalTxInvocationContext ctx) |
TxDistributedCacheStream(Address localAddress,
boolean parallel,
DistributionManager dm,
Supplier<CacheStream<CacheEntry<K,V>>> supplier,
TxClusterStreamManager<?> csm,
boolean includeLoader,
int distributedBatchSize,
Executor executor,
ComponentRegistry registry,
LocalTxInvocationContext ctx) |
Modifier and Type | Field and Description |
---|---|
protected Map<Object,CacheEntry> |
AbstractCacheTransaction.lookedUpEntries |
Modifier and Type | Method and Description |
---|---|
CacheEntry |
AbstractCacheTransaction.lookupEntry(Object key) |
Modifier and Type | Method and Description |
---|---|
Map<Object,CacheEntry> |
AbstractCacheTransaction.getLookedUpEntries() |
Map<Object,CacheEntry> |
LocalTransaction.getLookedUpEntries() |
Modifier and Type | Method and Description |
---|---|
void |
RemoteTransaction.putLookedUpEntry(Object key,
CacheEntry e) |
void |
LocalTransaction.putLookedUpEntry(Object key,
CacheEntry e) |
Modifier and Type | Method and Description |
---|---|
void |
RemoteTransaction.putLookedUpEntries(Map<Object,CacheEntry> entries) |
void |
LocalTransaction.putLookedUpEntries(Map<Object,CacheEntry> entries) |
Modifier and Type | Method and Description |
---|---|
CacheEntry |
CacheTransaction.lookupEntry(Object key) |
Modifier and Type | Method and Description |
---|---|
Map<Object,CacheEntry> |
CacheTransaction.getLookedUpEntries() |
Modifier and Type | Method and Description |
---|---|
void |
CacheTransaction.putLookedUpEntry(Object key,
CacheEntry e) |
Modifier and Type | Method and Description |
---|---|
void |
CacheTransaction.putLookedUpEntries(Map<Object,CacheEntry> entries) |
Modifier and Type | Method and Description |
---|---|
CacheEntry<K,V> |
DataContainerRemoveIterator.next() |
Copyright © 2022 JBoss, a division of Red Hat. All rights reserved.