Interface Cache<K,V>
-
- All Superinterfaces:
AsyncCache<K,V>
,BasicCache<K,V>
,BatchingCache
,ConcurrentMap<K,V>
,FilteringListenable<K,V>
,Lifecycle
,Listenable
,Map<K,V>
- All Known Subinterfaces:
AdvancedCache<K,V>
,SecureCache<K,V>
public interface Cache<K,V> extends BasicCache<K,V>, BatchingCache, FilteringListenable<K,V>
The central interface of Infinispan. A Cache provides a highly concurrent, optionally distributed data structure with additional features such as:- JTA transaction compatibility
- Eviction support for evicting entries from memory to prevent
OutOfMemoryError
s - Persisting entries to a
CacheLoader
, either when they are evicted as an overflow, or all the time, to maintain persistent copies that would withstand server failure or restarts.
ConcurrentMap
and implements all methods accordingly. Methods likekeySet()
,values()
andentrySet()
produce backing collections in that updates done to them also update the original Cache instance. Certain methods on these maps can be expensive however (prohibitively so when using a distributed cache). Thesize()
andMap.containsValue(Object)
methods upon invocation can also be expensive just as well. The reason these methods are expensive are that they take into account entries stored in a configuredCacheLoader
and remote entries when using a distributed cache. Frequent use of these methods is not recommended if used in this manner. These aforementioned methods do take into account in-flight transactions, however key/value pairs read in using an iterator will not be placed into the transactional context to preventOutOfMemoryError
s. Please note all of these methods behavior can be controlled using aFlag
to disable certain things such as taking into account the loader. Please see each method on this interface for more details. Also, like manyConcurrentMap
implementations, Cache does not support the use of null keys or values.Asynchronous operations
Cache also supports the use of "async" remote operations. Note that these methods only really make sense if you are using a clustered cache. I.e., when used in LOCAL mode, these "async" operations offer no benefit whatsoever. These methods, such asAsyncCache.putAsync(Object, Object)
offer the best of both worlds between a fully synchronous and a fully asynchronous cache in that aCompletableFuture
is returned. The CompletableFuture can then be ignored or thrown away for typical asynchronous behaviour, or queried for synchronous behaviour, which would block until any remote calls complete. Note that all remote calls are, as far as the transport is concerned, synchronous. This allows you the guarantees that remote calls succeed, while not blocking your application thread unnecessarily. For example, usage such as the following could benefit from the async operations:CompletableFuture f1 = cache.putAsync("key1", "value1"); CompletableFuture f2 = cache.putAsync("key2", "value2"); CompletableFuture f3 = cache.putAsync("key3", "value3"); f1.get(); f2.get(); f3.get();
The net result is behavior similar to synchronous RPC calls in that at the end, you have guarantees that all calls completed successfully, but you have the added benefit that the three calls could happen in parallel. This is especially advantageous if the cache uses distribution and the three keys map to different cache instances in the cluster. Also, the use of async operations when within a transaction return your local value only, as expected. A CompletableFuture is still returned though for API consistency.Constructing a Cache
An instance of the Cache is usually obtained by using aCacheContainer
.CacheManager cm = new DefaultCacheManager(); // optionally pass in a default configuration Cache c = cm.getCache();
See theCacheContainer
interface for more details on providing specific configurations, using multiple caches in the same JVM, etc. Please see the Infinispan documentation and/or the 5 Minute Usage Tutorial for more details.- Since:
- 4.0
- Author:
- Mircea.Markus@jboss.com, Manik Surtani, Galder ZamarreƱo
- See Also:
CacheContainer
,DefaultCacheManager
, Infinispan documentation, 5 Minute Usage Tutorial
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Modifier and Type Method Description void
clear()
Removes all mappings from the cache.V
compute(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)
default V
compute(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction)
Overloadedcompute(Object, BiFunction)
with InfinispanSerializableBiFunction
.default V
compute(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedBasicCache.compute(Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
.default V
compute(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedBasicCache.compute(Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
.default CompletableFuture<V>
computeAsync(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction)
OverloadedAsyncCache.computeAsync(Object, BiFunction)
with InfinispanSerializableBiFunction
.default CompletableFuture<V>
computeAsync(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedAsyncCache.computeAsync(Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
.default CompletableFuture<V>
computeAsync(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedAsyncCache.computeAsync(Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
.V
computeIfAbsent(K key, Function<? super K,? extends V> mappingFunction)
default V
computeIfAbsent(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction)
OverloadedcomputeIfAbsent(Object, Function)
with InfinispanSerializableFunction
.default V
computeIfAbsent(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedBasicCache.computeIfAbsent(Object, Function, long, TimeUnit)
with InfinispanSerializableFunction
.default V
computeIfAbsent(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedBasicCache.computeIfAbsent(Object, Function, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableFunction
.default CompletableFuture<V>
computeIfAbsentAsync(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction)
OverloadedAsyncCache.computeIfAbsentAsync(Object, Function)
with InfinispanSerializableFunction
.default CompletableFuture<V>
computeIfAbsentAsync(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedAsyncCache.computeIfAbsentAsync(Object, Function, long, TimeUnit)
with InfinispanSerializableFunction
.default CompletableFuture<V>
computeIfAbsentAsync(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedAsyncCache.computeIfAbsentAsync(Object, Function, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableFunction
.V
computeIfPresent(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)
default V
computeIfPresent(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction)
OverloadedcomputeIfPresent(Object, BiFunction)
with InfinispanSerializableBiFunction
The compiler will pick this overload for lambda parameters, making themSerializable
default CompletableFuture<V>
computeIfPresentAsync(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction)
OverloadedAsyncCache.computeIfPresentAsync(Object, BiFunction)
with InfinispanSerializableBiFunction
The compiler will pick this overload for lambda parameters, making themSerializable
CacheSet<Map.Entry<K,V>>
entrySet()
Returns a set view of the mappings contained in this cache and cache loader across the entire cluster.void
evict(K key)
Evicts an entry from the memory of the cache.AdvancedCache<K,V>
getAdvancedCache()
Configuration
getCacheConfiguration()
EmbeddedCacheManager
getCacheManager()
Retrieves the cache manager responsible for creating this cache instance.ComponentStatus
getStatus()
CacheSet<K>
keySet()
Returns a set view of the keys contained in this cache and cache loader across the entire cluster.V
merge(K key, V value, BiFunction<? super V,? super V,? extends V> remappingFunction)
default V
merge(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction)
Overloadedmerge(Object, Object, BiFunction)
with InfinispanSerializableBiFunction
.default V
merge(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedBasicCache.merge(Object, Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
.default V
merge(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedBasicCache.merge(Object, Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
.default CompletableFuture<V>
mergeAsync(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction)
OverloadedAsyncCache.mergeAsync(Object, Object, BiFunction)
with InfinispanSerializableBiFunction
.default CompletableFuture<V>
mergeAsync(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedAsyncCache.mergeAsync(Object, Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
.default CompletableFuture<V>
mergeAsync(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedAsyncCache.mergeAsync(Object, Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
.void
putForExternalRead(K key, V value)
Under special operating behavior, associates the value with the specified key.void
putForExternalRead(K key, V value, long lifespan, TimeUnit unit)
An overloaded form of#putForExternalRead(K, V)
, which takes in lifespan parameters.void
putForExternalRead(K key, V value, long lifespan, TimeUnit lifespanUnit, long maxIdle, TimeUnit maxIdleUnit)
An overloaded form of#putForExternalRead(K, V)
, which takes in lifespan parameters.default void
shutdown()
Performs a controlled, clustered shutdown of the cache.int
size()
Returns a count of all elements in this cache and cache loader across the entire cluster.void
stop()
Stops a cache.CacheCollection<V>
values()
Returns a collection view of the values contained in this cache across the entire cluster.-
Methods inherited from interface org.infinispan.commons.api.AsyncCache
clearAsync, computeAsync, computeAsync, computeAsync, computeIfAbsentAsync, computeIfAbsentAsync, computeIfAbsentAsync, computeIfPresentAsync, computeIfPresentAsync, computeIfPresentAsync, containsKeyAsync, getAllAsync, getAsync, mergeAsync, mergeAsync, mergeAsync, putAllAsync, putAllAsync, putAllAsync, putAsync, putAsync, putAsync, putIfAbsentAsync, putIfAbsentAsync, putIfAbsentAsync, removeAsync, removeAsync, replaceAsync, replaceAsync, replaceAsync, replaceAsync, replaceAsync, replaceAsync, sizeAsync
-
Methods inherited from interface org.infinispan.commons.api.BasicCache
compute, compute, computeIfAbsent, computeIfAbsent, computeIfPresent, computeIfPresent, getName, getVersion, merge, merge, put, put, put, putAll, putAll, putIfAbsent, putIfAbsent, remove, replace, replace, replace, replace
-
Methods inherited from interface org.infinispan.commons.api.BatchingCache
endBatch, startBatch
-
Methods inherited from interface org.infinispan.notifications.FilteringListenable
addFilteredListener, addFilteredListenerAsync, addListener, addListenerAsync, addStorageFormatFilteredListener, addStorageFormatFilteredListenerAsync
-
Methods inherited from interface org.infinispan.notifications.Listenable
addListener, addListenerAsync, getListeners, removeListener, removeListenerAsync
-
-
-
-
Method Detail
-
putForExternalRead
void putForExternalRead(K key, V value)
Under special operating behavior, associates the value with the specified key.- Only goes through if the
key specified does not exist; no-op otherwise (similar to
ConcurrentMap.putIfAbsent(Object, Object)
) - Force asynchronous mode for replication to prevent any blocking.
- invalidation does not take place.
- 0ms lock timeout to prevent any blocking here either. If the lock is not acquired, this method is a no-op, and swallows the timeout exception.
- Ongoing transactions are suspended before this call, so failures here will not affect any ongoing transactions.
- Errors and exceptions are 'silent' - logged at a much lower level than normal, and this method does not throw exceptions
- Parameters:
key
- key with which the specified value is to be associated.value
- value to be associated with the specified key.- Throws:
IllegalStateException
- ifgetStatus()
would not returnComponentStatus.RUNNING
.
- Only goes through if the
key specified does not exist; no-op otherwise (similar to
-
putForExternalRead
void putForExternalRead(K key, V value, long lifespan, TimeUnit unit)
An overloaded form of#putForExternalRead(K, V)
, which takes in lifespan parameters.- Parameters:
key
- key to usevalue
- value to storelifespan
- lifespan of the entry. Negative values are interpreted as unlimited lifespan.unit
- unit of measurement for the lifespan- Since:
- 7.0
-
putForExternalRead
void putForExternalRead(K key, V value, long lifespan, TimeUnit lifespanUnit, long maxIdle, TimeUnit maxIdleUnit)
An overloaded form of#putForExternalRead(K, V)
, which takes in lifespan parameters.- Parameters:
key
- key to usevalue
- value to storelifespan
- lifespan of the entry. Negative values are interpreted as unlimited lifespan.lifespanUnit
- time unit for lifespanmaxIdle
- the maximum amount of time this key is allowed to be idle for before it is considered as expiredmaxIdleUnit
- time unit for max idle time- Since:
- 7.0
-
evict
void evict(K key)
Evicts an entry from the memory of the cache. Note that the entry is not removed from any configured cache stores or any other caches in the cluster (if used in a clustered mode). UseBasicCache.remove(Object)
to remove an entry from the entire cache system. This method is designed to evict an entry from memory to free up memory used by the application. This method uses a 0 lock acquisition timeout so it does not block in attempting to acquire locks. It behaves as a no-op if the lock on the entry cannot be acquired immediately. Important: this method should not be called from within a transaction scope.- Parameters:
key
- key to evict
-
getCacheConfiguration
Configuration getCacheConfiguration()
-
getCacheManager
EmbeddedCacheManager getCacheManager()
Retrieves the cache manager responsible for creating this cache instance.- Returns:
- a cache manager
-
getAdvancedCache
AdvancedCache<K,V> getAdvancedCache()
-
getStatus
ComponentStatus getStatus()
-
size
int size()
Returns a count of all elements in this cache and cache loader across the entire cluster. Only a subset of entries is held in memory at a time when using a loader or remote entries, to prevent possible memory issues, however the loading of said entries can still be vary slow. If there are performance concerns then theFlag.SKIP_CACHE_LOAD
flag should be used to avoid hitting the cache loader in case if this is not needed in the size calculation. Also if you want the local contents only you can use theFlag.CACHE_MODE_LOCAL
flag so that other remote nodes are not queried for data. However the loader will still be used unless the previously mentionedFlag.SKIP_CACHE_LOAD
is also configured. If this method is used in a transactional context, note this method will not bring additional values into the transaction context and thus objects that haven't yet been read will act in aIsolationLevel.READ_COMMITTED
behavior irrespective of the configured isolation level. However values that have been previously modified or read that are in the context will be adhered to. e.g. any write modification or any previous read when usingIsolationLevel.REPEATABLE_READ
This method should only be used for debugging purposes such as to verify that the cache contains all the keys entered. Any other use involving execution of this method on a production system is not recommended.- Returns:
- the number of key-value mappings in this cache and cache loader across the entire cluster.
-
keySet
CacheSet<K> keySet()
Returns a set view of the keys contained in this cache and cache loader across the entire cluster. Modifications and changes to the cache will be reflected in the set and vice versa. When this method is called nothing is actually queried as the backing set is just returned. Invocation on the set itself is when the various operations are ran.Unsupported Operations
Care should be taken when invokingSet.toArray()
,Set.toArray(Object[])
,Set.size()
,Set.retainAll(Collection)
andSet.iterator()
methods as they will traverse the entire contents of the cluster including a configuredCacheLoader
and remote entries. The former 2 methods especially have a very high likely hood of causing aOutOfMemoryError
due to storing all the keys in the entire cluster in the array. Use involving execution of this method on a production system is not recommended as they can be quite expensive operationsSupported Flags
Note any flag configured for the cache will also be passed along to the backing set when it was created. If additional flags are configured on the cache they will not affect any existing backings sets. If there are performance concerns then theFlag.SKIP_CACHE_LOAD
flag should be used to avoid hitting the cache store as this will cause all entries there to be read in (albeit in a batched form to preventOutOfMemoryError
) Also if you want the local contents only you can use theFlag.CACHE_MODE_LOCAL
flag so that other remote nodes are not queried for data. However the loader will still be used unless the previously mentionedFlag.SKIP_CACHE_LOAD
is also configured.Iterator Use
This class implements theCloseableIteratorSet
interface which creates aCloseableIterator
instead of a regular one. This means this iterator must be explicitly closed either through try with resource or calling the close method directly. Technically this iterator will also close itself if you iterate fully over it, but it is safest to always make sure you close it explicitly.Unsupported Operations
Due to not being able to add null values the following methods are not supported and will throwUnsupportedOperationException
if invoked.Set.add(Object)
Set.addAll(java.util.Collection)
- Returns:
- a set view of the keys contained in this cache and cache loader across the entire cluster.
-
values
CacheCollection<V> values()
Returns a collection view of the values contained in this cache across the entire cluster. Modifications and changes to the cache will be reflected in the set and vice versa. When this method is called nothing is actually queried as the backing collection is just returned. Invocation on the collection itself is when the various operations are ran. Care should be taken when invokingCollection.toArray()
,Collection.toArray(Object[])
,Collection.size()
,Collection.retainAll(Collection)
andCollection.iterator()
methods as they will traverse the entire contents of the cluster including a configuredCacheLoader
and remote entries. The former 2 methods especially have a very high likely hood of causing aOutOfMemoryError
due to storing all the keys in the entire cluster in the array. Use involving execution of this method on a production system is not recommended as they can be quite expensive operations *Supported Flags
Note any flag configured for the cache will also be passed along to the backing set when it was created. If additional flags are configured on the cache they will not affect any existing backings sets. If there are performance concerns then theFlag.SKIP_CACHE_LOAD
flag should be used to avoid hitting the cache store as this will cause all entries there to be read in (albeit in a batched form to preventOutOfMemoryError
) Also if you want the local contents only you can use theFlag.CACHE_MODE_LOCAL
flag so that other remote nodes are not queried for data. However the loader will still be used unless the previously mentionedFlag.SKIP_CACHE_LOAD
is also configured.Iterator Use
This class implements the
CloseableIteratorCollection
interface which creates aCloseableIterator
instead of a regular one. This means this iterator must be explicitly closed either through try with resource or calling the close method directly. Technically this iterator will also close itself if you iterate fully over it, but it is safest to always make sure you close it explicitly.The iterator retrieved using
CloseableIteratorCollection.iterator()
supports the remove method, however the iterator retrieved fromCacheStream.iterator()
will not support remove.Unsupported Operations
Due to not being able to add null values the following methods are not supported and will throwUnsupportedOperationException
if invoked.Set.add(Object)
Set.addAll(java.util.Collection)
- Returns:
- a collection view of the values contained in this cache and cache loader across the entire cluster.
-
entrySet
CacheSet<Map.Entry<K,V>> entrySet()
Returns a set view of the mappings contained in this cache and cache loader across the entire cluster. Modifications and changes to the cache will be reflected in the set and vice versa. When this method is called nothing is actually queried as the backing set is just returned. Invocation on the set itself is when the various operations are ran. Care should be taken when invokingSet.toArray()
,Set.toArray(Object[])
,Set.size()
,Set.retainAll(Collection)
andSet.iterator()
methods as they will traverse the entire contents of the cluster including a configuredCacheLoader
and remote entries. The former 2 methods especially have a very high likely hood of causing aOutOfMemoryError
due to storing all the keys in the entire cluster in the array. Use involving execution of this method on a production system is not recommended as they can be quite expensive operations *Supported Flags
Note any flag configured for the cache will also be passed along to the backing set when it was created. If additional flags are configured on the cache they will not affect any existing backings sets. If there are performance concerns then theFlag.SKIP_CACHE_LOAD
flag should be used to avoid hitting the cache store as this will cause all entries there to be read in (albeit in a batched form to preventOutOfMemoryError
) Also if you want the local contents only you can use theFlag.CACHE_MODE_LOCAL
flag so that other remote nodes are not queried for data. However the loader will still be used unless the previously mentionedFlag.SKIP_CACHE_LOAD
is also configured.Modifying or Adding Entries
An entry's value is supported to be modified by using theMap.Entry.setValue(Object)
and it will update the cache as well. Also this backing set does allow addition of a new Map.Entry(s) via theSet.add(Object)
orSet.addAll(java.util.Collection)
methods.Iterator Use
This class implements theCloseableIteratorSet
interface which creates aCloseableIterator
instead of a regular one. This means this iterator must be explicitly closed either through try with resource or calling the close method directly. Technically this iterator will also close itself if you iterate fully over it, but it is safest to always make sure you close it explicitly.- Returns:
- a set view of the mappings contained in this cache and cache loader across the entire cluster.
-
clear
void clear()
Removes all mappings from the cache. Note: This should never be invoked in production unless you can guarantee no other invocations are ran concurrently. If the cache is transactional, it will not interact with the transaction.
-
stop
void stop()
Stops a cache. If the cache is clustered, this only stops the cache on the node where it is being invoked. If you need to stop the cache across a cluster, use theshutdown()
method.
-
shutdown
default void shutdown()
Performs a controlled, clustered shutdown of the cache. When invoked, the following operations are performed:- rebalancing for the cache is disabled
- in-memory data is flushed/passivated to any persistent stores
- state is persisted to the location defined in
GlobalStateConfigurationBuilder.persistentLocation(String)
stop()
only in clustered modes, and only whenGlobalStateConfiguration.enabled()
is true, otherwise it just behaves likestop()
.
-
computeIfAbsent
V computeIfAbsent(K key, Function<? super K,? extends V> mappingFunction)
When this method is used on a clustered cache, either replicated or distributed, the function will be serialized to owning nodes to perform the operation in the most performant way. However this means the function must have an appropriate
Externalizer
or beSerializable
itself.For transactional caches, whenever the values of the caches are collections, and the mapping function modifies the collection, the collection must be copied and not directly modified, otherwise whenever rollback is called it won't work. This limitation could disappear in following releases if technically possible.
-
computeIfAbsent
default V computeIfAbsent(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction)
OverloadedcomputeIfAbsent(Object, Function)
with InfinispanSerializableFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedmappingFunction
- , mapping function to be appliyed to the key- Returns:
- computed value or null if nothing is computed or computation value is null
-
computeIfAbsent
default V computeIfAbsent(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedBasicCache.computeIfAbsent(Object, Function, long, TimeUnit)
with InfinispanSerializableFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedmappingFunction
- , mapping function to be appliyed to the key- Returns:
- computed value or null if nothing is computed or computation value is null
-
computeIfAbsent
default V computeIfAbsent(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedBasicCache.computeIfAbsent(Object, Function, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedmappingFunction
- , mapping function to be appliyed to the key- Returns:
- computed value or null if nothing is computed or computation value is null
-
computeIfAbsentAsync
default CompletableFuture<V> computeIfAbsentAsync(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction)
OverloadedAsyncCache.computeIfAbsentAsync(Object, Function)
with InfinispanSerializableFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedmappingFunction
- , mapping function to be appliyed to the key- Returns:
- computed value or null if nothing is computed or computation value is null
-
computeIfAbsentAsync
default CompletableFuture<V> computeIfAbsentAsync(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedAsyncCache.computeIfAbsentAsync(Object, Function, long, TimeUnit)
with InfinispanSerializableFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedmappingFunction
- , mapping function to be appliyed to the key- Returns:
- computed value or null if nothing is computed or computation value is null
-
computeIfAbsentAsync
default CompletableFuture<V> computeIfAbsentAsync(K key, org.infinispan.util.function.SerializableFunction<? super K,? extends V> mappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedAsyncCache.computeIfAbsentAsync(Object, Function, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedmappingFunction
- , mapping function to be appliyed to the key- Returns:
- computed value or null if nothing is computed or computation value is null
-
computeIfPresent
V computeIfPresent(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)
When this method is used on a clustered cache, either replicated or distributed, the bifunction will be serialized to owning nodes to perform the operation in the most performant way. However this means the bifunction must have an appropriate
Externalizer
or beSerializable
itself.For transactional caches, whenever the values of the caches are collections, and the mapping function modifies the collection, the collection must be copied and not directly modified, otherwise whenever rollback is called it won't work. This limitation could disappear in following releases if technically possible.
-
computeIfPresent
default V computeIfPresent(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction)
OverloadedcomputeIfPresent(Object, BiFunction)
with InfinispanSerializableBiFunction
The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedremappingFunction
- , mapping function to be appliyed to the key- Returns:
- computed value or null if nothing is computed or computation result is null
-
computeIfPresentAsync
default CompletableFuture<V> computeIfPresentAsync(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction)
OverloadedAsyncCache.computeIfPresentAsync(Object, BiFunction)
with InfinispanSerializableBiFunction
The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedremappingFunction
- , mapping function to be appliyed to the key- Returns:
- computed value or null if nothing is computed or computation result is null
-
compute
V compute(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)
When this method is used on a clustered cache, either replicated or distributed, the bifunction will be serialized to owning nodes to perform the operation in the most performant way. However this means the bifunction must have an appropriate
Externalizer
or beSerializable
itself.For transactional caches, whenever the values of the caches are collections, and the mapping function modifies the collection, the collection must be copied and not directly modified, otherwise whenever rollback is called it won't work. This limitation could disappear in following releases if technically possible.
-
compute
default V compute(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction)
Overloadedcompute(Object, BiFunction)
with InfinispanSerializableBiFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedremappingFunction
- , mapping function to be appliyed to the key- Returns:
- computation result (can be null)
-
compute
default V compute(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedBasicCache.compute(Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedremappingFunction
- , mapping function to be appliyed to the key- Returns:
- computation result (can be null)
-
compute
default V compute(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedBasicCache.compute(Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedremappingFunction
- , mapping function to be appliyed to the key- Returns:
- computation result (can be null)
-
computeAsync
default CompletableFuture<V> computeAsync(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction)
OverloadedAsyncCache.computeAsync(Object, BiFunction)
with InfinispanSerializableBiFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedremappingFunction
- , mapping function to be appliyed to the key- Returns:
- computation result (can be null)
-
computeAsync
default CompletableFuture<V> computeAsync(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedAsyncCache.computeAsync(Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedremappingFunction
- , mapping function to be appliyed to the key- Returns:
- computation result (can be null)
-
computeAsync
default CompletableFuture<V> computeAsync(K key, org.infinispan.util.function.SerializableBiFunction<? super K,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedAsyncCache.computeAsync(Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
. The compiler will pick this overload for lambda parameters, making themSerializable
- Parameters:
key
- , the key to be computedremappingFunction
- , mapping function to be appliyed to the key- Returns:
- computation result (can be null)
-
merge
V merge(K key, V value, BiFunction<? super V,? super V,? extends V> remappingFunction)
When this method is used on a clustered cache, either replicated or distributed, the bifunction will be serialized to owning nodes to perform the operation in the most performant way. However this means the bifunction must have an appropriate
Externalizer
or beSerializable
itself.For transactional caches, whenever the values of the caches are collections, and the mapping function modifies the collection, the collection must be copied and not directly modified, otherwise whenever rollback is called it won't work. This limitation could disappear in following releases if technically possible.
-
merge
default V merge(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction)
Overloadedmerge(Object, Object, BiFunction)
with InfinispanSerializableBiFunction
.The compiler will pick this overload for lambda parameters, making them
Serializable
.- Parameters:
key
- key with which the resulting value is to be associatedvalue
- the non-null value to be merged with the existing value associated with the key or, if no existing value or a null value is associated with the key, to be associated with the keyremappingFunction
- the function to recompute a value if present
-
merge
default V merge(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedBasicCache.merge(Object, Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
.- Parameters:
key
- key to usevalue
- new value to merge with existing valueremappingFunction
- function to use to merge new and existing values into a merged value to store under keylifespan
- lifespan of the entry. Negative values are interpreted as unlimited lifespan.lifespanUnit
- time unit for lifespan- Returns:
- the merged value that was stored under key
- Since:
- 9.4
-
merge
default V merge(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedBasicCache.merge(Object, Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
.- Parameters:
key
- key to usevalue
- new value to merge with existing valueremappingFunction
- function to use to merge new and existing values into a merged value to store under keylifespan
- lifespan of the entry. Negative values are interpreted as unlimited lifespan.lifespanUnit
- time unit for lifespanmaxIdleTime
- the maximum amount of time this key is allowed to be idle for before it is considered as expiredmaxIdleTimeUnit
- time unit for max idle time- Returns:
- the merged value that was stored under key
- Since:
- 9.4
-
mergeAsync
default CompletableFuture<V> mergeAsync(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction)
OverloadedAsyncCache.mergeAsync(Object, Object, BiFunction)
with InfinispanSerializableBiFunction
.- Parameters:
key
- key to usevalue
- new value to merge with existing valueremappingFunction
- function to use to merge new and existing values into a merged value to store under key- Returns:
- the merged value that was stored under key
- Since:
- 10.0
-
mergeAsync
default CompletableFuture<V> mergeAsync(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit)
OverloadedAsyncCache.mergeAsync(Object, Object, BiFunction, long, TimeUnit)
with InfinispanSerializableBiFunction
.- Parameters:
key
- key to usevalue
- new value to merge with existing valueremappingFunction
- function to use to merge new and existing values into a merged value to store under keylifespan
- lifespan of the entry. Negative values are interpreted as unlimited lifespan.lifespanUnit
- time unit for lifespan- Returns:
- the merged value that was stored under key
- Since:
- 10.0
-
mergeAsync
default CompletableFuture<V> mergeAsync(K key, V value, org.infinispan.util.function.SerializableBiFunction<? super V,? super V,? extends V> remappingFunction, long lifespan, TimeUnit lifespanUnit, long maxIdleTime, TimeUnit maxIdleTimeUnit)
OverloadedAsyncCache.mergeAsync(Object, Object, BiFunction, long, TimeUnit, long, TimeUnit)
with InfinispanSerializableBiFunction
.- Parameters:
key
- key to usevalue
- new value to merge with existing valueremappingFunction
- function to use to merge new and existing values into a merged value to store under keylifespan
- lifespan of the entry. Negative values are interpreted as unlimited lifespan.lifespanUnit
- time unit for lifespanmaxIdleTime
- the maximum amount of time this key is allowed to be idle for before it is considered as expiredmaxIdleTimeUnit
- time unit for max idle time- Returns:
- the merged value that was stored under key
- Since:
- 10.0
-
-