Class RedissonMap<K,V>
- java.lang.Object
 - 
- org.redisson.RedissonObject
 - 
- org.redisson.RedissonMap<K,V>
 
 
 
- 
- Type Parameters:
 K- keyV- value
- All Implemented Interfaces:
 ConcurrentMap<K,V>,Map<K,V>,RExpirable,RExpirableAsync,RMap<K,V>,RMapAsync<K,V>,RObject,RObjectAsync
- Direct Known Subclasses:
 RedissonLocalCachedMap,RedissonMapCache,RedissonTransactionalMap
public class RedissonMap<K,V> extends RedissonObject implements RMap<K,V>
Distributed and concurrent implementation ofConcurrentMapandMap- Author:
 - Nikita Koksharov
 
 
- 
- 
Field Summary
- 
Fields inherited from class org.redisson.RedissonObject
codec, commandExecutor, name 
 - 
 
- 
Constructor Summary
Constructors Constructor Description RedissonMap(Codec codec, CommandAsyncExecutor commandExecutor, String name, RedissonClient redisson, MapOptions<K,V> options, WriteBehindService writeBehindService)RedissonMap(CommandAsyncExecutor commandExecutor, String name, RedissonClient redisson, MapOptions<K,V> options, WriteBehindService writeBehindService) 
- 
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description VaddAndGet(K key, Number value)Adds the givendeltato the current value by mappedkey.RFuture<V>addAndGetAsync(K key, Number value)Adds the givendeltato the current value by mappedkey.protected RFuture<V>addAndGetOperationAsync(K key, Number value)protected voidcheckKey(Object key)protected voidcheckValue(Object value)voidclear()booleanclearExpire()Clear an expire timeout or expire date for object.RFuture<Boolean>clearExpireAsync()Clear an expire timeout or expire date for object in async mode.protected RFuture<Boolean>clearExpireAsync(String... keys)Vcompute(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)RFuture<V>computeAsync(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)Computes a new mapping for the specified key and its current mapped value.VcomputeIfAbsent(K key, Function<? super K,? extends V> mappingFunction)RFuture<V>computeIfAbsentAsync(K key, Function<? super K,? extends V> mappingFunction)Computes a mapping for the specified key if it's not mapped before.VcomputeIfPresent(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)RFuture<V>computeIfPresentAsync(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)Computes a mapping for the specified key only if it's already mapped.booleancontainsKey(Object key)Returnstrueif this map contains map entry mapped by specifiedkey, otherwisefalseRFuture<Boolean>containsKeyAsync(Object key)Returnstrueif this map contains map entry mapped by specifiedkey, otherwisefalseprotected RFuture<Boolean>containsKeyAsync(Object key, RPromise<V> promise)booleancontainsValue(Object value)Returnstrueif this map contains any map entry with specifiedvalue, otherwisefalseRFuture<Boolean>containsValueAsync(Object value)Returnstrueif this map contains any map entry with specifiedvalue, otherwisefalseprotected Iterator<Map.Entry<K,V>>entryIterator(String pattern, int count)Set<Map.Entry<K,V>>entrySet()Returns map entries collection.Set<Map.Entry<K,V>>entrySet(int count)Returns map entries collection.Set<Map.Entry<K,V>>entrySet(String keyPattern)Returns map entries collection.Set<Map.Entry<K,V>>entrySet(String keyPattern, int count)Returns map entries collection.booleanequals(Object o)booleanexpire(long timeToLive, TimeUnit timeUnit)Set a timeout for object.booleanexpire(Instant instant)Set an expire date for object.RFuture<Boolean>expireAsync(long timeToLive, TimeUnit timeUnit)Set a timeout for object in async mode.protected RFuture<Boolean>expireAsync(long timeToLive, TimeUnit timeUnit, String... keys)RFuture<Boolean>expireAsync(Instant instant)Set an expire date for object.booleanexpireAt(long timestamp)UseRExpirable.expire(Instant)insteadbooleanexpireAt(Date timestamp)UseRExpirable.expire(Instant)insteadRFuture<Boolean>expireAtAsync(long timestamp)UseRExpirableAsync.expireAsync(Instant)insteadprotected RFuture<Boolean>expireAtAsync(long timestamp, String... keys)RFuture<Boolean>expireAtAsync(Date timestamp)UseRExpirableAsync.expireAsync(Instant)insteadbooleanfastPut(K key, V value)Stores the specifiedvaluemapped by specifiedkey.RFuture<Boolean>fastPutAsync(K key, V value)Stores the specifiedvaluemapped by specifiedkey.booleanfastPutIfAbsent(K key, V value)Stores the specifiedvaluemapped by specifiedkeyonly if there is no value with specifiedkeystored before.RFuture<Boolean>fastPutIfAbsentAsync(K key, V value)Stores the specifiedvaluemapped by specifiedkeyonly if there is no value with specifiedkeystored before.protected RFuture<Boolean>fastPutIfAbsentOperationAsync(K key, V value)booleanfastPutIfExists(K key, V value)Stores the specifiedvaluemapped bykeyonly if mapping already exists.RFuture<Boolean>fastPutIfExistsAsync(K key, V value)Stores the specifiedvaluemapped bykeyonly if mapping already exists.protected RFuture<Boolean>fastPutIfExistsOperationAsync(K key, V value)protected RFuture<Boolean>fastPutOperationAsync(K key, V value)longfastRemove(K... keys)Removes map entries mapped by specifiedkeys.RFuture<Long>fastRemoveAsync(K... keys)Removes map entries mapped by specifiedkeys.protected RFuture<Long>fastRemoveOperationAsync(K... keys)protected RFuture<List<Long>>fastRemoveOperationBatchAsync(K... keys)booleanfastReplace(K key, V value)Replaces previous value with a newvaluemapped by specifiedkey.RFuture<Boolean>fastReplaceAsync(K key, V value)Replaces previous value with a newvaluemapped by specifiedkey.protected RFuture<Boolean>fastReplaceOperationAsync(K key, V value)Vget(Object key)Returns the value mapped by definedkeyornullif value is absent.Map<K,V>getAll(Set<K> keys)Returns map slice contained the mappings with definedkeys.RFuture<Map<K,V>>getAllAsync(Set<K> keys)Returns map slice contained the mappings with definedkeys.RFuture<Map<K,V>>getAllOperationAsync(Set<K> keys)RFuture<V>getAsync(K key)Returns the value mapped by definedkeyornullif value is absent.RCountDownLatchgetCountDownLatch(K key)ReturnsRCountDownLatchinstance associated with keyRLockgetFairLock(K key)ReturnsRLockinstance associated with keyRLockgetLock(K key)ReturnsRLockinstance associated with keyRFuture<V>getOperationAsync(K key)RPermitExpirableSemaphoregetPermitExpirableSemaphore(K key)ReturnsRPermitExpirableSemaphoreinstance associated with keyRReadWriteLockgetReadWriteLock(K key)ReturnsRReadWriteLockinstance associated with keyRSemaphoregetSemaphore(K key)ReturnsRSemaphoreinstance associated with keyinthashCode()protected booleanhasNoLoader()protected booleanhasNoWriter()booleanisEmpty()protected Iterator<K>keyIterator(String pattern, int count)Set<K>keySet()Returns key set of this map.Set<K>keySet(int count)Returns key set of this map.Set<K>keySet(String pattern)Returns key set of this map.Set<K>keySet(String pattern, int count)Returns key set of this map.voidloadAll(boolean replaceExistingValues, int parallelism)Loads all map entries to this Redis map usingMapLoader.voidloadAll(Set<? extends K> keys, boolean replaceExistingValues, int parallelism)Loads map entries usingMapLoaderwhose keys are listed in definedkeysparameter.RFuture<Void>loadAllAsync(boolean replaceExistingValues, int parallelism)Loads all map entries to this Redis map usingMapLoader.protected RFuture<Void>loadAllAsync(Iterable<? extends K> keys, boolean replaceExistingValues, int parallelism, Map<K,V> loadedEntires)RFuture<Void>loadAllAsync(Set<? extends K> keys, boolean replaceExistingValues, int parallelism)Loads map entries usingMapLoaderwhose keys are listed in definedkeysparameter.protected voidloadValue(K key, RPromise<V> result, boolean replaceValue)<KOut,VOut>
RMapReduce<K,V,KOut,VOut>mapReduce()ReturnsRMapReduceobject associated with this mapprotected <M> RFuture<M>mapWriterFuture(RFuture<M> future, MapWriterTask task)protected <M> RFuture<M>mapWriterFuture(RFuture<M> future, MapWriterTask task, Function<M,Boolean> condition)Vmerge(K key, V value, BiFunction<? super V,? super V,? extends V> remappingFunction)RFuture<V>mergeAsync(K key, V value, BiFunction<? super V,? super V,? extends V> remappingFunction)Associates specified key with the given value if key isn't already associated with a value.Vput(K key, V value)Stores the specifiedvaluemapped by specifiedkey.voidputAll(Map<? extends K,? extends V> map)Stores map entries specified inmapobject in batch mode.voidputAll(Map<? extends K,? extends V> map, int batchSize)Stores map entries specified inmapobject in batch mode.RFuture<Void>putAllAsync(Map<? extends K,? extends V> map)Stores map entries specified inmapobject in batch mode.RFuture<Void>putAllAsync(Map<? extends K,? extends V> map, int batchSize)Stores map entries specified inmapobject in batch mode.protected RFuture<Void>putAllOperationAsync(Map<? extends K,? extends V> map)RFuture<V>putAsync(K key, V value)Stores the specifiedvaluemapped by specifiedkey.VputIfAbsent(K key, V value)Stores the specifiedvaluemapped bykeyonly if there is no value with specifiedkeystored before.RFuture<V>putIfAbsentAsync(K key, V value)Stores the specifiedvaluemapped by specifiedkeyonly if there is no value with specifiedkeystored before.protected RFuture<V>putIfAbsentOperationAsync(K key, V value)VputIfExists(K key, V value)Stores the specifiedvaluemapped bykeyonly if mapping already exists.RFuture<V>putIfExistsAsync(K key, V value)Stores the specifiedvaluemapped bykeyonly if mapping already exists.protected RFuture<V>putIfExistsOperationAsync(K key, V value)protected RFuture<V>putOperationAsync(K key, V value)Map<K,V>randomEntries(int count)Returns random map entries from this map limited bycountRFuture<Map<K,V>>randomEntriesAsync(int count)Returns random map entries from this map limited bycountSet<K>randomKeys(int count)Returns random keys from this map limited bycountRFuture<Set<K>>randomKeysAsync(int count)Returns random keys from this map limited bycountSet<Map.Entry<K,V>>readAllEntrySet()Read all map entries at onceRFuture<Set<Map.Entry<K,V>>>readAllEntrySetAsync()Read all map entries at onceSet<K>readAllKeySet()Read all keys at onceRFuture<Set<K>>readAllKeySetAsync()Read all keys at onceMap<K,V>readAllMap()Read all map as local instance at onceRFuture<Map<K,V>>readAllMapAsync()Read all map as local instance at onceCollection<V>readAllValues()Read all values at onceRFuture<Collection<V>>readAllValuesAsync()Read all values at oncelongremainTimeToLive()Remaining time to live of Redisson object that has a timeoutRFuture<Long>remainTimeToLiveAsync()Remaining time to live of Redisson object that has a timeoutVremove(Object key)Removes map entry by specifiedkeyand returns value.booleanremove(Object key, Object value)Removes map entry only if it exists with specifiedkeyandvalue.RFuture<Boolean>removeAsync(Object key, Object value)Removes map entry only if it exists with specifiedkeyandvalue.RFuture<V>removeAsync(K key)Removes map entry by specifiedkeyand returns value.protected RFuture<Boolean>removeOperationAsync(Object key, Object value)protected RFuture<V>removeOperationAsync(K key)Vreplace(K key, V value)Replaces previous value with a newvaluemapped by specifiedkey.booleanreplace(K key, V oldValue, V newValue)Replaces previousoldValuewith anewValuemapped by specifiedkey.RFuture<V>replaceAsync(K key, V value)Replaces previous value with a newvaluemapped by specifiedkey.RFuture<Boolean>replaceAsync(K key, V oldValue, V newValue)Replaces previousoldValuewith anewValuemapped by specifiedkey.protected RFuture<V>replaceOperationAsync(K key, V value)protected RFuture<Boolean>replaceOperationAsync(K key, V oldValue, V newValue)ScanResult<Map.Entry<Object,Object>>scanIterator(String name, RedisClient client, long startPos, String pattern, int count)RFuture<ScanResult<Map.Entry<Object,Object>>>scanIteratorAsync(String name, RedisClient client, long startPos, String pattern, int count)intsize()RFuture<Integer>sizeAsync()Returns size of this mapprotected Iterator<V>valueIterator(String pattern, int count)Collection<V>values()Returns values collection of this map.Collection<V>values(int count)Returns values collection of this map.Collection<V>values(String keyPattern)Returns values collection of this map.Collection<V>values(String keyPattern, int count)Returns values collection of this map.intvalueSize(K key)Returns size of value mapped by specifiedkeyin bytesRFuture<Integer>valueSizeAsync(K key)Returns size of value mapped by key in bytes- 
Methods inherited from class org.redisson.RedissonObject
addListener, addListener, addListenerAsync, addListenerAsync, copy, copyAsync, delete, deleteAsync, deleteAsync, dump, dumpAsync, encode, encode, encode, encode, encodeMapKey, encodeMapKeys, encodeMapValue, encodeMapValues, get, getCodec, getIdleTime, getIdleTimeAsync, getLockByMapKey, getLockByValue, getName, getRawName, getRawName, isExists, isExistsAsync, migrate, migrateAsync, move, moveAsync, prefixName, removeListener, removeListenerAsync, removeListenersAsync, rename, renameAsync, renamenx, renamenxAsync, restore, restore, restoreAndReplace, restoreAndReplace, restoreAndReplaceAsync, restoreAndReplaceAsync, restoreAsync, restoreAsync, setName, sizeInMemory, sizeInMemoryAsync, sizeInMemoryAsync, sizeInMemoryAsync, suffixName, toSeconds, toStream, touch, touchAsync, unlink, unlinkAsync 
- 
Methods inherited from class java.lang.Object
clone, finalize, getClass, notify, notifyAll, toString, wait, wait, wait 
- 
Methods inherited from interface java.util.concurrent.ConcurrentMap
forEach, getOrDefault, replaceAll 
- 
Methods inherited from interface org.redisson.api.RExpirable
clearExpire, expire, expire, expireAt, expireAt, remainTimeToLive 
- 
Methods inherited from interface org.redisson.api.RExpirableAsync
clearExpireAsync, expireAsync, expireAsync, expireAtAsync, expireAtAsync, remainTimeToLiveAsync 
- 
Methods inherited from interface org.redisson.api.RObject
addListener, copy, delete, dump, getCodec, getIdleTime, getName, isExists, migrate, move, removeListener, rename, renamenx, restore, restore, restoreAndReplace, restoreAndReplace, sizeInMemory, touch, unlink 
- 
Methods inherited from interface org.redisson.api.RObjectAsync
addListenerAsync, copyAsync, deleteAsync, dumpAsync, getIdleTimeAsync, isExistsAsync, migrateAsync, moveAsync, removeListenerAsync, renameAsync, renamenxAsync, restoreAndReplaceAsync, restoreAndReplaceAsync, restoreAsync, restoreAsync, sizeInMemoryAsync, touchAsync, unlinkAsync 
 - 
 
 - 
 
