Package org.redisson.transaction
Class RedissonTransactionalMapCache<K,V>
- java.lang.Object
-
- org.redisson.RedissonObject
-
- org.redisson.RedissonMap<K,V>
-
- org.redisson.RedissonMapCache<K,V>
-
- org.redisson.transaction.RedissonTransactionalMapCache<K,V>
-
- Type Parameters:
K- key typeV- value type
- All Implemented Interfaces:
ConcurrentMap<K,V>,Map<K,V>,RDestroyable,RExpirable,RExpirableAsync,RMap<K,V>,RMapAsync<K,V>,RMapCache<K,V>,RMapCacheAsync<K,V>,RObject,RObjectAsync
public class RedissonTransactionalMapCache<K,V> extends RedissonMapCache<K,V>
- Author:
- Nikita Koksharov
-
-
Field Summary
-
Fields inherited from class org.redisson.RedissonObject
codec, commandExecutor, name
-
-
Constructor Summary
Constructors Constructor Description RedissonTransactionalMapCache(Codec codec, CommandAsyncExecutor commandExecutor, String name, List<TransactionalOperation> operations, long timeout, AtomicBoolean executed, String transactionId)RedissonTransactionalMapCache(CommandAsyncExecutor commandExecutor, String name, List<TransactionalOperation> operations, long timeout, AtomicBoolean executed, String transactionId)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected RFuture<V>addAndGetOperationAsync(K key, Number value)protected voidcheckState()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)RFuture<Boolean>containsKeyAsync(Object key)Returnstrueif this map contains map entry mapped by specifiedkey, otherwisefalseRFuture<Boolean>containsValueAsync(Object value)Returnstrueif this map contains any map entry with specifiedvalue, otherwisefalseRFuture<Boolean>deleteAsync()Delete object in async modebooleanexpire(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 timestamp)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)insteadRFuture<Boolean>expireAtAsync(Date timestamp)UseRExpirableAsync.expireAsync(Instant)insteadRFuture<Boolean>fastPutIfAbsentAsync(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit)If the specified key is not already associated with a value, associate it with the given value.protected RFuture<Boolean>fastPutIfAbsentOperationAsync(K key, V value)protected RFuture<Boolean>fastPutIfExistsOperationAsync(K key, V value)protected RFuture<Boolean>fastPutOperationAsync(K key, V value)RFuture<Boolean>fastPutOperationAsync(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit)protected RFuture<Long>fastRemoveOperationAsync(K... keys)RFuture<Map<K,V>>getAllOperationAsync(Set<K> keys)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 keyRFuture<Boolean>isExistsAsync()Check object existence in async mode.RFuture<Void>loadAllAsync(boolean replaceExistingValues, int parallelism)Loads all map entries to this Redis map usingMapLoader.RFuture<Void>loadAllAsync(Set<? extends K> keys, boolean replaceExistingValues, int parallelism)Loads map entries usingMapLoaderwhose keys are listed in definedkeysparameter.<KOut,VOut>
RMapReduce<K,V,KOut,VOut>mapReduce()ReturnsRMapReduceobject associated with this mapRFuture<Void>migrateAsync(String host, int port, int database, long timeout)Transfer object from source Redis instance to destination Redis instance in async modeRFuture<Boolean>moveAsync(int database)Move object to another database in async modeprotected RFuture<Void>putAllOperationAsync(Map<? extends K,? extends V> entries)RFuture<V>putIfAbsentAsync(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit)If the specified key is not already associated with a value, associate it with the given value.protected RFuture<V>putIfAbsentOperationAsync(K key, V value)protected RFuture<V>putIfExistsOperationAsync(K key, V value)protected RFuture<V>putOperationAsync(K key, V value)RFuture<V>putOperationAsync(K key, V value, long ttlTimeout, long maxIdleTimeout, long maxIdleDelta, long ttlTimeoutDelta)RFuture<Set<Map.Entry<K,V>>>readAllEntrySetAsync()Read all map entries at onceRFuture<Set<K>>readAllKeySetAsync()Read all keys at onceRFuture<Map<K,V>>readAllMapAsync()Read all map as local instance 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 timeoutprotected RFuture<Boolean>removeOperationAsync(Object key, Object value)protected RFuture<V>removeOperationAsync(K key)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<Void>setMaxSizeAsync(int maxSize)Sets max size of the map and overrides current value.RFuture<Boolean>touchAsync()Update the last access time of an object in async mode.RFuture<Boolean>trySetMaxSizeAsync(int maxSize)Tries to set max size of the map.RFuture<Boolean>unlinkAsync()Delete the objects.RFuture<Integer>valueSizeAsync(K key)Returns size of value mapped by key in bytes-
Methods inherited from class org.redisson.RedissonMapCache
addAndGet, addListener, clear, destroy, expireAtAsync, fastPut, fastPut, fastPutAsync, fastPutAsync, fastPutIfAbsent, fastPutIfAbsent, fastRemoveOperationBatchAsync, fastReplaceOperationAsync, getWithTTLOnly, getWithTTLOnlyAsync, put, put, putAll, putAllAsync, putAsync, putAsync, putIfAbsent, putIfAbsent, putIfAbsentAsync, randomEntriesAsync, randomKeysAsync, remainTimeToLive, remainTimeToLiveAsync, removeListener, scanIteratorAsync, setMaxSize, setMaxSize, setMaxSizeAsync, sizeInMemoryAsync, trySetMaxSize, trySetMaxSize, trySetMaxSizeAsync, updateEntryExpiration, updateEntryExpirationAsync
-
Methods inherited from class org.redisson.RedissonMap
addAndGetAsync, checkKey, checkValue, compute, computeAsync, computeIfAbsent, computeIfAbsentAsync, computeIfPresent, computeIfPresentAsync, containsKey, containsKeyAsync, containsValue, entryIterator, entrySet, entrySet, entrySet, entrySet, equals, fastPut, fastPutAsync, fastPutIfAbsent, fastPutIfAbsentAsync, fastPutIfExists, fastPutIfExistsAsync, fastRemove, fastRemoveAsync, fastReplace, fastReplaceAsync, get, getAll, getAllAsync, getAsync, hashCode, hasNoLoader, hasNoWriter, isEmpty, keyIterator, keySet, keySet, keySet, keySet, loadAll, loadAll, loadAllAsync, loadValue, mapWriterFuture, mapWriterFuture, merge, mergeAsync, put, putAll, putAll, putAllAsync, putAllAsync, putAsync, putIfAbsent, putIfAbsentAsync, putIfExists, putIfExistsAsync, randomEntries, randomKeys, readAllEntrySet, readAllKeySet, readAllMap, readAllValues, remove, remove, removeAsync, removeAsync, replace, replace, replaceAsync, replaceAsync, size, sizeAsync, valueIterator, values, values, values, values, valueSize
-
Methods inherited from class org.redisson.RedissonObject
addListener, addListener, addListenerAsync, addListenerAsync, copy, copyAsync, delete, deleteAsync, dump, dumpAsync, encode, encode, encode, encode, encodeMapKey, encodeMapKeys, encodeMapValue, encodeMapValues, get, getCodec, getIdleTime, getIdleTimeAsync, getLockByMapKey, getLockByValue, getName, getRawName, getRawName, isExists, migrate, move, prefixName, removeListenerAsync, removeListenersAsync, rename, renameAsync, renamenx, renamenxAsync, restore, restore, restoreAndReplace, restoreAndReplace, restoreAndReplaceAsync, restoreAndReplaceAsync, restoreAsync, restoreAsync, setName, sizeInMemory, sizeInMemoryAsync, sizeInMemoryAsync, suffixName, toSeconds, toStream, touch, unlink
-
Methods inherited from class java.lang.Object
clone, finalize, getClass, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface java.util.concurrent.ConcurrentMap
compute, computeIfAbsent, computeIfPresent, forEach, getOrDefault, merge, replaceAll
-
Methods inherited from interface org.redisson.api.RExpirable
clearExpire, expire, expire, expireAt, expireAt, remainTimeToLive
-
Methods inherited from interface org.redisson.api.RMap
containsKey, containsValue, entrySet, entrySet, entrySet, entrySet, fastPut, fastPutIfAbsent, fastPutIfExists, fastRemove, fastReplace, get, getAll, keySet, keySet, keySet, keySet, loadAll, loadAll, put, putAll, putAll, putIfAbsent, putIfExists, randomEntries, randomKeys, readAllEntrySet, readAllKeySet, readAllMap, readAllValues, remove, remove, replace, replace, values, values, values, values, valueSize
-
Methods inherited from interface org.redisson.api.RMapAsync
addAndGetAsync, computeAsync, computeIfAbsentAsync, computeIfPresentAsync, fastPutAsync, fastPutIfAbsentAsync, fastPutIfExistsAsync, fastRemoveAsync, fastReplaceAsync, getAllAsync, getAsync, mergeAsync, putAllAsync, putAllAsync, putAsync, putIfAbsentAsync, putIfExistsAsync, removeAsync, removeAsync, replaceAsync, replaceAsync
-
Methods inherited from interface org.redisson.api.RMapCacheAsync
sizeAsync
-
Methods inherited from interface org.redisson.api.RObject
addListener, copy, delete, dump, getCodec, getIdleTime, getName, isExists, migrate, move, rename, renamenx, restore, restore, restoreAndReplace, restoreAndReplace, sizeInMemory, touch, unlink
-
Methods inherited from interface org.redisson.api.RObjectAsync
addListenerAsync, copyAsync, dumpAsync, getIdleTimeAsync, removeListenerAsync, renameAsync, renamenxAsync, restoreAndReplaceAsync, restoreAndReplaceAsync, restoreAsync, restoreAsync
-
-
-
-
Constructor Detail
-
RedissonTransactionalMapCache
public RedissonTransactionalMapCache(CommandAsyncExecutor commandExecutor, String name, List<TransactionalOperation> operations, long timeout, AtomicBoolean executed, String transactionId)
-
RedissonTransactionalMapCache
public RedissonTransactionalMapCache(Codec codec, CommandAsyncExecutor commandExecutor, String name, List<TransactionalOperation> operations, long timeout, AtomicBoolean executed, String transactionId)
-
-
Method Detail
-
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- Overrides:
expireAsyncin classRedissonMapCache<K,V>- Parameters:
timeToLive- - timeout before object will be deletedtimeUnit- - timeout time unit- 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
-
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
-
expireAsync
public RFuture<Boolean> expireAsync(Instant timestamp)
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:
timestamp- - expire date- Returns:
trueif the timeout was set andfalseif not
-
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- Overrides:
clearExpireAsyncin classRedissonMapCache<K,V>- Returns:
trueif the timeout was cleared andfalseif not
-
moveAsync
public RFuture<Boolean> moveAsync(int database)
Description copied from interface:RObjectAsyncMove object to another database in async mode- Specified by:
moveAsyncin interfaceRObjectAsync- Overrides:
moveAsyncin classRedissonObject- Parameters:
database- - number of Redis database- Returns:
trueif key was movedfalseif not
-
migrateAsync
public RFuture<Void> migrateAsync(String host, int port, int database, long timeout)
Description copied from interface:RObjectAsyncTransfer object from source Redis instance to destination Redis instance in async mode- Specified by:
migrateAsyncin interfaceRObjectAsync- Overrides:
migrateAsyncin classRedissonObject- Parameters:
host- - destination hostport- - destination portdatabase- - destination databasetimeout- - maximum idle time in any moment of the communication with the destination instance in milliseconds- Returns:
- void
-
touchAsync
public RFuture<Boolean> touchAsync()
Description copied from interface:RObjectAsyncUpdate the last access time of an object in async mode.- Specified by:
touchAsyncin interfaceRObjectAsync- Overrides:
touchAsyncin classRedissonObject- Returns:
trueif object was touched elsefalse
-
isExistsAsync
public RFuture<Boolean> isExistsAsync()
Description copied from interface:RObjectAsyncCheck object existence in async mode.- Specified by:
isExistsAsyncin interfaceRObjectAsync- Overrides:
isExistsAsyncin classRedissonObject- Returns:
trueif object exists andfalseotherwise
-
unlinkAsync
public RFuture<Boolean> unlinkAsync()
Description copied from interface:RObjectAsyncDelete the objects. Actual removal will happen later asynchronously.Requires Redis 4.0+
- Specified by:
unlinkAsyncin interfaceRObjectAsync- Overrides:
unlinkAsyncin classRedissonObject- Returns:
trueif it was exist and deleted elsefalse
-
deleteAsync
public RFuture<Boolean> deleteAsync()
Description copied from interface:RObjectAsyncDelete object in async mode- Specified by:
deleteAsyncin interfaceRObjectAsync- Overrides:
deleteAsyncin classRedissonMapCache<K,V>- Returns:
trueif object was deletedfalseif not
-
putIfAbsentAsync
public RFuture<V> putIfAbsentAsync(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit)
Description copied from interface:RMapCacheAsyncIf the specified key is not already associated with a value, associate it with the given value.Stores value mapped by key with specified time to live and max idle time. Entry expires when specified time to live or max idle time has expired.
If the map previously contained a mapping for the key, the old value is replaced by the specified value.
- Specified by:
putIfAbsentAsyncin interfaceRMapCacheAsync<K,V>- Overrides:
putIfAbsentAsyncin classRedissonMapCache<K,V>- Parameters:
key- - map keyvalue- - map valuettl- - time to live for key\value entry. If0then time to live doesn't affect entry expiration.ttlUnit- - time unitmaxIdleTime- - max idle time for key\value entry. If0then max idle time doesn't affect entry expiration.maxIdleUnit- - time unitif
maxIdleTimeandttlparams are equal to0then entry stores infinitely.- Returns:
- previous associated value
-
fastPutOperationAsync
public RFuture<Boolean> fastPutOperationAsync(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit)
- Overrides:
fastPutOperationAsyncin classRedissonMapCache<K,V>
-
putOperationAsync
public RFuture<V> putOperationAsync(K key, V value, long ttlTimeout, long maxIdleTimeout, long maxIdleDelta, long ttlTimeoutDelta)
- Overrides:
putOperationAsyncin classRedissonMapCache<K,V>
-
fastPutIfAbsentAsync
public RFuture<Boolean> fastPutIfAbsentAsync(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit)
Description copied from interface:RMapCacheAsyncIf the specified key is not already associated with a value, associate it with the given value.Stores value mapped by key with specified time to live and max idle time. Entry expires when specified time to live or max idle time has expired.
Works faster than usual
RMapCacheAsync.putIfAbsentAsync(Object, Object, long, TimeUnit, long, TimeUnit)as it not returns previous value.- Specified by:
fastPutIfAbsentAsyncin interfaceRMapCacheAsync<K,V>- Overrides:
fastPutIfAbsentAsyncin classRedissonMapCache<K,V>- Parameters:
key- - map keyvalue- - map valuettl- - time to live for key\value entry. If0then time to live doesn't affect entry expiration.ttlUnit- - time unitmaxIdleTime- - max idle time for key\value entry. If0then max idle time doesn't affect entry expiration.maxIdleUnit- - time unitif
maxIdleTimeandttlparams are equal to0then entry stores infinitely.- Returns:
trueif key is a new key in the hash and value was set.falseif key already exists in the hash
-
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.
-
setMaxSizeAsync
public RFuture<Void> setMaxSizeAsync(int maxSize)
Description copied from interface:RMapCacheAsyncSets max size of the map and overrides current value. Superfluous elements are evicted using LRU algorithm by default.- Specified by:
setMaxSizeAsyncin interfaceRMapCacheAsync<K,V>- Overrides:
setMaxSizeAsyncin classRedissonMapCache<K,V>- Parameters:
maxSize- - max size- Returns:
- void
-
trySetMaxSizeAsync
public RFuture<Boolean> trySetMaxSizeAsync(int maxSize)
Description copied from interface:RMapCacheAsyncTries to set max size of the map. Superfluous elements are evicted using LRU algorithm by default.- Specified by:
trySetMaxSizeAsyncin interfaceRMapCacheAsync<K,V>- Overrides:
trySetMaxSizeAsyncin classRedissonMapCache<K,V>- Parameters:
maxSize- - max size- Returns:
trueif max size has been successfully set, otherwisefalse.
-
mapReduce
public <KOut,VOut> RMapReduce<K,V,KOut,VOut> mapReduce()
Description copied from interface:RMapReturnsRMapReduceobject associated with this map
-
scanIterator
public ScanResult<Map.Entry<Object,Object>> scanIterator(String name, RedisClient client, long startPos, String pattern, int count)
- Overrides:
scanIteratorin classRedissonMapCache<K,V>
-
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>- Overrides:
containsKeyAsyncin classRedissonMapCache<K,V>- Parameters:
key- - map key- Returns:
trueif this map contains map entry mapped by specifiedkey, 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>- Overrides:
containsValueAsyncin classRedissonMapCache<K,V>- Parameters:
value- - map value- Returns:
trueif this map contains any map entry with specifiedvalue, otherwisefalse
-
addAndGetOperationAsync
protected RFuture<V> addAndGetOperationAsync(K key, Number value)
- Overrides:
addAndGetOperationAsyncin classRedissonMapCache<K,V>
-
fastPutIfExistsOperationAsync
protected RFuture<Boolean> fastPutIfExistsOperationAsync(K key, V value)
- Overrides:
fastPutIfExistsOperationAsyncin classRedissonMapCache<K,V>
-
putIfExistsOperationAsync
protected RFuture<V> putIfExistsOperationAsync(K key, V value)
- Overrides:
putIfExistsOperationAsyncin classRedissonMapCache<K,V>
-
putIfAbsentOperationAsync
protected RFuture<V> putIfAbsentOperationAsync(K key, V value)
- Overrides:
putIfAbsentOperationAsyncin classRedissonMapCache<K,V>
-
putOperationAsync
protected RFuture<V> putOperationAsync(K key, V value)
- Overrides:
putOperationAsyncin classRedissonMapCache<K,V>
-
fastPutIfAbsentOperationAsync
protected RFuture<Boolean> fastPutIfAbsentOperationAsync(K key, V value)
- Overrides:
fastPutIfAbsentOperationAsyncin classRedissonMapCache<K,V>
-
fastPutOperationAsync
protected RFuture<Boolean> fastPutOperationAsync(K key, V value)
- Overrides:
fastPutOperationAsyncin classRedissonMapCache<K,V>
-
fastRemoveOperationAsync
protected RFuture<Long> fastRemoveOperationAsync(K... keys)
- Overrides:
fastRemoveOperationAsyncin classRedissonMapCache<K,V>
-
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>- Overrides:
valueSizeAsyncin classRedissonMap<K,V>- Parameters:
key- - map key- Returns:
- size of value
-
getOperationAsync
public RFuture<V> getOperationAsync(K key)
- Overrides:
getOperationAsyncin classRedissonMapCache<K,V>
-
readAllKeySetAsync
public RFuture<Set<K>> readAllKeySetAsync()
Description copied from interface:RMapAsyncRead all keys at once- Specified by:
readAllKeySetAsyncin interfaceRMapAsync<K,V>- Overrides:
readAllKeySetAsyncin classRedissonMapCache<K,V>- Returns:
- keys
-
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>- Overrides:
readAllEntrySetAsyncin classRedissonMapCache<K,V>- Returns:
- entries
-
readAllValuesAsync
public RFuture<Collection<V>> readAllValuesAsync()
Description copied from interface:RMapAsyncRead all values at once- Specified by:
readAllValuesAsyncin interfaceRMapAsync<K,V>- Overrides:
readAllValuesAsyncin classRedissonMapCache<K,V>- Returns:
- values
-
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>- Overrides:
readAllMapAsyncin classRedissonMapCache<K,V>- Returns:
- map
-
getAllOperationAsync
public RFuture<Map<K,V>> getAllOperationAsync(Set<K> keys)
- Overrides:
getAllOperationAsyncin classRedissonMapCache<K,V>
-
removeOperationAsync
protected RFuture<V> removeOperationAsync(K key)
- Overrides:
removeOperationAsyncin classRedissonMapCache<K,V>
-
removeOperationAsync
protected RFuture<Boolean> removeOperationAsync(Object key, Object value)
- Overrides:
removeOperationAsyncin classRedissonMapCache<K,V>
-
putAllOperationAsync
protected RFuture<Void> putAllOperationAsync(Map<? extends K,? extends V> entries)
- Overrides:
putAllOperationAsyncin classRedissonMapCache<K,V>
-
replaceOperationAsync
protected RFuture<Boolean> replaceOperationAsync(K key, V oldValue, V newValue)
- Overrides:
replaceOperationAsyncin classRedissonMapCache<K,V>
-
replaceOperationAsync
protected RFuture<V> replaceOperationAsync(K key, V value)
- Overrides:
replaceOperationAsyncin classRedissonMapCache<K,V>
-
checkState
protected void checkState()
-
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>- Overrides:
loadAllAsyncin classRedissonMap<K,V>- Parameters:
replaceExistingValues- -trueif existed values should be replaced,falseotherwise.parallelism- - parallelism level, used to increase speed of process execution- Returns:
- void
-
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>- Overrides:
loadAllAsyncin classRedissonMap<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
-
getFairLock
public RLock getFairLock(K key)
Description copied from interface:RMapReturnsRLockinstance associated with key- Specified by:
getFairLockin interfaceRMap<K,V>- Overrides:
getFairLockin classRedissonMap<K,V>- Parameters:
key- - map key- Returns:
- fairlock
-
getCountDownLatch
public RCountDownLatch getCountDownLatch(K key)
Description copied from interface:RMapReturnsRCountDownLatchinstance associated with key- Specified by:
getCountDownLatchin interfaceRMap<K,V>- Overrides:
getCountDownLatchin classRedissonMap<K,V>- Parameters:
key- - map key- Returns:
- countdownlatch
-
getPermitExpirableSemaphore
public RPermitExpirableSemaphore getPermitExpirableSemaphore(K key)
Description copied from interface:RMapReturnsRPermitExpirableSemaphoreinstance associated with key- Specified by:
getPermitExpirableSemaphorein interfaceRMap<K,V>- Overrides:
getPermitExpirableSemaphorein classRedissonMap<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>- Overrides:
getSemaphorein classRedissonMap<K,V>- Parameters:
key- - map key- Returns:
- semaphore
-
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>- Overrides:
getReadWriteLockin classRedissonMap<K,V>- Parameters:
key- - map key- Returns:
- readWriteLock
-
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
-
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
-
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
-
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
-
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
-
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.
-
expireAsync
protected RFuture<Boolean> expireAsync(long timeToLive, TimeUnit timeUnit, String... keys)
-
-