Uses of Interface
org.redisson.api.RFuture
Package
Description
-
Uses of RFuture in org.redisson
Modifier and TypeMethodDescriptionRedissonStream.ackAsync
(String groupName, StreamMessageId... ids) RedissonPermitExpirableSemaphore.acquireAsync()
RedissonPermitExpirableSemaphore.acquireAsync
(long leaseTime, TimeUnit timeUnit) RedissonRateLimiter.acquireAsync()
RedissonRateLimiter.acquireAsync
(long permits) RedissonSemaphore.acquireAsync()
RedissonSemaphore.acquireAsync
(int permits) RedissonList.addAfterAsync
(V elementToFind, V element) RedissonListMultimapValues.addAfterAsync
(V elementToFind, V element) RedissonBoundedBlockingQueue.addAllAsync
(Collection<? extends V> c) RedissonDelayedQueue.addAllAsync
(Collection<? extends V> c) RedissonHyperLogLog.addAllAsync
(Collection<V> objects) RedissonLexSortedSet.addAllAsync
(Collection<? extends String> c) RedissonList.addAllAsync
(int index, Collection<? extends V> coll) RedissonList.addAllAsync
(Collection<? extends V> c) RedissonListMultimapValues.addAllAsync
(int index, Collection<? extends V> coll) RedissonListMultimapValues.addAllAsync
(Collection<? extends V> c) RedissonRingBuffer.addAllAsync
(Collection<? extends V> c) RedissonScoredSortedSet.addAllAsync
(Map<V, Double> objects) RedissonSet.addAllAsync
(Collection<? extends V> c) RedissonSetCache.addAllAsync
(Collection<? extends V> c) RedissonSetMultimapValues.addAllAsync
(Collection<? extends V> c) RedissonStream.addAllAsync
(Map<K, V> entries) RedissonStream.addAllAsync
(Map<K, V> entries, int trimLen, boolean trimStrict) RedissonStream.addAllAsync
(StreamMessageId id, Map<K, V> entries) RedissonStream.addAllAsync
(StreamMessageId id, Map<K, V> entries, int trimLen, boolean trimStrict) RedissonSubList.addAllAsync
(int index, Collection<? extends V> coll) RedissonSubList.addAllAsync
(Collection<? extends V> c) RedissonTimeSeries.addAllAsync
(Collection<TimeSeriesEntry<V, L>> entries) RedissonTimeSeries.addAllAsync
(Collection<TimeSeriesEntry<V, L>> entries, Duration timeToLive) RedissonTimeSeries.addAllAsync
(Map<Long, V> objects) RedissonTimeSeries.addAllAsync
(Map<Long, V> objects, long timeToLive, TimeUnit timeUnit) RedissonTransferQueue.addAllAsync
(Collection<? extends V> c) RedissonSet.addAllCountedAsync
(Collection<? extends V> c) RedissonSetMultimapValues.addAllCountedAsync
(Collection<? extends V> c) RedissonScoredSortedSet.addAllIfAbsentAsync
(Map<V, Double> objects) RedissonScoredSortedSet.addAllIfExistAsync
(Map<V, Double> objects) RedissonScoredSortedSet.addAllIfGreaterAsync
(Map<V, Double> objects) RedissonScoredSortedSet.addAllIfLessAsync
(Map<V, Double> objects) RedissonAtomicDouble.addAndGetAsync
(double delta) RedissonAtomicLong.addAndGetAsync
(long delta) RedissonBaseAdder.addAndGetAsync
(String id) RedissonDoubleAdder.addAndGetAsync
(String id) RedissonLongAdder.addAndGetAsync
(String id) RedissonMap.addAndGetAsync
(K key, Number value) RedissonLocalCachedMap.addAndGetOperationAsync
(K key, Number value) RedissonMap.addAndGetOperationAsync
(K key, Number value) RedissonMapCache.addAndGetOperationAsync
(K key, Number value) RedissonScoredSortedSet.addAndGetRankAsync
(double score, V object) RedissonScoredSortedSet.addAndGetRevRankAsync
(double score, V object) RedissonScoredSortedSet.addAndGetRevRankAsync
(Map<? extends V, Double> map) protected <T> RFuture<T>
RedissonList.addAsync
(V e, RedisCommand<T> command) RedissonStream.addAsync
(StreamAddArgs<K, V> args) RedissonStream.addAsync
(StreamMessageId id, K key, V value) RedissonStream.addAsync
(StreamMessageId id, K key, V value, int trimLen, boolean trimStrict) RedissonStream.addAsync
(StreamMessageId id, StreamAddArgs<K, V> args) RedissonList.addBeforeAsync
(V elementToFind, V element) RedissonListMultimapValues.addBeforeAsync
(V elementToFind, V element) <R> RFuture<R>
RedissonStream.addCustomAsync
(StreamMessageId id, StreamAddArgs<K, V> args) RedissonDeque.addFirstAsync
(V e) RedissonDeque.addFirstAsync
(V... elements) RedissonPriorityDeque.addFirstAsync
(V e) RedissonPriorityDeque.addFirstAsync
(V... elements) RedissonDeque.addFirstIfExistsAsync
(V... elements) RedissonPriorityDeque.addFirstIfExistsAsync
(V... elements) RedissonScoredSortedSet.addIfAbsentAsync
(double score, V object) RedissonGeo.addIfExistsAsync
(double longitude, double latitude, V member) RedissonGeo.addIfExistsAsync
(GeoEntry... entries) RedissonScoredSortedSet.addIfExistsAsync
(double score, V object) RedissonScoredSortedSet.addIfGreaterAsync
(double score, V object) RedissonScoredSortedSet.addIfLessAsync
(double score, V object) RedissonDeque.addLastAsync
(V e) RedissonDeque.addLastAsync
(V... elements) RedissonPriorityDeque.addLastAsync
(V e) RedissonPriorityDeque.addLastAsync
(V... elements) RedissonDeque.addLastIfExistsAsync
(V... elements) RedissonPriorityDeque.addLastIfExistsAsync
(V... elements) RedissonBucket.addListenerAsync
(ObjectListener listener) RedissonList.addListenerAsync
(ObjectListener listener) protected final <T extends ObjectListener>
RFuture<Integer>RedissonObject.addListenerAsync
(String name, T listener, BiConsumer<T, String> consumer) RedissonObject.addListenerAsync
(ObjectListener listener) RedissonPatternTopic.addListenerAsync
(Class<T> type, PatternMessageListener<T> listener) RedissonPatternTopic.addListenerAsync
(PatternStatusListener listener) RedissonReliableTopic.addListenerAsync
(Class<M> type, MessageListener<M> listener) RedissonScoredSortedSet.addListenerAsync
(ObjectListener listener) RedissonShardedTopic.addListenerAsync
(RedisPubSubListener<?> pubSubListener) RedissonTopic.addListenerAsync
(Class<M> type, MessageListener<M> listener) RedissonTopic.addListenerAsync
(StatusListener listener) RedissonTopic.addListenerAsync
(RedisPubSubListener<?> pubSubListener) RedissonPermitExpirableSemaphore.addPermitsAsync
(int permits) RedissonSemaphore.addPermitsAsync
(int permits) RedissonScoredSortedSet.addScoreAndGetRankAsync
(V object, Number value) RedissonScoredSortedSet.addScoreAndGetRevRankAsync
(V object, Number value) RedissonScoredSortedSet.addScoreAsync
(V object, Number value) RedissonJsonBucket.arrayAppendAsync
(String path, Object... values) RedissonJsonBucket.arrayAppendMultiAsync
(String path, Object... values) RedissonJsonBucket.arrayIndexAsync
(String path, Object value) RedissonJsonBucket.arrayIndexAsync
(String path, Object value, long start, long end) RedissonJsonBucket.arrayIndexMultiAsync
(String path, Object value) RedissonJsonBucket.arrayIndexMultiAsync
(String path, Object value, long start, long end) RedissonJsonBucket.arrayInsertAsync
(String path, long index, Object... values) RedissonJsonBucket.arrayInsertMultiAsync
(String path, long index, Object... values) <T> RFuture<T>
RedissonJsonBucket.arrayPollFirstAsync
(JsonCodec<T> codec, String path) RedissonJsonBucket.arrayPollFirstMultiAsync
(JsonCodec<T> codec, String path) <T> RFuture<T>
RedissonJsonBucket.arrayPollLastAsync
(JsonCodec<T> codec, String path) RedissonJsonBucket.arrayPollLastMultiAsync
(JsonCodec<T> codec, String path) <T> RFuture<T>
RedissonJsonBucket.arrayPopAsync
(JsonCodec<T> codec, String path, long index) RedissonJsonBucket.arrayPopMultiAsync
(JsonCodec<T> codec, String path, long index) RedissonJsonBucket.arraySizeAsync
(String path) RedissonJsonBucket.arraySizeMultiAsync
(String path) RedissonJsonBucket.arrayTrimAsync
(String path, long start, long end) RedissonJsonBucket.arrayTrimMultiAsync
(String path, long start, long end) RedissonStream.autoClaimAsync
(String groupName, String consumerName, long idleTime, TimeUnit idleTimeUnit, StreamMessageId startId, int count) RedissonPermitExpirableSemaphore.availablePermitsAsync()
RedissonRateLimiter.availablePermitsAsync()
RedissonSemaphore.availablePermitsAsync()
RedissonCountDownLatch.awaitAsync()
RedissonCountDownLatch.awaitAsync
(long waitTime, TimeUnit unit) <R> RFuture<R>
RedissonFuction.callAsync
(String key, FunctionMode mode, String name, FunctionResult returnType, List<Object> keys, Object... values) <R> RFuture<R>
RedissonFuction.callAsync
(FunctionMode mode, String name, FunctionResult returnType) <R> RFuture<R>
RedissonFuction.callAsync
(FunctionMode mode, String name, FunctionResult returnType, List<Object> keys, Object... values) RedissonExecutorService.cancelTaskAsync
(String taskId) RedissonRingBuffer.capacityAsync()
RedissonBitSet.cardinalityAsync()
RedissonStream.claimAsync
(String groupName, String consumerName, long idleTime, TimeUnit idleTimeUnit, StreamMessageId... ids) RedissonBitSet.clearAsync()
RedissonBitSet.clearAsync
(long bitIndex) RedissonBitSet.clearAsync
(long fromIndex, long toIndex) RedissonJsonBucket.clearAsync()
RedissonJsonBucket.clearAsync
(String path) RedissonTransferQueue.clearAsync()
RedissonBloomFilter.clearExpireAsync()
RedissonBoundedBlockingQueue.clearExpireAsync()
RedissonDelayedQueue.clearExpireAsync()
RedissonFairLock.clearExpireAsync()
RedissonIdGenerator.clearExpireAsync()
RedissonKeys.clearExpireAsync
(String name) RedissonListMultimapCache.clearExpireAsync()
RedissonListMultimapValues.clearExpireAsync()
RedissonMapCache.clearExpireAsync()
RedissonMultimap.clearExpireAsync()
RedissonMultimapCache.clearExpireAsync()
RedissonPermitExpirableSemaphore.clearExpireAsync()
RedissonPriorityQueue.clearExpireAsync()
RedissonRateLimiter.clearExpireAsync()
RedissonReliableTopic.clearExpireAsync()
RedissonSetMultimapCache.clearExpireAsync()
RedissonSetMultimapValues.clearExpireAsync()
RedissonTimeSeries.clearExpireAsync()
RedissonLocalCachedMap.clearLocalCacheAsync()
RedissonAtomicDouble.compareAndSetAsync
(double expect, double update) RedissonAtomicLong.compareAndSetAsync
(long expect, long update) RedissonBucket.compareAndSetAsync
(V expect, V update) RedissonJsonBucket.compareAndSetAsync
(String path, Object expect, Object update) RedissonJsonBucket.compareAndSetAsync
(V expect, V update) RedissonJsonBucket.compareAndSetUpdateAsync
(String path, Object expect, Object update) RedissonMap.computeAsync
(K key, BiFunction<? super K, ? super V, ? extends V> remappingFunction) RedissonMap.computeIfAbsentAsync
(K key, Function<? super K, ? extends V> mappingFunction) RedissonMap.computeIfPresentAsync
(K key, BiFunction<? super K, ? super V, ? extends V> remappingFunction) RedissonDelayedQueue.containsAllAsync
(Collection<?> c) RedissonList.containsAllAsync
(Collection<?> c) RedissonListMultimapValues.containsAllAsync
(Collection<?> c) RedissonScoredSortedSet.containsAllAsync
(Collection<?> c) RedissonSet.containsAllAsync
(Collection<?> c) RedissonSetCache.containsAllAsync
(Collection<?> c) RedissonSetMultimapValues.containsAllAsync
(Collection<?> c) RedissonSubList.containsAllAsync
(Collection<?> c) RedissonTransferQueue.containsAllAsync
(Collection<?> c) RedissonDelayedQueue.containsAsync
(Object o) RedissonList.containsAsync
(Object o) RedissonListMultimapValues.containsAsync
(Object o) RedissonScoredSortedSet.containsAsync
(Object o) RedissonSet.containsAsync
(Object o) RedissonSetCache.containsAsync
(Object o) RedissonSetMultimapValues.containsAsync
(Object o) RedissonTransferQueue.containsAsync
(Object o) RedissonListMultimap.containsEntryAsync
(Object key, Object value) RedissonListMultimapCache.containsEntryAsync
(Object key, Object value) RedissonSetMultimap.containsEntryAsync
(Object key, Object value) RedissonSetMultimapCache.containsEntryAsync
(Object key, Object value) RedissonListMultimap.containsKeyAsync
(Object key) RedissonListMultimapCache.containsKeyAsync
(Object key) RedissonLocalCachedMap.containsKeyAsync
(Object key) RedissonMap.containsKeyAsync
(Object key) RedissonMap.containsKeyAsync
(Object key, CompletableFuture<V> promise) RedissonSetMultimap.containsKeyAsync
(Object key) RedissonSetMultimapCache.containsKeyAsync
(Object key) RedissonMap.containsKeyOperationAsync
(String name, Object key) RedissonMapCache.containsKeyOperationAsync
(String name, Object key) RedissonListMultimap.containsValueAsync
(Object value) RedissonListMultimapCache.containsValueAsync
(Object value) RedissonLocalCachedMap.containsValueAsync
(Object value) RedissonMap.containsValueAsync
(Object value) RedissonMapCache.containsValueAsync
(Object value) RedissonSetMultimap.containsValueAsync
(Object value) RedissonSetMultimapCache.containsValueAsync
(Object value) RedissonHyperLogLog.countAsync()
RedissonKeys.countAsync()
RedissonLexSortedSet.countAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive) RedissonScoredSortedSet.countAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) RedissonCountDownLatch.countDownAsync()
RedissonKeys.countExistsAsync
(String... names) RedissonLexSortedSet.countHeadAsync
(String toElement, boolean toInclusive) RedissonScoredSortedSet.countIntersectionAsync
(int limit, String... names) RedissonScoredSortedSet.countIntersectionAsync
(String... names) RedissonSet.countIntersectionAsync
(int limit, String... names) RedissonSet.countIntersectionAsync
(String... names) RedissonSetMultimapValues.countIntersectionAsync
(int limit, String... names) RedissonSetMultimapValues.countIntersectionAsync
(String... names) RedissonJsonBucket.countKeysAsync()
RedissonJsonBucket.countKeysAsync
(String path) RedissonJsonBucket.countKeysMultiAsync
(String path) RedissonReliableTopic.countSubscribersAsync()
RedissonShardedTopic.countSubscribersAsync()
RedissonTopic.countSubscribersAsync()
RedissonLexSortedSet.countTailAsync
(String fromElement, boolean fromInclusive) RedissonHyperLogLog.countWithAsync
(String... otherLogNames) RedissonStream.createConsumerAsync
(String groupName, String consumerName) RedissonStream.createGroupAsync
(String groupName) RedissonStream.createGroupAsync
(String groupName, StreamMessageId id) RedissonAtomicDouble.decrementAndGetAsync()
RedissonAtomicLong.decrementAndGetAsync()
RedissonLiveObjectService.delete
(Object id, Class<?> entityClass, NamingScheme namingScheme, CommandBatchService ce) RedissonBaseLock.deleteAsync()
RedissonBloomFilter.deleteAsync()
RedissonBoundedBlockingQueue.deleteAsync()
RedissonCountDownLatch.deleteAsync()
RedissonDelayedQueue.deleteAsync()
RedissonExecutorService.deleteAsync()
RedissonFairLock.deleteAsync()
RedissonFuction.deleteAsync
(String libraryName) RedissonIdGenerator.deleteAsync()
RedissonJsonBucket.deleteAsync()
RedissonJsonBucket.deleteAsync
(String path) RedissonKeys.deleteAsync
(String... keys) RedissonKeys.deleteAsync
(RObject... objects) RedissonListMultimapCache.deleteAsync()
RedissonListMultimapValues.deleteAsync()
RedissonLocalCachedMap.deleteAsync()
RedissonMapCache.deleteAsync()
RedissonMultimap.deleteAsync()
RedissonMultimapCache.deleteAsync()
RedissonObject.deleteAsync()
RedissonObject.deleteAsync
(String... keys) RedissonPermitExpirableSemaphore.deleteAsync()
RedissonPriorityQueue.deleteAsync()
RedissonRateLimiter.deleteAsync()
RedissonReliableTopic.deleteAsync()
RedissonSetMultimapCache.deleteAsync()
RedissonSetMultimapValues.deleteAsync()
RedissonTimeSeries.deleteAsync()
RedissonKeys.deleteByPatternAsync
(String pattern) RedissonBatch.discardAsync()
RedissonSemaphore.drainPermitsAsync()
RedissonBlockingDeque.drainToAsync
(Collection<? super V> c) RedissonBlockingDeque.drainToAsync
(Collection<? super V> c, int maxElements) RedissonBlockingQueue.drainToAsync
(Collection<? super V> c) RedissonBlockingQueue.drainToAsync
(Collection<? super V> c, int maxElements) RedissonBoundedBlockingQueue.drainToAsync
(Collection<? super V> c) RedissonBoundedBlockingQueue.drainToAsync
(Collection<? super V> c, int maxElements) RedissonPriorityBlockingDeque.drainToAsync
(Collection<? super V> c) RedissonPriorityBlockingDeque.drainToAsync
(Collection<? super V> c, int maxElements) RedissonPriorityBlockingQueue.drainToAsync
(Collection<? super V> c) RedissonPriorityBlockingQueue.drainToAsync
(Collection<? super V> c, int maxElements) RedissonTransferQueue.drainToAsync
(Collection<? super V> c) RedissonTransferQueue.drainToAsync
(Collection<? super V> c, int maxElements) RFuture<byte[]>
RedissonFuction.dumpAsync()
RFuture<byte[]>
RedissonObject.dumpAsync()
RedissonScoredSortedSet.entryRangeAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) RedissonScoredSortedSet.entryRangeAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) RedissonScoredSortedSet.entryRangeAsync
(int startIndex, int endIndex) RedissonTimeSeries.entryRangeAsync
(long startTimestamp, long endTimestamp) RedissonTimeSeries.entryRangeAsync
(long startTimestamp, long endTimestamp, int limit) RedissonScoredSortedSet.entryRangeReversedAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) RedissonScoredSortedSet.entryRangeReversedAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) RedissonScoredSortedSet.entryRangeReversedAsync
(int startIndex, int endIndex) RedissonTimeSeries.entryRangeReversedAsync
(long startTimestamp, long endTimestamp) RedissonTimeSeries.entryRangeReversedAsync
(long startTimestamp, long endTimestamp, int limit) <R> RFuture<R>
RedissonScript.evalAsync
(String key, RScript.Mode mode, String luaScript, RScript.ReturnType returnType, List<Object> keys, Object... values) <R> RFuture<R>
RedissonScript.evalAsync
(RScript.Mode mode, String luaScript, RScript.ReturnType returnType) <R> RFuture<R>
RedissonScript.evalAsync
(RScript.Mode mode, String luaScript, RScript.ReturnType returnType, List<Object> keys, Object... values) <R> RFuture<R>
RedissonScript.evalShaAsync
(String key, RScript.Mode mode, String shaDigest, RScript.ReturnType returnType, List<Object> keys, Object... values) <R> RFuture<R>
RedissonScript.evalShaAsync
(String key, RScript.Mode mode, Codec codec, String shaDigest, RScript.ReturnType returnType, List<Object> keys, Object... values) <R> RFuture<R>
RedissonScript.evalShaAsync
(RScript.Mode mode, String shaDigest, RScript.ReturnType returnType) <R> RFuture<R>
RedissonScript.evalShaAsync
(RScript.Mode mode, String shaDigest, RScript.ReturnType returnType, List<Object> keys, Object... values) protected <T> RFuture<T>
RedissonBaseLock.evalWriteAsync
(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) RFuture<BatchResult<?>>
RedissonBatch.executeAsync()
RedissonBloomFilter.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonBoundedBlockingQueue.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonDelayedQueue.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonFairLock.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonIdGenerator.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonKeys.expireAsync
(String name, long timeToLive, TimeUnit timeUnit) RedissonListMultimapCache.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonListMultimapValues.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonMapCache.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonMultimap.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonMultimapCache.expireAsync
(long timeToLive, TimeUnit timeUnit, String param) RedissonPermitExpirableSemaphore.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonPriorityQueue.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonRateLimiter.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonReliableTopic.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonSetMultimapCache.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonSetMultimapValues.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonTimeSeries.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonBloomFilter.expireAtAsync
(long timestamp, String param, String... keys) RedissonBoundedBlockingQueue.expireAtAsync
(long timestamp, String param, String... keys) RedissonDelayedQueue.expireAtAsync
(long timestamp, String param, String... keys) RedissonFairLock.expireAtAsync
(long timestamp, String param, String... keys) RedissonIdGenerator.expireAtAsync
(long timestamp, String param, String... keys) RedissonKeys.expireAtAsync
(String name, long timestamp) RedissonListMultimapCache.expireAtAsync
(long timestamp, String param, String... keys) RedissonListMultimapValues.expireAtAsync
(long timestamp, String param, String... keys) RedissonMapCache.expireAtAsync
(long timestamp, String param, String... keys) RedissonMultimap.expireAtAsync
(long timestamp, String param, String... keys) RedissonMultimapCache.expireAtAsync
(long timestamp, String param) RedissonPermitExpirableSemaphore.expireAtAsync
(long timestamp, String param, String... keys) RedissonPriorityQueue.expireAtAsync
(long timestamp, String param, String... keys) RedissonRateLimiter.expireAtAsync
(long timestamp, String param, String... keys) RedissonReliableTopic.expireAtAsync
(long timestamp, String param, String... keys) RedissonSetMultimapCache.expireAtAsync
(long timestamp, String param, String... keys) RedissonSetMultimapValues.expireAtAsync
(long timestamp, String param, String... keys) RedissonTimeSeries.expireAtAsync
(long timestamp, String param, String... keys) RedissonListMultimapCache.expireKeyAsync
(K key, long timeToLive, TimeUnit timeUnit) RedissonMultimapCache.expireKeyAsync
(K key, long timeToLive, TimeUnit timeUnit) RedissonSetMultimapCache.expireKeyAsync
(K key, long timeToLive, TimeUnit timeUnit) RedissonStream.fastAutoClaimAsync
(String groupName, String consumerName, long idleTime, TimeUnit idleTimeUnit, StreamMessageId startId, int count) RedissonStream.fastClaimAsync
(String groupName, String consumerName, long idleTime, TimeUnit idleTimeUnit, StreamMessageId... ids) RedissonMap.fastPutAsync
(K key, V value) RedissonMapCache.fastPutAsync
(K key, V value, long ttl, TimeUnit ttlUnit) RedissonMapCache.fastPutAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) RedissonLocalCachedMap.fastPutIfAbsentAsync
(K key, V value) RedissonMap.fastPutIfAbsentAsync
(K key, V value) RedissonMapCache.fastPutIfAbsentAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) RedissonMap.fastPutIfAbsentOperationAsync
(K key, V value) RedissonMapCache.fastPutIfAbsentOperationAsync
(K key, V value) RedissonLocalCachedMap.fastPutIfExistsAsync
(K key, V value) RedissonMap.fastPutIfExistsAsync
(K key, V value) RedissonMap.fastPutIfExistsOperationAsync
(K key, V value) RedissonMapCache.fastPutIfExistsOperationAsync
(K key, V value) RedissonLocalCachedMap.fastPutOperationAsync
(K key, V value) RedissonMap.fastPutOperationAsync
(K key, V value) RedissonMapCache.fastPutOperationAsync
(K key, V value) RedissonMapCache.fastPutOperationAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) RedissonList.fastRemoveAsync
(int index) RedissonListMultimapValues.fastRemoveAsync
(int index) RedissonMap.fastRemoveAsync
(K... keys) protected <T> RFuture<T>
RedissonMultimap.fastRemoveAsync
(List<Object> mapKeys, List<Object> listKeys, RedisCommand<T> evalCommandType) RedissonMultimap.fastRemoveAsync
(K... keys) RedissonLocalCachedMap.fastRemoveOperationAsync
(K... keys) RedissonMap.fastRemoveOperationAsync
(K... keys) RedissonMapCache.fastRemoveOperationAsync
(K... keys) RedissonLocalCachedMap.fastRemoveOperationBatchAsync
(K... keys) RedissonMap.fastRemoveOperationBatchAsync
(K... keys) RedissonMapCache.fastRemoveOperationBatchAsync
(K... keys) RedissonLocalCachedMap.fastReplaceAsync
(K key, V value) RedissonMap.fastReplaceAsync
(K key, V value) RedissonLocalCachedMap.fastReplaceOperationAsync
(K key, V value) RedissonMap.fastReplaceOperationAsync
(K key, V value) RedissonMapCache.fastReplaceOperationAsync
(K key, V value) RedissonList.fastSetAsync
(int index, V element) RedissonListMultimapValues.fastSetAsync
(int index, V element) RedissonSubList.fastSetAsync
(int index, V element) RedissonScoredSortedSet.firstAsync()
RedissonTimeSeries.firstAsync()
RedissonTimeSeries.firstAsync
(int count) RedissonTimeSeries.firstEntriesAsync
(int count) RedissonTimeSeries.firstEntryAsync()
RedissonScoredSortedSet.firstScoreAsync()
RedissonTimeSeries.firstTimestampAsync()
RedissonKeys.flushallAsync()
RedissonKeys.flushallParallelAsync()
RedissonFuction.flushAsync()
RedissonKeys.flushdbAsync()
RedissonKeys.flushdbParallelAsync()
RedissonFairLock.forceUnlockAsync()
RedissonLock.forceUnlockAsync()
RedissonMultiLock.forceUnlockAsync()
RedissonReadLock.forceUnlockAsync()
RedissonSpinLock.forceUnlockAsync()
RedissonWriteLock.forceUnlockAsync()
RedissonListMultimap.getAllAsync
(K key) RedissonListMultimapCache.getAllAsync
(K key) RedissonLocalCachedMap.getAllAsync
(Set<K> keys) RedissonMap.getAllAsync
(Set<K> keys) RedissonSetMultimap.getAllAsync
(K key) RedissonSetMultimapCache.getAllAsync
(K key) RedissonMap.getAllOperationAsync
(Set<K> keys) RedissonMapCache.getAllOperationAsync
(Set<K> keys) RedissonAtomicDouble.getAndAddAsync
(double delta) RedissonAtomicLong.getAndAddAsync
(long delta) RedissonBucket.getAndClearExpireAsync()
RedissonJsonBucket.getAndClearExpireAsync()
RedissonAtomicDouble.getAndDecrementAsync()
RedissonAtomicLong.getAndDecrementAsync()
RedissonAtomicDouble.getAndDeleteAsync()
RedissonAtomicLong.getAndDeleteAsync()
RedissonBaseAdder.getAndDeleteAsync
(String id) RedissonBucket.getAndDeleteAsync()
RedissonDoubleAdder.getAndDeleteAsync
(String id) RedissonJsonBucket.getAndDeleteAsync()
RedissonLongAdder.getAndDeleteAsync
(String id) RedissonBucket.getAndExpireAsync
(Duration duration) RedissonBucket.getAndExpireAsync
(Instant time) RedissonJsonBucket.getAndExpireAsync
(Duration duration) RedissonJsonBucket.getAndExpireAsync
(Instant time) RedissonAtomicDouble.getAndIncrementAsync()
RedissonAtomicLong.getAndIncrementAsync()
RedissonTimeSeries.getAndRemoveAsync
(long timestamp) RedissonTimeSeries.getAndRemoveEntryAsync
(long timestamp) RedissonAtomicDouble.getAndSetAsync
(double newValue) RedissonAtomicLong.getAndSetAsync
(long newValue) RedissonBucket.getAndSetAsync
(V newValue) RedissonBucket.getAndSetAsync
(V value, long timeToLive, TimeUnit timeUnit) <T> RFuture<T>
RedissonJsonBucket.getAndSetAsync
(JsonCodec<T> codec, String path, Object newValue) RedissonJsonBucket.getAndSetAsync
(V newValue) RedissonJsonBucket.getAndSetAsync
(V value, long timeToLive, TimeUnit timeUnit) RedissonAtomicDouble.getAsync()
RedissonAtomicLong.getAsync()
RedissonBitSet.getAsync
(long bitIndex) RedissonBucket.getAsync()
RedissonJsonBucket.getAsync()
<T> RFuture<T>
RedissonList.getAsync
(int index) RedissonList.getAsync
(int... indexes) RedissonListMultimapValues.getAsync
(int index) RedissonListMultimapValues.getAsync
(int... indexes) RedissonSubList.getAsync
(int index) RedissonTimeSeries.getAsync
(long timestamp) RedissonBitSet.getByteAsync
(long offset) RedissonRateLimiter.getConfigAsync()
RedissonCountDownLatch.getCountAsync()
RedissonTimeSeries.getEntryAsync
(long timestamp) RedissonRemoteService.Entry.getFuture()
RedissonBaseLock.getHoldCountAsync()
RedissonMultiLock.getHoldCountAsync()
RedissonObject.getIdleTimeAsync()
RFuture<StreamInfo<K,
V>> RedissonStream.getInfoAsync()
RedissonBitSet.getIntegerAsync
(long offset) RedissonJsonBucket.getKeysAsync()
RedissonJsonBucket.getKeysAsync
(String path) RedissonJsonBucket.getKeysMultiAsync
(String path) RedissonDeque.getLastAsync()
RedissonPriorityDeque.getLastAsync()
RedissonBitSet.getLongAsync
(long offset) RedissonMap.getOperationAsync
(K key) RedissonMapCache.getOperationAsync
(K key) RedissonStream.getPendingInfoAsync
(String groupName) RedissonRemoteService.getPendingInvocationsAsync
(Class<?> remoteInterface) RedissonScoredSortedSet.getScoreAsync
(Collection<V> elements) RedissonScoredSortedSet.getScoreAsync
(V o) RedissonBitSet.getShortAsync
(long offset) RedissonBitSet.getSignedAsync
(int size, long offset) RedissonKeys.getSlotAsync
(String key) protected RFuture<RemoteServiceRequest>
RedissonRemoteService.getTask
(String requestId, RMap<String, RemoteServiceRequest> tasks) RedissonExecutorService.getTaskCountAsync()
RedissonExecutorService.getTaskIdsAsync()
RedissonJsonBucket.getTypeAsync()
RedissonJsonBucket.getTypeAsync
(String path) RedissonKeys.getTypeAsync
(String key) RedissonBitSet.getUnsignedAsync
(int size, long offset) RedissonTransferQueue.getValueAsync
(int index) RedissonMapCache.getWithTTLOnlyAsync
(K key) RedissonExecutorService.hasTaskAsync
(String taskId) RedissonAtomicDouble.incrementAndGetAsync()
RedissonAtomicLong.incrementAndGetAsync()
RedissonJsonBucket.incrementAndGetAsync
(String path, T delta) RedissonBitSet.incrementAndGetByteAsync
(long offset, byte increment) RedissonBitSet.incrementAndGetIntegerAsync
(long offset, int increment) RedissonBitSet.incrementAndGetLongAsync
(long offset, long increment) RedissonJsonBucket.incrementAndGetMultiAsync
(String path, T delta) RedissonBitSet.incrementAndGetShortAsync
(long offset, short increment) RedissonBitSet.incrementAndGetSignedAsync
(int size, long offset, long increment) RedissonBitSet.incrementAndGetUnsignedAsync
(int size, long offset, long increment) RedissonList.indexOfAsync
(Object o) <R> RFuture<R>
RedissonList.indexOfAsync
(Object o, Convertor<R> convertor) RedissonListMultimapValues.indexOfAsync
(Object o) <R> RFuture<R>
RedissonSubList.indexOfAsync
(Object o, Convertor<R> convertor) RedissonScoredSortedSet.intersectionAsync
(String... names) RedissonScoredSortedSet.intersectionAsync
(Map<String, Double> nameWithWeight) RedissonScoredSortedSet.intersectionAsync
(RScoredSortedSet.Aggregate aggregate, String... names) RedissonScoredSortedSet.intersectionAsync
(RScoredSortedSet.Aggregate aggregate, Map<String, Double> nameWithWeight) RedissonSet.intersectionAsync
(String... names) RedissonSetMultimapValues.intersectionAsync
(String... names) RedissonTransferQueue.TransferQueueServiceAsync.invoke
(V value) RedissonBloomFilter.isExistsAsync()
RedissonObject.isExistsAsync()
RedissonBaseLock.isLockedAsync()
RedissonMultiLock.isLockedAsync()
RedissonMultimap.keySizeAsync()
RedissonFuction.killAsync()
RedissonScoredSortedSet.lastAsync()
RedissonTimeSeries.lastAsync()
RedissonTimeSeries.lastAsync
(int count) RedissonTimeSeries.lastEntriesAsync
(int count) RedissonTimeSeries.lastEntryAsync()
RedissonList.lastIndexOfAsync
(Object o) <R> RFuture<R>
RedissonList.lastIndexOfAsync
(Object o, Convertor<R> convertor) RedissonListMultimapValues.lastIndexOfAsync
(Object o) RedissonSubList.lastIndexOfAsync
(Object o) RedissonScoredSortedSet.lastScoreAsync()
RedissonTimeSeries.lastTimestampAsync()
RedissonBitSet.lengthAsync()
RedissonFuction.listAsync()
RedissonStream.listConsumersAsync
(String groupName) RedissonStream.listGroupsAsync()
RedissonStream.listPendingAsync
(String groupName, String consumerName, StreamMessageId startId, StreamMessageId endId, int count) RedissonStream.listPendingAsync
(String groupName, String consumerName, StreamMessageId startId, StreamMessageId endId, long idleTime, TimeUnit idleTimeUnit, int count) RedissonStream.listPendingAsync
(String groupName, StreamMessageId startId, StreamMessageId endId, int count) RedissonStream.listPendingAsync
(String groupName, StreamMessageId startId, StreamMessageId endId, long idleTime, TimeUnit idleTimeUnit, int count) RedissonMap.loadAllAsync
(boolean replaceExistingValues, int parallelism) RedissonMap.loadAllAsync
(Set<? extends K> keys, boolean replaceExistingValues, int parallelism) RedissonFuction.loadAndReplaceAsync
(String libraryName, String code) RedissonLock.lockAsync()
RedissonLock.lockAsync
(long currentThreadId) RedissonMultiLock.lockAsync()
RedissonMultiLock.lockAsync
(long threadId) RedissonSpinLock.lockAsync()
RedissonSpinLock.lockAsync
(long currentThreadId) protected final <M> RFuture<M>
RedissonMap.mapWriterFuture
(RFuture<M> future, MapWriterTask task) protected final <M> RFuture<M>
RedissonMap.mapWriterFuture
(RFuture<M> future, MapWriterTask task, Function<M, Boolean> condition) RedissonMap.mergeAsync
(K key, V value, BiFunction<? super V, ? super V, ? extends V> remappingFunction) RedissonHyperLogLog.mergeWithAsync
(String... otherLogNames) RedissonKeys.migrateAsync
(String name, String host, int port, int database, long timeout) RedissonObject.migrateAsync
(String host, int port, int database, long timeout) RedissonBlockingDeque.moveAsync
(Duration timeout, DequeMoveArgs args) RedissonDeque.moveAsync
(DequeMoveArgs args) RedissonObject.moveAsync
(int database) RedissonPriorityBlockingDeque.moveAsync
(Duration timeout, DequeMoveArgs args) RedissonPriorityDeque.moveAsync
(DequeMoveArgs args) RedissonIdGenerator.nextIdAsync()
RedissonBitSet.notAsync()
RedissonBoundedBlockingQueue.offerAsync
(V e) RedissonBoundedBlockingQueue.offerAsync
(V e, long timeout, TimeUnit unit) RedissonDelayedQueue.offerAsync
(V e) RedissonDelayedQueue.offerAsync
(V e, long delay, TimeUnit timeUnit) RedissonPriorityBlockingDeque.offerAsync
(V e) RedissonPriorityBlockingQueue.offerAsync
(V e) RedissonPriorityQueue.offerAsync
(V e) RedissonQueue.offerAsync
(V e) RedissonTransferQueue.offerAsync
(V e) RedissonDeque.offerFirstAsync
(V e) RedissonPriorityDeque.offerFirstAsync
(V e) RedissonDeque.offerLastAsync
(V e) RedissonPriorityDeque.offerLastAsync
(V e) RedissonDelayedQueue.peekAsync()
RedissonPriorityQueue.peekAsync()
RedissonQueue.peekAsync()
RedissonTransferQueue.peekAsync()
RedissonDeque.peekFirstAsync()
RedissonPriorityDeque.peekFirstAsync()
RedissonDeque.peekLastAsync()
RedissonPriorityDeque.peekLastAsync()
RedissonStream.pendingRangeAsync
(String groupName, String consumerName, StreamMessageId startId, StreamMessageId endId, int count) RedissonStream.pendingRangeAsync
(String groupName, String consumerName, StreamMessageId startId, StreamMessageId endId, long idleTime, TimeUnit idleTimeUnit, int count) RedissonStream.pendingRangeAsync
(String groupName, StreamMessageId startId, StreamMessageId endId, int count) RedissonStream.pendingRangeAsync
(String groupName, StreamMessageId startId, StreamMessageId endId, long idleTime, TimeUnit idleTimeUnit, int count) RedissonBoundedBlockingQueue.pollAsync()
RedissonDelayedQueue.pollAsync()
RedissonDelayedQueue.pollAsync
(int limit) RedissonPriorityBlockingDeque.pollAsync
(int limit) RedissonPriorityBlockingQueue.pollAsync
(int limit) RedissonPriorityQueue.pollAsync()
RedissonPriorityQueue.pollAsync
(int limit) RedissonQueue.pollAsync()
RedissonQueue.pollAsync
(int limit) RedissonTransferQueue.pollAsync()
RedissonTransferQueue.pollAsync
(int limit) RedissonBlockingDeque.pollFirstAsync
(long timeout, TimeUnit unit) RedissonDeque.pollFirstAsync()
RedissonDeque.pollFirstAsync
(int limit) RedissonPriorityBlockingDeque.pollFirstAsync
(int limit) RedissonPriorityBlockingDeque.pollFirstAsync
(long timeout, TimeUnit unit) RedissonPriorityDeque.pollFirstAsync()
RedissonPriorityDeque.pollFirstAsync
(int limit) RedissonScoredSortedSet.pollFirstAsync()
RedissonScoredSortedSet.pollFirstAsync
(int count) RedissonScoredSortedSet.pollFirstAsync
(long timeout, TimeUnit unit) RedissonScoredSortedSet.pollFirstAsync
(Duration duration, int count) RedissonTimeSeries.pollFirstAsync()
RedissonTimeSeries.pollFirstAsync
(int count) RedissonTimeSeries.pollFirstEntriesAsync
(int count) RedissonScoredSortedSet.pollFirstEntriesFromAnyAsync
(int count, String... queueNames) RedissonScoredSortedSet.pollFirstEntriesFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonTimeSeries.pollFirstEntryAsync()
RedissonBlockingDeque.pollFirstFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonBlockingDeque.pollFirstFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonBlockingQueue.pollFirstFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonBoundedBlockingQueue.pollFirstFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonPriorityBlockingDeque.pollFirstFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonPriorityBlockingDeque.pollFirstFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonPriorityBlockingQueue.pollFirstFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonScoredSortedSet.pollFirstFromAnyAsync
(int count, String... queueNames) RedissonScoredSortedSet.pollFirstFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonScoredSortedSet.pollFirstFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonTransferQueue.pollFirstFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonBlockingDeque.pollFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonBlockingQueue.pollFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonBoundedBlockingQueue.pollFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonPriorityBlockingDeque.pollFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonPriorityBlockingQueue.pollFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonTransferQueue.pollFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonBlockingDeque.pollLastAndOfferFirstToAsync
(String queueName, long timeout, TimeUnit unit) RedissonBlockingQueue.pollLastAndOfferFirstToAsync
(String queueName, long timeout, TimeUnit unit) RedissonBoundedBlockingQueue.pollLastAndOfferFirstToAsync
(String queueName, long timeout, TimeUnit unit) RedissonDelayedQueue.pollLastAndOfferFirstToAsync
(String queueName) RedissonPriorityBlockingDeque.pollLastAndOfferFirstToAsync
(String queueName, long timeout, TimeUnit unit) RedissonPriorityBlockingQueue.pollLastAndOfferFirstToAsync
(String queueName, long timeout, TimeUnit unit) RedissonPriorityQueue.pollLastAndOfferFirstToAsync
(String queueName) RedissonQueue.pollLastAndOfferFirstToAsync
(String queueName) RedissonTransferQueue.pollLastAndOfferFirstToAsync
(String queueName) RedissonTransferQueue.pollLastAndOfferFirstToAsync
(String queueName, long timeout, TimeUnit unit) RedissonBlockingDeque.pollLastAsync
(long timeout, TimeUnit unit) RedissonDeque.pollLastAsync()
RedissonDeque.pollLastAsync
(int limit) RedissonPriorityBlockingDeque.pollLastAsync
(int limit) RedissonPriorityBlockingDeque.pollLastAsync
(long timeout, TimeUnit unit) RedissonPriorityDeque.pollLastAsync()
RedissonPriorityDeque.pollLastAsync
(int limit) RedissonScoredSortedSet.pollLastAsync()
RedissonScoredSortedSet.pollLastAsync
(int count) RedissonScoredSortedSet.pollLastAsync
(long timeout, TimeUnit unit) RedissonScoredSortedSet.pollLastAsync
(Duration duration, int count) RedissonTimeSeries.pollLastAsync()
RedissonTimeSeries.pollLastAsync
(int count) RedissonTimeSeries.pollLastEntriesAsync
(int count) RedissonScoredSortedSet.pollLastEntriesFromAnyAsync
(int count, String... queueNames) RedissonScoredSortedSet.pollLastEntriesFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonTimeSeries.pollLastEntryAsync()
RedissonBlockingDeque.pollLastFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonBlockingDeque.pollLastFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonBlockingQueue.pollLastFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonBoundedBlockingQueue.pollLastFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonPriorityBlockingDeque.pollLastFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonPriorityBlockingDeque.pollLastFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonPriorityBlockingQueue.pollLastFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonScoredSortedSet.pollLastFromAnyAsync
(int count, String... queueNames) RedissonScoredSortedSet.pollLastFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) RedissonScoredSortedSet.pollLastFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonTransferQueue.pollLastFromAnyAsync
(Duration duration, int count, String... queueNames) RedissonDeque.popAsync()
RedissonPriorityDeque.popAsync()
RedissonReliableTopic.publishAsync
(Object message) RedissonShardedTopic.publishAsync
(Object message) RedissonTopic.publishAsync
(Object message) QueueTransferTask.pushTaskAsync()
RedissonListMultimap.putAllAsync
(K key, Iterable<? extends V> values) RedissonMap.putAllAsync
(Map<? extends K, ? extends V> map) RedissonMap.putAllAsync
(Map<? extends K, ? extends V> map, int batchSize) RedissonMapCache.putAllAsync
(Map<? extends K, ? extends V> map, long ttl, TimeUnit ttlUnit) RedissonSetMultimap.putAllAsync
(K key, Iterable<? extends V> values) RedissonLocalCachedMap.putAllOperationAsync
(Map<? extends K, ? extends V> map) RedissonMap.putAllOperationAsync
(Map<? extends K, ? extends V> map) RedissonMapCache.putAllOperationAsync
(Map<? extends K, ? extends V> map) RedissonMapCache.putAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) RedissonBlockingDeque.putFirstAsync
(V e) RedissonPriorityBlockingDeque.putFirstAsync
(V e) RedissonLocalCachedMap.putIfAbsentAsync
(K key, V value) RedissonMap.putIfAbsentAsync
(K key, V value) RedissonMapCache.putIfAbsentAsync
(K key, V value, long ttl, TimeUnit ttlUnit) RedissonMapCache.putIfAbsentAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) RedissonMap.putIfAbsentOperationAsync
(K key, V value) RedissonMapCache.putIfAbsentOperationAsync
(K key, V value) RedissonLocalCachedMap.putIfExistsAsync
(K key, V value) RedissonMap.putIfExistsAsync
(K key, V value) RedissonMap.putIfExistsOperationAsync
(K key, V value) RedissonMapCache.putIfExistsOperationAsync
(K key, V value) RedissonBlockingDeque.putLastAsync
(V e) RedissonPriorityBlockingDeque.putLastAsync
(V e) RedissonLocalCachedMap.putOperationAsync
(K key, V value) RedissonMap.putOperationAsync
(K key, V value) RedissonMapCache.putOperationAsync
(K key, V value) RedissonMapCache.putOperationAsync
(K key, V value, long ttlTimeout, long maxIdleTimeout, long maxIdleDelta, long ttlTimeoutDelta) RedissonGeo.radiusAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit) RedissonGeo.radiusAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RedissonGeo.radiusAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonGeo.radiusAsync
(V member, double radius, GeoUnit geoUnit) RedissonGeo.radiusAsync
(V member, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RedissonGeo.radiusAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonGeo.radiusStoreSortedToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit) RedissonGeo.radiusStoreSortedToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusStoreSortedToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonGeo.radiusStoreSortedToAsync
(String destName, V member, double radius, GeoUnit geoUnit) RedissonGeo.radiusStoreSortedToAsync
(String destName, V member, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusStoreSortedToAsync
(String destName, V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonGeo.radiusStoreToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit) RedissonGeo.radiusStoreToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusStoreToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonGeo.radiusStoreToAsync
(String destName, V member, double radius, GeoUnit geoUnit) RedissonGeo.radiusStoreToAsync
(String destName, V member, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusStoreToAsync
(String destName, V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonGeo.radiusWithDistanceAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit) RedissonGeo.radiusWithDistanceAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusWithDistanceAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RedissonGeo.radiusWithDistanceAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonGeo.radiusWithDistanceAsync
(V member, double radius, GeoUnit geoUnit) RedissonGeo.radiusWithDistanceAsync
(V member, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusWithDistanceAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RedissonGeo.radiusWithDistanceAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonGeo.radiusWithPositionAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit) RedissonGeo.radiusWithPositionAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusWithPositionAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RedissonGeo.radiusWithPositionAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonGeo.radiusWithPositionAsync
(V member, double radius, GeoUnit geoUnit) RedissonGeo.radiusWithPositionAsync
(V member, double radius, GeoUnit geoUnit, int count) RedissonGeo.radiusWithPositionAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RedissonGeo.radiusWithPositionAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RedissonScoredSortedSet.randomAsync()
RedissonScoredSortedSet.randomAsync
(int count) RedissonSet.randomAsync()
RedissonSet.randomAsync
(int count) RedissonSetMultimapValues.randomAsync()
RedissonSetMultimapValues.randomAsync
(int count) RedissonMap.randomEntriesAsync
(int count) RedissonMapCache.randomEntriesAsync
(int count) RedissonScoredSortedSet.randomEntriesAsync
(int count) RedissonKeys.randomKeyAsync()
RedissonMap.randomKeysAsync
(int count) RedissonMapCache.randomKeysAsync
(int count) RedissonLexSortedSet.rangeAsync
(int startIndex, int endIndex) RedissonLexSortedSet.rangeAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive) RedissonLexSortedSet.rangeAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive, int offset, int count) RedissonList.rangeAsync
(int toIndex) RedissonList.rangeAsync
(int fromIndex, int toIndex) RedissonListMultimapValues.rangeAsync
(int toIndex) RedissonListMultimapValues.rangeAsync
(int fromIndex, int toIndex) RedissonStream.rangeAsync
(int count, StreamMessageId startId, StreamMessageId endId) RedissonStream.rangeAsync
(StreamMessageId startId, StreamMessageId endId) RedissonTimeSeries.rangeAsync
(long startTimestamp, long endTimestamp) RedissonTimeSeries.rangeAsync
(long startTimestamp, long endTimestamp, int limit) RedissonLexSortedSet.rangeHeadAsync
(String toElement, boolean toInclusive) RedissonLexSortedSet.rangeHeadAsync
(String toElement, boolean toInclusive, int offset, int count) RedissonLexSortedSet.rangeHeadReversedAsync
(String toElement, boolean toInclusive) RedissonLexSortedSet.rangeHeadReversedAsync
(String toElement, boolean toInclusive, int offset, int count) RedissonLexSortedSet.rangeReversedAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive) RedissonLexSortedSet.rangeReversedAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive, int offset, int count) RedissonStream.rangeReversedAsync
(int count, StreamMessageId startId, StreamMessageId endId) RedissonStream.rangeReversedAsync
(StreamMessageId startId, StreamMessageId endId) RedissonTimeSeries.rangeReversedAsync
(long startTimestamp, long endTimestamp) RedissonTimeSeries.rangeReversedAsync
(long startTimestamp, long endTimestamp, int limit) RedissonLexSortedSet.rangeTailAsync
(String fromElement, boolean fromInclusive) RedissonLexSortedSet.rangeTailAsync
(String fromElement, boolean fromInclusive, int offset, int count) RedissonLexSortedSet.rangeTailReversedAsync
(String fromElement, boolean fromInclusive) RedissonLexSortedSet.rangeTailReversedAsync
(String fromElement, boolean fromInclusive, int offset, int count) RedissonScoredSortedSet.rangeToAsync
(String destName, double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) RedissonScoredSortedSet.rangeToAsync
(String destName, double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) RedissonScoredSortedSet.rangeToAsync
(String destName, int startIndex, int endIndex) RedissonDelayedQueue.readAllAsync()
RedissonList.readAllAsync()
RedissonListMultimapValues.readAllAsync()
RedissonScoredSortedSet.readAllAsync()
RedissonSet.readAllAsync()
RedissonSetCache.readAllAsync()
RedissonSetMultimapValues.readAllAsync()
RedissonSortedSet.readAllAsync()
RedissonSubList.readAllAsync()
RedissonTransferQueue.readAllAsync()
RedissonLocalCachedMap.readAllEntrySetAsync()
RedissonMap.readAllEntrySetAsync()
RedissonMapCache.readAllEntrySetAsync()
RedissonMap.readAllKeySetAsync()
RedissonMapCache.readAllKeySetAsync()
RedissonMultimap.readAllKeySetAsync()
RedissonLocalCachedMap.readAllMapAsync()
RedissonMap.readAllMapAsync()
RedissonMapCache.readAllMapAsync()
RedissonLocalCachedMap.readAllValuesAsync()
RedissonMap.readAllValuesAsync()
RedissonMapCache.readAllValuesAsync()
RedissonStream.readAsync
(int count, long timeout, TimeUnit unit, StreamMessageId... ids) RedissonStream.readAsync
(int count, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2) RedissonStream.readAsync
(int count, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) RedissonStream.readAsync
(int count, long timeout, TimeUnit unit, StreamMessageId id, Map<String, StreamMessageId> keyToId) RedissonStream.readAsync
(int count, StreamMessageId... ids) RedissonStream.readAsync
(int count, StreamMessageId id, String key2, StreamMessageId id2) RedissonStream.readAsync
(int count, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) RedissonStream.readAsync
(int count, StreamMessageId id, Map<String, StreamMessageId> keyToId) RedissonStream.readAsync
(long timeout, TimeUnit unit, StreamMessageId... ids) RedissonStream.readAsync
(long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2) RedissonStream.readAsync
(long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) RedissonStream.readAsync
(long timeout, TimeUnit unit, StreamMessageId id, Map<String, StreamMessageId> keyToId) RedissonStream.readAsync
(StreamMultiReadArgs args) RedissonStream.readAsync
(StreamReadArgs args) RedissonStream.readAsync
(StreamMessageId... ids) RedissonStream.readAsync
(StreamMessageId id, String key2, StreamMessageId id2) RedissonStream.readAsync
(StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) RedissonStream.readAsync
(StreamMessageId id, Map<String, StreamMessageId> keyToId) RedissonScoredSortedSet.readDiffAsync
(String... names) RedissonSet.readDiffAsync
(String... names) RedissonSetMultimapValues.readDiffAsync
(String... names) RedissonStream.readGroupAsync
(String groupName, String consumerName, int count, long timeout, TimeUnit unit, StreamMessageId... ids) RedissonStream.readGroupAsync
(String groupName, String consumerName, int count, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2) RedissonStream.readGroupAsync
(String groupName, String consumerName, int count, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) RedissonStream.readGroupAsync
(String groupName, String consumerName, int count, long timeout, TimeUnit unit, StreamMessageId id, Map<String, StreamMessageId> keyToId) RedissonStream.readGroupAsync
(String groupName, String consumerName, int count, StreamMessageId... ids) RedissonStream.readGroupAsync
(String groupName, String consumerName, int count, StreamMessageId id, String key2, StreamMessageId id2) RedissonStream.readGroupAsync
(String groupName, String consumerName, int count, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) RedissonStream.readGroupAsync
(String groupName, String consumerName, int count, StreamMessageId id, Map<String, StreamMessageId> keyToId) RedissonStream.readGroupAsync
(String groupName, String consumerName, long timeout, TimeUnit unit, StreamMessageId... ids) RedissonStream.readGroupAsync
(String groupName, String consumerName, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2) RedissonStream.readGroupAsync
(String groupName, String consumerName, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) RedissonStream.readGroupAsync
(String groupName, String consumerName, long timeout, TimeUnit unit, StreamMessageId id, Map<String, StreamMessageId> keyToId) RedissonStream.readGroupAsync
(String groupName, String consumerName, StreamMultiReadGroupArgs args) RedissonStream.readGroupAsync
(String groupName, String consumerName, StreamReadGroupArgs args) RedissonStream.readGroupAsync
(String groupName, String consumerName, StreamMessageId... ids) RedissonStream.readGroupAsync
(String groupName, String consumerName, StreamMessageId id, String key2, StreamMessageId id2) RedissonStream.readGroupAsync
(String groupName, String consumerName, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) RedissonStream.readGroupAsync
(String groupName, String consumerName, StreamMessageId id, Map<String, StreamMessageId> keyToId) RedissonScoredSortedSet.readIntersectionAsync
(String... names) RedissonScoredSortedSet.readIntersectionAsync
(Map<String, Double> nameWithWeight) RedissonScoredSortedSet.readIntersectionAsync
(RScoredSortedSet.Aggregate aggregate, String... names) RedissonScoredSortedSet.readIntersectionAsync
(RScoredSortedSet.Aggregate aggregate, Map<String, Double> nameWithWeight) RedissonSet.readIntersectionAsync
(String... names) RedissonSetMultimapValues.readIntersectionAsync
(String... names) <T> RFuture<Collection<T>>
RedissonList.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonList.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonList.readSortAlphaAsync
(String byPattern, SortOrder order) RedissonList.readSortAlphaAsync
(String byPattern, SortOrder order, int offset, int count) RedissonList.readSortAlphaAsync
(SortOrder order) RedissonList.readSortAlphaAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonListMultimapValues.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonListMultimapValues.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonListMultimapValues.readSortAlphaAsync
(String byPattern, SortOrder order) RedissonListMultimapValues.readSortAlphaAsync
(String byPattern, SortOrder order, int offset, int count) RedissonListMultimapValues.readSortAlphaAsync
(SortOrder order) RedissonListMultimapValues.readSortAlphaAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonScoredSortedSet.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonScoredSortedSet.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonScoredSortedSet.readSortAlphaAsync
(String byPattern, SortOrder order) RedissonScoredSortedSet.readSortAlphaAsync
(String byPattern, SortOrder order, int offset, int count) RedissonScoredSortedSet.readSortAlphaAsync
(SortOrder order) RedissonScoredSortedSet.readSortAlphaAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonSet.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonSet.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonSet.readSortAlphaAsync
(String byPattern, SortOrder order) RedissonSet.readSortAlphaAsync
(String byPattern, SortOrder order, int offset, int count) RedissonSet.readSortAlphaAsync
(SortOrder order) RedissonSet.readSortAlphaAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonSetMultimapValues.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonSetMultimapValues.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonSetMultimapValues.readSortAlphaAsync
(String byPattern, SortOrder order) RedissonSetMultimapValues.readSortAlphaAsync
(String byPattern, SortOrder order, int offset, int count) RedissonSetMultimapValues.readSortAlphaAsync
(SortOrder order) RedissonSetMultimapValues.readSortAlphaAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonList.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonList.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonList.readSortAsync
(String byPattern, SortOrder order) RedissonList.readSortAsync
(String byPattern, SortOrder order, int offset, int count) RedissonList.readSortAsync
(SortOrder order) RedissonList.readSortAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonListMultimapValues.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonListMultimapValues.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonListMultimapValues.readSortAsync
(String byPattern, SortOrder order) RedissonListMultimapValues.readSortAsync
(String byPattern, SortOrder order, int offset, int count) RedissonListMultimapValues.readSortAsync
(SortOrder order) RedissonListMultimapValues.readSortAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonScoredSortedSet.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonScoredSortedSet.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonScoredSortedSet.readSortAsync
(String byPattern, SortOrder order) RedissonScoredSortedSet.readSortAsync
(String byPattern, SortOrder order, int offset, int count) RedissonScoredSortedSet.readSortAsync
(SortOrder order) RedissonScoredSortedSet.readSortAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonSet.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonSet.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonSet.readSortAsync
(String byPattern, SortOrder order) RedissonSet.readSortAsync
(String byPattern, SortOrder order, int offset, int count) RedissonSet.readSortAsync
(SortOrder order) RedissonSet.readSortAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonSetMultimapValues.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonSetMultimapValues.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonSetMultimapValues.readSortAsync
(String byPattern, SortOrder order) RedissonSetMultimapValues.readSortAsync
(String byPattern, SortOrder order, int offset, int count) RedissonSetMultimapValues.readSortAsync
(SortOrder order) RedissonSetMultimapValues.readSortAsync
(SortOrder order, int offset, int count) RedissonScoredSortedSet.readUnionAsync
(String... names) RedissonScoredSortedSet.readUnionAsync
(Map<String, Double> nameWithWeight) RedissonScoredSortedSet.readUnionAsync
(RScoredSortedSet.Aggregate aggregate, String... names) RedissonScoredSortedSet.readUnionAsync
(RScoredSortedSet.Aggregate aggregate, Map<String, Double> nameWithWeight) RedissonSet.readUnionAsync
(String... names) RedissonSetMultimapValues.readUnionAsync
(String... names) RedissonPermitExpirableSemaphore.releaseAsync
(String permitId) RedissonSemaphore.releaseAsync()
RedissonSemaphore.releaseAsync
(int permits) RedissonRingBuffer.remainingCapacityAsync()
RedissonKeys.remainTimeToLiveAsync
(String name) RedissonListMultimapValues.remainTimeToLiveAsync()
RedissonMapCache.remainTimeToLiveAsync
(K key) RedissonMultiLock.remainTimeToLiveAsync()
RedissonSetMultimapValues.remainTimeToLiveAsync()
RedissonBoundedBlockingQueue.removeAllAsync
(Collection<?> c) RedissonDelayedQueue.removeAllAsync
(Collection<?> c) RedissonList.removeAllAsync
(Collection<?> c) RedissonListMultimap.removeAllAsync
(Object key) RedissonListMultimapCache.removeAllAsync
(Object key) RedissonListMultimapValues.removeAllAsync
(Collection<?> c) RedissonScoredSortedSet.removeAllAsync
(Collection<?> c) RedissonSet.removeAllAsync
(Collection<?> c) RedissonSetCache.removeAllAsync
(Collection<?> c) RedissonSetMultimap.removeAllAsync
(Object key) RedissonSetMultimapCache.removeAllAsync
(Object key) RedissonSetMultimapValues.removeAllAsync
(Collection<?> c) RedissonSubList.removeAllAsync
(Collection<?> c) RedissonTransferQueue.removeAllAsync
(Collection<?> c) RedissonSet.removeAllCountedAsync
(Collection<? extends V> c) RedissonSetMultimapValues.removeAllCountedAsync
(Collection<? extends V> c) RedissonPatternTopic.removeAllListenersAsync()
RedissonReliableTopic.removeAllListenersAsync()
RedissonShardedTopic.removeAllListenersAsync()
RedissonTopic.removeAllListenersAsync()
RedissonBoundedBlockingQueue.removeAsync
(Object o) RedissonDelayedQueue.removeAsync
(Object o) RedissonDelayedQueue.removeAsync
(Object o, int count) RedissonList.removeAsync
(int index) RedissonList.removeAsync
(Object o) RedissonList.removeAsync
(Object o, int count) RedissonListMultimap.removeAsync
(Object key, Object value) RedissonListMultimapValues.removeAsync
(int index) RedissonListMultimapValues.removeAsync
(Object o) RedissonListMultimapValues.removeAsync
(Object o, int count) RedissonLocalCachedMap.removeAsync
(Object key, Object value) RedissonMap.removeAsync
(Object key, Object value) RedissonMap.removeAsync
(K key) RedissonPriorityDeque.removeAsync
(Object o, int count) RedissonScoredSortedSet.removeAsync
(Object object) RedissonSet.removeAsync
(Object o) RedissonSetCache.removeAsync
(Object o) RedissonSetMultimap.removeAsync
(Object key, Object value) RedissonSetMultimapValues.removeAsync
(Object o) RedissonSortedSet.removeAsync
(Object value) RedissonStream.removeAsync
(StreamMessageId... ids) RedissonSubList.removeAsync
(Object o) RedissonTimeSeries.removeAsync
(long timestamp) RedissonTransferQueue.removeAsync
(Object o) RedissonStream.removeConsumerAsync
(String groupName, String consumerName) RedissonDeque.removeFirstAsync()
RedissonPriorityDeque.removeFirstAsync()
RedissonDeque.removeFirstOccurrenceAsync
(Object o) RedissonPriorityDeque.removeFirstOccurrenceAsync
(Object o) RedissonStream.removeGroupAsync
(String groupName) RedissonDeque.removeLastAsync()
RedissonPriorityDeque.removeLastAsync()
RedissonDeque.removeLastOccurrenceAsync
(Object o) RedissonPriorityDeque.removeLastOccurrenceAsync
(Object o) RedissonBucket.removeListenerAsync
(int listenerId) RedissonList.removeListenerAsync
(int listenerId) RedissonObject.removeListenerAsync
(int listenerId) RedissonPatternTopic.removeListenerAsync
(int listenerId) RedissonReliableTopic.removeListenerAsync
(String... listenerIds) RedissonScoredSortedSet.removeListenerAsync
(int listenerId) RedissonShardedTopic.removeListenerAsync
(Integer... listenerIds) RedissonShardedTopic.removeListenerAsync
(MessageListener<?> listener) RedissonTopic.removeListenerAsync
(Integer... listenerIds) RedissonTopic.removeListenerAsync
(MessageListener<?> listener) RedissonLocalCachedMap.removeOperationAsync
(Object key, Object value) RedissonLocalCachedMap.removeOperationAsync
(K key) RedissonMap.removeOperationAsync
(Object key, Object value) RedissonMap.removeOperationAsync
(K key) RedissonMapCache.removeOperationAsync
(Object key, Object value) RedissonMapCache.removeOperationAsync
(K key) RedissonSet.removeRandomAsync()
RedissonSet.removeRandomAsync
(int amount) RedissonSetMultimapValues.removeRandomAsync()
RedissonSetMultimapValues.removeRandomAsync
(int amount) RedissonLexSortedSet.removeRangeAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive) RedissonTimeSeries.removeRangeAsync
(long startTimestamp, long endTimestamp) RedissonScoredSortedSet.removeRangeByRankAsync
(int startIndex, int endIndex) RedissonScoredSortedSet.removeRangeByScoreAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) RedissonLexSortedSet.removeRangeHeadAsync
(String toElement, boolean toInclusive) RedissonLexSortedSet.removeRangeTailAsync
(String fromElement, boolean fromInclusive) RedissonBloomFilter.renameAsync
(String newName) RedissonKeys.renameAsync
(String currentName, String newName) RedissonListMultimapValues.renameAsync
(String newName) RedissonMultimap.renameAsync
(String newName) RedissonObject.renameAsync
(String newName) RedissonSetMultimapValues.renameAsync
(String newName) RedissonBloomFilter.renamenxAsync
(String newName) RedissonKeys.renamenxAsync
(String oldName, String newName) RedissonListMultimapValues.renamenxAsync
(String newName) RedissonMultimap.renamenxAsync
(String newName) RedissonObject.renamenxAsync
(String newName) RedissonSetMultimapValues.renamenxAsync
(String newName) RedissonLocalCachedMap.replaceAsync
(K key, V value) RedissonLocalCachedMap.replaceAsync
(K key, V oldValue, V newValue) RedissonMap.replaceAsync
(K key, V value) RedissonMap.replaceAsync
(K key, V oldValue, V newValue) RedissonScoredSortedSet.replaceAsync
(V oldObject, V newObject) RedissonLocalCachedMap.replaceOperationAsync
(K key, V value) RedissonLocalCachedMap.replaceOperationAsync
(K key, V oldValue, V newValue) RedissonMap.replaceOperationAsync
(K key, V value) RedissonMap.replaceOperationAsync
(K key, V oldValue, V newValue) RedissonMapCache.replaceOperationAsync
(K key, V value) RedissonMapCache.replaceOperationAsync
(K key, V oldValue, V newValue) RedissonListMultimap.replaceValuesAsync
(K key, Iterable<? extends V> values) RedissonSetMultimap.replaceValuesAsync
(K key, Iterable<? extends V> values) RedissonBaseAdder.resetAsync()
RedissonBaseAdder.resetAsync
(long timeout, TimeUnit timeUnit) RedissonFuction.restoreAfterFlushAsync
(byte[] payload) RedissonFuction.restoreAndReplaceAsync
(byte[] payload) RedissonObject.restoreAndReplaceAsync
(byte[] state) RedissonObject.restoreAndReplaceAsync
(byte[] state, long timeToLive, TimeUnit timeUnit) RedissonFuction.restoreAsync
(byte[] payload) RedissonObject.restoreAsync
(byte[] state) RedissonObject.restoreAsync
(byte[] state, long timeToLive, TimeUnit timeUnit) RedissonDelayedQueue.retainAllAsync
(Collection<?> c) RedissonList.retainAllAsync
(Collection<?> c) RedissonListMultimapValues.retainAllAsync
(Collection<?> c) RedissonScoredSortedSet.retainAllAsync
(Collection<?> c) RedissonSet.retainAllAsync
(Collection<?> c) RedissonSetCache.retainAllAsync
(Collection<?> c) RedissonSetMultimapValues.retainAllAsync
(Collection<?> c) RedissonSubList.retainAllAsync
(Collection<?> c) RedissonTransferQueue.retainAllAsync
(Collection<?> c) RedissonScoredSortedSet.revRangeToAsync
(String destName, double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) RedissonScoredSortedSet.revRangeToAsync
(String destName, double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) RedissonScoredSortedSet.revRangeToAsync
(String destName, int startIndex, int endIndex) RedissonScoredSortedSet.revRankAsync
(Collection<V> elements) RedissonScoredSortedSet.revRankAsync
(V o) RedissonKeys.scanIteratorAsync
(RedisClient client, MasterSlaveEntry entry, long startPos, String pattern, int count) RedissonKeys.scanIteratorAsync
(RedisClient client, MasterSlaveEntry entry, RedisCommand<?> command, long startPos, String pattern, int count) RedissonMap.scanIteratorAsync
(String name, RedisClient client, long startPos, String pattern, int count) RedissonMapCache.scanIteratorAsync
(String name, RedisClient client, long startPos, String pattern, int count) RedissonScoredSortedSet.scanIteratorAsync
(RedisClient client, long startPos, String pattern, int count) RedissonSet.scanIteratorAsync
(String name, RedisClient client, long startPos, String pattern, int count) RedissonSetCache.scanIteratorAsync
(String name, RedisClient client, long startPos, String pattern, int count) RedissonTimeSeries.scanIteratorAsync
(String name, RedisClient client, long startPos, int count) ScanIterator.scanIteratorAsync
(String name, RedisClient client, long startPos, String pattern, int count) RedissonScript.scriptExistsAsync
(String... shaDigests) RedissonScript.scriptExistsAsync
(String key, String... shaDigests) RedissonScript.scriptFlushAsync()
RedissonScript.scriptFlushAsync
(String key) RedissonScript.scriptKillAsync()
RedissonScript.scriptKillAsync
(String key) RedissonScript.scriptLoadAsync
(String luaScript) RedissonScript.scriptLoadAsync
(String key, String luaScript) RedissonGeo.searchAsync
(GeoSearchArgs args) RedissonGeo.searchWithDistanceAsync
(GeoSearchArgs args) RedissonGeo.searchWithPositionAsync
(GeoSearchArgs args) RedissonBucket.setAndKeepTTLAsync
(V value) RedissonJsonBucket.setAndKeepTTLAsync
(V value) RedissonAtomicDouble.setAsync
(double newValue) RedissonAtomicLong.setAsync
(long newValue) RedissonBitSet.setAsync
(long bitIndex) RedissonBitSet.setAsync
(long bitIndex, boolean value) RedissonBitSet.setAsync
(long fromIndex, long toIndex) RedissonBitSet.setAsync
(long fromIndex, long toIndex, boolean value) RedissonBitSet.setByteAsync
(long offset, byte value) RedissonRingBuffer.setCapacityAsync
(int capacity) RedissonBucket.setIfAbsentAsync
(V value) RedissonBucket.setIfAbsentAsync
(V value, Duration duration) RedissonJsonBucket.setIfAbsentAsync
(String path, Object value) RedissonJsonBucket.setIfAbsentAsync
(V value) RedissonJsonBucket.setIfAbsentAsync
(V value, Duration duration) RedissonBucket.setIfExistsAsync
(V value) RedissonBucket.setIfExistsAsync
(V value, long timeToLive, TimeUnit timeUnit) RedissonJsonBucket.setIfExistsAsync
(String path, Object value) RedissonJsonBucket.setIfExistsAsync
(V value) RedissonJsonBucket.setIfExistsAsync
(V value, long timeToLive, TimeUnit timeUnit) RedissonBitSet.setIntegerAsync
(long offset, int value) RedissonBitSet.setLongAsync
(long offset, long value) RedissonMapCache.setMaxSizeAsync
(int maxSize) RedissonMapCache.setMaxSizeAsync
(int maxSize, EvictionMode mode) RedissonRateLimiter.setRateAsync
(RateType type, long rate, long rateInterval, RateIntervalUnit unit) RedissonBitSet.setShortAsync
(long offset, short value) RedissonBitSet.setSignedAsync
(int size, long offset, long value) RedissonBitSet.setUnsignedAsync
(int size, long offset, long value) RedissonBitSet.sizeAsync()
RedissonBucket.sizeAsync()
RedissonDelayedQueue.sizeAsync()
RedissonJsonBucket.sizeAsync()
RedissonList.sizeAsync()
RedissonListMultimap.sizeAsync()
RedissonListMultimapValues.sizeAsync()
RedissonLocalCachedMap.sizeAsync()
RedissonMap.sizeAsync()
RedissonReliableTopic.sizeAsync()
RedissonScoredSortedSet.sizeAsync()
RedissonSet.sizeAsync()
RedissonSetCache.sizeAsync()
RedissonSetMultimap.sizeAsync()
RedissonSetMultimapValues.sizeAsync()
RedissonStream.sizeAsync()
RedissonSubList.sizeAsync()
RedissonTimeSeries.sizeAsync()
RedissonTransferQueue.sizeAsync()
RedissonBloomFilter.sizeInMemoryAsync()
RedissonBoundedBlockingQueue.sizeInMemoryAsync()
RedissonDelayedQueue.sizeInMemoryAsync()
RedissonFairLock.sizeInMemoryAsync()
RedissonIdGenerator.sizeInMemoryAsync()
RedissonListMultimapCache.sizeInMemoryAsync()
RedissonListMultimapValues.sizeInMemoryAsync()
RedissonLocalCachedMap.sizeInMemoryAsync()
RedissonMapCache.sizeInMemoryAsync()
RedissonMultimap.sizeInMemoryAsync()
RedissonMultimapCache.sizeInMemoryAsync()
RedissonObject.sizeInMemoryAsync()
RedissonObject.sizeInMemoryAsync
(List<Object> keys) RedissonObject.sizeInMemoryAsync
(CommandAsyncExecutor commandExecutor, List<Object> keys) RedissonPermitExpirableSemaphore.sizeInMemoryAsync()
RedissonReliableTopic.sizeInMemoryAsync()
RedissonSetMultimapCache.sizeInMemoryAsync()
RedissonSetMultimapValues.sizeInMemoryAsync()
RedissonTimeSeries.sizeInMemoryAsync()
RedissonList.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order) RedissonList.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonList.sortToAsync
(String destName, String byPattern, SortOrder order) RedissonList.sortToAsync
(String destName, String byPattern, SortOrder order, int offset, int count) RedissonList.sortToAsync
(String destName, SortOrder order) RedissonList.sortToAsync
(String destName, SortOrder order, int offset, int count) RedissonListMultimapValues.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order) RedissonListMultimapValues.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonListMultimapValues.sortToAsync
(String destName, String byPattern, SortOrder order) RedissonListMultimapValues.sortToAsync
(String destName, String byPattern, SortOrder order, int offset, int count) RedissonListMultimapValues.sortToAsync
(String destName, SortOrder order) RedissonListMultimapValues.sortToAsync
(String destName, SortOrder order, int offset, int count) RedissonScoredSortedSet.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order) RedissonScoredSortedSet.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonScoredSortedSet.sortToAsync
(String destName, String byPattern, SortOrder order) RedissonScoredSortedSet.sortToAsync
(String destName, String byPattern, SortOrder order, int offset, int count) RedissonScoredSortedSet.sortToAsync
(String destName, SortOrder order) RedissonScoredSortedSet.sortToAsync
(String destName, SortOrder order, int offset, int count) RedissonSet.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order) RedissonSet.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonSet.sortToAsync
(String destName, String byPattern, SortOrder order) RedissonSet.sortToAsync
(String destName, String byPattern, SortOrder order, int offset, int count) RedissonSet.sortToAsync
(String destName, SortOrder order) RedissonSet.sortToAsync
(String destName, SortOrder order, int offset, int count) RedissonSetMultimapValues.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order) RedissonSetMultimapValues.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonSetMultimapValues.sortToAsync
(String destName, String byPattern, SortOrder order) RedissonSetMultimapValues.sortToAsync
(String destName, String byPattern, SortOrder order, int offset, int count) RedissonSetMultimapValues.sortToAsync
(String destName, SortOrder order) RedissonSetMultimapValues.sortToAsync
(String destName, SortOrder order, int offset, int count) RedissonFuction.statsAsync()
RedissonGeo.storeSearchToAsync
(String destName, GeoSearchArgs args) RedissonGeo.storeSortedSearchToAsync
(String destName, GeoSearchArgs args) RedissonJsonBucket.stringAppendAsync
(String path, Object value) RedissonJsonBucket.stringAppendMultiAsync
(String path, Object value) RedissonJsonBucket.stringSizeAsync
(String path) RedissonJsonBucket.stringSizeMultiAsync
(String path) RedissonBaseAdder.sumAsync()
RedissonKeys.swapdbAsync
(int db1, int db2) RedissonBlockingDeque.takeAsync()
RedissonBlockingQueue.takeAsync()
RedissonBoundedBlockingQueue.takeAsync()
RedissonPriorityBlockingDeque.takeAsync()
RedissonPriorityBlockingQueue.takeAsync()
RedissonTransferQueue.takeAsync()
RedissonBlockingDeque.takeFirstAsync()
RedissonPriorityBlockingDeque.takeFirstAsync()
RedissonScoredSortedSet.takeFirstAsync()
RedissonBlockingDeque.takeLastAndOfferFirstToAsync
(String queueName) RedissonBlockingQueue.takeLastAndOfferFirstToAsync
(String queueName) RedissonBoundedBlockingQueue.takeLastAndOfferFirstToAsync
(String queueName) RedissonPriorityBlockingDeque.takeLastAndOfferFirstToAsync
(String queueName) RedissonPriorityBlockingQueue.takeLastAndOfferFirstToAsync
(String queueName) RedissonTransferQueue.takeLastAndOfferFirstToAsync
(String queueName) RedissonBlockingDeque.takeLastAsync()
RedissonPriorityBlockingDeque.takeLastAsync()
RedissonScoredSortedSet.takeLastAsync()
RFuture<byte[]>
RedissonBitSet.toByteArrayAsync()
RedissonJsonBucket.toggleAsync
(String path) RedissonJsonBucket.toggleMultiAsync
(String path) RedissonKeys.touchAsync
(String... names) RedissonObject.touchAsync()
RedissonTransferQueue.transferAsync
(V v) RedissonList.trimAsync
(int fromIndex, int toIndex) RedissonListMultimapValues.trimAsync
(int fromIndex, int toIndex) RedissonStream.trimAsync
(int count) RedissonStream.trimAsync
(StreamTrimArgs args) RedissonStream.trimAsync
(TrimStrategy strategy, int threshold) RedissonSubList.trimAsync
(int fromIndex, int toIndex) RedissonStream.trimNonStrictAsync
(int count) RedissonStream.trimNonStrictAsync
(StreamTrimArgs args) RedissonStream.trimNonStrictAsync
(TrimStrategy strategy, int threshold) RedissonStream.trimNonStrictAsync
(TrimStrategy strategy, int threshold, int limit) RedissonPermitExpirableSemaphore.tryAcquireAsync()
RedissonPermitExpirableSemaphore.tryAcquireAsync
(long waitTime, long ttl, TimeUnit unit) RedissonPermitExpirableSemaphore.tryAcquireAsync
(long waitTime, TimeUnit unit) RedissonQueueSemaphore.tryAcquireAsync
(int permits) RedissonRateLimiter.tryAcquireAsync()
RedissonRateLimiter.tryAcquireAsync
(long permits) RedissonRateLimiter.tryAcquireAsync
(long permits, long timeout, TimeUnit unit) RedissonRateLimiter.tryAcquireAsync
(long timeout, TimeUnit unit) RedissonSemaphore.tryAcquireAsync()
RedissonSemaphore.tryAcquireAsync
(int permits) RedissonSemaphore.tryAcquireAsync
(int permits, long waitTime, TimeUnit unit) RedissonSemaphore.tryAcquireAsync
(long waitTime, TimeUnit unit) RedissonGeo.tryAddAsync
(double longitude, double latitude, V member) RedissonGeo.tryAddAsync
(GeoEntry... entries) RedissonScoredSortedSet.tryAddAsync
(double score, V object) RedissonSet.tryAddAsync
(V... values) RedissonSetCache.tryAddAsync
(long ttl, TimeUnit unit, V... values) RedissonSetCache.tryAddAsync
(V... values) RedissonSetMultimapValues.tryAddAsync
(V... values) RedissonRemoteService.tryExecuteAsync
(Class<T> remoteInterface, T object) RedissonRemoteService.tryExecuteAsync
(Class<T> remoteInterface, T object, long timeout, TimeUnit timeUnit) RedissonRemoteService.tryExecuteAsync
(Class<T> remoteInterface, T object, ExecutorService executor, long timeout, TimeUnit timeUnit) RedissonIdGenerator.tryInitAsync
(long value, long allocationSize) RedissonLock.tryLockAsync()
RedissonLock.tryLockAsync
(long threadId) RedissonLock.tryLockAsync
(long waitTime, long leaseTime, TimeUnit unit) RedissonLock.tryLockAsync
(long waitTime, long leaseTime, TimeUnit unit, long currentThreadId) RedissonLock.tryLockAsync
(long waitTime, TimeUnit unit) RedissonMultiLock.tryLockAsync()
RedissonMultiLock.tryLockAsync
(long threadId) RedissonMultiLock.tryLockAsync
(long waitTime, long leaseTime, TimeUnit unit) RedissonMultiLock.tryLockAsync
(long waitTime, long leaseTime, TimeUnit unit, long threadId) RedissonMultiLock.tryLockAsync
(long waitTime, TimeUnit unit) RedissonSpinLock.tryLockAsync()
RedissonSpinLock.tryLockAsync
(long threadId) RedissonSpinLock.tryLockAsync
(long waitTime, long leaseTime, TimeUnit unit) RedissonSpinLock.tryLockAsync
(long waitTime, long leaseTime, TimeUnit unit, long currentThreadId) RedissonSpinLock.tryLockAsync
(long waitTime, TimeUnit unit) RedissonPermitExpirableSemaphore.tryReleaseAsync
(String permitId) RedissonBucket.trySetAsync
(V value) RedissonBucket.trySetAsync
(V value, long timeToLive, TimeUnit timeUnit) RedissonBuckets.trySetAsync
(Map<String, ?> buckets) RedissonJsonBucket.trySetAsync
(String path, Object value) RedissonJsonBucket.trySetAsync
(V value) RedissonJsonBucket.trySetAsync
(V value, long timeToLive, TimeUnit timeUnit) RedissonBoundedBlockingQueue.trySetCapacityAsync
(int capacity) RedissonRingBuffer.trySetCapacityAsync
(int capacity) RedissonCountDownLatch.trySetCountAsync
(long count) RedissonMapCache.trySetMaxSizeAsync
(int maxSize) RedissonMapCache.trySetMaxSizeAsync
(int maxSize, EvictionMode mode) RedissonPermitExpirableSemaphore.trySetPermitsAsync
(int permits) RedissonSemaphore.trySetPermitsAsync
(int permits) RedissonRateLimiter.trySetRateAsync
(RateType type, long rate, long rateInterval, RateIntervalUnit unit) RedissonTransferQueue.tryTransferAsync
(V v) RedissonTransferQueue.tryTransferAsync
(V v, long timeout, TimeUnit unit) RedissonScoredSortedSet.unionAsync
(String... names) RedissonScoredSortedSet.unionAsync
(Map<String, Double> nameWithWeight) RedissonScoredSortedSet.unionAsync
(RScoredSortedSet.Aggregate aggregate, String... names) RedissonScoredSortedSet.unionAsync
(RScoredSortedSet.Aggregate aggregate, Map<String, Double> nameWithWeight) RedissonSet.unionAsync
(String... names) RedissonSetMultimapValues.unionAsync
(String... names) RedissonKeys.unlinkAsync
(String... keys) RedissonObject.unlinkAsync()
RedissonBaseLock.unlockAsync()
RedissonBaseLock.unlockAsync
(long threadId) RedissonMultiLock.unlockAsync()
RedissonMultiLock.unlockAsync
(long threadId) RedissonBaseLock.unlockInnerAsync
(long threadId) RedissonFairLock.unlockInnerAsync
(long threadId) RedissonLock.unlockInnerAsync
(long threadId) RedissonMultiLock.unlockInnerAsync
(Collection<RLock> locks, long threadId) RedissonReadLock.unlockInnerAsync
(long threadId) RedissonSpinLock.unlockInnerAsync
(long threadId) RedissonWriteLock.unlockInnerAsync
(long threadId) RedissonMapCache.updateEntryExpirationAsync
(K key, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) RedissonStream.updateGroupMessageIdAsync
(String groupName, StreamMessageId id) RedissonPermitExpirableSemaphore.updateLeaseTimeAsync
(String permitId, long leaseTime, TimeUnit unit) RedissonScoredSortedSet.valueRangeAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) RedissonScoredSortedSet.valueRangeAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) RedissonScoredSortedSet.valueRangeAsync
(int startIndex, int endIndex) RedissonScoredSortedSet.valueRangeReversedAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) RedissonScoredSortedSet.valueRangeReversedAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) RedissonScoredSortedSet.valueRangeReversedAsync
(int startIndex, int endIndex) RedissonMap.valueSizeAsync
(K key) protected final <T,
R> RFuture<R> RedissonPriorityQueue.wrapLockedAsync
(Supplier<RFuture<R>> callable) RedissonPriorityQueue.wrapLockedAsync
(RedisCommand<T> command, Object... params) Modifier and TypeMethodDescriptionprotected final <V> V
protected final <M> RFuture<M>
RedissonMap.mapWriterFuture
(RFuture<M> future, MapWriterTask task) protected final <M> RFuture<M>
RedissonMap.mapWriterFuture
(RFuture<M> future, MapWriterTask task, Function<M, Boolean> condition) void
Modifier and TypeMethodDescription<V> int
ElementsSubscribeService.subscribeOnElements
(Supplier<RFuture<V>> func, Consumer<V> consumer) protected final <T,
R> RFuture<R> RedissonPriorityQueue.wrapLockedAsync
(Supplier<RFuture<R>> callable) -
Uses of RFuture in org.redisson.api
Modifier and TypeInterfaceDescriptioninterface
Future object for submitted tasks in a batchinterface
Future object for submitted taskinterface
Modifier and TypeMethodDescriptionRStreamAsync.ackAsync
(String groupName, StreamMessageId... ids) Marks pending messages by group name and streamids
as correctly processed.RPermitExpirableSemaphoreAsync.acquireAsync()
Acquires a permit and returns its id.RPermitExpirableSemaphoreAsync.acquireAsync
(long leaseTime, TimeUnit unit) Acquires a permit with definedleaseTime
and return its id.RRateLimiterAsync.acquireAsync()
Acquires a permit from this RateLimiter, blocking until one is available.RRateLimiterAsync.acquireAsync
(long permits) Acquires a specifiedpermits
from this RateLimiter, blocking until one is available.RSemaphoreAsync.acquireAsync()
Acquires a permit.RSemaphoreAsync.acquireAsync
(int permits) Acquires defined amount ofpermits
.RListAsync.addAfterAsync
(V elementToFind, V element) Insertselement
afterelementToFind
RCollectionAsync.addAllAsync
(Collection<? extends V> c) Adds all elements contained in the specified collectionRHyperLogLogAsync.addAllAsync
(Collection<V> objects) Adds all elements contained inobjects
collection into this structureRListAsync.addAllAsync
(int index, Collection<? extends V> elements) Insertselements
atindex
.RScoredSortedSetAsync.addAllAsync
(Map<V, Double> objects) Adds all elements contained in the specified map to this sorted set.RStreamAsync.addAllAsync
(Map<K, V> entries) Deprecated.RStreamAsync.addAllAsync
(Map<K, V> entries, int trimLen, boolean trimStrict) Deprecated.RStreamAsync.addAllAsync
(StreamMessageId id, Map<K, V> entries) Deprecated.RStreamAsync.addAllAsync
(StreamMessageId id, Map<K, V> entries, int trimLen, boolean trimStrict) Deprecated.RTimeSeriesAsync.addAllAsync
(Collection<TimeSeriesEntry<V, L>> entries) Adds all entries collection to this time-series collection.RTimeSeriesAsync.addAllAsync
(Collection<TimeSeriesEntry<V, L>> entries, Duration timeToLive) Adds all time series entries collection to this time-series collection.RTimeSeriesAsync.addAllAsync
(Map<Long, V> objects) Adds all elements contained in the specified map to this time-series collection.RTimeSeriesAsync.addAllAsync
(Map<Long, V> objects, long timeToLive, TimeUnit timeUnit) Adds all elements contained in the specified map to this time-series collection.RSetAsync.addAllCountedAsync
(Collection<? extends V> c) Adds all elements contained in the specified collection.RScoredSortedSetAsync.addAllIfAbsentAsync
(Map<V, Double> objects) Adds elements to this set only if they haven't been added before.RScoredSortedSetAsync.addAllIfExistAsync
(Map<V, Double> objects) Adds elements to this set only if they already exist.RScoredSortedSetAsync.addAllIfGreaterAsync
(Map<V, Double> objects) Adds elements to this set only if new scores greater than current score of existed elements.RScoredSortedSetAsync.addAllIfLessAsync
(Map<V, Double> objects) Adds elements to this set only if new scores less than current score of existed elements.RAtomicDoubleAsync.addAndGetAsync
(double delta) Atomically adds the given value to the current value.RAtomicLongAsync.addAndGetAsync
(long delta) Atomically adds the given value to the current value.RMapAsync.addAndGetAsync
(K key, Number delta) Adds the givendelta
to the current value by mappedkey
.RScoredSortedSetAsync.addAndGetRankAsync
(double score, V object) Adds element to this set, overrides previous score if it has been already added.RScoredSortedSetAsync.addAndGetRevRankAsync
(double score, V object) Adds element to this set, overrides previous score if it has been already added.RScoredSortedSetAsync.addAndGetRevRankAsync
(Map<? extends V, Double> map) Adds elements to this set, overrides previous score if it has been already added.Adds element into this collection.Adds geospatial member.Adds geospatial members.Adds element into this structure.Insertselement
atindex
.Adds element to this set, overrides previous score if it has been already added.Stores value with specified time to live.Deprecated.Deprecated.RStreamAsync.addAsync
(StreamAddArgs<K, V> args) Appends a new entry/entries and returns generated Stream Message IDRStreamAsync.addAsync
(StreamMessageId id, K key, V value) Deprecated.RStreamAsync.addAsync
(StreamMessageId id, K key, V value, int trimLen, boolean trimStrict) Deprecated.RStreamAsync.addAsync
(StreamMessageId id, StreamAddArgs<K, V> args) Appends a new entry/entries by specified Stream Message IDAdds element to this time-series collection by specifiedtimestamp
.Adds element to this time-series collection by specifiedtimestamp
.Adds element withlabel
to this time-series collection by specifiedtimestamp
.Adds element withlabel
to this time-series collection by specifiedtimestamp
.RListAsync.addBeforeAsync
(V elementToFind, V element) Insertselement
beforeelementToFind
RDequeAsync.addFirstAsync
(V e) Adds element at the head of this deque.RDequeAsync.addFirstAsync
(V... elements) Adds elements at the head of deque.RDequeAsync.addFirstIfExistsAsync
(V... elements) Adds element at the head of existing deque.RScoredSortedSetAsync.addIfAbsentAsync
(double score, V object) Adds element to this set only if has not been added before.RGeoAsync.addIfExistsAsync
(double longitude, double latitude, V member) Adds geospatial member only if it's already exists.RGeoAsync.addIfExistsAsync
(GeoEntry... entries) Adds geospatial members only if it's already exists.RScoredSortedSetAsync.addIfExistsAsync
(double score, V object) Adds element to this set only if it's already exists.RScoredSortedSetAsync.addIfGreaterAsync
(double score, V object) Adds element to this set only if new score greater than current score of existed element.RScoredSortedSetAsync.addIfLessAsync
(double score, V object) Adds element to this set only if new score less than current score of existed element.RDequeAsync.addLastAsync
(V e) Adds element at the tail of this deque.RDequeAsync.addLastAsync
(V... elements) Adds elements at the tail of deque.RDequeAsync.addLastIfExistsAsync
(V... elements) Adds element at the tail of existing deque.RBucketAsync.addListenerAsync
(ObjectListener listener) Adds object event listenerRListAsync.addListenerAsync
(ObjectListener listener) Adds object event listenerRObjectAsync.addListenerAsync
(ObjectListener listener) Adds object event listenerRPatternTopic.addListenerAsync
(Class<T> type, PatternMessageListener<T> listener) RPatternTopic.addListenerAsync
(PatternStatusListener listener) RQueueAsync.addListenerAsync
(ObjectListener listener) Adds object event listenerRReliableTopicAsync.addListenerAsync
(Class<M> type, MessageListener<M> listener) Subscribes to this topic.RTopicAsync.addListenerAsync
(Class<M> type, MessageListener<M> listener) Subscribes to this topic.RTopicAsync.addListenerAsync
(StatusListener listener) Subscribes to status changes of this topicRPermitExpirableSemaphoreAsync.addPermitsAsync
(int permits) Increases or decreases the number of available permits by defined value.RSemaphoreAsync.addPermitsAsync
(int permits) Increases or decreases the number of available permits by defined value.RScoredSortedSetAsync.addScoreAndGetRankAsync
(V object, Number value) Adds score to element and returns its rankRScoredSortedSetAsync.addScoreAndGetRevRankAsync
(V object, Number value) Adds score to element and returns its reverse rankRScoredSortedSetAsync.addScoreAsync
(V element, Number value) Increases score of specified element by value.Executes AND operation over this object and specified bitsets.RJsonBucketAsync.arrayAppendAsync
(String path, Object... values) Appends values to array specified by JSONPath.RJsonBucketAsync.arrayAppendMultiAsync
(String path, Object... values) Appends values to arrays specified by JSONPath.RJsonBucketAsync.arrayIndexAsync
(String path, Object value) Returns index of object in array specified by JSONPathRJsonBucketAsync.arrayIndexAsync
(String path, Object value, long start, long end) Returns index of object in array specified by JSONPath in range betweenstart
(inclusive) andend
(exclusive) indexesRJsonBucketAsync.arrayIndexMultiAsync
(String path, Object value) Returns index of object in arrays specified by JSONPathRJsonBucketAsync.arrayIndexMultiAsync
(String path, Object value, long start, long end) Returns index of object in arrays specified by JSONPath in range betweenstart
(inclusive) andend
(exclusive) indexesRJsonBucketAsync.arrayInsertAsync
(String path, long index, Object... values) Inserts values into array specified by JSONPath.RJsonBucketAsync.arrayInsertMultiAsync
(String path, long index, Object... values) Inserts values into arrays specified by JSONPath.<T> RFuture<T>
RJsonBucketAsync.arrayPollFirstAsync
(JsonCodec<T> codec, String path) Polls first element of array specified by JSONPath.RJsonBucketAsync.arrayPollFirstMultiAsync
(JsonCodec<T> codec, String path) Polls first element of arrays specified by JSONPath.<T> RFuture<T>
RJsonBucketAsync.arrayPollLastAsync
(JsonCodec<T> codec, String path) Polls last element of array specified by JSONPath.RJsonBucketAsync.arrayPollLastMultiAsync
(JsonCodec<T> codec, String path) Polls last element of arrays specified by JSONPath.<T> RFuture<T>
RJsonBucketAsync.arrayPopAsync
(JsonCodec<T> codec, String path, long index) Pops element located at index of array specified by JSONPath.RJsonBucketAsync.arrayPopMultiAsync
(JsonCodec<T> codec, String path, long index) Pops elements located at index of arrays specified by JSONPath.RJsonBucketAsync.arraySizeAsync
(String path) Returns size of array specified by JSONPath.RJsonBucketAsync.arraySizeMultiAsync
(String path) Returns size of arrays specified by JSONPath.RJsonBucketAsync.arrayTrimAsync
(String path, long start, long end) Trims array specified by JSONPath in range betweenstart
(inclusive) andend
(inclusive) indexes.RJsonBucketAsync.arrayTrimMultiAsync
(String path, long start, long end) Trims arrays specified by JSONPath in range betweenstart
(inclusive) andend
(inclusive) indexes.RStreamAsync.autoClaimAsync
(String groupName, String consumerName, long idleTime, TimeUnit idleTimeUnit, StreamMessageId startId, int count) Transfers ownership of pending messages by id to a new consumer by name if idle time of messages and startId are greater than defined value.RPermitExpirableSemaphoreAsync.availablePermitsAsync()
Returns amount of available permits.RRateLimiterAsync.availablePermitsAsync()
Returns amount of available permits.RSemaphoreAsync.availablePermitsAsync()
Returns amount of available permits.RFuture.await()
Deprecated.RCountDownLatchAsync.awaitAsync()
Waits until counter reach zero.RCountDownLatchAsync.awaitAsync
(long waitTime, TimeUnit unit) Waits until counter reach zero or up to definedtimeout
.RFuture.awaitUninterruptibly()
Deprecated.<R> RFuture<R>
RFunctionAsync.callAsync
(String key, FunctionMode mode, String name, FunctionResult returnType, List<Object> keys, Object... values) Executes function<R> RFuture<R>
RFunctionAsync.callAsync
(FunctionMode mode, String name, FunctionResult returnType) Executes function<R> RFuture<R>
RFunctionAsync.callAsync
(FunctionMode mode, String name, FunctionResult returnType, List<Object> keys, Object... values) Executes functionRExecutorServiceAsync.cancelTaskAsync
(String taskId) Cancel task by idRRingBufferAsync.capacityAsync()
Returns capacity of this queueRBitSetAsync.cardinalityAsync()
Returns the number of bits set to one.RStreamAsync.claimAsync
(String groupName, String consumerName, long idleTime, TimeUnit idleTimeUnit, StreamMessageId... ids) Transfers ownership of pending messages by id to a new consumer by name if idle time of messages is greater than defined value.CacheAsync.clearAsync()
This method empties the cache's contents, without notifying listeners orCacheWriter
s.RBitSetAsync.clearAsync()
Set all bits to zeroRBitSetAsync.clearAsync
(long bitIndex) Set bit to zero at specifiedbitIndex
RBitSetAsync.clearAsync
(long fromIndex, long toIndex) Set all bits to zero fromfromIndex
(inclusive) totoIndex
(exclusive)RJsonBucketAsync.clearAsync()
Clears json container.RJsonBucketAsync.clearAsync
(String path) Clears json container specified by JSONPath.RExpirableAsync.clearExpireAsync()
Clear an expire timeout or expire date for object in async mode.RKeysAsync.clearExpireAsync
(String name) Clear an expire timeout or expire date for object.RLocalCachedMap.clearLocalCacheAsync()
Clears local cache across all instancesNodeAsync.clusterInfoAsync()
Deprecated.RTransaction.commitAsync()
Commits all changes made on this transaction in async mode.RAtomicDoubleAsync.compareAndSetAsync
(double expect, double update) Atomically sets the value to the given updated value only if the current value==
the expected value.RAtomicLongAsync.compareAndSetAsync
(long expect, long update) Atomically sets the value to the given updated value only if the current value==
the expected value.RBucketAsync.compareAndSetAsync
(V expect, V update) Atomically sets the value to the given updated value only if serialized state of the current value equals to serialized state of the expected value.RJsonBucketAsync.compareAndSetAsync
(String path, Object expect, Object update) Atomically sets the value to the given updated value by given JSONPath, only if serialized state of the current value equals to serialized state of the expected value.RMapAsync.computeAsync
(K key, BiFunction<? super K, ? super V, ? extends V> remappingFunction) Computes a new mapping for the specified key and its current mapped value.RMapAsync.computeIfAbsentAsync
(K key, Function<? super K, ? extends V> mappingFunction) Computes a mapping for the specified key if it's not mapped before.RMapAsync.computeIfPresentAsync
(K key, BiFunction<? super K, ? super V, ? extends V> remappingFunction) Computes a mapping for the specified key only if it's already mapped.RCollectionAsync.containsAllAsync
(Collection<?> c) Returnstrue
if this collection contains all of the elements in the specified collection.RScoredSortedSetAsync.containsAllAsync
(Collection<?> c) Returnstrue
if this sorted set contains all of the elements in encoded state in the specified collection.RCollectionAsync.containsAsync
(Object o) Returnstrue
if this collection contains encoded state of the specified element.RScoredSortedSetAsync.containsAsync
(Object o) Returnstrue
if this sorted set contains encoded state of the specified element.RMultimapAsync.containsEntryAsync
(Object key, Object value) Returnstrue
if this multimap contains at least one key-value pair with the keykey
and the valuevalue
.CacheAsync.containsKeyAsync
(K key) This method returns a Boolean true/false value, depending on whether theCacheAsync
has a mapping for a key k such that key.equals(k).RMapAsync.containsKeyAsync
(Object key) Returnstrue
if this map contains map entry mapped by specifiedkey
, otherwisefalse
RMultimapAsync.containsKeyAsync
(Object key) Returnstrue
if this multimap contains at least one key-value pair with the keykey
.RMapAsync.containsValueAsync
(Object value) Returnstrue
if this map contains any map entry with specifiedvalue
, otherwisefalse
RMultimapAsync.containsValueAsync
(Object value) Returnstrue
if this multimap contains at least one key-value pair with the valuevalue
.Copy object from source Redis instance to destination Redis instance in async modeCopy object from source Redis instance to destination Redis instance in async modeRHyperLogLogAsync.countAsync()
Returns approximated number of unique elements added into this structure.RKeysAsync.countAsync()
Returns the number of keys in the currently-selected database in async modeRLexSortedSetAsync.countAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive) Returns the number of elements betweenfromElement
andtoElement
.RScoredSortedSetAsync.countAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) Returns the number of elements with a score betweenstartScore
andendScore
.RCountDownLatchAsync.countDownAsync()
Decrements the counter of the latch.RKeysAsync.countExistsAsync
(String... names) Checks if provided keys existRLexSortedSetAsync.countHeadAsync
(String toElement, boolean toInclusive) Returns the number of head values ending withtoElement
.RScoredSortedSetAsync.countIntersectionAsync
(int limit, String... names) Counts elements of set as a result of sets intersection with current set.RScoredSortedSetAsync.countIntersectionAsync
(String... names) Counts elements of set as a result of sets intersection with current set.RSetAsync.countIntersectionAsync
(int limit, String... names) Counts elements of set as a result of sets intersection with current set.RSetAsync.countIntersectionAsync
(String... names) Counts elements of set as a result of sets intersection with current set.RJsonBucketAsync.countKeysAsync()
Returns keys amount in JSON containerRJsonBucketAsync.countKeysAsync
(String path) Returns keys amount in JSON container specified by JSONPathRJsonBucketAsync.countKeysMultiAsync
(String path) Returns list of keys amount in JSON containers specified by JSONPathRReliableTopicAsync.countSubscribersAsync()
Returns amount of subscribers to this topic across all Redisson instances.RTopicAsync.countSubscribersAsync()
Returns amount of subscribers to this topic across all Redisson instances.RLexSortedSetAsync.countTailAsync
(String fromElement, boolean fromInclusive) Returns the number of tail values starting withfromElement
.RHyperLogLogAsync.countWithAsync
(String... otherLogNames) Returns approximated number of unique elements added into this instances and other instances defined throughotherLogNames
.RStreamAsync.createConsumerAsync
(String groupName, String consumerName) Creates consumer of the group by name.RStreamAsync.createGroupAsync
(String groupName) Creates consumer group by name.RStreamAsync.createGroupAsync
(String groupName, StreamMessageId id) Creates consumer group by name and stream id.RAtomicDoubleAsync.decrementAndGetAsync()
Atomically decrements the current value by one.RAtomicLongAsync.decrementAndGetAsync()
Atomically decrements the current value by one.RExecutorServiceAsync.deleteAsync()
Deletes executor request queue and state objectsRFunctionAsync.deleteAsync
(String libraryName) Deletes library.RJsonBucketAsync.deleteAsync
(String path) Deletes JSON elements specified by JSONPathRKeysAsync.deleteAsync
(String... keys) Delete multiple objects by nameRKeysAsync.deleteAsync
(RObject... objects) Delete multiple objectsRObjectAsync.deleteAsync()
Delete object in async modeRKeysAsync.deleteByPatternAsync
(String pattern) Delete multiple objects by a key pattern.Diff provided ScoredSortedSets and store result to current ScoredSortedSetDiff sets specified by name and write to current set.RBatch.discardAsync()
Discard batched commands and release allocated buffers used for parameters encoding.Returns distance between members inGeoUnit
units.RSemaphoreAsync.drainPermitsAsync()
Acquires and returns all permits that are immediately available.RBlockingQueueAsync.drainToAsync
(Collection<? super V> c) Removes all available elements from this queue and adds them to the given collection in async mode.RBlockingQueueAsync.drainToAsync
(Collection<? super V> c, int maxElements) Removes at most the given number of available elements from this queue and adds them to the given collection in async mode.RFuture<byte[]>
RFunctionAsync.dumpAsync()
Returns serialized state of all libraries.RFuture<byte[]>
RObjectAsync.dumpAsync()
Returns dump of objectRScoredSortedSetAsync.entryRangeAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) Returns all entries (value and its score) betweenstartScore
andendScore
.RScoredSortedSetAsync.entryRangeAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) Returns all entries (value and its score) betweenstartScore
andendScore
.RScoredSortedSetAsync.entryRangeAsync
(int startIndex, int endIndex) Returns entries (value and its score) by rank range.RTimeSeriesAsync.entryRangeAsync
(long startTimestamp, long endTimestamp) Returns ordered entries of this time-series collection within timestamp range.RTimeSeriesAsync.entryRangeAsync
(long startTimestamp, long endTimestamp, int limit) Returns ordered entries of this time-series collection within timestamp range.RScoredSortedSetAsync.entryRangeReversedAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) Returns all entries (value and its score) betweenstartScore
andendScore
in reversed order.RScoredSortedSetAsync.entryRangeReversedAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) Returns all entries (value and its score) betweenstartScore
andendScore
in reversed order.RScoredSortedSetAsync.entryRangeReversedAsync
(int startIndex, int endIndex) Returns entries (value and its score) by rank range in reverse order.RTimeSeriesAsync.entryRangeReversedAsync
(long startTimestamp, long endTimestamp) Returns entries of this time-series collection in reverse order within timestamp range.RTimeSeriesAsync.entryRangeReversedAsync
(long startTimestamp, long endTimestamp, int limit) Returns entries of this time-series collection in reverse order within timestamp range.<R> RFuture<R>
RScriptAsync.evalAsync
(String key, RScript.Mode mode, String luaScript, RScript.ReturnType returnType, List<Object> keys, Object... values) Executes Lua script<R> RFuture<R>
RScriptAsync.evalAsync
(RScript.Mode mode, String luaScript, RScript.ReturnType returnType) Executes Lua script<R> RFuture<R>
RScriptAsync.evalAsync
(RScript.Mode mode, String luaScript, RScript.ReturnType returnType, List<Object> keys, Object... values) Executes Lua script<R> RFuture<R>
RScriptAsync.evalShaAsync
(String key, RScript.Mode mode, String shaDigest, RScript.ReturnType returnType, List<Object> keys, Object... values) Executes Lua script stored in Redis scripts cache by SHA-1 digest<R> RFuture<R>
RScriptAsync.evalShaAsync
(RScript.Mode mode, String shaDigest, RScript.ReturnType returnType) Executes Lua script stored in Redis scripts cache by SHA-1 digest<R> RFuture<R>
RScriptAsync.evalShaAsync
(RScript.Mode mode, String shaDigest, RScript.ReturnType returnType, List<Object> keys, Object... values) Executes Lua script stored in Redis scripts cache by SHA-1 digestRFuture<BatchResult<?>>
RBatch.executeAsync()
Executes all operations accumulated during async methods invocations asynchronously.RExpirableAsync.expireAsync
(long timeToLive, TimeUnit timeUnit) Deprecated.RExpirableAsync.expireAsync
(Duration duration) Set a timeout for object.RExpirableAsync.expireAsync
(Instant time) Set an expire date for object.RKeysAsync.expireAsync
(String name, long timeToLive, TimeUnit timeUnit) Set a timeout for object.RExpirableAsync.expireAtAsync
(long timestamp) Deprecated.RExpirableAsync.expireAtAsync
(Date timestamp) Deprecated.RKeysAsync.expireAtAsync
(String name, long timestamp) Set an expire date for object.RExpirableAsync.expireIfGreaterAsync
(Duration duration) Sets a timeout for this object only if it's greater than timeout set before.RExpirableAsync.expireIfGreaterAsync
(Instant time) Sets an expiration date for this object only if it's greater than expiration date set before.RExpirableAsync.expireIfLessAsync
(Duration duration) Sets a timeout for this object only if it's less than timeout set before.RExpirableAsync.expireIfLessAsync
(Instant time) Sets an expiration date for this object only if it's less than expiration date set before.RExpirableAsync.expireIfNotSetAsync
(Duration duration) Sets a timeout for this object only if it hasn't been set before.RExpirableAsync.expireIfNotSetAsync
(Instant time) Sets an expiration date for this object only if it hasn't been set before.RExpirableAsync.expireIfSetAsync
(Duration duration) Sets a timeout for this object only if it has been already set.RExpirableAsync.expireIfSetAsync
(Instant time) Sets an expiration date for this object only if it has been already set.RMultimapCacheAsync.expireKeyAsync
(K key, long timeToLive, TimeUnit timeUnit) Set a timeout for key in async mode.RStreamAsync.fastAutoClaimAsync
(String groupName, String consumerName, long idleTime, TimeUnit idleTimeUnit, StreamMessageId startId, int count) Transfers ownership of pending messages by id to a new consumer by name if idle time of messages and startId are greater than defined value.RStreamAsync.fastClaimAsync
(String groupName, String consumerName, long idleTime, TimeUnit idleTimeUnit, StreamMessageId... ids) Transfers ownership of pending messages by id to a new consumer by name if idle time of messages is greater than defined value.RMapAsync.fastPutAsync
(K key, V value) Stores the specifiedvalue
mapped by specifiedkey
.RMapCacheAsync.fastPutAsync
(K key, V value, long ttl, TimeUnit unit) Stores value mapped by key with specified time to live.RMapCacheAsync.fastPutAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) Stores value mapped by key with specified time to live and max idle time.RMapAsync.fastPutIfAbsentAsync
(K key, V value) Stores the specifiedvalue
mapped by specifiedkey
only if there is no value with specifiedkey
stored before.RMapCacheAsync.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.RMapAsync.fastPutIfExistsAsync
(K key, V value) Stores the specifiedvalue
mapped bykey
only if mapping already exists.RListAsync.fastRemoveAsync
(int index) Removes element atindex
.RMapAsync.fastRemoveAsync
(K... keys) Removes map entries mapped by specifiedkeys
.RMultimapAsync.fastRemoveAsync
(K... keys) Removeskeys
from map by one operation Works faster thanRMultimap.remove
but not returning the value associated withkey
RMapAsync.fastReplaceAsync
(K key, V value) Replaces previous value with a newvalue
mapped by specifiedkey
.RListAsync.fastSetAsync
(int index, V element) Setelement
atindex
.RLexSortedSetAsync.firstAsync()
Returns the first element.RScoredSortedSetAsync.firstAsync()
Returns the head element ornull
if this sorted set is empty.RTimeSeriesAsync.firstAsync()
Returns the head element ornull
if this time-series collection is empty.RTimeSeriesAsync.firstAsync
(int count) Returns the head elements of this time-series collection.RTimeSeriesAsync.firstEntriesAsync
(int count) Returns the head entries of this time-series collection.RTimeSeriesAsync.firstEntryAsync()
Returns the head entry ornull
if this time-series collection is empty.RScoredSortedSetAsync.firstScoreAsync()
Returns score of the head element or returnsnull
if this sorted set is empty.RTimeSeriesAsync.firstTimestampAsync()
Returns timestamp of the head timestamp ornull
if this time-series collection is empty.RKeysAsync.flushallAsync()
Delete all keys of all existing databasesRKeysAsync.flushallParallelAsync()
Delete all keys of all existing databases in background without blocking server.RFunctionAsync.flushAsync()
Deletes all libraries.RKeysAsync.flushdbAsync()
Delete all keys of currently selected databaseRKeysAsync.flushdbParallelAsync()
Delete all keys of currently selected database in background without blocking server.RLockAsync.forceUnlockAsync()
Unlocks the lock independently of its stateCacheAsync.getAllAsync
(Set<? extends K> keys) This method accepts a set of requested keys and retrieves a collection of entries from theCacheAsync
, returning them as aMap
of the associated values.RMapAsync.getAllAsync
(Set<K> keys) Returns map slice contained the mappings with definedkeys
.RMultimapAsync.getAllAsync
(K key) RAtomicDoubleAsync.getAndAddAsync
(double delta) Atomically adds the given value to the current value.RAtomicLongAsync.getAndAddAsync
(long delta) Atomically adds the given value to the current value.RBucketAsync.getAndClearExpireAsync()
Retrieves current element in the holder and clears expiration date set before.RAtomicDoubleAsync.getAndDecrementAsync()
Atomically decrements by one the current value.RAtomicLongAsync.getAndDecrementAsync()
Atomically decrements by one the current value.RAtomicDoubleAsync.getAndDeleteAsync()
Returns and deletes objectRAtomicLongAsync.getAndDeleteAsync()
Returns and deletes objectRBucketAsync.getAndDeleteAsync()
Retrieves element in the holder and removes it.RBucketAsync.getAndExpireAsync
(Duration duration) Retrieves current element in the holder and sets an expiration duration for it.RBucketAsync.getAndExpireAsync
(Instant time) Retrieves current element in the holder and sets an expiration date for it.RAtomicDoubleAsync.getAndIncrementAsync()
Atomically increments the current value by one.RAtomicLongAsync.getAndIncrementAsync()
Atomically increments the current value by one.CacheAsync.getAndPutAsync
(K key, V value) This method places the given key and value in the cache.CacheAsync.getAndRemoveAsync
(K key) This method atomically removes the entry for a key only if it is currently mapped to some value.RTimeSeriesAsync.getAndRemoveAsync
(long timestamp) Removes and returns object by specifiedtimestamp
.RTimeSeriesAsync.getAndRemoveEntryAsync
(long timestamp) Removes and returns entry by specifiedtimestamp
.CacheAsync.getAndReplaceAsync
(K key, V value) This method atomically replaces a given key's value if and only if the key is currently mapped to a value.RAtomicDoubleAsync.getAndSetAsync
(double newValue) Atomically sets the given value and returns the old value.RAtomicLongAsync.getAndSetAsync
(long newValue) Atomically sets the given value and returns the old value.RBucketAsync.getAndSetAsync
(V newValue) Retrieves current element in the holder and replaces it withnewValue
.RBucketAsync.getAndSetAsync
(V value, long timeToLive, TimeUnit timeUnit) Retrieves current element in the holder and replaces it withnewValue
with definedtimeToLive
interval.<T> RFuture<T>
RJsonBucketAsync.getAndSetAsync
(JsonCodec<T> codec, String path, Object newValue) Retrieves current value of element specified by JSONPath and replaces it withnewValue
.This method retrieves an entry from the cache.RAtomicDoubleAsync.getAsync()
Returns current value.RAtomicLongAsync.getAsync()
Returns current value.RBitSetAsync.getAsync
(long bitIndex) Returnstrue
if bit set to one andfalse
overwise.RBucketAsync.getAsync()
Retrieves element stored in the holder.Returns Redis object mapped by key.<T> RFuture<T>
Get Json object/objects by JSONPathRListAsync.getAsync
(int index) Get element atindex
RListAsync.getAsync
(int... indexes) Loads elements by specifiedindexes
Returns the value mapped by definedkey
ornull
if value is absent.RTimeSeriesAsync.getAsync
(long timestamp) Returns object by specifiedtimestamp
ornull
if it doesn't exist.RBitSetAsync.getByteAsync
(long offset) Returns byte number at specifiedoffset
RRateLimiterAsync.getConfigAsync()
Returns current configuration of this RateLimiter object.RCountDownLatchAsync.getCountAsync()
Returns value of current count.RTimeSeriesAsync.getEntryAsync
(long timestamp) Returns time series entry by specifiedtimestamp
ornull
if it doesn't exist.RExpirableAsync.getExpireTimeAsync()
Expiration time of Redisson object that has a timeoutRLockAsync.getHoldCountAsync()
Number of holds on this lock by the current threadRObjectAsync.getIdleTimeAsync()
Returns number of seconds spent since last write or read operation over this object.RFuture<StreamInfo<K,
V>> RStreamAsync.getInfoAsync()
Returns information about this stream.RBitSetAsync.getIntegerAsync
(long offset) Returns integer number at specifiedoffset
RJsonBucketAsync.getKeysAsync()
Returns list of keys in JSON containerRJsonBucketAsync.getKeysAsync
(String path) Returns list of keys in JSON container specified by JSONPathRJsonBucketAsync.getKeysMultiAsync
(String path) Returns list of keys in JSON containers specified by JSONPathRDequeAsync.getLastAsync()
Returns element at the tail of this deque ornull
if there are no elements in deque.RBitSetAsync.getLongAsync
(long offset) Returns long number at specifiedoffset
RStreamAsync.getPendingInfoAsync
(String groupName) Returns common info about pending messages by group name.RRemoteService.getPendingInvocationsAsync
(Class<?> remoteInterface) Returns pending invocations amount for handling in free workers.RScoredSortedSetAsync.getScoreAsync
(Collection<V> elements) Returns scores of elements.RScoredSortedSetAsync.getScoreAsync
(V o) Returns score of element ornull
if it doesn't exist.RBitSetAsync.getShortAsync
(long offset) Returns short number at specifiedoffset
RBitSetAsync.getSignedAsync
(int size, long offset) Returns signed number at specifiedoffset
andsize
RKeysAsync.getSlotAsync
(String key) Get hash slot identifier for key in async mode.RExecutorServiceAsync.getTaskCountAsync()
Returns amount of tasks awaiting execution or currently in execution.RExecutorServiceAsync.getTaskIdsAsync()
Returns list of task ids awaiting execution or currently in execution.RJsonBucketAsync.getTypeAsync()
Returns type of elementRJsonBucketAsync.getTypeAsync
(String path) Returns type of element specified by JSONPathRKeysAsync.getTypeAsync
(String key) Get Redis object type by keyRBitSetAsync.getUnsignedAsync
(int size, long offset) Returns unsigned number at specifiedoffset
andsize
RMapCacheAsync.getWithTTLOnlyAsync
(K key) Returns the value mapped by definedkey
ornull
if value is absent.Returns 11 characters Geohash string mapped by defined member.RExecutorServiceAsync.hasTaskAsync
(String taskId) Returnstrue
if this Executor Service has task bytaskId
awaiting execution or currently in executionRAtomicDoubleAsync.incrementAndGetAsync()
Atomically increments the current value by one.RAtomicLongAsync.incrementAndGetAsync()
Atomically increments the current value by one.RJsonBucketAsync.incrementAndGetAsync
(String path, T delta) Increments the current value specified by JSONPath bydelta
.RBitSetAsync.incrementAndGetByteAsync
(long offset, byte increment) Increments current byte value on definedincrement
value at specifiedoffset
and returns result.RBitSetAsync.incrementAndGetIntegerAsync
(long offset, int increment) Increments current integer value on definedincrement
value at specifiedoffset
and returns result.RBitSetAsync.incrementAndGetLongAsync
(long offset, long increment) Increments current long value on definedincrement
value at specifiedoffset
and returns result.RJsonBucketAsync.incrementAndGetMultiAsync
(String path, T delta) Increments the current values specified by JSONPath bydelta
.RBitSetAsync.incrementAndGetShortAsync
(long offset, short increment) Increments current short value on definedincrement
value at specifiedoffset
and returns result.RBitSetAsync.incrementAndGetSignedAsync
(int size, long offset, long increment) Increments current signed value by definedincrement
value andsize
at specifiedoffset
and returns result.RBitSetAsync.incrementAndGetUnsignedAsync
(int size, long offset, long increment) Increments current unsigned value by definedincrement
value andsize
at specifiedoffset
and returns result.RListAsync.indexOfAsync
(Object element) Returns last index ofelement
or -1 if element isn't foundNodeAsync.infoAsync
(Node.InfoSection section) Deprecated.RScoredSortedSetAsync.intersectionAsync
(String... names) Intersect provided ScoredSortedSets and store result to current ScoredSortedSetRScoredSortedSetAsync.intersectionAsync
(Map<String, Double> nameWithWeight) Intersect provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSetRScoredSortedSetAsync.intersectionAsync
(RScoredSortedSet.Aggregate aggregate, String... names) Intersect provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSetRScoredSortedSetAsync.intersectionAsync
(RScoredSortedSet.Aggregate aggregate, Map<String, Double> nameWithWeight) Intersect provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSetRSetAsync.intersectionAsync
(String... names) Intersection sets specified by name and write to current set.RObjectAsync.isExistsAsync()
Check object existence in async mode.RLockAsync.isLockedAsync()
Checks if the lock locked by any threadRMultimapAsync.keySizeAsync()
Returns the number of key-value pairs in this multimap.RFunctionAsync.killAsync()
Kills currently executed functions.RLexSortedSetAsync.lastAsync()
Returns the last element.RScoredSortedSetAsync.lastAsync()
Returns the tail element ornull
if this sorted set is empty.RTimeSeriesAsync.lastAsync()
Returns the tail element ornull
if this time-series collection is empty.RTimeSeriesAsync.lastAsync
(int count) Returns the tail elements of this time-series collection.RTimeSeriesAsync.lastEntriesAsync
(int count) Returns the tail entries of this time-series collection.RTimeSeriesAsync.lastEntryAsync()
Returns the tail entry ornull
if this time-series collection is empty.RListAsync.lastIndexOfAsync
(Object element) Returns last index ofelement
or -1 if element isn't foundRScoredSortedSetAsync.lastScoreAsync()
Returns score of the tail element or returnsnull
if this sorted set is empty.RTimeSeriesAsync.lastTimestampAsync()
Returns timestamp of the tail element ornull
if this time-series collection is empty.RBitSetAsync.lengthAsync()
Returns "logical size" = index of highest set bit plus one.RFunctionAsync.listAsync()
Returns information about libraries and functions per each.Returns information about libraries and functions per each by name pattern.RStreamAsync.listConsumersAsync
(String groupName) Returns list of objects with information about group customers for specifiedgroupName
.RStreamAsync.listGroupsAsync()
Returns list of objects with information about groups belonging to this stream.RStreamAsync.listPendingAsync
(String groupName, String consumerName, StreamMessageId startId, StreamMessageId endId, int count) Returns list of common info about pending messages by group and consumer name.RStreamAsync.listPendingAsync
(String groupName, String consumerName, StreamMessageId startId, StreamMessageId endId, long idleTime, TimeUnit idleTimeUnit, int count) Returns list of common info about pending messages by group and consumer name.RStreamAsync.listPendingAsync
(String groupName, StreamMessageId startId, StreamMessageId endId, int count) Returns list of common info about pending messages by group name.RStreamAsync.listPendingAsync
(String groupName, StreamMessageId startId, StreamMessageId endId, long idleTime, TimeUnit idleTimeUnit, int count) Returns list of common info about pending messages by group name.RMapAsync.loadAllAsync
(boolean replaceExistingValues, int parallelism) Loads all map entries to this Redis map usingMapLoader
.RMapAsync.loadAllAsync
(Set<? extends K> keys, boolean replaceExistingValues, int parallelism) Loads map entries usingMapLoader
whose keys are listed in definedkeys
parameter.RFunctionAsync.loadAndReplaceAsync
(String libraryName, String code) Loads a library and overwrites existing library.Loads a library.RLockAsync.lockAsync()
Acquires the lock.RLockAsync.lockAsync
(long threadId) Acquires the lock by thread with definedthreadId
.Acquires the lock with definedleaseTime
.Acquires the lock with definedleaseTime
andthreadId
.RMapAsync.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.RHyperLogLogAsync.mergeWithAsync
(String... otherLogNames) Merges multiple instances into this instance.RKeysAsync.migrateAsync
(String name, String host, int port, int database, long timeout) Transfer object from source Redis instance to destination Redis instanceRObjectAsync.migrateAsync
(String host, int port, int database, long timeout) Transfer object from source Redis instance to destination Redis instance in async modeRBlockingDequeAsync.moveAsync
(Duration timeout, DequeMoveArgs args) RDequeAsync.moveAsync
(DequeMoveArgs args) Move element from this deque to the given destination deque.Move object to another databaseRObjectAsync.moveAsync
(int database) Move object to another database in async modeMove a member from this set to the given destination set in async mode.RIdGeneratorAsync.nextIdAsync()
Returns next unique number but not monotonically increasedRBitSetAsync.notAsync()
Executes NOT operation over all bitsRBoundedBlockingQueueAsync.offerAsync
(V e, long timeout, TimeUnit unit) Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.RDelayedQueue.offerAsync
(V e, long delay, TimeUnit timeUnit) Inserts element into this queue with specified transfer delay to destination queue.RQueueAsync.offerAsync
(V e) Inserts the specified element into this queue.RDequeAsync.offerFirstAsync
(V e) Adds element at the head of this deque.RDequeAsync.offerLastAsync
(V e) Adds element at the tail of this deque.Executes OR operation over this object and specified bitsets.RQueueAsync.peekAsync()
Retrieves the head of this queue in async mode.RDequeAsync.peekFirstAsync()
Returns element at the head of this deque ornull
if there are no elements in deque.RDequeAsync.peekLastAsync()
Returns element at the tail of this deque ornull
if there are no elements in deque.RStreamAsync.pendingRangeAsync
(String groupName, String consumerName, StreamMessageId startId, StreamMessageId endId, int count) Returns stream data of pending messages by group and customer name.RStreamAsync.pendingRangeAsync
(String groupName, String consumerName, StreamMessageId startId, StreamMessageId endId, long idleTime, TimeUnit idleTimeUnit, int count) Returns stream data of pending messages by group and customer name.RStreamAsync.pendingRangeAsync
(String groupName, StreamMessageId startId, StreamMessageId endId, int count) Returns stream data of pending messages by group name.RStreamAsync.pendingRangeAsync
(String groupName, StreamMessageId startId, StreamMessageId endId, long idleTime, TimeUnit idleTimeUnit, int count) Returns stream data of pending messages by group name.NodeAsync.pingAsync()
Deprecated.Deprecated.Ping Redis node with specified timeout.Retrieves and removes the head of this queue in async mode, waiting up to the specified wait time if necessary for an element to become available.RQueueAsync.pollAsync()
Retrieves and removes the head of this queue in async mode.RQueueAsync.pollAsync
(int limit) Retrieves and removes the head elements of this queue.RBlockingDequeAsync.pollFirstAsync
(long timeout, TimeUnit unit) Retrieves and removes value at the head of queue.RDequeAsync.pollFirstAsync()
Retrieves and removes element at the head of this deque.RDequeAsync.pollFirstAsync
(int limit) Retrieves and removes the head elements of this queue.RLexSortedSetAsync.pollFirstAsync()
Removes and returns the head element ornull
if this sorted set is empty.RScoredSortedSetAsync.pollFirstAsync()
Removes and returns the head element ornull
if this sorted set is empty.RScoredSortedSetAsync.pollFirstAsync
(int count) Removes and returns the head elements of this sorted set.RScoredSortedSetAsync.pollFirstAsync
(long timeout, TimeUnit unit) Removes and returns the head element ornull
if this sorted set is empty.RScoredSortedSetAsync.pollFirstAsync
(Duration duration, int count) Removes and returns the head elements.RTimeSeriesAsync.pollFirstAsync()
Removes and returns the head element ornull
if this time-series collection is empty.RTimeSeriesAsync.pollFirstAsync
(int count) Removes and returns the head elementsRTimeSeriesAsync.pollFirstEntriesAsync
(int count) Removes and returns head entriesRScoredSortedSetAsync.pollFirstEntriesFromAnyAsync
(int count, String... queueNames) Removes and returns first available head elements of any sorted set including this one.RScoredSortedSetAsync.pollFirstEntriesFromAnyAsync
(Duration duration, int count, String... queueNames) Removes and returns first available head elements of any sorted set, waiting up to the specified wait time if necessary for elements to become available in any of defined sorted sets including this one.RTimeSeriesAsync.pollFirstEntryAsync()
Removes and returns head entry ornull
if this time-series collection is empty.RBlockingDequeAsync.pollFirstFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) Retrieves and removes first available head element of any queue in async mode, waiting up to the specified wait time if necessary for an element to become available in any of defined queues including queue own.RBlockingQueueAsync.pollFirstFromAnyAsync
(Duration duration, int count, String... queueNames) Retrieves and removes first available head elements of any queue, waiting up to the specified wait time if necessary for an element to become available in any of defined queues including queue itself.RScoredSortedSetAsync.pollFirstFromAnyAsync
(int count, String... queueNames) Removes and returns first available head elements of any sorted set including this one.RScoredSortedSetAsync.pollFirstFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) Removes and returns first available head element of any sorted set, waiting up to the specified wait time if necessary for an element to become available in any of defined sorted sets including this one.RScoredSortedSetAsync.pollFirstFromAnyAsync
(Duration duration, int count, String... queueNames) Removes and returns first available head elements of any sorted set, waiting up to the specified wait time if necessary for elements to become available in any of defined sorted sets including this one.RBlockingQueueAsync.pollFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) Retrieves and removes first available head element of any queue in async mode, waiting up to the specified wait time if necessary for an element to become available in any of defined queues including queue itself.RBlockingQueueAsync.pollLastAndOfferFirstToAsync
(String queueName, long timeout, TimeUnit unit) Retrieves and removes last available tail element of this queue and adds it at the head ofqueueName
, waiting up to the specified wait time if necessary for an element to become available.RQueueAsync.pollLastAndOfferFirstToAsync
(String queueName) Retrieves and removes last available tail element of this queue queue and adds it at the head ofqueueName
.RBlockingDequeAsync.pollLastAsync
(long timeout, TimeUnit unit) Retrieves and removes value at the tail of queue.RDequeAsync.pollLastAsync()
Retrieves and removes element at the tail of this deque.RDequeAsync.pollLastAsync
(int limit) Retrieves and removes the tail elements of this queue.RLexSortedSetAsync.pollLastAsync()
Removes and returns the tail element ornull
if this sorted set is empty.RScoredSortedSetAsync.pollLastAsync()
Removes and returns the tail element ornull
if this sorted set is empty.RScoredSortedSetAsync.pollLastAsync
(int count) Removes and returns the tail elements of this sorted set.RScoredSortedSetAsync.pollLastAsync
(long timeout, TimeUnit unit) Removes and returns the tail element ornull
if this sorted set is empty.RScoredSortedSetAsync.pollLastAsync
(Duration duration, int count) Removes and returns the tail elements.RTimeSeriesAsync.pollLastAsync()
Removes and returns the tail element ornull
if this time-series collection is empty.RTimeSeriesAsync.pollLastAsync
(int count) Removes and returns the tail elements ornull
if this time-series collection is empty.RTimeSeriesAsync.pollLastEntriesAsync
(int count) Removes and returns tail entriesRScoredSortedSetAsync.pollLastEntriesFromAnyAsync
(int count, String... queueNames) Removes and returns first available tail entries of any sorted set including this one.RScoredSortedSetAsync.pollLastEntriesFromAnyAsync
(Duration duration, int count, String... queueNames) Removes and returns first available tail entries of any sorted set, waiting up to the specified wait time if necessary for elements to become available in any of defined sorted sets including this one.RTimeSeriesAsync.pollLastEntryAsync()
Removes and returns the tail entry ornull
if this time-series collection is empty.RBlockingDequeAsync.pollLastFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) Retrieves and removes first available tail element of any queue in async mode, waiting up to the specified wait time if necessary for an element to become available in any of defined queues including queue own.RBlockingQueueAsync.pollLastFromAnyAsync
(Duration duration, int count, String... queueNames) Retrieves and removes first available tail elements of any queue, waiting up to the specified wait time if necessary for an element to become available in any of defined queues including queue itself.RScoredSortedSetAsync.pollLastFromAnyAsync
(int count, String... queueNames) Removes and returns first available tail elements of any sorted set including this one.RScoredSortedSetAsync.pollLastFromAnyAsync
(long timeout, TimeUnit unit, String... queueNames) Removes and returns first available tail element of any sorted set, waiting up to the specified wait time if necessary for an element to become available in any of defined sorted sets including this one.RScoredSortedSetAsync.pollLastFromAnyAsync
(Duration duration, int count, String... queueNames) Removes and returns first available tail elements of any sorted set, waiting up to the specified wait time if necessary for elements to become available in any of defined sorted sets including this one.RDequeAsync.popAsync()
Retrieves and removes element at the head of this deque.Returns geo-position mapped by defined member.RReliableTopicAsync.publishAsync
(Object message) Publish the message to all subscribers of this topic asynchronously.RTopicAsync.publishAsync
(Object message) Publish the message to all subscribers of this topic asynchronouslyAdds element at the head of this deque.CacheAsync.putAllAsync
(Map<? extends K, ? extends V> map) This method copies all of the entries from the given Map to theCacheAsync
.RMapAsync.putAllAsync
(Map<? extends K, ? extends V> map) Stores map entries specified inmap
object in batch mode.RMapAsync.putAllAsync
(Map<? extends K, ? extends V> map, int batchSize) Stores map entries specified inmap
object in batch mode.RMapCacheAsync.putAllAsync
(Map<? extends K, ? extends V> map, long ttl, TimeUnit ttlUnit) Associates the specifiedvalue
with the specifiedkey
in batch.RMultimapAsync.putAllAsync
(K key, Iterable<? extends V> values) Stores a key-value pair in this multimap for each ofvalues
, all using the same key,key
.This method places the given value V in the cache and associates it with the given key K.Inserts the specified element into this queue in async mode, waiting if necessary for space to become available.Stores the specifiedvalue
mapped by specifiedkey
.Stores value mapped by key with specified time to live.RMapCacheAsync.putAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) Stores value mapped by key with specified time to live and max idle time.Stores a key-value pair in this multimap.RBlockingDequeAsync.putFirstAsync
(V e) Adds value to the head of queue.CacheAsync.putIfAbsentAsync
(K key, V value) This method places the given key and value in the cache atomically, if the key is not already associated with a value in the cache.RMapAsync.putIfAbsentAsync
(K key, V value) Stores the specifiedvalue
mapped by specifiedkey
only if there is no value with specifiedkey
stored before.RMapCacheAsync.putIfAbsentAsync
(K key, V value, long ttl, TimeUnit unit) If the specified key is not already associated with a value, associate it with the given value.RMapCacheAsync.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.RMapAsync.putIfExistsAsync
(K key, V value) Stores the specifiedvalue
mapped bykey
only if mapping already exists.RBlockingDequeAsync.putLastAsync
(V e) Adds value to the tail of queue.RGeoAsync.radiusAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit) Deprecated.RGeoAsync.radiusAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, int count) Deprecated.RGeoAsync.radiusAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder) Deprecated.RGeoAsync.radiusAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) Deprecated.RGeoAsync.radiusAsync
(V member, double radius, GeoUnit geoUnit) Deprecated.RGeoAsync.radiusAsync
(V member, double radius, GeoUnit geoUnit, int count) Deprecated.RGeoAsync.radiusAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder) Deprecated.RGeoAsync.radiusAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) Deprecated.RGeoAsync.radiusStoreSortedToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit) RGeoAsync.radiusStoreSortedToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit, int count) RGeoAsync.radiusStoreSortedToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RGeoAsync.radiusStoreSortedToAsync
(String destName, V member, double radius, GeoUnit geoUnit) RGeoAsync.radiusStoreSortedToAsync
(String destName, V member, double radius, GeoUnit geoUnit, int count) RGeoAsync.radiusStoreSortedToAsync
(String destName, V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RGeoAsync.radiusStoreToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit) Deprecated.RGeoAsync.radiusStoreToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit, int count) Deprecated.RGeoAsync.radiusStoreToAsync
(String destName, double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) Deprecated.RGeoAsync.radiusStoreToAsync
(String destName, V member, double radius, GeoUnit geoUnit) Deprecated.RGeoAsync.radiusStoreToAsync
(String destName, V member, double radius, GeoUnit geoUnit, int count) Deprecated.RGeoAsync.radiusStoreToAsync
(String destName, V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) Deprecated.RGeoAsync.radiusWithDistanceAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit) RGeoAsync.radiusWithDistanceAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, int count) RGeoAsync.radiusWithDistanceAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RGeoAsync.radiusWithDistanceAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RGeoAsync.radiusWithDistanceAsync
(V member, double radius, GeoUnit geoUnit) RGeoAsync.radiusWithDistanceAsync
(V member, double radius, GeoUnit geoUnit, int count) RGeoAsync.radiusWithDistanceAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RGeoAsync.radiusWithDistanceAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RGeoAsync.radiusWithPositionAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit) RGeoAsync.radiusWithPositionAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, int count) RGeoAsync.radiusWithPositionAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RGeoAsync.radiusWithPositionAsync
(double longitude, double latitude, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RGeoAsync.radiusWithPositionAsync
(V member, double radius, GeoUnit geoUnit) RGeoAsync.radiusWithPositionAsync
(V member, double radius, GeoUnit geoUnit, int count) RGeoAsync.radiusWithPositionAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder) RGeoAsync.radiusWithPositionAsync
(V member, double radius, GeoUnit geoUnit, GeoOrder geoOrder, int count) RScoredSortedSetAsync.randomAsync()
Returns random element from this sorted setRScoredSortedSetAsync.randomAsync
(int count) Returns random elements from this sorted set limited bycount
RSetAsync.randomAsync()
Returns random element from set in async modeRSetAsync.randomAsync
(int count) Returns random elements from set limited bycount
RMapAsync.randomEntriesAsync
(int count) Returns random map entries from this map limited bycount
RScoredSortedSetAsync.randomEntriesAsync
(int count) Returns random entries from this sorted set limited bycount
.RKeysAsync.randomKeyAsync()
Get random key in async modeRMapAsync.randomKeysAsync
(int count) Returns random keys from this map limited bycount
RLexSortedSetAsync.rangeAsync
(int startIndex, int endIndex) Returns values by rank range.RLexSortedSetAsync.rangeAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive) Returns values range starting withfromElement
and ending withtoElement
.RLexSortedSetAsync.rangeAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive, int offset, int count) Returns values range starting withfromElement
and ending withtoElement
.RListAsync.rangeAsync
(int toIndex) Returns range of values from 0 index totoIndex
.RListAsync.rangeAsync
(int fromIndex, int toIndex) Returns range of values fromfromIndex
totoIndex
index including.RStreamAsync.rangeAsync
(int count, StreamMessageId startId, StreamMessageId endId) Returns stream data in range by specified start Stream ID (included) and end Stream ID (included).RStreamAsync.rangeAsync
(StreamMessageId startId, StreamMessageId endId) Returns stream data in range by specified start Stream ID (included) and end Stream ID (included).RTimeSeriesAsync.rangeAsync
(long startTimestamp, long endTimestamp) Returns ordered elements of this time-series collection within timestamp range.RTimeSeriesAsync.rangeAsync
(long startTimestamp, long endTimestamp, int limit) Returns ordered elements of this time-series collection within timestamp range.RLexSortedSetAsync.rangeHeadAsync
(String toElement, boolean toInclusive) Returns head values range ending withtoElement
.RLexSortedSetAsync.rangeHeadAsync
(String toElement, boolean toInclusive, int offset, int count) Returns head values range ending withtoElement
.RLexSortedSetAsync.rangeHeadReversedAsync
(String toElement, boolean toInclusive) Returns head values range in reverse order ending withtoElement
.RLexSortedSetAsync.rangeHeadReversedAsync
(String toElement, boolean toInclusive, int offset, int count) Returns head values range in reverse order ending withtoElement
.RLexSortedSetAsync.rangeReversedAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive) Returns values range in reverse order starting withfromElement
and ending withtoElement
.RLexSortedSetAsync.rangeReversedAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive, int offset, int count) Returns values range in reverse order starting withfromElement
and ending withtoElement
.RStreamAsync.rangeReversedAsync
(int count, StreamMessageId startId, StreamMessageId endId) Returns stream data in reverse order in range by specified start Stream ID (included) and end Stream ID (included).RStreamAsync.rangeReversedAsync
(StreamMessageId startId, StreamMessageId endId) Returns stream data in reverse order in range by specified start Stream ID (included) and end Stream ID (included).RTimeSeriesAsync.rangeReversedAsync
(long startTimestamp, long endTimestamp) Returns elements of this time-series collection in reverse order within timestamp range.RTimeSeriesAsync.rangeReversedAsync
(long startTimestamp, long endTimestamp, int limit) Returns elements of this time-series collection in reverse order within timestamp range.RLexSortedSetAsync.rangeTailAsync
(String fromElement, boolean fromInclusive) Returns tail values range starting withfromElement
.RLexSortedSetAsync.rangeTailAsync
(String fromElement, boolean fromInclusive, int offset, int count) Returns tail values range starting withfromElement
.RLexSortedSetAsync.rangeTailReversedAsync
(String fromElement, boolean fromInclusive) Returns tail values range in reverse order starting withfromElement
.RLexSortedSetAsync.rangeTailReversedAsync
(String fromElement, boolean fromInclusive, int offset, int count) Returns tail values range in reverse order starting withfromElement
.RScoredSortedSetAsync.rangeToAsync
(String destName, double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) Stores to defined ScoredSortedSet values betweenstartScore
andendScore
.RScoredSortedSetAsync.rangeToAsync
(String destName, double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) Stores to defined ScoredSortedSet values betweenstartScore
andendScore
.RScoredSortedSetAsync.rangeToAsync
(String destName, int startIndex, int endIndex) Stores to defined ScoredSortedSet values by rank range.Returns rank of the elementReturns rank of value, with the scores ordered from low to high.RLexSortedSetAsync.readAllAsync()
Read all values at once.RListAsync.readAllAsync()
Read all elements at onceRQueueAsync.readAllAsync()
Returns all queue elements at onceRScoredSortedSetAsync.readAllAsync()
Read all values at once.RSetAsync.readAllAsync()
Read all elements at onceRSetCacheAsync.readAllAsync()
Read all elements at onceRSortedSet.readAllAsync()
RMapAsync.readAllEntrySetAsync()
Read all map entries at onceRMapAsync.readAllKeySetAsync()
Read all keys at onceRMultimapAsync.readAllKeySetAsync()
Read all keys at onceRMapAsync.readAllMapAsync()
Read all map as local instance at onceRMapAsync.readAllValuesAsync()
Read all values at onceRStreamAsync.readAsync
(int count, long timeout, TimeUnit unit, StreamMessageId... ids) Deprecated.RStreamAsync.readAsync
(int count, long timeout, TimeUnit unit, StreamMessageId id, String name2, StreamMessageId id2) Deprecated.RStreamAsync.readAsync
(int count, long timeout, TimeUnit unit, StreamMessageId id, String name2, StreamMessageId id2, String name3, StreamMessageId id3) Deprecated.RStreamAsync.readAsync
(int count, long timeout, TimeUnit unit, StreamMessageId id, Map<String, StreamMessageId> nameToId) Deprecated.RStreamAsync.readAsync
(int count, StreamMessageId... ids) Deprecated.RStreamAsync.readAsync
(int count, StreamMessageId id, String name2, StreamMessageId id2) Deprecated.RStreamAsync.readAsync
(int count, StreamMessageId id, String name2, StreamMessageId id2, String name3, StreamMessageId id3) Deprecated.RStreamAsync.readAsync
(int count, StreamMessageId id, Map<String, StreamMessageId> nameToId) Deprecated.RStreamAsync.readAsync
(long timeout, TimeUnit unit, StreamMessageId... ids) Deprecated.RStreamAsync.readAsync
(long timeout, TimeUnit unit, StreamMessageId id, String name2, StreamMessageId id2) Deprecated.RStreamAsync.readAsync
(long timeout, TimeUnit unit, StreamMessageId id, String name2, StreamMessageId id2, String name3, StreamMessageId id3) Deprecated.RStreamAsync.readAsync
(long timeout, TimeUnit unit, StreamMessageId id, Map<String, StreamMessageId> nameToId) Deprecated.RStreamAsync.readAsync
(StreamMultiReadArgs args) Read stream data from multiple streams including current.RStreamAsync.readAsync
(StreamReadArgs args) Read stream data from current stream only.RStreamAsync.readAsync
(StreamMessageId... ids) Deprecated.RStreamAsync.readAsync
(StreamMessageId id, String name2, StreamMessageId id2) Deprecated.RStreamAsync.readAsync
(StreamMessageId id, String name2, StreamMessageId id2, String name3, StreamMessageId id3) Deprecated.RStreamAsync.readAsync
(StreamMessageId id, Map<String, StreamMessageId> nameToId) Deprecated.RScoredSortedSetAsync.readDiffAsync
(String... names) Diff ScoredSortedSets specified by name with current ScoredSortedSet without state change.RSetAsync.readDiffAsync
(String... names) Diff sets specified by name with current set.RStreamAsync.readGroupAsync
(String groupName, String consumerName, int count, long timeout, TimeUnit unit, StreamMessageId... ids) Read stream data fromgroupName
byconsumerName
and specified collection of Stream IDs.RStreamAsync.readGroupAsync
(String groupName, String consumerName, int count, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, int count, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, int count, StreamMessageId... ids) Read stream data fromgroupName
byconsumerName
and specified collection of Stream IDs.RStreamAsync.readGroupAsync
(String groupName, String consumerName, int count, StreamMessageId id, String key2, StreamMessageId id2) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, int count, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, int count, StreamMessageId id, Map<String, StreamMessageId> nameToId) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, long timeout, TimeUnit unit, StreamMessageId... ids) Read stream data fromgroupName
byconsumerName
and specified collection of Stream IDs.RStreamAsync.readGroupAsync
(String groupName, String consumerName, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, long timeout, TimeUnit unit, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, long timeout, TimeUnit unit, StreamMessageId id, Map<String, StreamMessageId> nameToId) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, StreamMultiReadGroupArgs args) Read stream data from consumer group and multiple streams including current.RStreamAsync.readGroupAsync
(String groupName, String consumerName, StreamReadGroupArgs args) Read stream data from consumer group and current stream only.RStreamAsync.readGroupAsync
(String groupName, String consumerName, StreamMessageId... ids) Read stream data fromgroupName
byconsumerName
and specified collection of Stream IDs.RStreamAsync.readGroupAsync
(String groupName, String consumerName, StreamMessageId id, String key2, StreamMessageId id2) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, StreamMessageId id, String key2, StreamMessageId id2, String key3, StreamMessageId id3) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RStreamAsync.readGroupAsync
(String groupName, String consumerName, StreamMessageId id, Map<String, StreamMessageId> nameToId) Read stream data fromgroupName
byconsumerName
, starting by specified message ids for this and other streams.RScoredSortedSetAsync.readIntersectionAsync
(String... names) Intersect provided ScoredSortedSets with current ScoredSortedSet without state changeRScoredSortedSetAsync.readIntersectionAsync
(Map<String, Double> nameWithWeight) Intersect provided ScoredSortedSets mapped to weight multiplier with current ScoredSortedSet without state changeRScoredSortedSetAsync.readIntersectionAsync
(RScoredSortedSet.Aggregate aggregate, String... names) Intersect provided ScoredSortedSets with current ScoredSortedSet using defined aggregation method without state changeRScoredSortedSetAsync.readIntersectionAsync
(RScoredSortedSet.Aggregate aggregate, Map<String, Double> nameWithWeight) Intersect provided ScoredSortedSets mapped to weight multiplier with current ScoredSortedSet using defined aggregation method without state changeRSetAsync.readIntersectionAsync
(String... names) Intersection sets specified by name with current set.<T> RFuture<Collection<T>>
RSortableAsync.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order) Read data in sorted view lexicographically<T> RFuture<Collection<T>>
RSortableAsync.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) Read data in sorted view lexicographicallyRSortableAsync.readSortAlphaAsync
(String byPattern, SortOrder order) Read data in sorted view lexicographicallyRSortableAsync.readSortAlphaAsync
(String byPattern, SortOrder order, int offset, int count) Read data in sorted view lexicographicallyRSortableAsync.readSortAlphaAsync
(SortOrder order) Read data in sorted view lexicographicallyRSortableAsync.readSortAlphaAsync
(SortOrder order, int offset, int count) Read data in sorted view lexicographically<T> RFuture<Collection<T>>
RSortableAsync.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order) Read data in sorted view<T> RFuture<Collection<T>>
RSortableAsync.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) Read data in sorted viewRSortableAsync.readSortAsync
(String byPattern, SortOrder order) Read data in sorted viewRSortableAsync.readSortAsync
(String byPattern, SortOrder order, int offset, int count) Read data in sorted viewRSortableAsync.readSortAsync
(SortOrder order) Read data in sorted viewRSortableAsync.readSortAsync
(SortOrder order, int offset, int count) Read data in sorted viewRScoredSortedSetAsync.readUnionAsync
(String... names) Union ScoredSortedSets specified by name with current ScoredSortedSet without state change.RScoredSortedSetAsync.readUnionAsync
(Map<String, Double> nameWithWeight) Union provided ScoredSortedSets mapped to weight multiplier and current ScoredSortedSet without state change.RScoredSortedSetAsync.readUnionAsync
(RScoredSortedSet.Aggregate aggregate, String... names) Union ScoredSortedSets specified by name with defined aggregation method and current ScoredSortedSet without state change.RScoredSortedSetAsync.readUnionAsync
(RScoredSortedSet.Aggregate aggregate, Map<String, Double> nameWithWeight) Union provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and current ScoredSortedSet without state changeRSetAsync.readUnionAsync
(String... names) Union sets specified by name with current set.RPermitExpirableSemaphoreAsync.releaseAsync
(String permitId) Releases a permit by its id.RSemaphoreAsync.releaseAsync()
Releases a permit.RSemaphoreAsync.releaseAsync
(int permits) Releases defined amount ofpermits
.RRingBufferAsync.remainingCapacityAsync()
Returns remaining capacity of this queueRExpirableAsync.remainTimeToLiveAsync()
Remaining time to live of Redisson object that has a timeoutRKeysAsync.remainTimeToLiveAsync
(String name) Remaining time to live of Redisson object that has a timeoutRLockAsync.remainTimeToLiveAsync()
Remaining time to live of the lockRMapCacheAsync.remainTimeToLiveAsync
(K key) Remaining time to live of map entry associated with akey
.CacheAsync.removeAllAsync
(Set<? extends K> keys) This method deletes the entries for the given keys.RCollectionAsync.removeAllAsync
(Collection<?> c) Removes all of this collection's elements that are also contained in the specified collection.RMultimapAsync.removeAllAsync
(Object key) Removes all values associated with the keykey
.RScoredSortedSetAsync.removeAllAsync
(Collection<?> c) Removes all of this sorted set's elements that are also contained in the specified collection.RSetAsync.removeAllCountedAsync
(Collection<? extends V> c) Removes all elements contained in the specified collection.RPatternTopic.removeAllListenersAsync()
Removes all listeners from this topicRReliableTopicAsync.removeAllListenersAsync()
Removes all listeners attached to this topic instanceRTopicAsync.removeAllListenersAsync()
Removes all listeners from this topicCacheAsync.removeAsync
(K key) This method deletes the mapping for a given key from the cache, if it is present.CacheAsync.removeAsync
(K key, V oldValue) This method atomically removes a key's mapping only if it is currently mapped to the provided value.RCollectionAsync.removeAsync
(Object o) Removes a single instance of the specified element from this collection, if it is present.RListAsync.removeAsync
(int index) Removes element atindex
.RListAsync.removeAsync
(Object element, int count) Removes up tocount
occurrences ofelement
RMapAsync.removeAsync
(Object key, Object value) Removes map entry only if it exists with specifiedkey
andvalue
.RMapAsync.removeAsync
(K key) Removes map entry by specifiedkey
and returns value.RMultimapAsync.removeAsync
(Object key, Object value) Removes a single key-value pair with the keykey
and the valuevalue
from this multimap, if such exists.RScoredSortedSetAsync.removeAsync
(V o) Removes a single instance of the specified element from this sorted set, if it is present.RSortedSet.removeAsync
(Object value) RStreamAsync.removeAsync
(StreamMessageId... ids) Removes messages by id.RTimeSeriesAsync.removeAsync
(long timestamp) Removes object by specifiedtimestamp
.RStreamAsync.removeConsumerAsync
(String groupName, String consumerName) Removes consumer of the group by name.RDequeAsync.removeFirstAsync()
Retrieves and removes the first element of deque.RDequeAsync.removeFirstOccurrenceAsync
(Object o) Removes first occurrence of elemento
RStreamAsync.removeGroupAsync
(String groupName) Removes group by name.RDequeAsync.removeLastAsync()
Retrieves and removes the last element of deque.RDequeAsync.removeLastOccurrenceAsync
(Object o) Removes last occurrence of elemento
RObjectAsync.removeListenerAsync
(int listenerId) Removes object event listenerRPatternTopic.removeListenerAsync
(int listenerId) RReliableTopicAsync.removeListenerAsync
(String... listenerIds) Removes the listener byid
attached to this topic instanceRTopicAsync.removeListenerAsync
(Integer... listenerIds) Removes the listener byid
for listening this topicRTopicAsync.removeListenerAsync
(MessageListener<?> listener) Removes the listener by its instanceRSetAsync.removeRandomAsync()
Removes and returns random element from set in async modeRSetAsync.removeRandomAsync
(int amount) Removes and returns random elements from set in async modeRLexSortedSetAsync.removeRangeAsync
(String fromElement, boolean fromInclusive, String toElement, boolean toInclusive) Removes values range starting withfromElement
and ending withtoElement
.RTimeSeriesAsync.removeRangeAsync
(long startTimestamp, long endTimestamp) Removes values within timestamp range.RScoredSortedSetAsync.removeRangeByRankAsync
(int startIndex, int endIndex) Removes values by rank range.RScoredSortedSetAsync.removeRangeByScoreAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) Removes values by score range.RLexSortedSetAsync.removeRangeHeadAsync
(String toElement, boolean toInclusive) Removes head values range ending withtoElement
.RLexSortedSetAsync.removeRangeTailAsync
(String fromElement, boolean fromInclusive) Removes tail values range starting withfromElement
.RKeysAsync.renameAsync
(String currentName, String newName) Rename current object key tonewName
RObjectAsync.renameAsync
(String newName) Rename current object key tonewName
in async modeRKeysAsync.renamenxAsync
(String oldName, String newName) Rename object witholdName
tonewName
only if new key is not existsRObjectAsync.renamenxAsync
(String newName) Rename current object key tonewName
in async mode only if new key is not existsCacheAsync.replaceAsync
(K key, V value) This method atomically replaces an entry only if the key is currently mapped to some value.CacheAsync.replaceAsync
(K key, V oldValue, V newValue) This method atomically replaces an entry only if the key is currently mapped to a given value.RMapAsync.replaceAsync
(K key, V value) Replaces previous value with a newvalue
mapped by specifiedkey
.RMapAsync.replaceAsync
(K key, V oldValue, V newValue) Replaces previousoldValue
with anewValue
mapped by specifiedkey
.RScoredSortedSetAsync.replaceAsync
(V oldObject, V newObject) Replaces a previousoldObject
with anewObject
.RMultimapAsync.replaceValuesAsync
(K key, Iterable<? extends V> values) Stores a collection of values with the same key, replacing any existing values for that key.RDoubleAdder.resetAsync()
Resets value across all RDoubleAdder instancesRDoubleAdder.resetAsync
(long timeout, TimeUnit timeUnit) Resets value across all RDoubleAdder instances within definedtimeout
.RLongAdder.resetAsync()
Resets value across all RLongAdder instancesRLongAdder.resetAsync
(long timeout, TimeUnit timeUnit) Resets value across all RLongAdder instances within definedtimeout
.RFunctionAsync.restoreAfterFlushAsync
(byte[] payload) Restores libraries using their state returned byRFunctionAsync.dumpAsync()
method.RFunctionAsync.restoreAndReplaceAsync
(byte[] payload) Restores libraries using their state returned byRFunctionAsync.dumpAsync()
method.RObjectAsync.restoreAndReplaceAsync
(byte[] state) Restores and replaces object if it already exists.RObjectAsync.restoreAndReplaceAsync
(byte[] state, long timeToLive, TimeUnit timeUnit) Restores and replaces object if it already exists and set time to live for it.RFunctionAsync.restoreAsync
(byte[] payload) Restores libraries using their state returned byRFunctionAsync.dumpAsync()
method.RObjectAsync.restoreAsync
(byte[] state) Restores object using its state returned byRObjectAsync.dumpAsync()
method.RObjectAsync.restoreAsync
(byte[] state, long timeToLive, TimeUnit timeUnit) Restores object using its state returned byRObjectAsync.dumpAsync()
method and set time to live for it.RCollectionAsync.retainAllAsync
(Collection<?> c) Retains only the elements in this collection that are contained in the specified collection.RScoredSortedSetAsync.retainAllAsync
(Collection<?> c) Retains only the elements in this sorted set that are contained in the specified collection.RScoredSortedSetAsync.revRangeToAsync
(String destName, double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) Stores to defined ScoredSortedSet values in reversed order betweenstartScore
andendScore
.RScoredSortedSetAsync.revRangeToAsync
(String destName, double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) Stores to defined ScoredSortedSet values in reversed order betweenstartScore
andendScore
.RScoredSortedSetAsync.revRangeToAsync
(String destName, int startIndex, int endIndex) Stores to defined ScoredSortedSet values in reversed order by rank range.RLexSortedSetAsync.revRankAsync
(String o) Returns rank of value, with the scores ordered from high to low.RScoredSortedSetAsync.revRankAsync
(Collection<V> elements) Returns ranks of elements, with the scores ordered from high to low.RScoredSortedSetAsync.revRankAsync
(V o) Returns rank of value, with the scores ordered from high to low.RTransaction.rollbackAsync()
Rollback all changes made on this transaction in async mode.RScriptAsync.scriptExistsAsync
(String... shaDigests) Checks for presence Lua scripts in Redis script cache by SHA-1 digest.RScriptAsync.scriptExistsAsync
(String key, String... shaDigests) Checks for presence Lua scripts in Redis script cache by SHA-1 digest.RScriptAsync.scriptFlushAsync()
Flushes Lua script cache.RScriptAsync.scriptKillAsync()
Kills currently executed Lua scriptRScriptAsync.scriptLoadAsync
(String luaScript) Loads Lua script into Redis scripts cache and returns its SHA-1 digestRScriptAsync.scriptLoadAsync
(String key, String luaScript) Loads Lua script into Redis scripts cache and returns its SHA-1 digestRGeoAsync.searchAsync
(GeoSearchArgs args) Returns the members of a sorted set, which are within the borders of specified search conditions.RGeoAsync.searchWithDistanceAsync
(GeoSearchArgs args) Returns the distance mapped by member of a sorted set, which are within the borders of specified search conditions.RGeoAsync.searchWithPositionAsync
(GeoSearchArgs args) Returns the position mapped by member of a sorted set, which are within the borders of specified search conditions.RBucketAsync.setAndKeepTTLAsync
(V value) Set value and keep existing TTL.RAtomicDoubleAsync.setAsync
(double newValue) Atomically sets the given value.RAtomicLongAsync.setAsync
(long newValue) Atomically sets the given value.RBitSetAsync.setAsync
(long bitIndex) Set bit to one at specified bitIndexRBitSetAsync.setAsync
(long bitIndex, boolean value) Set bit tovalue
at specifiedbitIndex
RBitSetAsync.setAsync
(long fromIndex, long toIndex) Set all bits to one fromfromIndex
(inclusive) totoIndex
(exclusive)RBitSetAsync.setAsync
(long fromIndex, long toIndex, boolean value) Set all bits tovalue
fromfromIndex
(inclusive) totoIndex
(exclusive)Copy bits state of source BitSet object to this objectStores element into the holder.Stores element into the holder with definedtimeToLive
interval.Saves objects mapped by Redis key.Stores object into element by specified JSONPath.Setelement
atindex
and returns previous element.RBitSetAsync.setByteAsync
(long offset, byte value) Returns previous value of byte number and replaces it with definedvalue
at specifiedoffset
RRingBufferAsync.setCapacityAsync
(int capacity) Sets capacity of the queue and overrides current value.RBucketAsync.setIfAbsentAsync
(V value) Sets value only if object holder doesn't exist.RBucketAsync.setIfAbsentAsync
(V value, Duration duration) Sets value with defined duration only if object holder doesn't exist.RJsonBucketAsync.setIfAbsentAsync
(String path, Object value) Sets Json object by JSONPath only if previous value is emptyRBucketAsync.setIfExistsAsync
(V value) Sets value only if it's already exists.RBucketAsync.setIfExistsAsync
(V value, long timeToLive, TimeUnit timeUnit) Sets value only if it's already exists.RJsonBucketAsync.setIfExistsAsync
(String path, Object value) Sets Json object by JSONPath only if previous value is non-emptyRBitSetAsync.setIntegerAsync
(long offset, int value) Returns previous value of integer number and replaces it with definedvalue
at specifiedoffset
RBitSetAsync.setLongAsync
(long offset, long value) Returns previous value of long number and replaces it with definedvalue
at specifiedoffset
RMapCacheAsync.setMaxSizeAsync
(int maxSize) Sets max size of the map and overrides current value.RMapCacheAsync.setMaxSizeAsync
(int maxSize, EvictionMode mode) Sets max size of the map and overrides current value.RRateLimiterAsync.setRateAsync
(RateType mode, long rate, long rateInterval, RateIntervalUnit rateIntervalUnit) Updates RateLimiter's state and stores config to Redis server.RBitSetAsync.setShortAsync
(long offset, short value) Returns previous value of short number and replaces it with definedvalue
at specifiedoffset
RBitSetAsync.setSignedAsync
(int size, long offset, long value) Returns previous value of signed number and replaces it with definedvalue
at specifiedoffset
RBitSetAsync.setUnsignedAsync
(int size, long offset, long value) Returns previous value of unsigned number and replaces it with definedvalue
at specifiedoffset
RBitSetAsync.sizeAsync()
Returns number of set bits.RBucketAsync.sizeAsync()
Returns size of object in bytesRCollectionAsync.sizeAsync()
Returns number of elements in this collection.RMapAsync.sizeAsync()
Returns size of this mapRMapCacheAsync.sizeAsync()
Returns the number of entries in cache.RMultimapAsync.sizeAsync()
Returns the number of key-value pairs in this multimap.RReliableTopicAsync.sizeAsync()
Amount of messages stored in Redis Stream object.RScoredSortedSetAsync.sizeAsync()
Returns size of this set.RSetCacheAsync.sizeAsync()
Returns the number of elements in cache.RStreamAsync.sizeAsync()
Returns number of entries in streamRTimeSeriesAsync.sizeAsync()
Returns size of this set.RObjectAsync.sizeInMemoryAsync()
Returns bytes amount used by object in Redis memory.RSortableAsync.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order) Sort data and store todestName
listRSortableAsync.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) Sort data and store todestName
listRSortableAsync.sortToAsync
(String destName, String byPattern, SortOrder order) Sort data and store todestName
listRSortableAsync.sortToAsync
(String destName, String byPattern, SortOrder order, int offset, int count) Sort data and store todestName
listRSortableAsync.sortToAsync
(String destName, SortOrder order) Sort data and store todestName
listRSortableAsync.sortToAsync
(String destName, SortOrder order, int offset, int count) Sort data and store todestName
listRFunctionAsync.statsAsync()
Returns information about currently running Redis function and available execution engines.RGeoAsync.storeSearchToAsync
(String destName, GeoSearchArgs args) Finds the members of a sorted set, which are within the borders of specified search conditions.RGeoReactive.storeSortedSearchTo
(String destName, GeoSearchArgs args) Finds the members of a sorted set, which are within the borders of specified search conditions.RGeoRx.storeSortedSearchTo
(String destName, GeoSearchArgs args) Finds the members of a sorted set, which are within the borders of specified search conditions.RGeoAsync.storeSortedSearchToAsync
(String destName, GeoSearchArgs args) Finds the members of a sorted set, which are within the borders of specified search conditions.RJsonBucketAsync.stringAppendAsync
(String path, Object value) Appends string data to element specified by JSONPath.RJsonBucketAsync.stringAppendMultiAsync
(String path, Object value) Appends string data to elements specified by JSONPath.RJsonBucketAsync.stringSizeAsync
(String path) Returns size of string data by JSONPathRJsonBucketAsync.stringSizeMultiAsync
(String path) Returns list of string data size by JSONPath.RDoubleAdder.sumAsync()
Accumulates sum across all RDoubleAdder instancesAccumulates sum across all RDoubleAdder instances within definedtimeout
.RLongAdder.sumAsync()
Accumulates sum across all RLongAdder instancesAccumulates sum across all RLongAdder instances within definedtimeout
.RKeysAsync.swapdbAsync
(int db1, int db2) Swap two databases.RFuture.sync()
Deprecated.RFuture.syncUninterruptibly()
Deprecated.RBlockingQueueAsync.takeAsync()
Retrieves and removes the head of this queue in async mode, waiting if necessary until an element becomes available.RBlockingDequeAsync.takeFirstAsync()
Retrieves and removes value at the head of queue.RScoredSortedSetAsync.takeFirstAsync()
Removes and returns the head element waiting if necessary for an element to become available.RBlockingQueueAsync.takeLastAndOfferFirstToAsync
(String queueName) Retrieves and removes last available tail element of any queue and adds it at the head ofqueueName
, waiting if necessary for an element to become available in any of defined queues including queue itself.RBlockingDequeAsync.takeLastAsync()
Retrieves and removes value at the tail of queue.RScoredSortedSetAsync.takeLastAsync()
Removes and returns the tail element waiting if necessary for an element to become available.NodeAsync.timeAsync()
Deprecated.RFuture<byte[]>
RBitSetAsync.toByteArrayAsync()
RJsonBucketAsync.toggleAsync
(String path) Toggle boolean value specified by JSONPathRJsonBucketAsync.toggleMultiAsync
(String path) Toggle boolean values specified by JSONPathRKeysAsync.touchAsync
(String... names) Update the last access time of an object.RObjectAsync.touchAsync()
Update the last access time of an object in async mode.RTransferQueueAsync.transferAsync
(V e) Transfers the element to waiting consumer which invokedRBlockingQueueAsync.takeAsync()
orRBlockingQueueAsync.pollAsync(long, java.util.concurrent.TimeUnit)
method at the moment of transfer.RListAsync.trimAsync
(int fromIndex, int toIndex) Trim list and remains elements only in specified rangefromIndex
, inclusive, andtoIndex
, inclusive.RStreamAsync.trimAsync
(int size) Deprecated.RStreamAsync.trimAsync
(StreamTrimArgs args) RStreamAsync.trimAsync
(TrimStrategy strategy, int threshold) Deprecated.RStreamAsync.trimNonStrictAsync
(int size) Deprecated.RStreamAsync.trimNonStrictAsync
(StreamTrimArgs args) RStreamAsync.trimNonStrictAsync
(TrimStrategy strategy, int threshold) Deprecated.RStreamAsync.trimNonStrictAsync
(TrimStrategy strategy, int threshold, int limit) Deprecated.RPermitExpirableSemaphoreAsync.tryAcquireAsync()
Tries to acquire currently available permit and return its id.RPermitExpirableSemaphoreAsync.tryAcquireAsync
(long waitTime, long leaseTime, TimeUnit unit) Tries to acquire currently available permit with definedleaseTime
and return its id.RPermitExpirableSemaphoreAsync.tryAcquireAsync
(long waitTime, TimeUnit unit) Tries to acquire currently available permit and return its id.RRateLimiterAsync.tryAcquireAsync()
Acquires a permit only if one is available at the time of invocation.RRateLimiterAsync.tryAcquireAsync
(long permits) Acquires the given number ofpermits
only if all are available at the time of invocation.RRateLimiterAsync.tryAcquireAsync
(long permits, long timeout, TimeUnit unit) Acquires the given number ofpermits
only if all are available within the given waiting time.RRateLimiterAsync.tryAcquireAsync
(long timeout, TimeUnit unit) Acquires a permit from this RateLimiter, if one becomes available within the given waiting time.RSemaphoreAsync.tryAcquireAsync()
Acquires a permit.RSemaphoreAsync.tryAcquireAsync
(int permits) Tries to acquire defined amount of currently availablepermits
.RSemaphoreAsync.tryAcquireAsync
(int permits, long waitTime, TimeUnit unit) Tries to acquire defined amount of currently availablepermits
.RSemaphoreAsync.tryAcquireAsync
(long waitTime, TimeUnit unit) Tries to acquire currently available permit.RGeoAsync.tryAddAsync
(double longitude, double latitude, V member) Adds geospatial member only if has not been added before.RGeoAsync.tryAddAsync
(GeoEntry... entries) Adds geospatial members only if has not been added before.RScoredSortedSetAsync.tryAddAsync
(double score, V object) Deprecated.RSetAsync.tryAddAsync
(V... values) Tries to add elements only if none of them in set.RSetCacheAsync.tryAddAsync
(long ttl, TimeUnit unit, V... values) Tries to add elements only if none of them in set.RSetCacheAsync.tryAddAsync
(V... values) Tries to add elements only if none of them in set.RRemoteService.tryExecuteAsync
(Class<T> remoteInterface, T object) Tries to execute one awaiting remote request.RRemoteService.tryExecuteAsync
(Class<T> remoteInterface, T object, long timeout, TimeUnit timeUnit) Tries to execute one awaiting remote request.RRemoteService.tryExecuteAsync
(Class<T> remoteInterface, T object, ExecutorService executorService, long timeout, TimeUnit timeUnit) Tries to execute one awaiting remote request.RIdGeneratorAsync.tryInitAsync
(long value, long allocationSize) Initializes Id generator params.RLockAsync.tryLockAsync()
Tries to acquire the lock.RLockAsync.tryLockAsync
(long threadId) Tries to acquire the lock by thread with specifiedthreadId
.RLockAsync.tryLockAsync
(long waitTime, long leaseTime, TimeUnit unit) Tries to acquire the lock with definedleaseTime
.RLockAsync.tryLockAsync
(long waitTime, long leaseTime, TimeUnit unit, long threadId) Tries to acquire the lock by thread with specifiedthreadId
andleaseTime
.RLockAsync.tryLockAsync
(long waitTime, TimeUnit unit) Tries to acquire the lock.RPermitExpirableSemaphoreAsync.tryReleaseAsync
(String permitId) Tries to release permit by its id.RBucketAsync.trySetAsync
(V value) Deprecated.RBucketAsync.trySetAsync
(V value, long timeToLive, TimeUnit timeUnit) Deprecated.RBucketsAsync.trySetAsync
(Map<String, ?> buckets) Try to save objects mapped by Redis key.RJsonBucketAsync.trySetAsync
(String path, Object value) Deprecated.RBoundedBlockingQueueAsync.trySetCapacityAsync
(int capacity) Sets queue capacity only if it is not set before.RRingBufferAsync.trySetCapacityAsync
(int capacity) Sets capacity of the queue only if it wasn't set before.RCountDownLatchAsync.trySetCountAsync
(long count) Sets new count value only if previous count already has reached zero or is not set at all.RMapCacheAsync.trySetMaxSizeAsync
(int maxSize) Tries to set max size of the map.RMapCacheAsync.trySetMaxSizeAsync
(int maxSize, EvictionMode mode) Tries to set max size of the map.RPermitExpirableSemaphoreAsync.trySetPermitsAsync
(int permits) Tries to set number of permits.RSemaphoreAsync.trySetPermitsAsync
(int permits) Tries to set number of permits.RRateLimiterAsync.trySetRateAsync
(RateType mode, long rate, long rateInterval, RateIntervalUnit rateIntervalUnit) Initializes RateLimiter's state and stores config to Redis server.RTransferQueueAsync.tryTransferAsync
(V e) Tries to transfer the element to waiting consumer which invokedRBlockingQueueAsync.takeAsync()
orRBlockingQueueAsync.pollAsync(long, java.util.concurrent.TimeUnit)
method at the moment of transfer.RTransferQueueAsync.tryTransferAsync
(V e, long timeout, TimeUnit unit) Transfers the element to waiting consumer which invokedRBlockingQueueAsync.takeAsync()
orRBlockingQueueAsync.pollAsync(long, java.util.concurrent.TimeUnit)
method at the moment of transfer.RScoredSortedSetAsync.unionAsync
(String... names) Union provided ScoredSortedSets and store result to current ScoredSortedSetRScoredSortedSetAsync.unionAsync
(Map<String, Double> nameWithWeight) Union provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSetRScoredSortedSetAsync.unionAsync
(RScoredSortedSet.Aggregate aggregate, String... names) Union provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSetRScoredSortedSetAsync.unionAsync
(RScoredSortedSet.Aggregate aggregate, Map<String, Double> nameWithWeight) Union provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSetRSetAsync.unionAsync
(String... names) Union sets specified by name and write to current set.RKeysAsync.unlinkAsync
(String... keys) Delete multiple objects by name.RObjectAsync.unlinkAsync()
Delete the objects.RLockAsync.unlockAsync()
Unlocks the lockRLockAsync.unlockAsync
(long threadId) Unlocks the lock.RMapCacheAsync.updateEntryExpirationAsync
(K key, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) Updates time to live and max idle time of specified entry by key.RStreamAsync.updateGroupMessageIdAsync
(String groupName, StreamMessageId id) Updates next message id delivered to consumers.RPermitExpirableSemaphoreAsync.updateLeaseTimeAsync
(String permitId, long leaseTime, TimeUnit unit) Overrides and updates lease time for defined permit id.RScoredSortedSetAsync.valueRangeAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) Returns all values betweenstartScore
andendScore
.RScoredSortedSetAsync.valueRangeAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) Returns all values betweenstartScore
andendScore
.RScoredSortedSetAsync.valueRangeAsync
(int startIndex, int endIndex) Returns values by rank range.RScoredSortedSetAsync.valueRangeReversedAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive) Returns all values betweenstartScore
andendScore
in reversed order.RScoredSortedSetAsync.valueRangeReversedAsync
(double startScore, boolean startScoreInclusive, double endScore, boolean endScoreInclusive, int offset, int count) Returns all values betweenstartScore
andendScore
in reversed order.RScoredSortedSetAsync.valueRangeReversedAsync
(int startIndex, int endIndex) Returns values by rank range in reverse order.RMapAsync.valueSizeAsync
(K key) Returns size of value mapped by key in bytesExecutes XOR operation over this object and specified bitsets. -
Uses of RFuture in org.redisson.api.mapreduce
Modifier and TypeMethodDescriptionRMapReduceExecutor.executeAsync()
Executes MapReduce process across Redisson Nodes in asynchronous modeRMapReduceExecutor.executeAsync
(String resultMapName) Executes MapReduce process across Redisson Nodes in asynchronous mode and stores result in map withresultMapName
<R> RFuture<R>
RMapReduceExecutor.executeAsync
(RCollator<KOut, VOut, R> collator) Executes MapReduce process across Redisson Nodes in asynchronous mode and collides result using definedcollator
-
Uses of RFuture in org.redisson.api.redisnode
Modifier and TypeMethodDescriptionRedisClusterNodeAsync.clusterAddSlotsAsync
(int... slots) Adds slots to this Redis nodeRedisClusterNodeAsync.clusterCountFailureReportsAsync
(String nodeId) Returns number of failure reports for Redis node by defined idRedisClusterNodeAsync.clusterCountKeysInSlotAsync
(int slot) Counts keys in defined slotRedisClusterNodeAsync.clusterDeleteSlotsAsync
(int... slots) Removes slots from this Redis nodeRedisClusterNodeAsync.clusterFlushSlotsAsync()
Removes all slots from this Redis nodeRedisClusterNodeAsync.clusterForgetAsync
(String nodeId) Removes Redis node by defined id from ClusterRedisClusterNodeAsync.clusterGetKeysInSlotAsync
(int slot, int count) Returns keys in defines slot limited by countRedisClusterNodeAsync.clusterIdAsync()
Returns id of this Redis nodeRedisClusterNodeAsync.clusterInfoAsync()
Returns cluster information reported by this Redis nodeRedisClusterNodeAsync.clusterMeetAsync
(String address) Joins Redis node by the defined address to ClusterRedisClusterNodeAsync.clusterReplicateAsync
(String nodeId) Reconfigures this Redis node as replica of Redis node by defined id.RedisClusterNodeAsync.clusterSetSlotAsync
(int slot, SetSlotCommand command) Sets slot to this Redis node according to defined commandRedisClusterNodeAsync.clusterSetSlotAsync
(int slot, SetSlotCommand command, String nodeId) Sets slot to this Redis node according to defined commandRedisClusterNodeAsync.clusterSlotsAsync()
Return Redis Cluster slots mapped to Redis nodesRedisSentinelAsync.failoverAsync
(String masterName) Starts failover process for defined Redis masterRedisNodeAsync.getConfigAsync
(String parameter) Get value of Redis configuration parameter.RedisSentinelAsync.getMasterAddrAsync
(String masterName) Returns network address of defined Redis master.RedisSentinelAsync.getMasterAsync
(String masterName) Returns map containing info regarding defined Redis master.RedisSentinelAsync.getMastersAsync()
Returns list of map containing info regarding Redis Master server monitored by current Redis Sentinel server.RedisNodeAsync.getMemoryStatisticsAsync()
Returns Redis memory statisticsRedisSentinelAsync.getSentinelsAsync
(String masterName) Returns list of map containing info regarding Redis Sentinel server monitoring defined master.RedisSentinelAsync.getSlavesAsync
(String masterName) Returns list of map containing info regarding Redis Slave server of defined master.RedisNodeAsync.infoAsync
(RedisNode.InfoSection section) Returns information about Redis node.RedisNodeAsync.pingAsync()
Ping Redis node.Ping Redis node with specified timeout.RedisNodeAsync.setConfigAsync
(String parameter, String value) Set value of Redis configuration parameter.RedisNodeAsync.timeAsync()
Returns current Redis server time in seconds -
Uses of RFuture in org.redisson.cache
-
Uses of RFuture in org.redisson.client
Modifier and TypeMethodDescription<T,
R> RFuture<R> RedisConnection.async
(long timeout, Codec encoder, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> RedisConnection.async
(long timeout, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> RedisConnection.async
(Codec encoder, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> RedisConnection.async
(RedisCommand<T> command, Object... params) RedisClient.connectAsync()
RedisClient.connectPubSubAsync()
RedisClient.shutdownAsync()
-
Uses of RFuture in org.redisson.client.handler
-
Uses of RFuture in org.redisson.command
Modifier and TypeMethodDescription<V,
R> RFuture<R> CommandAsyncExecutor.async
(boolean readOnlyMode, NodeSource source, Codec codec, RedisCommand<V> command, Object[] params, boolean ignoreRedirect, boolean noRetry) <V,
R> RFuture<R> CommandAsyncService.async
(boolean readOnlyMode, NodeSource source, Codec codec, RedisCommand<V> command, Object[] params, boolean ignoreRedirect, boolean noRetry) <V,
R> RFuture<R> CommandBatchService.async
(boolean readOnlyMode, NodeSource nodeSource, Codec codec, RedisCommand<V> command, Object[] params, boolean ignoreRedirect, boolean noRetry) CommandBatchService.discardAsync()
<T,
R> RFuture<R> CommandAsyncExecutor.evalReadAsync
(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.evalReadAsync
(RedisClient client, String name, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.evalReadAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncService.evalReadAsync
(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncService.evalReadAsync
(RedisClient client, String name, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncService.evalReadAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.evalWriteAsync
(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.evalWriteAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncService.evalWriteAsync
(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncService.evalWriteAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.evalWriteNoRetryAsync
(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) <T,
R> RFuture<R> CommandAsyncService.evalWriteNoRetryAsync
(String key, Codec codec, RedisCommand<T> evalCommandType, String script, List<Object> keys, Object... params) RFuture<BatchResult<?>>
CommandBatchService.executeAsync()
CommandBatchService.executeAsyncVoid()
<V> RFuture<V>
CommandAsyncExecutor.pollFromAnyAsync
(String name, Codec codec, RedisCommand<?> command, long secondsTimeout, String... queueNames) <V> RFuture<V>
CommandAsyncService.pollFromAnyAsync
(String name, Codec codec, RedisCommand<?> command, long secondsTimeout, String... queueNames) <T,
R> RFuture<R> CommandAsyncExecutor.readAsync
(byte[] key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.readAsync
(String key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.readAsync
(String key, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.readAsync
(RedisClient client, byte[] key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.readAsync
(RedisClient client, String name, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.readAsync
(RedisClient client, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.readAsync
(RedisClient client, MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.readAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readAsync
(byte[] key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readAsync
(String key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readAsync
(String key, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readAsync
(RedisClient client, byte[] key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readAsync
(RedisClient client, String name, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readAsync
(RedisClient client, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readAsync
(RedisClient client, MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.readBatchedAsync
(Codec codec, RedisCommand<T> command, SlotCallback<T, R> callback, String... keys) <T,
R> RFuture<R> CommandAsyncService.readBatchedAsync
(Codec codec, RedisCommand<T> command, SlotCallback<T, R> callback, String... keys) <T,
R> RFuture<R> CommandAsyncExecutor.readRandomAsync
(Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.readRandomAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readRandomAsync
(Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.readRandomAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params) CommandAsyncExecutor.writeAllVoidAsync
(RedisCommand<T> command, Object... params) CommandAsyncService.writeAllVoidAsync
(RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.writeAsync
(byte[] key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.writeAsync
(String key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.writeAsync
(String key, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.writeAsync
(RedisClient client, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.writeAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.writeAsync
(byte[] key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.writeAsync
(String key, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.writeAsync
(String key, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.writeAsync
(RedisClient client, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncService.writeAsync
(MasterSlaveEntry entry, Codec codec, RedisCommand<T> command, Object... params) <T,
R> RFuture<R> CommandAsyncExecutor.writeBatchedAsync
(Codec codec, RedisCommand<T> command, SlotCallback<T, R> callback, String... keys) <T,
R> RFuture<R> CommandAsyncService.writeBatchedAsync
(Codec codec, RedisCommand<T> command, SlotCallback<T, R> callback, String... keys) Modifier and TypeMethodDescriptionvoid
CommandBatchService.add
(RFuture<?> future, List<CommandBatchService> services) <V> V
<V> V
<V> V
<V> V
CommandAsyncExecutor.getInterrupted
(RFuture<V> future) <V> V
CommandAsyncService.getInterrupted
(RFuture<V> future) protected void
CommandBatchService.handle
(CompletableFuture<Void> mainPromise, AtomicInteger slots, RFuture<?> future) -
Uses of RFuture in org.redisson.connection
Modifier and TypeMethodDescriptionRedisClientEntry.clusterInfoAsync()
RedisClientEntry.infoAsync
(Node.InfoSection section) RedisClientEntry.pingAsync()
RedisClientEntry.timeAsync()
-
Uses of RFuture in org.redisson.executor
Modifier and TypeClassDescriptionclass
class
class
Modifier and TypeFieldDescriptionprotected final BlockingQueue<RFuture<V>>
RedissonCompletionService.completionQueue
Modifier and TypeMethodDescriptionTasksService.cancelExecutionAsync
(String requestId) TasksBatchService.executeAddAsync()
<T> RFuture<T>
RemoteExecutorServiceAsync.executeCallable
(TaskParameters params) RemoteExecutorServiceAsync.executeRunnable
(TaskParameters params) protected RFuture<RemoteServiceRequest>
RedissonExecutorRemoteService.getTask
(String requestId, RMap<String, RemoteServiceRequest> tasks) TasksService.hasTaskAsync
(String taskId) TasksRunnerService.renewRetryTime
(String requestId) RemoteExecutorServiceAsync.schedule
(ScheduledCronExpressionParameters params) RemoteExecutorServiceAsync.scheduleAtFixedRate
(ScheduledAtFixedRateParameters params) <T> RFuture<T>
RemoteExecutorServiceAsync.scheduleCallable
(ScheduledParameters params) RemoteExecutorServiceAsync.scheduleRunnable
(ScheduledParameters params) RemoteExecutorServiceAsync.scheduleWithFixedDelay
(ScheduledWithFixedDelayParameters params) ModifierConstructorDescriptionRedissonCompletionService
(RScheduledExecutorService executorService, BlockingQueue<RFuture<V>> completionQueue) -
Uses of RFuture in org.redisson.jcache
Modifier and TypeMethodDescriptionJCache.clearAsync()
JCache.containsKeyAsync
(K key) JCache.getAllAsync
(Set<? extends K> keys) JCache.getAndPutAsync
(K key, V value) JCache.getAndRemoveAsync
(K key) JCache.getAndReplaceAsync
(K key, V value) JCache.putAllAsync
(Map<? extends K, ? extends V> map) JCache.putIfAbsentAsync
(K key, V value) JCache.removeAllAsync
(Set<? extends K> keys) JCache.removeAsync
(K key) JCache.removeAsync
(K key, V value) JCache.replaceAsync
(K key, V value) JCache.replaceAsync
(K key, V oldValue, V newValue) -
Uses of RFuture in org.redisson.misc
-
Uses of RFuture in org.redisson.reactive
Modifier and TypeMethodDescription<V,
R> RFuture<R> CommandReactiveBatchService.async
(boolean readOnlyMode, NodeSource nodeSource, Codec codec, RedisCommand<V> command, Object[] params, boolean ignoreRedirect, boolean noRetry) CommandReactiveBatchService.discardAsync()
RFuture<BatchResult<?>>
CommandReactiveBatchService.executeAsync()
protected abstract RFuture<ScanResult<Object>>
IteratorConsumer.scanIterator
(RedisClient client, long nextIterPos) MapReactiveIterator.scanIterator
(RedisClient client, long nextIterPos) protected abstract RFuture<ScanResult<Object>>
SetReactiveIterator.scanIterator
(RedisClient client, long nextIterPos) Modifier and TypeMethodDescription<R> reactor.core.publisher.Mono<R>
<R> reactor.core.publisher.Mono<R>
<R> reactor.core.publisher.Mono<R>
static <V> reactor.core.publisher.Flux<V>
ElementsStream.takeElements
(Callable<RFuture<V>> callable) -
Uses of RFuture in org.redisson.redisnode
Modifier and TypeMethodDescriptionRedisNode.clusterAddSlotsAsync
(int... slots) RedisNode.clusterCountFailureReportsAsync
(String nodeId) RedisNode.clusterCountKeysInSlotAsync
(int slot) RedisNode.clusterDeleteSlotsAsync
(int... slots) RedisNode.clusterFlushSlotsAsync()
RedisNode.clusterForgetAsync
(String nodeId) RedisNode.clusterGetKeysInSlotAsync
(int slot, int count) RedisNode.clusterIdAsync()
RedisNode.clusterInfoAsync()
RedisNode.clusterMeetAsync
(String address) RedisNode.clusterReplicateAsync
(String nodeId) RedisNode.clusterSetSlotAsync
(int slot, SetSlotCommand command) RedisNode.clusterSetSlotAsync
(int slot, SetSlotCommand command, String nodeId) RedisNode.clusterSlotsAsync()
SentinelRedisNode.failoverAsync
(String masterName) RedisNode.getConfigAsync
(String parameter) SentinelRedisNode.getConfigAsync
(String parameter) SentinelRedisNode.getMasterAddrAsync
(String masterName) SentinelRedisNode.getMasterAsync
(String masterName) SentinelRedisNode.getMastersAsync()
RedisNode.getMemoryStatisticsAsync()
SentinelRedisNode.getMemoryStatisticsAsync()
SentinelRedisNode.getSentinelsAsync
(String masterName) SentinelRedisNode.getSlavesAsync
(String masterName) RedisNode.infoAsync
(RedisNode.InfoSection section) SentinelRedisNode.infoAsync
(RedisNode.InfoSection section) RedisNode.pingAsync()
SentinelRedisNode.pingAsync()
RedisNode.setConfigAsync
(String parameter, String value) SentinelRedisNode.setConfigAsync
(String parameter, String value) RedisNode.timeAsync()
SentinelRedisNode.timeAsync()
-
Uses of RFuture in org.redisson.rx
Modifier and TypeMethodDescription<V,
R> RFuture<R> CommandRxBatchService.async
(boolean readOnlyMode, NodeSource nodeSource, Codec codec, RedisCommand<V> command, Object[] params, boolean ignoreRedirect, boolean noRetry) protected abstract RFuture<ScanResult<Object>>
SetRxIterator.scanIterator
(RedisClient client, long nextIterPos) Modifier and TypeMethodDescriptionstatic <V> io.reactivex.rxjava3.core.Flowable<V>
ElementsStream.takeElements
(Supplier<RFuture<V>> callable) -
Uses of RFuture in org.redisson.transaction
Modifier and TypeMethodDescriptionBaseTransactionalSet.addAllAsync
(Collection<? extends V> c) RedissonTransactionalSet.addAllAsync
(Collection<? extends V> c) RedissonTransactionalSetCache.addAllAsync
(Collection<? extends V> c) BaseTransactionalMap.addAndGetOperationAsync
(K key, Number value) RedissonTransactionalMap.addAndGetOperationAsync
(K key, Number value) RedissonTransactionalMapCache.addAndGetOperationAsync
(K key, Number value) BaseTransactionalSet.addAsync
(V value, TransactionalOperation operation) BaseTransactionalMap.clearExpireAsync()
BaseTransactionalSet.clearExpireAsync()
RedissonTransactionalBucket.clearExpireAsync()
RedissonTransactionalMap.clearExpireAsync()
RedissonTransactionalMapCache.clearExpireAsync()
RedissonTransactionalSet.clearExpireAsync()
RedissonTransactionalSetCache.clearExpireAsync()
RedissonTransactionalLocalCachedMap.clearLocalCacheAsync()
RedissonTransaction.commitAsync()
RedissonTransactionalBucket.compareAndSetAsync
(V expect, V update) BaseTransactionalSet.containsAllAsync
(Collection<?> c) BaseTransactionalSet.containsAsync
(Object value) RedissonTransactionalSet.containsAsync
(Object o) RedissonTransactionalSetCache.containsAsync
(Object o) BaseTransactionalMap.containsKeyAsync
(Object key) RedissonTransactionalMap.containsKeyAsync
(Object key) RedissonTransactionalMapCache.containsKeyAsync
(Object key) BaseTransactionalMap.containsValueAsync
(Object value) RedissonTransactionalMap.containsValueAsync
(Object value) RedissonTransactionalMapCache.containsValueAsync
(Object value) BaseTransactionalMap.deleteAsync
(CommandAsyncExecutor commandExecutor) BaseTransactionalMap.deleteAsync
(CommandAsyncExecutor commandExecutor, TransactionalOperation operation) BaseTransactionalSet.deleteAsync()
BaseTransactionalSet.deleteAsync
(TransactionalOperation operation) RedissonTransactionalBucket.deleteAsync()
RedissonTransactionalMap.deleteAsync()
RedissonTransactionalMapCache.deleteAsync()
RedissonTransactionalSet.deleteAsync()
RedissonTransactionalSetCache.deleteAsync()
protected <R> RFuture<R>
BaseTransactionalMap.executeLocked
(K key, Supplier<CompletionStage<R>> runnable) protected <R> RFuture<R>
BaseTransactionalObject.executeLocked
(long threadId, long timeout, Supplier<CompletionStage<R>> runnable, RLock lock) protected <R> RFuture<R>
BaseTransactionalObject.executeLocked
(long timeout, Supplier<CompletionStage<R>> runnable, List<RLock> locks) protected <R> RFuture<R>
BaseTransactionalObject.executeLocked
(long timeout, Supplier<CompletionStage<R>> runnable, RLock lock) protected <R> RFuture<R>
BaseTransactionalSet.executeLocked
(Object value, Supplier<CompletionStage<R>> runnable) protected <R> RFuture<R>
BaseTransactionalSet.executeLocked
(Supplier<CompletionStage<R>> runnable, Collection<?> values) protected <R> RFuture<R>
RedissonTransactionalBucket.executeLocked
(Supplier<CompletionStage<R>> runnable) protected <R> RFuture<R>
RedissonTransactionalBuckets.executeLocked
(Supplier<CompletionStage<R>> runnable, Collection<String> keys) BaseTransactionalMap.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) BaseTransactionalSet.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonTransactionalBucket.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonTransactionalMap.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonTransactionalMapCache.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonTransactionalSet.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) RedissonTransactionalSetCache.expireAsync
(long timeToLive, TimeUnit timeUnit, String param, String... keys) BaseTransactionalMap.expireAtAsync
(long timestamp, String param, String... keys) BaseTransactionalSet.expireAtAsync
(long timestamp, String param, String... keys) RedissonTransactionalBucket.expireAtAsync
(long timestamp, String param, String... keys) RedissonTransactionalMap.expireAtAsync
(long timestamp, String param, String... keys) RedissonTransactionalMapCache.expireAtAsync
(long timestamp, String param, String... keys) RedissonTransactionalSet.expireAtAsync
(long timestamp, String param, String... keys) RedissonTransactionalSetCache.expireAtAsync
(long timestamp, String param, String... keys) BaseTransactionalMapCache.fastPutIfAbsentAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) RedissonTransactionalMapCache.fastPutIfAbsentAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) BaseTransactionalMap.fastPutIfAbsentOperationAsync
(K key, V value) BaseTransactionalMap.fastPutIfAbsentOperationAsync
(K key, V value, MapOperation mapOperation) RedissonTransactionalMap.fastPutIfAbsentOperationAsync
(K key, V value) RedissonTransactionalMapCache.fastPutIfAbsentOperationAsync
(K key, V value) BaseTransactionalMap.fastPutIfExistsOperationAsync
(K key, V value) BaseTransactionalMap.fastPutIfExistsOperationAsync
(K key, V value, MapOperation mapOperation) RedissonTransactionalMap.fastPutIfExistsOperationAsync
(K key, V value) RedissonTransactionalMapCache.fastPutIfExistsOperationAsync
(K key, V value) BaseTransactionalMap.fastPutOperationAsync
(K key, V value) BaseTransactionalMap.fastPutOperationAsync
(K key, V value, MapOperation operation) BaseTransactionalMapCache.fastPutOperationAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) RedissonTransactionalMap.fastPutOperationAsync
(K key, V value) RedissonTransactionalMapCache.fastPutOperationAsync
(K key, V value) RedissonTransactionalMapCache.fastPutOperationAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) BaseTransactionalMap.fastRemoveOperationAsync
(K... keys) RedissonTransactionalMap.fastRemoveOperationAsync
(K... keys) RedissonTransactionalMapCache.fastRemoveOperationAsync
(K... keys) BaseTransactionalMap.getAllOperationAsync
(Set<K> keys) RedissonTransactionalMap.getAllOperationAsync
(Set<K> keys) RedissonTransactionalMapCache.getAllOperationAsync
(Set<K> keys) RedissonTransactionalBucket.getAndDeleteAsync()
RedissonTransactionalBucket.getAndSetAsync
(V value) RedissonTransactionalBucket.getAndSetAsync
(V value, long timeToLive, TimeUnit timeUnit) RedissonTransactionalBucket.getAsync()
BaseTransactionalMap.getOperationAsync
(K key) RedissonTransactionalMap.getOperationAsync
(K key) RedissonTransactionalMapCache.getOperationAsync
(K key) BaseTransactionalSet.intersectionAsync
(String... names) RedissonTransactionalSet.intersectionAsync
(String... names) BaseTransactionalMap.isExistsAsync()
BaseTransactionalSet.isExistsAsync()
RedissonTransactionalBucket.isExistsAsync()
RedissonTransactionalMap.isExistsAsync()
RedissonTransactionalMapCache.isExistsAsync()
RedissonTransactionalMap.loadAllAsync
(boolean replaceExistingValues, int parallelism) RedissonTransactionalMap.loadAllAsync
(Set<? extends K> keys, boolean replaceExistingValues, int parallelism) RedissonTransactionalMapCache.loadAllAsync
(boolean replaceExistingValues, int parallelism) RedissonTransactionalMapCache.loadAllAsync
(Set<? extends K> keys, boolean replaceExistingValues, int parallelism) BaseTransactionalObject.migrateAsync
(String host, int port, int database) RedissonTransactionalBucket.migrateAsync
(String host, int port, int database, long timeout) RedissonTransactionalMap.migrateAsync
(String host, int port, int database, long timeout) RedissonTransactionalMapCache.migrateAsync
(String host, int port, int database, long timeout) RedissonTransactionalSet.migrateAsync
(String host, int port, int database, long timeout) RedissonTransactionalSetCache.migrateAsync
(String host, int port, int database, long timeout) BaseTransactionalObject.moveAsync
(int database) RedissonTransactionalBucket.moveAsync
(int database) RedissonTransactionalMap.moveAsync
(int database) RedissonTransactionalMapCache.moveAsync
(int database) RedissonTransactionalSet.moveAsync
(int database) RedissonTransactionalSetCache.moveAsync
(int database) BaseTransactionalMap.putAllOperationAsync
(Map<? extends K, ? extends V> entries) RedissonTransactionalMap.putAllOperationAsync
(Map<? extends K, ? extends V> entries) RedissonTransactionalMapCache.putAllOperationAsync
(Map<? extends K, ? extends V> entries) BaseTransactionalMapCache.putIfAbsentAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) RedissonTransactionalMapCache.putIfAbsentAsync
(K key, V value, long ttl, TimeUnit ttlUnit, long maxIdleTime, TimeUnit maxIdleUnit) BaseTransactionalMap.putIfAbsentOperationAsync
(K key, V value) BaseTransactionalMap.putIfAbsentOperationAsync
(K key, V value, MapOperation mapOperation) RedissonTransactionalMap.putIfAbsentOperationAsync
(K key, V value) RedissonTransactionalMapCache.putIfAbsentOperationAsync
(K key, V value) BaseTransactionalMap.putIfExistsOperationAsync
(K key, V value) BaseTransactionalMap.putIfExistsOperationAsync
(K key, V value, MapOperation mapOperation) RedissonTransactionalMap.putIfExistsOperationAsync
(K key, V value) RedissonTransactionalMapCache.putIfExistsOperationAsync
(K key, V value) BaseTransactionalMap.putOperationAsync
(K key, V value) BaseTransactionalMap.putOperationAsync
(K key, V value, MapOperation operation) BaseTransactionalMapCache.putOperationAsync
(K key, V value, long ttlTimeout, long maxIdleTimeout, long maxIdleDelta, long ttlTimeoutDelta) RedissonTransactionalMap.putOperationAsync
(K key, V value) RedissonTransactionalMapCache.putOperationAsync
(K key, V value) RedissonTransactionalMapCache.putOperationAsync
(K key, V value, long ttlTimeout, long maxIdleTimeout, long maxIdleDelta, long ttlTimeoutDelta) BaseTransactionalSet.readAllAsync()
RedissonTransactionalSet.readAllAsync()
RedissonTransactionalSetCache.readAllAsync()
BaseTransactionalSet.readAllAsyncSource()
TransactionalSet.readAllAsyncSource()
TransactionalSetCache.readAllAsyncSource()
BaseTransactionalMap.readAllEntrySetAsync()
RedissonTransactionalMap.readAllEntrySetAsync()
RedissonTransactionalMapCache.readAllEntrySetAsync()
BaseTransactionalMap.readAllKeySetAsync()
RedissonTransactionalMap.readAllKeySetAsync()
RedissonTransactionalMapCache.readAllKeySetAsync()
BaseTransactionalMap.readAllMapAsync()
RedissonTransactionalMap.readAllMapAsync()
RedissonTransactionalMapCache.readAllMapAsync()
BaseTransactionalMap.readAllValuesAsync()
RedissonTransactionalMap.readAllValuesAsync()
RedissonTransactionalMapCache.readAllValuesAsync()
BaseTransactionalSet.readDiffAsync
(String... names) RedissonTransactionalSet.readDiffAsync
(String... names) BaseTransactionalSet.readIntersectionAsync
(String... names) RedissonTransactionalSet.readIntersectionAsync
(String... names) <T> RFuture<Collection<T>>
BaseTransactionalSet.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
BaseTransactionalSet.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) BaseTransactionalSet.readSortAlphaAsync
(String byPattern, SortOrder order) BaseTransactionalSet.readSortAlphaAsync
(String byPattern, SortOrder order, int offset, int count) BaseTransactionalSet.readSortAlphaAsync
(SortOrder order) BaseTransactionalSet.readSortAlphaAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonTransactionalSet.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order) <T> RFuture<Collection<T>>
RedissonTransactionalSet.readSortAlphaAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonTransactionalSet.readSortAlphaAsync
(String byPattern, SortOrder order) RedissonTransactionalSet.readSortAlphaAsync
(String byPattern, SortOrder order, int offset, int count) RedissonTransactionalSet.readSortAlphaAsync
(SortOrder order) RedissonTransactionalSet.readSortAlphaAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
BaseTransactionalSet.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) BaseTransactionalSet.readSortAsync
(String byPattern, SortOrder order) BaseTransactionalSet.readSortAsync
(SortOrder order) BaseTransactionalSet.readSortAsync
(SortOrder order, int offset, int count) <T> RFuture<Collection<T>>
RedissonTransactionalSet.readSortAsync
(String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonTransactionalSet.readSortAsync
(String byPattern, SortOrder order) RedissonTransactionalSet.readSortAsync
(SortOrder order) RedissonTransactionalSet.readSortAsync
(SortOrder order, int offset, int count) BaseTransactionalSet.readUnionAsync
(String... names) RedissonTransactionalSet.readUnionAsync
(String... names) RedissonTransactionalMapCache.remainTimeToLiveAsync()
BaseTransactionalSet.removeAllAsync
(Collection<?> c) RedissonTransactionalSet.removeAllAsync
(Collection<?> c) RedissonTransactionalSetCache.removeAllAsync
(Collection<?> c) BaseTransactionalSet.removeAsync
(Object value) RedissonTransactionalSet.removeAsync
(Object o) RedissonTransactionalSetCache.removeAsync
(Object o) BaseTransactionalMap.removeOperationAsync
(Object key, Object value) BaseTransactionalMap.removeOperationAsync
(K key) RedissonTransactionalMap.removeOperationAsync
(Object key, Object value) RedissonTransactionalMap.removeOperationAsync
(K key) RedissonTransactionalMapCache.removeOperationAsync
(Object key, Object value) RedissonTransactionalMapCache.removeOperationAsync
(K key) BaseTransactionalSet.removeRandomAsync()
BaseTransactionalSet.removeRandomAsync
(int amount) RedissonTransactionalSet.removeRandomAsync()
RedissonTransactionalSet.removeRandomAsync
(int amount) BaseTransactionalMap.replaceOperationAsync
(K key, V value) BaseTransactionalMap.replaceOperationAsync
(K key, V oldValue, V newValue) RedissonTransactionalMap.replaceOperationAsync
(K key, V value) RedissonTransactionalMap.replaceOperationAsync
(K key, V oldValue, V newValue) RedissonTransactionalMapCache.replaceOperationAsync
(K key, V value) RedissonTransactionalMapCache.replaceOperationAsync
(K key, V oldValue, V newValue) BaseTransactionalSet.retainAllAsync
(Collection<?> c) RedissonTransactionalSet.retainAllAsync
(Collection<?> c) RedissonTransactionalSetCache.retainAllAsync
(Collection<?> c) RedissonTransaction.rollbackAsync()
RedissonTransactionalMapCache.setMaxSizeAsync
(int maxSize) RedissonTransactionalBucket.sizeAsync()
BaseTransactionalSet.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) RedissonTransactionalSet.sortToAsync
(String destName, String byPattern, List<String> getPatterns, SortOrder order, int offset, int count) BaseTransactionalMap.touchAsync
(CommandAsyncExecutor commandExecutor) BaseTransactionalSet.touchAsync()
RedissonTransactionalBucket.touchAsync()
RedissonTransactionalMap.touchAsync()
RedissonTransactionalMapCache.touchAsync()
RedissonTransactionalSet.touchAsync()
RedissonTransactionalSetCache.touchAsync()
RedissonTransactionalBucket.trySetAsync
(V newValue) RedissonTransactionalBucket.trySetAsync
(V value, long timeToLive, TimeUnit timeUnit) RedissonTransactionalBuckets.trySetAsync
(Map<String, ?> buckets) RedissonTransactionalMapCache.trySetMaxSizeAsync
(int maxSize) BaseTransactionalSet.unionAsync
(String... names) RedissonTransactionalSet.unionAsync
(String... names) BaseTransactionalMap.unlinkAsync
(CommandAsyncExecutor commandExecutor) BaseTransactionalSet.unlinkAsync()
RedissonTransactionalBucket.unlinkAsync()
RedissonTransactionalMap.unlinkAsync()
RedissonTransactionalMapCache.unlinkAsync()
RedissonTransactionalSet.unlinkAsync()
RedissonTransactionalSetCache.unlinkAsync()
BaseTransactionalMap.valueSizeAsync
(K key) RedissonTransactionalMap.valueSizeAsync
(K key) RedissonTransactionalMapCache.valueSizeAsync
(K key) -
Uses of RFuture in org.redisson.transaction.operation