- 
- 
Constructor Detail
- 
RedissonMap
public RedissonMap(CommandAsyncExecutor commandExecutor, String name, RedissonClient redisson, MapOptions<K,V> options, WriteBehindService writeBehindService)
 
- 
RedissonMap
public RedissonMap(Codec codec, CommandAsyncExecutor commandExecutor, String name, RedissonClient redisson, MapOptions<K,V> options, WriteBehindService writeBehindService)
 
 - 
 
- 
Method Detail
- 
mapReduce
public <KOut,VOut> RMapReduce<K,V,KOut,VOut> mapReduce()
Description copied from interface:RMapReturnsRMapReduceobject associated with this map 
- 
getPermitExpirableSemaphore
public RPermitExpirableSemaphore getPermitExpirableSemaphore(K key)
Description copied from interface:RMapReturnsRPermitExpirableSemaphoreinstance associated with key- Specified by:
 getPermitExpirableSemaphorein interfaceRMap<K,V>- Parameters:
 key- - map key- Returns:
 - permitExpirableSemaphore
 
 
- 
getSemaphore
public RSemaphore getSemaphore(K key)
Description copied from interface:RMapReturnsRSemaphoreinstance associated with key- Specified by:
 getSemaphorein interfaceRMap<K,V>- Parameters:
 key- - map key- Returns:
 - semaphore
 
 
- 
getCountDownLatch
public RCountDownLatch getCountDownLatch(K key)
Description copied from interface:RMapReturnsRCountDownLatchinstance associated with key- Specified by:
 getCountDownLatchin interfaceRMap<K,V>- Parameters:
 key- - map key- Returns:
 - countdownlatch
 
 
- 
getFairLock
public RLock getFairLock(K key)
Description copied from interface:RMapReturnsRLockinstance associated with key- Specified by:
 getFairLockin interfaceRMap<K,V>- Parameters:
 key- - map key- Returns:
 - fairlock
 
 
- 
getLock
public RLock getLock(K key)
Description copied from interface:RMapReturnsRLockinstance associated with key 
- 
getReadWriteLock
public RReadWriteLock getReadWriteLock(K key)
Description copied from interface:RMapReturnsRReadWriteLockinstance associated with key- Specified by:
 getReadWriteLockin interfaceRMap<K,V>- Parameters:
 key- - map key- Returns:
 - readWriteLock
 
 
- 
merge
public V merge(K key, V value, BiFunction<? super V,? super V,? extends V> remappingFunction)
 
- 
mergeAsync
public RFuture<V> mergeAsync(K key, V value, BiFunction<? super V,? super V,? extends V> remappingFunction)
Description copied from interface:RMapAsyncAssociates specified key with the given value if key isn't already associated with a value. Otherwise, replaces the associated value with the results of the given remapping function, or removes if the result isnull.- Specified by:
 mergeAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- - value to be merged with the existing value associated with the key or to be associated with the key, if no existing valueremappingFunction- - the function is invoked with the existing value to compute new value- Returns:
 - new value associated with the specified key or
         
nullif no value associated with the key 
 
- 
computeAsync
public RFuture<V> computeAsync(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)
Description copied from interface:RMapAsyncComputes a new mapping for the specified key and its current mapped value.- Specified by:
 computeAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyremappingFunction- - function to compute a value- Returns:
 - the new value associated with the specified key, or 
nullif none 
 
- 
computeIfAbsentAsync
public RFuture<V> computeIfAbsentAsync(K key, Function<? super K,? extends V> mappingFunction)
Description copied from interface:RMapAsyncComputes a mapping for the specified key if it's not mapped before.- Specified by:
 computeIfAbsentAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keymappingFunction- - function to compute a value- Returns:
 - current or new computed value associated with
         the specified key, or 
nullif the computed value is null 
 
- 
computeIfAbsent
public V computeIfAbsent(K key, Function<? super K,? extends V> mappingFunction)
- Specified by:
 computeIfAbsentin interfaceConcurrentMap<K,V>- Specified by:
 computeIfAbsentin interfaceMap<K,V>
 
- 
computeIfPresentAsync
public RFuture<V> computeIfPresentAsync(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)
Description copied from interface:RMapAsyncComputes a mapping for the specified key only if it's already mapped.- Specified by:
 computeIfPresentAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyremappingFunction- - function to compute a value- Returns:
 - the new value associated with the specified key, or null if none
 
 
- 
computeIfPresent
public V computeIfPresent(K key, BiFunction<? super K,? super V,? extends V> remappingFunction)
- Specified by:
 computeIfPresentin interfaceConcurrentMap<K,V>- Specified by:
 computeIfPresentin interfaceMap<K,V>
 
- 
sizeAsync
public RFuture<Integer> sizeAsync()
Description copied from interface:RMapAsyncReturns size of this map 
- 
valueSize
public int valueSize(K key)
Description copied from interface:RMapReturns size of value mapped by specifiedkeyin bytes 
- 
valueSizeAsync
public RFuture<Integer> valueSizeAsync(K key)
Description copied from interface:RMapAsyncReturns size of value mapped by key in bytes- Specified by:
 valueSizeAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map key- Returns:
 - size of value
 
 
- 
checkKey
protected void checkKey(Object key)
 
- 
containsKey
public boolean containsKey(Object key)
Description copied from interface:RMapReturnstrueif this map contains map entry mapped by specifiedkey, otherwisefalse- Specified by:
 containsKeyin interfaceMap<K,V>- Specified by:
 containsKeyin interfaceRMap<K,V>- Parameters:
 key- - map key- Returns:
 trueif this map contains map entry mapped by specifiedkey, otherwisefalse
 
- 
containsKeyAsync
public RFuture<Boolean> containsKeyAsync(Object key)
Description copied from interface:RMapAsyncReturnstrueif this map contains map entry mapped by specifiedkey, otherwisefalse- Specified by:
 containsKeyAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map key- Returns:
 trueif this map contains map entry mapped by specifiedkey, otherwisefalse
 
- 
containsValue
public boolean containsValue(Object value)
Description copied from interface:RMapReturnstrueif this map contains any map entry with specifiedvalue, otherwisefalse- Specified by:
 containsValuein interfaceMap<K,V>- Specified by:
 containsValuein interfaceRMap<K,V>- Parameters:
 value- - map value- Returns:
 trueif this map contains any map entry with specifiedvalue, otherwisefalse
 
- 
containsValueAsync
public RFuture<Boolean> containsValueAsync(Object value)
Description copied from interface:RMapAsyncReturnstrueif this map contains any map entry with specifiedvalue, otherwisefalse- Specified by:
 containsValueAsyncin interfaceRMapAsync<K,V>- Parameters:
 value- - map value- Returns:
 trueif this map contains any map entry with specifiedvalue, otherwisefalse
 
- 
getAll
public Map<K,V> getAll(Set<K> keys)
Description copied from interface:RMapReturns map slice contained the mappings with definedkeys.If map doesn't contain value/values for specified key/keys and
MapLoaderis defined then value/values will be loaded in read-through mode.The returned map is NOT backed by the original map.
 
- 
randomKeys
public Set<K> randomKeys(int count)
Description copied from interface:RMapReturns random keys from this map limited bycount- Specified by:
 randomKeysin interfaceRMap<K,V>- Parameters:
 count- - keys amount to return- Returns:
 - random keys
 
 
- 
randomEntries
public Map<K,V> randomEntries(int count)
Description copied from interface:RMapReturns random map entries from this map limited bycount- Specified by:
 randomEntriesin interfaceRMap<K,V>- Parameters:
 count- - entries amount to return- Returns:
 - random entries
 
 
- 
randomKeysAsync
public RFuture<Set<K>> randomKeysAsync(int count)
Description copied from interface:RMapAsyncReturns random keys from this map limited bycount- Specified by:
 randomKeysAsyncin interfaceRMapAsync<K,V>- Parameters:
 count- - keys amount to return- Returns:
 - random keys
 
 
- 
randomEntriesAsync
public RFuture<Map<K,V>> randomEntriesAsync(int count)
Description copied from interface:RMapAsyncReturns random map entries from this map limited bycount- Specified by:
 randomEntriesAsyncin interfaceRMapAsync<K,V>- Parameters:
 count- - entries amount to return- Returns:
 - random entries
 
 
- 
getAllAsync
public RFuture<Map<K,V>> getAllAsync(Set<K> keys)
Description copied from interface:RMapAsyncReturns map slice contained the mappings with definedkeys.If map doesn't contain value/values for specified key/keys and
MapLoaderis defined then value/values will be loaded in read-through mode.The returned map is NOT backed by the original map.
- Specified by:
 getAllAsyncin interfaceRMapAsync<K,V>- Parameters:
 keys- - map keys- Returns:
 - Map slice
 
 
- 
hasNoLoader
protected boolean hasNoLoader()
 
- 
get
public V get(Object key)
Description copied from interface:RMapReturns the value mapped by definedkeyornullif value is absent.If map doesn't contain value for specified key and
MapLoaderis defined then value will be loaded in read-through mode. 
- 
put
public V put(K key, V value)
Description copied from interface:RMapStores the specifiedvaluemapped by specifiedkey. Returns previous value if map entry with specifiedkeyalready existed.If
MapWriteris defined then map entry is stored in write-through mode. 
- 
remove
public V remove(Object key)
Description copied from interface:RMapRemoves map entry by specifiedkeyand returns value.If
MapWriteris defined thenkeyis deleted in write-through mode. 
- 
putAll
public final void putAll(Map<? extends K,? extends V> map)
Description copied from interface:RMapStores map entries specified inmapobject in batch mode.If
MapWriteris defined then map entries will be stored in write-through mode. 
- 
putAll
public void putAll(Map<? extends K,? extends V> map, int batchSize)
Description copied from interface:RMapStores map entries specified inmapobject in batch mode. Batch inserted by chunks limited bybatchSizevalue to avoid OOM and/or Redis response timeout error for map with big size.If
MapWriteris defined then map entries are stored in write-through mode. 
- 
putAllAsync
public RFuture<Void> putAllAsync(Map<? extends K,? extends V> map, int batchSize)
Description copied from interface:RMapAsyncStores map entries specified inmapobject in batch mode. Batch inserted by chunks limited bybatchSizevalue to avoid OOM and/or Redis response timeout error for map with big size.If
MapWriteris defined then map entries are stored in write-through mode.- Specified by:
 putAllAsyncin interfaceRMapAsync<K,V>- Parameters:
 map- mappings to be stored in this mapbatchSize- - size of map entries batch- Returns:
 - void
 
 
- 
putAllAsync
public final RFuture<Void> putAllAsync(Map<? extends K,? extends V> map)
Description copied from interface:RMapAsyncStores map entries specified inmapobject in batch mode.If
MapWriteris defined then map entries will be stored in write-through mode.- Specified by:
 putAllAsyncin interfaceRMapAsync<K,V>- Parameters:
 map- mappings to be stored in this map- Returns:
 - void
 
 
- 
mapWriterFuture
protected final <M> RFuture<M> mapWriterFuture(RFuture<M> future, MapWriterTask task)
 
- 
mapWriterFuture
protected final <M> RFuture<M> mapWriterFuture(RFuture<M> future, MapWriterTask task, Function<M,Boolean> condition)
 
- 
putAllOperationAsync
protected RFuture<Void> putAllOperationAsync(Map<? extends K,? extends V> map)
 
- 
keySet
public Set<K> keySet()
Description copied from interface:RMapReturns key set of this map. Keys are loaded in batch. Batch size is10. 
- 
keySet
public Set<K> keySet(String pattern)
Description copied from interface:RMapReturns key set of this map. Ifpatternis not null then only keys match this pattern are loaded.Use
org.redisson.client.codec.StringCodecfor Map keys.Supported glob-style patterns:
h?llo subscribes to hello, hallo and hxllo
h*llo subscribes to hllo and heeeello
h[ae]llo subscribes to hello and hallo, but not hillo
- Specified by:
 keySetin interfaceRMap<K,V>- Parameters:
 pattern- - key pattern- Returns:
 - key set
 - See Also:
 RMap.readAllKeySet()
 
- 
keySet
public Set<K> keySet(String pattern, int count)
Description copied from interface:RMapReturns key set of this map. Ifpatternis not null then only keys match this pattern are loaded. Keys are loaded in batch. Batch size is defined bycountparam.Use
org.redisson.client.codec.StringCodecfor Map keys.Supported glob-style patterns:
h?llo subscribes to hello, hallo and hxllo
h*llo subscribes to hllo and heeeello
h[ae]llo subscribes to hello and hallo, but not hillo
- Specified by:
 keySetin interfaceRMap<K,V>- Parameters:
 pattern- - key patterncount- - size of keys batch- Returns:
 - key set
 - See Also:
 RMap.readAllKeySet()
 
- 
keySet
public Set<K> keySet(int count)
Description copied from interface:RMapReturns key set of this map. Keys are loaded in batch. Batch size is defined bycountparam.- Specified by:
 keySetin interfaceRMap<K,V>- Parameters:
 count- - size of keys batch- Returns:
 - key set
 - See Also:
 RMap.readAllKeySet()
 
- 
values
public Collection<V> values()
Description copied from interface:RMapReturns values collection of this map. Values are loaded in batch. Batch size is10. 
- 
values
public Collection<V> values(String keyPattern, int count)
Description copied from interface:RMapReturns values collection of this map. Values are loaded in batch. Batch size is defined bycountparam. IfkeyPatternis not null then only values mapped by matched keys of this pattern are loaded.Use
org.redisson.client.codec.StringCodecfor Map keys.Supported glob-style patterns:
h?llo subscribes to hello, hallo and hxllo
h*llo subscribes to hllo and heeeello
h[ae]llo subscribes to hello and hallo, but not hillo
- Specified by:
 valuesin interfaceRMap<K,V>- Parameters:
 keyPattern- - key patterncount- - size of values batch- Returns:
 - values collection
 - See Also:
 RMap.readAllValues()
 
- 
values
public Collection<V> values(String keyPattern)
Description copied from interface:RMapReturns values collection of this map. Values are loaded in batch. Batch size is10. IfkeyPatternis not null then only values mapped by matched keys of this pattern are loaded.Use
org.redisson.client.codec.StringCodecfor Map keys.Supported glob-style patterns:
h?llo subscribes to hello, hallo and hxllo
h*llo subscribes to hllo and heeeello
h[ae]llo subscribes to hello and hallo, but not hillo
- Specified by:
 valuesin interfaceRMap<K,V>- Parameters:
 keyPattern- - key pattern- Returns:
 - values collection
 - See Also:
 RMap.readAllValues()
 
- 
values
public Collection<V> values(int count)
Description copied from interface:RMapReturns values collection of this map. Values are loaded in batch. Batch size is defined bycountparam.- Specified by:
 valuesin interfaceRMap<K,V>- Parameters:
 count- - size of values batch- Returns:
 - values collection
 - See Also:
 RMap.readAllValues()
 
- 
entrySet
public Set<Map.Entry<K,V>> entrySet()
Description copied from interface:RMapReturns map entries collection. Map entries are loaded in batch. Batch size is10. 
- 
entrySet
public Set<Map.Entry<K,V>> entrySet(String keyPattern)
Description copied from interface:RMapReturns map entries collection. Map entries are loaded in batch. Batch size is10. IfkeyPatternis not null then only entries mapped by matched keys of this pattern are loaded. Supported glob-style patterns:h?llo subscribes to hello, hallo and hxllo
h*llo subscribes to hllo and heeeello
h[ae]llo subscribes to hello and hallo, but not hillo
- Specified by:
 entrySetin interfaceRMap<K,V>- Parameters:
 keyPattern- - key pattern- Returns:
 - map entries collection
 - See Also:
 RMap.readAllEntrySet()
 
- 
entrySet
public Set<Map.Entry<K,V>> entrySet(String keyPattern, int count)
Description copied from interface:RMapReturns map entries collection. Map entries are loaded in batch. Batch size is defined bycountparam. IfkeyPatternis not null then only entries mapped by matched keys of this pattern are loaded. Supported glob-style patterns:h?llo subscribes to hello, hallo and hxllo
h*llo subscribes to hllo and heeeello
h[ae]llo subscribes to hello and hallo, but not hillo
- Specified by:
 entrySetin interfaceRMap<K,V>- Parameters:
 keyPattern- - key patterncount- - size of entries batch- Returns:
 - map entries collection
 - See Also:
 RMap.readAllEntrySet()
 
- 
entrySet
public Set<Map.Entry<K,V>> entrySet(int count)
Description copied from interface:RMapReturns map entries collection. Map entries are loaded in batch. Batch size is defined bycountparam.- Specified by:
 entrySetin interfaceRMap<K,V>- Parameters:
 count- - size of entries batch- Returns:
 - map entries collection
 - See Also:
 RMap.readAllEntrySet()
 
- 
readAllKeySet
public Set<K> readAllKeySet()
Description copied from interface:RMapRead all keys at once- Specified by:
 readAllKeySetin interfaceRMap<K,V>- Returns:
 - keys
 
 
- 
readAllKeySetAsync
public RFuture<Set<K>> readAllKeySetAsync()
Description copied from interface:RMapAsyncRead all keys at once- Specified by:
 readAllKeySetAsyncin interfaceRMapAsync<K,V>- Returns:
 - keys
 
 
- 
readAllValues
public Collection<V> readAllValues()
Description copied from interface:RMapRead all values at once- Specified by:
 readAllValuesin interfaceRMap<K,V>- Returns:
 - values
 
 
- 
readAllValuesAsync
public RFuture<Collection<V>> readAllValuesAsync()
Description copied from interface:RMapAsyncRead all values at once- Specified by:
 readAllValuesAsyncin interfaceRMapAsync<K,V>- Returns:
 - values
 
 
- 
readAllEntrySet
public Set<Map.Entry<K,V>> readAllEntrySet()
Description copied from interface:RMapRead all map entries at once- Specified by:
 readAllEntrySetin interfaceRMap<K,V>- Returns:
 - entries
 
 
- 
readAllEntrySetAsync
public RFuture<Set<Map.Entry<K,V>>> readAllEntrySetAsync()
Description copied from interface:RMapAsyncRead all map entries at once- Specified by:
 readAllEntrySetAsyncin interfaceRMapAsync<K,V>- Returns:
 - entries
 
 
- 
readAllMap
public Map<K,V> readAllMap()
Description copied from interface:RMapRead all map as local instance at once- Specified by:
 readAllMapin interfaceRMap<K,V>- Returns:
 - map
 
 
- 
readAllMapAsync
public RFuture<Map<K,V>> readAllMapAsync()
Description copied from interface:RMapAsyncRead all map as local instance at once- Specified by:
 readAllMapAsyncin interfaceRMapAsync<K,V>- Returns:
 - map
 
 
- 
putIfExists
public V putIfExists(K key, V value)
Description copied from interface:RMapStores the specifiedvaluemapped bykeyonly if mapping already exists.If
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 putIfExistsin interfaceRMap<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 nullif key doesn't exist in the hash and value hasn't been set. Previous value if key already exists in the hash and new value has been stored.
 
- 
putIfExistsAsync
public RFuture<V> putIfExistsAsync(K key, V value)
Description copied from interface:RMapAsyncStores the specifiedvaluemapped bykeyonly if mapping already exists.If
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 putIfExistsAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 nullif key is doesn't exists in the hash and value hasn't been set. Previous value if key already exists in the hash and new value has been stored.
 
- 
putIfAbsent
public V putIfAbsent(K key, V value)
Description copied from interface:RMapStores the specifiedvaluemapped bykeyonly if there is no value with specifiedkeystored before.If
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 putIfAbsentin interfaceConcurrentMap<K,V>- Specified by:
 putIfAbsentin interfaceMap<K,V>- Specified by:
 putIfAbsentin interfaceRMap<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 nullif key is a new one in the hash and value was set. Previous value if key already exists in the hash and change hasn't been made.
 
- 
putIfAbsentAsync
public RFuture<V> putIfAbsentAsync(K key, V value)
Description copied from interface:RMapAsyncStores the specifiedvaluemapped by specifiedkeyonly if there is no value with specifiedkeystored before.If
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 putIfAbsentAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 nullif key is a new one in the hash and value was set. Previous value if key already exists in the hash and change hasn't been made.
 
- 
hasNoWriter
protected boolean hasNoWriter()
 
- 
fastPutIfAbsent
public boolean fastPutIfAbsent(K key, V value)
Description copied from interface:RMapStores the specifiedvaluemapped by specifiedkeyonly if there is no value with specifiedkeystored before.Returns
trueif key is a new one in the hash and value was set orfalseif key already exists in the hash and change hasn't been made.Works faster than
but not returning the previous value associated withRMap.putIfAbsent(Object, Object)keyIf
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 fastPutIfAbsentin interfaceRMap<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 trueif key is a new one in the hash and value was set.falseif key already exists in the hash and change hasn't been made.
 
- 
fastPutIfAbsentAsync
public RFuture<Boolean> fastPutIfAbsentAsync(K key, V value)
Description copied from interface:RMapAsyncStores the specifiedvaluemapped by specifiedkeyonly if there is no value with specifiedkeystored before.Returns
trueif key is a new one in the hash and value was set orfalseif key already exists in the hash and change hasn't been made.Works faster than
but not returning the previous value associated withRMapAsync.putIfAbsentAsync(Object, Object)keyIf
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 fastPutIfAbsentAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 trueif key is a new one in the hash and value was set.falseif key already exists in the hash and change hasn't been made.
 
- 
fastPutIfAbsentOperationAsync
protected RFuture<Boolean> fastPutIfAbsentOperationAsync(K key, V value)
 
- 
fastPutIfExists
public boolean fastPutIfExists(K key, V value)
Description copied from interface:RMapStores the specifiedvaluemapped bykeyonly if mapping already exists.Returns
trueif key is a new one in the hash and value was set orfalseif key already exists in the hash and change hasn't been made.Works faster than
but doesn't return previous value associated withRMap.putIfExists(Object, Object)keyIf
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 fastPutIfExistsin interfaceRMap<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 trueif key already exists in the hash and new value has been stored.falseif key doesn't exist in the hash and value hasn't been set.
 
- 
fastPutIfExistsAsync
public RFuture<Boolean> fastPutIfExistsAsync(K key, V value)
Description copied from interface:RMapAsyncStores the specifiedvaluemapped bykeyonly if mapping already exists.Returns
trueif key is a new one in the hash and value was set orfalseif key already exists in the hash and change hasn't been made.Works faster than
but doesn't return previous value associated withRMapAsync.putIfExistsAsync(Object, Object)keyIf
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 fastPutIfExistsAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 trueif key already exists in the hash and new value has been stored.falseif key doesn't exist in the hash and value hasn't been set.
 
- 
fastPutIfExistsOperationAsync
protected RFuture<Boolean> fastPutIfExistsOperationAsync(K key, V value)
 
- 
remove
public boolean remove(Object key, Object value)
Description copied from interface:RMapRemoves map entry only if it exists with specifiedkeyandvalue.If
MapWriteris defined thenkeyis deleted in write-through mode. 
- 
removeAsync
public RFuture<Boolean> removeAsync(Object key, Object value)
Description copied from interface:RMapAsyncRemoves map entry only if it exists with specifiedkeyandvalue.If
MapWriteris defined thenkeyis deleted in write-through mode.- Specified by:
 removeAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 trueif map entry has been removed otherwisefalse.
 
- 
checkValue
protected void checkValue(Object value)
 
- 
replace
public boolean replace(K key, V oldValue, V newValue)
Description copied from interface:RMapReplaces previousoldValuewith anewValuemapped by specifiedkey. Returnsfalseif previous value doesn't exist or equal tooldValue.If
MapWriteris defined thennewValueis written in write-through mode. 
- 
replaceAsync
public RFuture<Boolean> replaceAsync(K key, V oldValue, V newValue)
Description copied from interface:RMapAsyncReplaces previousoldValuewith anewValuemapped by specifiedkey. Returnsfalseif previous value doesn't exist or equal tooldValue.If
MapWriteris defined thennewValueis written in write-through mode.- Specified by:
 replaceAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyoldValue- - map old valuenewValue- - map new value- Returns:
 trueif value has been replaced otherwisefalse.
 
- 
replaceOperationAsync
protected RFuture<Boolean> replaceOperationAsync(K key, V oldValue, V newValue)
 
- 
replace
public V replace(K key, V value)
Description copied from interface:RMapReplaces previous value with a newvaluemapped by specifiedkey. Returnsnullif there is no map entry stored before and doesn't store new map entry.If
MapWriteris defined then newvalueis written in write-through mode.- Specified by:
 replacein interfaceConcurrentMap<K,V>- Specified by:
 replacein interfaceMap<K,V>- Specified by:
 replacein interfaceRMap<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 - previous associated value 
         or 
nullif there is no map entry stored before and doesn't store new map entry 
 
- 
replaceAsync
public RFuture<V> replaceAsync(K key, V value)
Description copied from interface:RMapAsyncReplaces previous value with a newvaluemapped by specifiedkey. Returnsnullif there is no map entry stored before and doesn't store new map entry.If
MapWriteris defined then newvalueis written in write-through mode.- Specified by:
 replaceAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 - previous associated value
         or 
nullif there is no map entry stored before and doesn't store new map entry 
 
- 
fastReplace
public boolean fastReplace(K key, V value)
Description copied from interface:RMapReplaces previous value with a newvaluemapped by specifiedkey.Works faster than
but not returning the previous value.RMap.replace(Object, Object)Returns
trueif key exists and value was updated orfalseif key doesn't exists and value wasn't updated.If
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 fastReplacein interfaceRMap<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 trueif key exists and value was updated.falseif key doesn't exists and value wasn't updated.
 
- 
fastReplaceAsync
public RFuture<Boolean> fastReplaceAsync(K key, V value)
Description copied from interface:RMapAsyncReplaces previous value with a newvaluemapped by specifiedkey.Works faster than
but not returning the previous value.RMapAsync.replaceAsync(Object, Object)Returns
trueif key exists and value was updated orfalseif key doesn't exists and value wasn't updated.If
MapWriteris defined then new map entry is stored in write-through mode.- Specified by:
 fastReplaceAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 trueif key exists and value was updated.falseif key doesn't exists and value wasn't updated.
 
- 
getAsync
public RFuture<V> getAsync(K key)
Description copied from interface:RMapAsyncReturns the value mapped by definedkeyornullif value is absent.If map doesn't contain value for specified key and
MapLoaderis defined then value will be loaded in read-through mode. 
- 
loadAll
public void loadAll(boolean replaceExistingValues, int parallelism)Description copied from interface:RMapLoads all map entries to this Redis map usingMapLoader. 
- 
loadAllAsync
public RFuture<Void> loadAllAsync(boolean replaceExistingValues, int parallelism)
Description copied from interface:RMapAsyncLoads all map entries to this Redis map usingMapLoader.- Specified by:
 loadAllAsyncin interfaceRMapAsync<K,V>- Parameters:
 replaceExistingValues- -trueif existed values should be replaced,falseotherwise.parallelism- - parallelism level, used to increase speed of process execution- Returns:
 - void
 
 
- 
loadAll
public void loadAll(Set<? extends K> keys, boolean replaceExistingValues, int parallelism)
Description copied from interface:RMapLoads map entries usingMapLoaderwhose keys are listed in definedkeysparameter. 
- 
loadAllAsync
public RFuture<Void> loadAllAsync(Set<? extends K> keys, boolean replaceExistingValues, int parallelism)
Description copied from interface:RMapAsyncLoads map entries usingMapLoaderwhose keys are listed in definedkeysparameter.- Specified by:
 loadAllAsyncin interfaceRMapAsync<K,V>- Parameters:
 keys- - map keysreplaceExistingValues- -trueif existed values should be replaced,falseotherwise.parallelism- - parallelism level, used to increase speed of process execution- Returns:
 - void
 
 
- 
loadAllAsync
protected RFuture<Void> loadAllAsync(Iterable<? extends K> keys, boolean replaceExistingValues, int parallelism, Map<K,V> loadedEntires)
 
- 
putAsync
public RFuture<V> putAsync(K key, V value)
Description copied from interface:RMapAsyncStores the specifiedvaluemapped by specifiedkey. Returns previous value if map entry with specifiedkeyalready existed.If
MapWriteris defined then map entry is stored in write-through mode. 
- 
removeAsync
public RFuture<V> removeAsync(K key)
Description copied from interface:RMapAsyncRemoves map entry by specifiedkeyand returns value.If
MapWriteris defined thenkeyis deleted in write-through mode.- Specified by:
 removeAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map key- Returns:
 - deleted value, 
nullif map entry doesn't exist 
 
- 
fastPutAsync
public RFuture<Boolean> fastPutAsync(K key, V value)
Description copied from interface:RMapAsyncStores the specifiedvaluemapped by specifiedkey.Works faster than
but not returning previous value.RMapAsync.putAsync(Object, Object)Returns
trueif key is a new key in the hash and value was set orfalseif key already exists in the hash and the value was updated.If
MapWriteris defined then map entry is stored in write-through mode.- Specified by:
 fastPutAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- - map value- Returns:
 trueif key is a new key in the hash and value was set.falseif key already exists in the hash and the value was updated.
 
- 
fastPut
public boolean fastPut(K key, V value)
Description copied from interface:RMapStores the specifiedvaluemapped by specifiedkey.Works faster than
but not returning previous value.RMap.put(Object, Object)Returns
trueif key is a new key in the hash and value was set orfalseif key already exists in the hash and the value was updated.If
MapWriteris defined then map entry is stored in write-through mode. 
- 
fastRemoveAsync
public RFuture<Long> fastRemoveAsync(K... keys)
Description copied from interface:RMapAsyncRemoves map entries mapped by specifiedkeys.Works faster than
but not returning the value.RMapAsync.removeAsync(Object)If
MapWriteris defined thenkeysare deleted in write-through mode.- Specified by:
 fastRemoveAsyncin interfaceRMapAsync<K,V>- Parameters:
 keys- - map keys- Returns:
 - the number of keys that were removed from the hash, not including specified but non existing keys
 
 
- 
fastRemoveOperationBatchAsync
protected RFuture<List<Long>> fastRemoveOperationBatchAsync(K... keys)
 
- 
fastRemove
public long fastRemove(K... keys)
Description copied from interface:RMapRemoves map entries mapped by specifiedkeys.Works faster than
but not returning the value.RMap.remove(Object)If
MapWriteris defined thenkeysare deleted in write-through mode.- Specified by:
 fastRemovein interfaceRMap<K,V>- Parameters:
 keys- - map keys- Returns:
 - the number of keys that were removed from the hash, not including specified but non existing keys
 
 
- 
scanIterator
public ScanResult<Map.Entry<Object,Object>> scanIterator(String name, RedisClient client, long startPos, String pattern, int count)
 
- 
scanIteratorAsync
public RFuture<ScanResult<Map.Entry<Object,Object>>> scanIteratorAsync(String name, RedisClient client, long startPos, String pattern, int count)
 
- 
addAndGet
public V addAndGet(K key, Number value)
Description copied from interface:RMapAdds the givendeltato the current value by mappedkey. Works only for numeric values! 
- 
addAndGetAsync
public RFuture<V> addAndGetAsync(K key, Number value)
Description copied from interface:RMapAsyncAdds the givendeltato the current value by mappedkey. Works only for numeric values!- Specified by:
 addAndGetAsyncin interfaceRMapAsync<K,V>- Parameters:
 key- - map keyvalue- the value to add- Returns:
 - the updated value
 
 
- 
equals
public boolean equals(Object o)
 
- 
hashCode
public int hashCode()
 
- 
expire
public boolean expire(long timeToLive, TimeUnit timeUnit)Description copied from interface:RExpirableSet a timeout for object. After the timeout has expired, the key will automatically be deleted.- Specified by:
 expirein interfaceRExpirable- Parameters:
 timeToLive- - timeout before object will be deletedtimeUnit- - timeout time unit- Returns:
 trueif the timeout was set andfalseif not
 
- 
expireAsync
public RFuture<Boolean> expireAsync(long timeToLive, TimeUnit timeUnit)
Description copied from interface:RExpirableAsyncSet a timeout for object in async mode. After the timeout has expired, the key will automatically be deleted.- Specified by:
 expireAsyncin interfaceRExpirableAsync- Parameters:
 timeToLive- - timeout before object will be deletedtimeUnit- - timeout time unit- Returns:
 trueif the timeout was set andfalseif not
 
- 
expireAt
public boolean expireAt(long timestamp)
Description copied from interface:RExpirableUseRExpirable.expire(Instant)instead- Specified by:
 expireAtin interfaceRExpirable- Parameters:
 timestamp- - expire date in milliseconds (Unix timestamp)- Returns:
 trueif the timeout was set andfalseif not
 
- 
expireAtAsync
public RFuture<Boolean> expireAtAsync(long timestamp)
Description copied from interface:RExpirableAsyncUseRExpirableAsync.expireAsync(Instant)instead- Specified by:
 expireAtAsyncin interfaceRExpirableAsync- Parameters:
 timestamp- - expire date in milliseconds (Unix timestamp)- Returns:
 trueif the timeout was set andfalseif not
 
- 
expire
public boolean expire(Instant instant)
Description copied from interface:RExpirableSet an expire date for object. When expire date comes the key will automatically be deleted.- Specified by:
 expirein interfaceRExpirable- Parameters:
 instant- - expire date- Returns:
 trueif the timeout was set andfalseif not
 
- 
expireAsync
public RFuture<Boolean> expireAsync(Instant instant)
Description copied from interface:RExpirableAsyncSet an expire date for object. When expire date comes the key will automatically be deleted.- Specified by:
 expireAsyncin interfaceRExpirableAsync- Parameters:
 instant- - expire date- Returns:
 trueif the timeout was set andfalseif not
 
- 
expireAt
public boolean expireAt(Date timestamp)
Description copied from interface:RExpirableUseRExpirable.expire(Instant)instead- Specified by:
 expireAtin interfaceRExpirable- Parameters:
 timestamp- - expire date- Returns:
 trueif the timeout was set andfalseif not
 
- 
expireAtAsync
public RFuture<Boolean> expireAtAsync(Date timestamp)
Description copied from interface:RExpirableAsyncUseRExpirableAsync.expireAsync(Instant)instead- Specified by:
 expireAtAsyncin interfaceRExpirableAsync- Parameters:
 timestamp- - expire date- Returns:
 trueif the timeout was set andfalseif not
 
- 
clearExpire
public boolean clearExpire()
Description copied from interface:RExpirableClear an expire timeout or expire date for object.- Specified by:
 clearExpirein interfaceRExpirable- Returns:
 trueif timeout was removedfalseif object does not exist or does not have an associated timeout
 
- 
clearExpireAsync
public RFuture<Boolean> clearExpireAsync()
Description copied from interface:RExpirableAsyncClear an expire timeout or expire date for object in async mode. Object will not be deleted.- Specified by:
 clearExpireAsyncin interfaceRExpirableAsync- Returns:
 trueif the timeout was cleared andfalseif not
 
- 
remainTimeToLive
public long remainTimeToLive()
Description copied from interface:RExpirableRemaining time to live of Redisson object that has a timeout- Specified by:
 remainTimeToLivein interfaceRExpirable- Returns:
 - time in milliseconds -2 if the key does not exist. -1 if the key exists but has no associated expire.
 
 
- 
remainTimeToLiveAsync
public RFuture<Long> remainTimeToLiveAsync()
Description copied from interface:RExpirableAsyncRemaining time to live of Redisson object that has a timeout- Specified by:
 remainTimeToLiveAsyncin interfaceRExpirableAsync- Returns:
 - time in milliseconds -2 if the key does not exist. -1 if the key exists but has no associated expire.
 
 
- 
expireAsync
protected RFuture<Boolean> expireAsync(long timeToLive, TimeUnit timeUnit, String... keys)
 
 - 
 
 -