Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

A

AbstractCacheMap<K,V> - Class in org.redisson.cache
 
AbstractCacheMap(int, long, long) - Constructor for class org.redisson.cache.AbstractCacheMap
 
AbstractNamingScheme - Class in org.redisson.liveobject.resolver
 
AbstractNamingScheme(Codec) - Constructor for class org.redisson.liveobject.resolver.AbstractNamingScheme
 
AbstractRedissonNamespaceDefinitionParser - Class in org.redisson.spring.support
 
AbstractRedissonNamespaceDefinitionParser(RedissonNamespaceParserSupport, String) - Constructor for class org.redisson.spring.support.AbstractRedissonNamespaceDefinitionParser
 
AbstractRedissonNamespaceDefinitionParser(RedissonNamespaceParserSupport, String, RedissonNamespaceDecorator) - Constructor for class org.redisson.spring.support.AbstractRedissonNamespaceDefinitionParser
 
accept(Object, Throwable) - Method in class org.redisson.mapreduce.SubTasksExecutor.LatchListener
 
accept(Object, Throwable) - Method in class org.redisson.misc.CountableListener
 
accept(T, Throwable) - Method in class org.redisson.misc.TransferListener
 
accept(FluxSink<M>) - Method in class org.redisson.reactive.MapReactiveIterator
 
accept(FluxSink<V>) - Method in class org.redisson.reactive.SetReactiveIterator
 
acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in class org.redisson.misc.PromiseDelegator
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in class org.redisson.misc.PromiseDelegator
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
AccessorInterceptor - Class in org.redisson.liveobject.core
This class is going to be instantiated and becomes a static field of the proxied target class.
AccessorInterceptor(CommandAsyncExecutor, ConnectionManager) - Constructor for class org.redisson.liveobject.core.AccessorInterceptor
 
ack(String, StreamMessageId...) - Method in interface org.redisson.api.RStream
Marks pending messages by group name and stream ids as correctly processed.
ack(String, StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Marks pending messages by group name and stream ids as correctly processed.
ack(String, StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Marks pending messages by group name and stream ids as correctly processed.
ack(String, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
ackAsync(String, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Marks pending messages by group name and stream ids as correctly processed.
ackAsync(String, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
acquire() - Method in interface org.redisson.api.RPermitExpirableSemaphore
Acquires a permit and returns its id.
acquire(long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphore
Acquires a permit with defined leaseTime and return its id.
acquire() - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Acquires a permit and returns its id.
acquire(long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Acquires a permit with defined leaseTime and return its id.
acquire() - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Acquires a permit from this semaphore, blocking until one is available, or the thread is interrupted.
acquire(long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Acquires a permit with defined lease time from this semaphore, blocking until one is available, or the thread is interrupted.
acquire() - Method in interface org.redisson.api.RRateLimiter
Acquires a permit from this RateLimiter, blocking until one is available.
acquire(long) - Method in interface org.redisson.api.RRateLimiter
Acquires a specified permits from this RateLimiter, blocking until one is available.
acquire() - Method in interface org.redisson.api.RRateLimiterReactive
Acquires a permit from this RateLimiter, blocking until one is available.
acquire(long) - Method in interface org.redisson.api.RRateLimiterReactive
Acquires a specified permits from this RateLimiter, blocking until one is available.
acquire() - Method in interface org.redisson.api.RRateLimiterRx
Acquires a permit from this RateLimiter, blocking until one is available.
acquire(long) - Method in interface org.redisson.api.RRateLimiterRx
Acquires a specified permits from this RateLimiter, blocking until one is available.
acquire() - Method in interface org.redisson.api.RSemaphore
Acquires a permit.
acquire(int) - Method in interface org.redisson.api.RSemaphore
Acquires defined amount of permits.
acquire() - Method in interface org.redisson.api.RSemaphoreReactive
Acquires a permit.
acquire(int) - Method in interface org.redisson.api.RSemaphoreReactive
Acquires defined amount of permits.
acquire() - Method in interface org.redisson.api.RSemaphoreRx
Acquires a permit.
acquire(int) - Method in interface org.redisson.api.RSemaphoreRx
Acquires defined amount of permits.
acquire() - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
acquire(Runnable) - Method in class org.redisson.pubsub.AsyncSemaphore
 
acquire(Runnable, int) - Method in class org.redisson.pubsub.AsyncSemaphore
 
acquire() - Method in interface org.redisson.PubSubEntry
 
acquire() - Method in class org.redisson.RedissonCountDownLatchEntry
 
acquire() - Method in class org.redisson.RedissonLockEntry
 
acquire(AsyncSemaphore) - Method in class org.redisson.RedissonPatternTopic
 
acquire() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
acquire(long, TimeUnit) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
acquire() - Method in class org.redisson.RedissonRateLimiter
 
acquire(long) - Method in class org.redisson.RedissonRateLimiter
 
acquire() - Method in class org.redisson.RedissonSemaphore
 
acquire(int) - Method in class org.redisson.RedissonSemaphore
 
acquire(AsyncSemaphore) - Method in class org.redisson.RedissonTopic
 
acquireAmount(int) - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
acquireAsync() - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Acquires a permit and returns its id.
acquireAsync(long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Acquires a permit with defined leaseTime and return its id.
acquireAsync() - Method in interface org.redisson.api.RRateLimiterAsync
Acquires a permit from this RateLimiter, blocking until one is available.
acquireAsync(long) - Method in interface org.redisson.api.RRateLimiterAsync
Acquires a specified permits from this RateLimiter, blocking until one is available.
acquireAsync() - Method in interface org.redisson.api.RSemaphoreAsync
Acquires a permit.
acquireAsync(int) - Method in interface org.redisson.api.RSemaphoreAsync
Acquires defined amount of permits.
acquireAsync(long, TimeUnit) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
acquireAsync() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
acquireAsync() - Method in class org.redisson.RedissonRateLimiter
 
acquireAsync(long) - Method in class org.redisson.RedissonRateLimiter
 
acquireAsync() - Method in class org.redisson.RedissonSemaphore
 
acquireAsync(int) - Method in class org.redisson.RedissonSemaphore
 
acquireConnection(Runnable) - Method in class org.redisson.connection.ClientConnectionsEntry
 
acquireConnection(ClientConnectionsEntry, Runnable) - Method in class org.redisson.connection.pool.PubSubConnectionPool
 
acquireFailedAsync(long) - Method in class org.redisson.RedissonFairLock
 
acquireFailedAsync(long) - Method in class org.redisson.RedissonLock
 
acquireSubscribeConnection(Runnable) - Method in class org.redisson.connection.ClientConnectionsEntry
 
add(T) - Method in interface org.redisson.api.RBloomFilter
Adds element
add(V) - Method in interface org.redisson.api.RCollectionReactive
Adds element into this collection.
add(V) - Method in interface org.redisson.api.RCollectionRx
Adds element into this collection.
add(double) - Method in interface org.redisson.api.RDoubleAdder
Adds value
add(double, double, V) - Method in interface org.redisson.api.RGeo
Adds geospatial member.
add(GeoEntry...) - Method in interface org.redisson.api.RGeo
Adds geospatial members.
add(double, double, V) - Method in interface org.redisson.api.RGeoReactive
Adds geospatial member.
add(GeoEntry...) - Method in interface org.redisson.api.RGeoReactive
Adds geospatial members.
add(double, double, V) - Method in interface org.redisson.api.RGeoRx
Adds geospatial member.
add(GeoEntry...) - Method in interface org.redisson.api.RGeoRx
Adds geospatial members.
add(V) - Method in interface org.redisson.api.RHyperLogLog
Adds element into this structure.
add(V) - Method in interface org.redisson.api.RHyperLogLogReactive
Adds element into this structure.
add(V) - Method in interface org.redisson.api.RHyperLogLogRx
Adds element into this structure.
add(int, V) - Method in interface org.redisson.api.RListReactive
Inserts element at index.
add(int, V) - Method in interface org.redisson.api.RListRx
Inserts element at index.
add(long) - Method in interface org.redisson.api.RLongAdder
Adds value
add(double, V) - Method in interface org.redisson.api.RScoredSortedSet
Adds element to this set, overrides previous score if it has been already added.
add(double, V) - Method in interface org.redisson.api.RScoredSortedSetReactive
Adds element to this set, overrides previous score if it has been already added.
add(double, V) - Method in interface org.redisson.api.RScoredSortedSetRx
Adds element to this set, overrides previous score if it has been already added.
add(V, long, TimeUnit) - Method in interface org.redisson.api.RSetCache
Stores value with specified time to live.
add(V, long, TimeUnit) - Method in interface org.redisson.api.RSetCacheReactive
Stores value with specified time to live.
add(V, long, TimeUnit) - Method in interface org.redisson.api.RSetCacheRx
Stores value with specified time to live.
add(K, V) - Method in interface org.redisson.api.RStream
Appends a new entry and returns generated Stream Message ID
add(StreamMessageId, K, V) - Method in interface org.redisson.api.RStream
Appends a new entry by specified Stream Message ID
add(K, V, int, boolean) - Method in interface org.redisson.api.RStream
Appends a new entry and returns generated Stream Message ID.
add(StreamMessageId, K, V, int, boolean) - Method in interface org.redisson.api.RStream
Appends a new entry by specified Stream Message ID.
add(K, V) - Method in interface org.redisson.api.RStreamReactive
Appends a new entry and returns generated Stream ID
add(StreamMessageId, K, V) - Method in interface org.redisson.api.RStreamReactive
Appends a new entry by specified Stream ID
add(K, V, int, boolean) - Method in interface org.redisson.api.RStreamReactive
Appends a new entry and returns generated Stream ID.
add(StreamMessageId, K, V, int, boolean) - Method in interface org.redisson.api.RStreamReactive
Appends a new entry by specified Stream ID.
add(K, V) - Method in interface org.redisson.api.RStreamRx
Appends a new entry and returns generated Stream ID
add(StreamMessageId, K, V) - Method in interface org.redisson.api.RStreamRx
Appends a new entry by specified Stream ID
add(K, V, int, boolean) - Method in interface org.redisson.api.RStreamRx
Appends a new entry and returns generated Stream ID.
add(StreamMessageId, K, V, int, boolean) - Method in interface org.redisson.api.RStreamRx
Appends a new entry by specified Stream ID.
add(Map<?, ?>) - Method in class org.redisson.cache.LocalCacheListener
 
add(RFuture<?>, List<CommandBatchService>) - Method in class org.redisson.command.CommandBatchService
 
add(ClientConnectionsEntry) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
add(int, int, Collection<? extends RedisConnection>, AsyncSemaphore, Function<RedisConnection, Boolean>) - Method in class org.redisson.connection.IdleConnectionWatcher
 
add(int, V) - Method in class org.redisson.iterator.RedissonListIterator
 
add(V) - Method in class org.redisson.iterator.RedissonListIterator
 
Add() - Constructor for class org.redisson.MapWriterTask.Add
 
Add(Map<?, ?>) - Constructor for class org.redisson.MapWriterTask.Add
 
Add(Object, Object) - Constructor for class org.redisson.MapWriterTask.Add
 
add(Object) - Method in class org.redisson.reactive.PublisherAdder
 
add(T) - Method in class org.redisson.RedissonBloomFilter
 
add(V) - Method in class org.redisson.RedissonDelayedQueue
 
add(double) - Method in class org.redisson.RedissonDoubleAdder
 
add(double, double, V) - Method in class org.redisson.RedissonGeo
 
add(GeoEntry...) - Method in class org.redisson.RedissonGeo
 
add(V) - Method in class org.redisson.RedissonHyperLogLog
 
add(String) - Method in class org.redisson.RedissonLexSortedSet
 
add(V) - Method in class org.redisson.RedissonList
 
add(int, V) - Method in class org.redisson.RedissonList
 
add(V) - Method in class org.redisson.RedissonListMultimapValues
 
add(int, V) - Method in class org.redisson.RedissonListMultimapValues
 
add(long) - Method in class org.redisson.RedissonLongAdder
 
add(V) - Method in class org.redisson.RedissonPriorityQueue
 
add(double, V) - Method in class org.redisson.RedissonScoredSortedSet
 
add(V) - Method in class org.redisson.RedissonSet
 
add(V) - Method in class org.redisson.RedissonSetCache
 
add(V, long, TimeUnit) - Method in class org.redisson.RedissonSetCache
 
add(V) - Method in class org.redisson.RedissonSetMultimapValues
 
add(V) - Method in class org.redisson.RedissonSortedSet
 
add(K, V) - Method in class org.redisson.RedissonStream
 
add(StreamMessageId, K, V) - Method in class org.redisson.RedissonStream
 
add(K, V, int, boolean) - Method in class org.redisson.RedissonStream
 
add(StreamMessageId, K, V, int, boolean) - Method in class org.redisson.RedissonStream
 
add(int, V) - Method in class org.redisson.RedissonSubList
 
add(V) - Method in class org.redisson.RedissonTransferQueue
 
add(Object) - Method in class org.redisson.rx.PublisherAdder
 
addAccessCount(long) - Method in class org.redisson.cache.LFUCacheMap.LFUCachedValue
 
addAfter(V, V) - Method in interface org.redisson.api.RList
Add element after elementToFind
addAfter(V, V) - Method in interface org.redisson.api.RListReactive
Add element after elementToFind
addAfter(V, V) - Method in interface org.redisson.api.RListRx
Add element after elementToFind
addAfter(V, V) - Method in class org.redisson.RedissonList
 
addAfter(V, V) - Method in class org.redisson.RedissonListMultimapValues
 
addAfterAsync(V, V) - Method in interface org.redisson.api.RListAsync
Inserts element after elementToFind
addAfterAsync(V, V) - Method in class org.redisson.RedissonList
 
addAfterAsync(V, V) - Method in class org.redisson.RedissonListMultimapValues
 
addAll(Publisher<? extends V>) - Method in interface org.redisson.api.RCollectionReactive
Adds all elements contained in the specified collection
addAll(Collection<? extends V>) - Method in interface org.redisson.api.RCollectionReactive
Adds all elements contained in the specified collection
addAll(Publisher<? extends V>) - Method in interface org.redisson.api.RCollectionRx
Adds all elements contained in the specified collection
addAll(Collection<? extends V>) - Method in interface org.redisson.api.RCollectionRx
Adds all elements contained in the specified collection
addAll(Collection<V>) - Method in interface org.redisson.api.RHyperLogLog
Adds all elements contained in objects collection into this structure
addAll(Collection<V>) - Method in interface org.redisson.api.RHyperLogLogReactive
Adds all elements contained in objects collection into this structure
addAll(Collection<V>) - Method in interface org.redisson.api.RHyperLogLogRx
Adds all elements contained in objects collection into this structure
addAll(int, Collection<? extends V>) - Method in interface org.redisson.api.RListReactive
Inserts elements at index.
addAll(int, Collection<? extends V>) - Method in interface org.redisson.api.RListRx
Inserts elements at index.
addAll(Map<V, Double>) - Method in interface org.redisson.api.RScoredSortedSet
Adds all elements contained in the specified map to this sorted set.
addAll(Map<V, Double>) - Method in interface org.redisson.api.RScoredSortedSetReactive
Adds all elements contained in the specified map to this sorted set.
addAll(Map<V, Double>) - Method in interface org.redisson.api.RScoredSortedSetRx
Adds all elements contained in the specified map to this sorted set.
addAll(Map<K, V>) - Method in interface org.redisson.api.RStream
Appends new entries and returns generated Stream Message ID
addAll(StreamMessageId, Map<K, V>) - Method in interface org.redisson.api.RStream
Appends new entries by specified Stream Message ID
addAll(Map<K, V>, int, boolean) - Method in interface org.redisson.api.RStream
Appends new entries and returns generated Stream Message ID.
addAll(StreamMessageId, Map<K, V>, int, boolean) - Method in interface org.redisson.api.RStream
Appends new entries by specified Stream Message ID.
addAll(Map<K, V>) - Method in interface org.redisson.api.RStreamReactive
Appends new entries and returns generated Stream ID
addAll(StreamMessageId, Map<K, V>) - Method in interface org.redisson.api.RStreamReactive
Appends new entries by specified Stream ID
addAll(Map<K, V>, int, boolean) - Method in interface org.redisson.api.RStreamReactive
Appends new entries and returns generated Stream ID.
addAll(StreamMessageId, Map<K, V>, int, boolean) - Method in interface org.redisson.api.RStreamReactive
Appends new entries by specified Stream ID.
addAll(Map<K, V>) - Method in interface org.redisson.api.RStreamRx
Appends new entries and returns generated Stream ID
addAll(StreamMessageId, Map<K, V>) - Method in interface org.redisson.api.RStreamRx
Appends new entries by specified Stream ID
addAll(Map<K, V>, int, boolean) - Method in interface org.redisson.api.RStreamRx
Appends new entries and returns generated Stream ID.
addAll(StreamMessageId, Map<K, V>, int, boolean) - Method in interface org.redisson.api.RStreamRx
Appends new entries by specified Stream ID.
addAll(Publisher<? extends V>) - Method in class org.redisson.reactive.PublisherAdder
 
addAll(Publisher<? extends String>) - Method in class org.redisson.reactive.RedissonLexSortedSetReactive
 
addAll(Publisher<? extends V>) - Method in class org.redisson.reactive.RedissonListReactive
 
addAll(Publisher<? extends V>) - Method in class org.redisson.reactive.RedissonSetCacheReactive
 
addAll(Publisher<? extends V>) - Method in class org.redisson.reactive.RedissonSetReactive
 
addAll(Publisher<? extends V>) - Method in class org.redisson.reactive.RedissonTransferQueueReactive
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonDelayedQueue
 
addAll(Collection<V>) - Method in class org.redisson.RedissonHyperLogLog
 
addAll(Collection<? extends String>) - Method in class org.redisson.RedissonLexSortedSet
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonList
 
addAll(int, Collection<? extends V>) - Method in class org.redisson.RedissonList
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonListMultimapValues
 
addAll(int, Collection<? extends V>) - Method in class org.redisson.RedissonListMultimapValues
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonPriorityQueue
 
addAll(Map<V, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonSet
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonSetCache
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonSetMultimapValues
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonSortedSet
 
addAll(Map<K, V>) - Method in class org.redisson.RedissonStream
 
addAll(StreamMessageId, Map<K, V>) - Method in class org.redisson.RedissonStream
 
addAll(Map<K, V>, int, boolean) - Method in class org.redisson.RedissonStream
 
addAll(StreamMessageId, Map<K, V>, int, boolean) - Method in class org.redisson.RedissonStream
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonTransferQueue
 
addAll(Publisher<? extends V>) - Method in class org.redisson.rx.PublisherAdder
 
addAll(Publisher<? extends String>) - Method in class org.redisson.rx.RedissonLexSortedSetRx
 
addAll(Publisher<? extends V>) - Method in class org.redisson.rx.RedissonListRx
 
addAll(Publisher<? extends V>) - Method in class org.redisson.rx.RedissonSetCacheRx
 
addAll(Publisher<? extends V>) - Method in class org.redisson.rx.RedissonSetRx
 
addAll(Publisher<? extends V>) - Method in class org.redisson.rx.RedissonTransferQueueRx
 
addAllAsync(Collection<? extends V>) - Method in interface org.redisson.api.RCollectionAsync
Adds all elements contained in the specified collection
addAllAsync(Collection<V>) - Method in interface org.redisson.api.RHyperLogLogAsync
Adds all elements contained in objects collection into this structure
addAllAsync(int, Collection<? extends V>) - Method in interface org.redisson.api.RListAsync
Inserts elements at index.
addAllAsync(Map<V, Double>) - Method in interface org.redisson.api.RScoredSortedSetAsync
Adds all elements contained in the specified map to this sorted set.
addAllAsync(Map<K, V>) - Method in interface org.redisson.api.RStreamAsync
Appends new entries and returns generated Stream ID
addAllAsync(StreamMessageId, Map<K, V>) - Method in interface org.redisson.api.RStreamAsync
Appends new entries by specified Stream ID
addAllAsync(Map<K, V>, int, boolean) - Method in interface org.redisson.api.RStreamAsync
Appends new entries and returns generated Stream ID.
addAllAsync(StreamMessageId, Map<K, V>, int, boolean) - Method in interface org.redisson.api.RStreamAsync
Appends new entries by specified Stream ID.
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonDelayedQueue
 
addAllAsync(Collection<V>) - Method in class org.redisson.RedissonHyperLogLog
 
addAllAsync(Collection<? extends String>) - Method in class org.redisson.RedissonLexSortedSet
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonList
 
addAllAsync(int, Collection<? extends V>) - Method in class org.redisson.RedissonList
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonListMultimapValues
 
addAllAsync(int, Collection<? extends V>) - Method in class org.redisson.RedissonListMultimapValues
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonRingBuffer
 
addAllAsync(Map<V, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonSet
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonSetCache
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonSetMultimapValues
 
addAllAsync(Map<K, V>) - Method in class org.redisson.RedissonStream
 
addAllAsync(StreamMessageId, Map<K, V>) - Method in class org.redisson.RedissonStream
 
addAllAsync(Map<K, V>, int, boolean) - Method in class org.redisson.RedissonStream
 
addAllAsync(StreamMessageId, Map<K, V>, int, boolean) - Method in class org.redisson.RedissonStream
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonSubList
 
addAllAsync(int, Collection<? extends V>) - Method in class org.redisson.RedissonSubList
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.RedissonTransferQueue
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.transaction.BaseTransactionalSet
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
addAllAsync(Collection<? extends V>) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
addAndGet(double) - Method in interface org.redisson.api.RAtomicDouble
Atomically adds the given value to the current value.
addAndGet(double) - Method in interface org.redisson.api.RAtomicDoubleReactive
Atomically adds the given value to the current value.
addAndGet(double) - Method in interface org.redisson.api.RAtomicDoubleRx
Atomically adds the given value to the current value.
addAndGet(long) - Method in interface org.redisson.api.RAtomicLong
Atomically adds the given value to the current value.
addAndGet(long) - Method in interface org.redisson.api.RAtomicLongReactive
Atomically adds the given value to the current value.
addAndGet(long) - Method in interface org.redisson.api.RAtomicLongRx
Atomically adds the given value to the current value.
addAndGet(K, Number) - Method in interface org.redisson.api.RMap
Adds the given delta to the current value by mapped key.
addAndGet(K, Number) - Method in interface org.redisson.api.RMapReactive
Adds the given delta to the current value by mapped key.
addAndGet(K, Number) - Method in interface org.redisson.api.RMapRx
Adds the given delta to the current value by mapped key.
addAndGet(double) - Method in class org.redisson.RedissonAtomicDouble
 
addAndGet(long) - Method in class org.redisson.RedissonAtomicLong
 
addAndGet(K, Number) - Method in class org.redisson.RedissonMap
 
addAndGet(K, Number) - Method in class org.redisson.RedissonMapCache
 
addAndGetAsync(double) - Method in interface org.redisson.api.RAtomicDoubleAsync
Atomically adds the given value to the current value.
addAndGetAsync(long) - Method in interface org.redisson.api.RAtomicLongAsync
Atomically adds the given value to the current value.
addAndGetAsync(K, Number) - Method in interface org.redisson.api.RMapAsync
Adds the given delta to the current value by mapped key.
addAndGetAsync(double) - Method in class org.redisson.RedissonAtomicDouble
 
addAndGetAsync(long) - Method in class org.redisson.RedissonAtomicLong
 
addAndGetAsync() - Method in class org.redisson.RedissonBaseAdder
 
addAndGetAsync() - Method in class org.redisson.RedissonDoubleAdder
 
addAndGetAsync() - Method in class org.redisson.RedissonLongAdder
 
addAndGetAsync(K, Number) - Method in class org.redisson.RedissonMap
 
addAndGetOperationAsync(K, Number) - Method in class org.redisson.RedissonLocalCachedMap
 
addAndGetOperationAsync(K, Number) - Method in class org.redisson.RedissonMap
 
addAndGetOperationAsync(K, Number) - Method in class org.redisson.RedissonMapCache
 
addAndGetOperationAsync(K, Number) - Method in class org.redisson.transaction.BaseTransactionalMap
 
addAndGetOperationAsync(K, Number) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
addAndGetOperationAsync(K, Number) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
addAndGetRank(double, V) - Method in interface org.redisson.api.RScoredSortedSet
Adds element to this set, overrides previous score if it has been already added.
addAndGetRank(double, V) - Method in interface org.redisson.api.RScoredSortedSetReactive
Adds element to this set, overrides previous score if it has been already added.
addAndGetRank(double, V) - Method in interface org.redisson.api.RScoredSortedSetRx
Adds element to this set, overrides previous score if it has been already added.
addAndGetRank(double, V) - Method in class org.redisson.RedissonScoredSortedSet
 
addAndGetRankAsync(double, V) - Method in interface org.redisson.api.RScoredSortedSetAsync
Adds element to this set, overrides previous score if it has been already added.
addAndGetRankAsync(double, V) - Method in class org.redisson.RedissonScoredSortedSet
 
addAndGetRevRank(double, V) - Method in interface org.redisson.api.RScoredSortedSet
Adds element to this set, overrides previous score if it has been already added.
addAndGetRevRank(double, V) - Method in interface org.redisson.api.RScoredSortedSetReactive
Adds element to this set, overrides previous score if it has been already added.
addAndGetRevRank(double, V) - Method in interface org.redisson.api.RScoredSortedSetRx
Adds element to this set, overrides previous score if it has been already added.
addAndGetRevRank(double, V) - Method in class org.redisson.RedissonScoredSortedSet
 
addAndGetRevRankAsync(double, V) - Method in interface org.redisson.api.RScoredSortedSetAsync
Adds element to this set, overrides previous score if it has been already added.
addAndGetRevRankAsync(double, V) - Method in class org.redisson.RedissonScoredSortedSet
 
addAsync(V) - Method in interface org.redisson.api.RCollectionAsync
Adds element into this collection.
addAsync(double, double, V) - Method in interface org.redisson.api.RGeoAsync
Adds geospatial member.
addAsync(GeoEntry...) - Method in interface org.redisson.api.RGeoAsync
Adds geospatial members.
addAsync(V) - Method in interface org.redisson.api.RHyperLogLogAsync
Adds element into this structure.
addAsync(int, V) - Method in interface org.redisson.api.RListAsync
Inserts element at index.
addAsync(double, V) - Method in interface org.redisson.api.RScoredSortedSetAsync
Adds element to this set, overrides previous score if it has been already added.
addAsync(V, long, TimeUnit) - Method in interface org.redisson.api.RSetCacheAsync
Stores value with specified time to live.
addAsync(V) - Method in interface org.redisson.api.RSortedSet
 
addAsync(K, V) - Method in interface org.redisson.api.RStreamAsync
Appends a new entry and returns generated Stream ID
addAsync(StreamMessageId, K, V) - Method in interface org.redisson.api.RStreamAsync
Appends a new entry by specified Stream ID
addAsync(K, V, int, boolean) - Method in interface org.redisson.api.RStreamAsync
Appends a new entry and returns generated Stream ID.
addAsync(StreamMessageId, K, V, int, boolean) - Method in interface org.redisson.api.RStreamAsync
Appends a new entry by specified Stream ID.
addAsync(String, RemoteServiceRequest) - Method in class org.redisson.executor.ScheduledTasksService
 
addAsync(String, RemoteServiceRequest, RemotePromise<Object>) - Method in class org.redisson.executor.TasksService
 
addAsync(String, RemoteServiceRequest) - Method in class org.redisson.executor.TasksService
 
addAsync(V) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
addAsync(V) - Method in class org.redisson.RedissonDelayedQueue
 
addAsync(double, double, V) - Method in class org.redisson.RedissonGeo
 
addAsync(GeoEntry...) - Method in class org.redisson.RedissonGeo
 
addAsync(V) - Method in class org.redisson.RedissonHyperLogLog
 
addAsync(String) - Method in class org.redisson.RedissonLexSortedSet
 
addAsync(V) - Method in class org.redisson.RedissonList
 
addAsync(V, RedisCommand<T>) - Method in class org.redisson.RedissonList
 
addAsync(int, V) - Method in class org.redisson.RedissonList
 
addAsync(V) - Method in class org.redisson.RedissonListMultimapValues
 
addAsync(int, V) - Method in class org.redisson.RedissonListMultimapValues
 
addAsync(V) - Method in class org.redisson.RedissonPriorityQueue
 
addAsync(String, RemoteServiceRequest, RemotePromise<Object>) - Method in class org.redisson.RedissonRemoteService
 
addAsync(V) - Method in class org.redisson.RedissonRingBuffer
 
addAsync(double, V) - Method in class org.redisson.RedissonScoredSortedSet
 
addAsync(V) - Method in class org.redisson.RedissonSet
 
addAsync(V, long, TimeUnit) - Method in class org.redisson.RedissonSetCache
 
addAsync(V) - Method in class org.redisson.RedissonSetCache
 
addAsync(V) - Method in class org.redisson.RedissonSetMultimapValues
 
addAsync(V) - Method in class org.redisson.RedissonSortedSet
 
addAsync(K, V) - Method in class org.redisson.RedissonStream
 
addAsync(StreamMessageId, K, V) - Method in class org.redisson.RedissonStream
 
addAsync(K, V, int, boolean) - Method in class org.redisson.RedissonStream
 
addAsync(StreamMessageId, K, V, int, boolean) - Method in class org.redisson.RedissonStream
 
addAsync(V) - Method in class org.redisson.RedissonSubList
 
addAsync(V) - Method in class org.redisson.RedissonTransferQueue
 
addAsync(String, RemoteServiceRequest, RemotePromise<Object>) - Method in class org.redisson.remote.BaseRemoteService
 
addAsync(V) - Method in class org.redisson.transaction.BaseTransactionalSet
 
addAsync(V, TransactionalOperation) - Method in class org.redisson.transaction.BaseTransactionalSet
 
addAsync(V) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
addAsync(V) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
addAsync(V, long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
addAsync(V, long, TimeUnit) - Method in class org.redisson.transaction.TransactionalSetCache
 
addBatchCommandData(Object[]) - Method in class org.redisson.command.BaseRedisBatchExecutor
 
addBefore(V, V) - Method in interface org.redisson.api.RList
Add element before elementToFind
addBefore(V, V) - Method in interface org.redisson.api.RListReactive
Add element before elementToFind
addBefore(V, V) - Method in interface org.redisson.api.RListRx
Add element before elementToFind
addBefore(V, V) - Method in class org.redisson.RedissonList
 
addBefore(V, V) - Method in class org.redisson.RedissonListMultimapValues
 
addBeforeAsync(V, V) - Method in interface org.redisson.api.RListAsync
Inserts element before elementToFind
addBeforeAsync(V, V) - Method in class org.redisson.RedissonList
 
addBeforeAsync(V, V) - Method in class org.redisson.RedissonListMultimapValues
 
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
AddCacheOperation - Class in org.redisson.transaction.operation.set
 
AddCacheOperation(RObject, Object, String, long) - Constructor for class org.redisson.transaction.operation.set.AddCacheOperation
 
AddCacheOperation(RObject, Object, long, TimeUnit, String, long) - Constructor for class org.redisson.transaction.operation.set.AddCacheOperation
 
AddCacheOperation(String, Codec, Object, long, TimeUnit, String, long) - Constructor for class org.redisson.transaction.operation.set.AddCacheOperation
 
addConnectionListener(ConnectionListener) - Method in interface org.redisson.api.NodesGroup
Deprecated.
Adds connection listener which will be triggered when Redisson connected to or disconnected from Redis server
addConnectionListener(ConnectionListener) - Method in class org.redisson.RedisNodes
Deprecated.
 
addConstructorArgs(Element, String, Class<?>, BeanDefinition) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
addConstructorArgs(Object, Class<?>, BeanDefinition) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
addConstructorArgs(Element, String, Class<?>, BeanDefinitionBuilder) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
addConstructorArgs(Object, Class<?>, BeanDefinitionBuilder) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
addEntry(Integer, MasterSlaveEntry) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
addEvictions(long) - Method in class org.redisson.jcache.bean.EmptyStatisticsMXBean
 
addEvictions(long) - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
addFailedSlaveAddress(RedisURI) - Method in class org.redisson.cluster.ClusterPartition
 
addFirst(V) - Method in interface org.redisson.api.RDequeReactive
Adds element at the head of this deque.
addFirst(V) - Method in interface org.redisson.api.RDequeRx
Adds element at the head of this deque.
addFirst(V) - Method in class org.redisson.RedissonDeque
 
addFirst(V) - Method in class org.redisson.RedissonPriorityDeque
 
addFirstAsync(V) - Method in interface org.redisson.api.RDequeAsync
Adds element at the head of this deque.
addFirstAsync(V) - Method in class org.redisson.RedissonDeque
 
addFirstAsync(V) - Method in class org.redisson.RedissonPriorityDeque
 
addFirstIfExists(V...) - Method in interface org.redisson.api.RDeque
Adds element at the head of existing deque.
addFirstIfExists(V...) - Method in interface org.redisson.api.RDequeReactive
Adds element at the head of existing deque.
addFirstIfExists(V...) - Method in interface org.redisson.api.RDequeRx
Adds element at the head of existing deque.
addFirstIfExists(V...) - Method in class org.redisson.RedissonDeque
 
addFirstIfExists(V...) - Method in class org.redisson.RedissonPriorityDeque
 
addFirstIfExistsAsync(V...) - Method in interface org.redisson.api.RDequeAsync
Adds element at the head of existing deque.
addFirstIfExistsAsync(V...) - Method in class org.redisson.RedissonDeque
 
addFirstIfExistsAsync(V...) - Method in class org.redisson.RedissonPriorityDeque
 
addFlag(ClusterNodeInfo.Flag) - Method in class org.redisson.cluster.ClusterNodeInfo
 
addGetTime(long) - Method in class org.redisson.jcache.bean.EmptyStatisticsMXBean
 
addGetTime(long) - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
addHits(long) - Method in class org.redisson.jcache.bean.EmptyStatisticsMXBean
 
addHits(long) - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
addLast(V) - Method in interface org.redisson.api.RDequeReactive
Adds element at the tail of this deque.
addLast(V) - Method in interface org.redisson.api.RDequeRx
Adds element at the tail of this deque.
addLast(V) - Method in class org.redisson.RedissonDeque
 
addLast(V) - Method in class org.redisson.RedissonPriorityDeque
 
addLastAsync(V) - Method in interface org.redisson.api.RDequeAsync
Adds element at the tail of this deque.
addLastAsync(V) - Method in class org.redisson.RedissonDeque
 
addLastAsync(V) - Method in class org.redisson.RedissonPriorityDeque
 
addLastIfExists(V...) - Method in interface org.redisson.api.RDeque
Adds element at the tail of existing deque.
addLastIfExists(V...) - Method in interface org.redisson.api.RDequeReactive
Adds element at the tail of existing deque.
addLastIfExists(V...) - Method in interface org.redisson.api.RDequeRx
Adds element at the tail of existing deque.
addLastIfExists(V...) - Method in class org.redisson.RedissonDeque
 
addLastIfExists(V...) - Method in class org.redisson.RedissonPriorityDeque
 
addLastIfExistsAsync(V...) - Method in interface org.redisson.api.RDequeAsync
Adds element at the tail of existing deque.
addLastIfExistsAsync(V...) - Method in class org.redisson.RedissonDeque
 
addLastIfExistsAsync(V...) - Method in class org.redisson.RedissonPriorityDeque
 
addListener(ObjectListener) - Method in interface org.redisson.api.RBucket
Adds object event listener
addListener(ObjectListener) - Method in interface org.redisson.api.RList
Adds object event listener
addListener(MapEntryListener) - Method in interface org.redisson.api.RMapCache
Adds map entry listener
addListener(ObjectListener) - Method in interface org.redisson.api.RObject
Adds object event listener
addListener(ObjectListener) - Method in interface org.redisson.api.RObjectReactive
Adds object event listener
addListener(ObjectListener) - Method in interface org.redisson.api.RObjectRx
Adds object event listener
addListener(Class<T>, PatternMessageListener<T>) - Method in interface org.redisson.api.RPatternTopic
Subscribes to this topic.
addListener(PatternStatusListener) - Method in interface org.redisson.api.RPatternTopic
Subscribes to status changes of this topic
addListener(Class<T>, PatternMessageListener<T>) - Method in interface org.redisson.api.RPatternTopicReactive
Subscribes to this topic.
addListener(PatternStatusListener) - Method in interface org.redisson.api.RPatternTopicReactive
Subscribes to status changes of this topic
addListener(Class<T>, PatternMessageListener<T>) - Method in interface org.redisson.api.RPatternTopicRx
Subscribes to this topic.
addListener(PatternStatusListener) - Method in interface org.redisson.api.RPatternTopicRx
Subscribes to status changes of this topic
addListener(ObjectListener) - Method in interface org.redisson.api.RQueue
Adds object event listener
addListener(Class<M>, MessageListener<? extends M>) - Method in interface org.redisson.api.RTopic
Subscribes to this topic.
addListener(StatusListener) - Method in interface org.redisson.api.RTopic
Subscribes to status changes of this topic
addListener(StatusListener) - Method in interface org.redisson.api.RTopicReactive
Subscribes to status changes of this topic
addListener(Class<M>, MessageListener<M>) - Method in interface org.redisson.api.RTopicReactive
Subscribes to this topic.
addListener(StatusListener) - Method in interface org.redisson.api.RTopicRx
Subscribes to status changes of this topic
addListener(Class<M>, MessageListener<M>) - Method in interface org.redisson.api.RTopicRx
Subscribes to this topic.
addListener(TaskListener) - Method in class org.redisson.api.WorkerOptions
Adds task listener
addListener(RedisPubSubListener<?>) - Method in class org.redisson.client.RedisPubSubConnection
 
addListener(ConnectionListener) - Method in class org.redisson.connection.ConnectionEventsHub
 
addListener(ChannelName, RedisPubSubListener<?>) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
addListener(ObjectListener) - Method in class org.redisson.RedissonBucket
 
addListener(Runnable) - Method in class org.redisson.RedissonCountDownLatchEntry
 
addListener(ObjectListener) - Method in class org.redisson.RedissonList
 
addListener(Runnable) - Method in class org.redisson.RedissonLockEntry
 
addListener(MapEntryListener) - Method in class org.redisson.RedissonMapCache
 
addListener(String, T, BiConsumer<T, String>) - Method in class org.redisson.RedissonObject
 
addListener(ObjectListener) - Method in class org.redisson.RedissonObject
 
addListener(PatternStatusListener) - Method in class org.redisson.RedissonPatternTopic
 
addListener(Class<T>, PatternMessageListener<T>) - Method in class org.redisson.RedissonPatternTopic
 
addListener(StatusListener) - Method in class org.redisson.RedissonTopic
 
addListener(Class<M>, MessageListener<? extends M>) - Method in class org.redisson.RedissonTopic
 
addListenerAsync(ObjectListener) - Method in interface org.redisson.api.RBucketAsync
Adds object event listener
addListenerAsync(ObjectListener) - Method in interface org.redisson.api.RListAsync
Adds object event listener
addListenerAsync(ObjectListener) - Method in interface org.redisson.api.RObjectAsync
Adds object event listener
addListenerAsync(PatternStatusListener) - Method in interface org.redisson.api.RPatternTopic
 
addListenerAsync(Class<T>, PatternMessageListener<T>) - Method in interface org.redisson.api.RPatternTopic
 
addListenerAsync(ObjectListener) - Method in interface org.redisson.api.RQueueAsync
Adds object event listener
addListenerAsync(StatusListener) - Method in interface org.redisson.api.RTopicAsync
Subscribes to status changes of this topic
addListenerAsync(Class<M>, MessageListener<M>) - Method in interface org.redisson.api.RTopicAsync
Subscribes to this topic.
addListenerAsync(ObjectListener) - Method in class org.redisson.RedissonBucket
 
addListenerAsync(ObjectListener) - Method in class org.redisson.RedissonList
 
addListenerAsync(String, T, BiConsumer<T, String>) - Method in class org.redisson.RedissonObject
 
addListenerAsync(ObjectListener) - Method in class org.redisson.RedissonObject
 
addListenerAsync(PatternStatusListener) - Method in class org.redisson.RedissonPatternTopic
 
addListenerAsync(Class<T>, PatternMessageListener<T>) - Method in class org.redisson.RedissonPatternTopic
 
addListenerAsync(StatusListener) - Method in class org.redisson.RedissonTopic
 
addListenerAsync(Class<M>, MessageListener<M>) - Method in class org.redisson.RedissonTopic
 
addMisses(long) - Method in class org.redisson.jcache.bean.EmptyStatisticsMXBean
 
addMisses(long) - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
addNodeAddress(String...) - Method in class org.redisson.config.ClusterServersConfig
Add Redis cluster node address.
addNodeAddress(String...) - Method in class org.redisson.config.ReplicatedServersConfig
Add Redis cluster node address.
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
addObjectName(String) - Method in class org.redisson.mapreduce.BaseMapperTask
 
AddOperation - Class in org.redisson.transaction.operation.set
 
AddOperation(RObject, Object, String, long) - Constructor for class org.redisson.transaction.operation.set.AddOperation
 
AddOperation(String, Codec, Object, String, long) - Constructor for class org.redisson.transaction.operation.set.AddOperation
 
addPermits(int) - Method in interface org.redisson.api.RPermitExpirableSemaphore
Increases or decreases the number of available permits by defined value.
addPermits(int) - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Increases or decreases the number of available permits by defined value.
addPermits(int) - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Increases or decreases the number of available permits by defined value.
addPermits(int) - Method in interface org.redisson.api.RSemaphore
Increases or decreases the number of available permits by defined value.
addPermits(int) - Method in interface org.redisson.api.RSemaphoreReactive
Increases or decreases the number of available permits by defined value.
addPermits(int) - Method in interface org.redisson.api.RSemaphoreRx
Increases or decreases the number of available permits by defined value.
addPermits(int) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
addPermits(int) - Method in class org.redisson.RedissonSemaphore
 
addPermitsAsync(int) - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Increases or decreases the number of available permits by defined value.
addPermitsAsync(int) - Method in interface org.redisson.api.RSemaphoreAsync
Increases or decreases the number of available permits by defined value.
addPermitsAsync(int) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
addPermitsAsync(int) - Method in class org.redisson.RedissonSemaphore
 
addPubSubCommand(ChannelName, CommandData<Object, Object>) - Method in class org.redisson.client.handler.CommandPubSubDecoder
 
addPuts(long) - Method in class org.redisson.jcache.bean.EmptyStatisticsMXBean
 
addPuts(long) - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
addPutTime(long) - Method in class org.redisson.jcache.bean.EmptyStatisticsMXBean
 
addPutTime(long) - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
addRemovals(long) - Method in class org.redisson.jcache.bean.EmptyStatisticsMXBean
 
addRemovals(long) - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
addRemoveTime(long) - Method in class org.redisson.jcache.bean.EmptyStatisticsMXBean
 
addRemoveTime(long) - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
AddressResolverGroupFactory - Interface in org.redisson.connection
Created by hasaadon on 15/02/2018.
addScore(V, Number) - Method in interface org.redisson.api.RScoredSortedSet
Increases score of specified element by value.
addScore(V, Number) - Method in interface org.redisson.api.RScoredSortedSetReactive
Increases score of specified element by value.
addScore(V, Number) - Method in interface org.redisson.api.RScoredSortedSetRx
Increases score of specified element by value.
addScore(V, Number) - Method in class org.redisson.RedissonScoredSortedSet
 
addScoreAndGetRank(V, Number) - Method in interface org.redisson.api.RScoredSortedSet
Adds score to element and returns its rank
addScoreAndGetRank(V, Number) - Method in interface org.redisson.api.RScoredSortedSetReactive
Adds score to element and returns its rank
addScoreAndGetRank(V, Number) - Method in interface org.redisson.api.RScoredSortedSetRx
Adds score to element and returns its rank
addScoreAndGetRank(V, Number) - Method in class org.redisson.RedissonScoredSortedSet
 
addScoreAndGetRankAsync(V, Number) - Method in interface org.redisson.api.RScoredSortedSetAsync
Adds score to element and returns its rank
addScoreAndGetRankAsync(V, Number) - Method in class org.redisson.RedissonScoredSortedSet
 
addScoreAndGetRevRank(V, Number) - Method in interface org.redisson.api.RScoredSortedSet
Adds score to element and returns its reverse rank
addScoreAndGetRevRank(V, Number) - Method in interface org.redisson.api.RScoredSortedSetReactive
Adds score to element and returns its reverse rank
addScoreAndGetRevRank(V, Number) - Method in interface org.redisson.api.RScoredSortedSetRx
Adds score to element and returns its reverse rank
addScoreAndGetRevRank(V, Number) - Method in class org.redisson.RedissonScoredSortedSet
 
addScoreAndGetRevRankAsync(V, Number) - Method in interface org.redisson.api.RScoredSortedSetAsync
Adds score to element and returns its reverse rank
addScoreAndGetRevRankAsync(V, Number) - Method in class org.redisson.RedissonScoredSortedSet
 
addScoreAsync(V, Number) - Method in interface org.redisson.api.RScoredSortedSetAsync
Increases score of specified element by value.
addScoreAsync(V, Number) - Method in class org.redisson.RedissonScoredSortedSet
 
addSentinelAddress(String...) - Method in class org.redisson.config.SentinelServersConfig
Add Redis Sentinel node address in host:port format.
addSlave(RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
 
addSlave(InetSocketAddress, RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
 
addSlaveAddress(RedisURI) - Method in class org.redisson.cluster.ClusterPartition
 
addSlaveAddress(String...) - Method in class org.redisson.config.MasterSlaveServersConfig
Add Redis slave server address.
addSlaveAddress(String) - Method in class org.redisson.config.MasterSlaveServersConfig
 
addSlotRange(ClusterSlotRange) - Method in class org.redisson.cluster.ClusterNodeInfo
 
addSlotRanges(Set<ClusterSlotRange>) - Method in class org.redisson.cluster.ClusterPartition
 
addSlots(BitSet) - Method in class org.redisson.cluster.ClusterPartition
 
addTask(MapWriterTask) - Method in class org.redisson.MapWriteBehindTask
 
addThreadId(long) - Method in class org.redisson.RedissonLock.ExpirationEntry
 
addToSet(int, int, int, int) - Method in class org.redisson.executor.CronExpression
 
AdvBeanCopy - Class in org.redisson.liveobject.misc
 
AdvBeanCopy(Object, Object) - Constructor for class org.redisson.liveobject.misc.AdvBeanCopy
 
afterBoostrapInitialization(Bootstrap) - Method in class org.redisson.client.DefaultNettyHook
 
afterBoostrapInitialization(Bootstrap) - Method in interface org.redisson.client.NettyHook
Invoked when Redis client created and initialized Netty Bootstrap object.
afterChannelInitialization(Channel) - Method in class org.redisson.client.DefaultNettyHook
 
afterChannelInitialization(Channel) - Method in interface org.redisson.client.NettyHook
Invoked when Netty Channel object was created and initialized.
afterPropertiesSet() - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
 
afterPropertiesSet() - Method in class org.redisson.spring.misc.BeanMethodInvoker
 
ALL - Static variable in class org.redisson.api.StreamMessageId
Defines id to receive all Stream entries.
ALL_SPEC - Static variable in class org.redisson.executor.CronExpression
 
ALL_SPEC_INT - Static variable in class org.redisson.executor.CronExpression
 
and(Condition...) - Static method in class org.redisson.api.condition.Conditions
Returns "AND" condition for collection of nested conditions
and(String...) - Method in interface org.redisson.api.RBitSet
Executes AND operation over this object and specified bitsets.
and(String...) - Method in interface org.redisson.api.RBitSetReactive
Executes AND operation over this object and specified bitsets.
and(String...) - Method in interface org.redisson.api.RBitSetRx
Executes AND operation over this object and specified bitsets.
and(String...) - Method in class org.redisson.RedissonBitSet
 
andAsync(String...) - Method in interface org.redisson.api.RBitSetAsync
Executes AND operation over this object and specified bitsets.
andAsync(String...) - Method in class org.redisson.RedissonBitSet
 
ANDCondition - Class in org.redisson.liveobject.condition
 
ANDCondition(Condition[]) - Constructor for class org.redisson.liveobject.condition.ANDCondition
 
APPEND - Static variable in interface org.redisson.client.protocol.RedisCommands
 
applyNatMap(RedisURI) - Method in class org.redisson.cluster.ClusterConnectionManager
 
applyNatMap(RedisURI) - Method in interface org.redisson.connection.ConnectionManager
 
applyNatMap(RedisURI) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
applyNatMap(RedisURI) - Method in class org.redisson.connection.SentinelConnectionManager
 
applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in class org.redisson.misc.PromiseDelegator
 
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in class org.redisson.misc.PromiseDelegator
 
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
asBitSet() - Method in interface org.redisson.api.RBitSet
 
asBitSet() - Method in class org.redisson.RedissonBitSet
 
ASKING - Static variable in interface org.redisson.client.protocol.RedisCommands
 
asLiveObject(T) - Method in interface org.redisson.api.RLiveObjectService
To cast the instance to RLiveObject instance.
asLiveObject(T) - Method in class org.redisson.RedissonLiveObjectService
 
asRExpirable(T) - Method in interface org.redisson.api.RLiveObjectService
Deprecated.
asRExpirable(T) - Method in class org.redisson.RedissonLiveObjectService
 
asRMap(T) - Method in interface org.redisson.api.RLiveObjectService
To cast the instance to RMap instance.
asRMap(T) - Method in class org.redisson.RedissonLiveObjectService
 
async(RedisCommand<T>, Object...) - Method in class org.redisson.client.RedisConnection
 
async(long, RedisCommand<T>, Object...) - Method in class org.redisson.client.RedisConnection
 
async(Codec, RedisCommand<T>, Object...) - Method in class org.redisson.client.RedisConnection
 
async(long, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.client.RedisConnection
 
async(boolean, NodeSource, Codec, RedisCommand<V>, Object[], RPromise<R>, boolean) - Method in class org.redisson.command.CommandAsyncService
 
async(boolean, NodeSource, Codec, RedisCommand<V>, Object[], RPromise<R>, boolean) - Method in class org.redisson.command.CommandBatchService
 
async(boolean, NodeSource, Codec, RedisCommand<V>, Object[], RPromise<R>, boolean) - Method in class org.redisson.reactive.CommandReactiveBatchService
 
async(boolean, NodeSource, Codec, RedisCommand<V>, Object[], RPromise<R>, boolean) - Method in class org.redisson.rx.CommandRxBatchService
 
AsyncRemoteProxy - Class in org.redisson.remote
 
AsyncRemoteProxy(CommandAsyncExecutor, String, String, ConcurrentMap<String, ResponseEntry>, Codec, String, String, BaseRemoteService) - Constructor for class org.redisson.remote.AsyncRemoteProxy
 
AsyncSemaphore - Class in org.redisson.pubsub
 
AsyncSemaphore(int) - Constructor for class org.redisson.pubsub.AsyncSemaphore
 
attach(T) - Method in interface org.redisson.api.RLiveObjectService
Returns proxied object for the detached object.
attach(T) - Method in class org.redisson.RedissonLiveObjectService
 
AUTH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
available() - Method in class org.redisson.codec.MarshallingCodec.ByteInputWrapper
 
availablePermits() - Method in interface org.redisson.api.RPermitExpirableSemaphore
Returns amount of available permits.
availablePermits() - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Returns amount of available permits.
availablePermits() - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Returns the current number of available permits.
availablePermits() - Method in interface org.redisson.api.RRateLimiter
Returns amount of available permits.
availablePermits() - Method in interface org.redisson.api.RRateLimiterReactive
Returns amount of available permits.
availablePermits() - Method in interface org.redisson.api.RRateLimiterRx
Returns amount of available permits.
availablePermits() - Method in interface org.redisson.api.RSemaphore
Returns amount of available permits.
availablePermits() - Method in interface org.redisson.api.RSemaphoreReactive
Returns amount of available permits.
availablePermits() - Method in interface org.redisson.api.RSemaphoreRx
Returns amount of available permits.
availablePermits() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
availablePermits() - Method in class org.redisson.RedissonRateLimiter
 
availablePermits() - Method in class org.redisson.RedissonSemaphore
 
availablePermitsAsync() - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Returns amount of available permits.
availablePermitsAsync() - Method in interface org.redisson.api.RRateLimiterAsync
Returns amount of available permits.
availablePermitsAsync() - Method in interface org.redisson.api.RSemaphoreAsync
Returns amount of available permits.
availablePermitsAsync() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
availablePermitsAsync() - Method in class org.redisson.RedissonRateLimiter
 
availablePermitsAsync() - Method in class org.redisson.RedissonSemaphore
 
AvroExtendedMapper(Class<?>, AvroSchema) - Constructor for class org.redisson.codec.AvroJacksonCodec.AvroExtendedMapper
 
AvroJacksonCodec - Class in org.redisson.codec
Avro binary codec
AvroJacksonCodec(Class<?>, AvroSchema) - Constructor for class org.redisson.codec.AvroJacksonCodec
 
AvroJacksonCodec(ClassLoader) - Constructor for class org.redisson.codec.AvroJacksonCodec
 
AvroJacksonCodec(ClassLoader, AvroJacksonCodec) - Constructor for class org.redisson.codec.AvroJacksonCodec
 
AvroJacksonCodec.AvroExtendedMapper - Class in org.redisson.codec
 
await() - Method in interface org.redisson.api.RCountDownLatch
Waits until counter reach zero.
await(long, TimeUnit) - Method in interface org.redisson.api.RCountDownLatch
Waits until counter reach zero or up to defined timeout.
await() - Method in interface org.redisson.api.RCountDownLatchReactive
Waits until counter reach zero.
await(long, TimeUnit) - Method in interface org.redisson.api.RCountDownLatchReactive
Waits until counter reach zero or up to defined timeout.
await() - Method in interface org.redisson.api.RCountDownLatchRx
Waits until counter reach zero.
await(long, TimeUnit) - Method in interface org.redisson.api.RCountDownLatchRx
Waits until counter reach zero or up to defined timeout.
await(long, TimeUnit) - Method in interface org.redisson.api.RFuture
Waits for this future to be completed within the specified time limit.
await(long) - Method in interface org.redisson.api.RFuture
Waits for this future to be completed within the specified time limit.
await() - Method in interface org.redisson.api.RFuture
Waits for this future to be completed.
await(RFuture<R>) - Method in class org.redisson.client.RedisConnection
 
await() - Method in class org.redisson.mapreduce.SubTasksExecutor
 
await(long, TimeUnit) - Method in class org.redisson.misc.PromiseDelegator
 
await(long) - Method in class org.redisson.misc.PromiseDelegator
 
await() - Method in class org.redisson.misc.PromiseDelegator
 
await() - Method in class org.redisson.misc.ReclosableLatch
 
await(long, TimeUnit) - Method in class org.redisson.misc.ReclosableLatch
 
await() - Method in class org.redisson.misc.RedissonPromise
 
await(long, TimeUnit) - Method in class org.redisson.misc.RedissonPromise
 
await(long) - Method in class org.redisson.misc.RedissonPromise
 
await() - Method in interface org.redisson.misc.RPromise
 
await() - Method in class org.redisson.RedissonCountDownLatch
 
await(long, TimeUnit) - Method in class org.redisson.RedissonCountDownLatch
 
awaitAsync() - Method in interface org.redisson.api.RCountDownLatchAsync
Waits until counter reach zero.
awaitAsync(long, TimeUnit) - Method in interface org.redisson.api.RCountDownLatchAsync
Waits until counter reach zero or up to defined timeout.
awaitAsync() - Method in class org.redisson.RedissonCountDownLatch
 
awaitAsync(long, TimeUnit) - Method in class org.redisson.RedissonCountDownLatch
 
awaitResultAsync(RemoteInvocationOptions, RemotePromise<Object>, RFuture<RRemoteServiceResponse>) - Method in class org.redisson.remote.AsyncRemoteProxy
 
awaitTermination(long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
awaitUninterruptibly() - Method in interface org.redisson.api.RFuture
Waits for this future to be completed without interruption.
awaitUninterruptibly(long, TimeUnit) - Method in interface org.redisson.api.RFuture
Waits for this future to be completed within the specified time limit without interruption.
awaitUninterruptibly(long) - Method in interface org.redisson.api.RFuture
Waits for this future to be completed within the specified time limit without interruption.
awaitUninterruptibly() - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
awaitUninterruptibly() - Method in class org.redisson.misc.PromiseDelegator
 
awaitUninterruptibly(long, TimeUnit) - Method in class org.redisson.misc.PromiseDelegator
 
awaitUninterruptibly(long) - Method in class org.redisson.misc.PromiseDelegator
 
awaitUninterruptibly() - Method in class org.redisson.misc.ReclosableLatch
 
awaitUninterruptibly() - Method in class org.redisson.misc.RedissonPromise
 
awaitUninterruptibly(long, TimeUnit) - Method in class org.redisson.misc.RedissonPromise
 
awaitUninterruptibly(long) - Method in class org.redisson.misc.RedissonPromise
 
awaitUninterruptibly() - Method in interface org.redisson.misc.RPromise
 

B

BaseCodec - Class in org.redisson.client.codec
 
BaseCodec() - Constructor for class org.redisson.client.codec.BaseCodec
 
BaseConfig<T extends BaseConfig<T>> - Class in org.redisson.config
 
BaseConnectionHandler<C extends RedisConnection> - Class in org.redisson.client.handler
 
BaseConnectionHandler(RedisClient) - Constructor for class org.redisson.client.handler.BaseConnectionHandler
 
BaseEventCodec - Class in org.redisson.codec
 
BaseEventCodec(Codec, BaseEventCodec.OSType) - Constructor for class org.redisson.codec.BaseEventCodec
 
BaseEventCodec.OSType - Enum in org.redisson.codec
 
BaseIterator<V,E> - Class in org.redisson.iterator
 
BaseIterator() - Constructor for class org.redisson.iterator.BaseIterator
 
BaseMapperTask<KOut,VOut> - Class in org.redisson.mapreduce
 
BaseMapperTask() - Constructor for class org.redisson.mapreduce.BaseMapperTask
 
BaseMapperTask(Class<?>, Class<?>) - Constructor for class org.redisson.mapreduce.BaseMapperTask
 
BaseMasterSlaveServersConfig<T extends BaseMasterSlaveServersConfig<T>> - Class in org.redisson.config
 
BaseMasterSlaveServersConfig() - Constructor for class org.redisson.config.BaseMasterSlaveServersConfig
 
BasePatternStatusListener - Class in org.redisson.api.listener
Base status listener for Redis PubSub channel status changes
BasePatternStatusListener() - Constructor for class org.redisson.api.listener.BasePatternStatusListener
 
BaseRedisBatchExecutor<V,R> - Class in org.redisson.command
 
BaseRedisBatchExecutor(boolean, NodeSource, Codec, RedisCommand<V>, Object[], RPromise<R>, boolean, ConnectionManager, RedissonObjectBuilder, ConcurrentMap<MasterSlaveEntry, CommandBatchService.Entry>, BatchOptions, AtomicInteger, AtomicBoolean) - Constructor for class org.redisson.command.BaseRedisBatchExecutor
 
BaseRedisNodes - Interface in org.redisson.api.redisnode
Base Redis nodes API interface
BaseRedisPubSubListener - Class in org.redisson.client
 
BaseRedisPubSubListener() - Constructor for class org.redisson.client.BaseRedisPubSubListener
 
BaseRemoteProxy - Class in org.redisson.remote
 
BaseRemoteService - Class in org.redisson.remote
 
BaseRemoteService(Codec, String, CommandAsyncExecutor, String, ConcurrentMap<String, ResponseEntry>) - Constructor for class org.redisson.remote.BaseRemoteService
 
BaseStatusListener - Class in org.redisson.api.listener
Base status listener for Redis PubSub channel status changes
BaseStatusListener() - Constructor for class org.redisson.api.listener.BaseStatusListener
 
BaseTransactionalMap<K,V> - Class in org.redisson.transaction
 
BaseTransactionalMap(CommandAsyncExecutor, long, List<TransactionalOperation>, RMap<K, V>, String) - Constructor for class org.redisson.transaction.BaseTransactionalMap
 
BaseTransactionalMap.MapEntry - Class in org.redisson.transaction
 
BaseTransactionalMapCache<K,V> - Class in org.redisson.transaction
 
BaseTransactionalMapCache(CommandAsyncExecutor, long, List<TransactionalOperation>, RMap<K, V>, String) - Constructor for class org.redisson.transaction.BaseTransactionalMapCache
 
BaseTransactionalObject - Class in org.redisson.transaction
 
BaseTransactionalObject() - Constructor for class org.redisson.transaction.BaseTransactionalObject
 
BaseTransactionalSet<V> - Class in org.redisson.transaction
 
BaseTransactionalSet(CommandAsyncExecutor, long, List<TransactionalOperation>, RCollectionAsync<V>) - Constructor for class org.redisson.transaction.BaseTransactionalSet
 
BatchCommandData<T,R> - Class in org.redisson.client.protocol
 
BatchCommandData(RedisCommand<T>, Object[], int) - Constructor for class org.redisson.client.protocol.BatchCommandData
 
BatchCommandData(RPromise<R>, Codec, RedisCommand<T>, Object[], int) - Constructor for class org.redisson.client.protocol.BatchCommandData
 
BatchOptions - Class in org.redisson.api
Configuration for Batch object.
BatchOptions.ExecutionMode - Enum in org.redisson.api
 
BatchPromise<T> - Class in org.redisson.command
 
BatchPromise(AtomicBoolean) - Constructor for class org.redisson.command.BatchPromise
 
BatchResult<E> - Class in org.redisson.api
 
BatchResult(List<E>, int) - Constructor for class org.redisson.api.BatchResult
 
beanFactory(BeanFactory) - Method in class org.redisson.api.WorkerOptions
Defines Spring BeanFactory instance to execute tasks with Spring's '@Autowired', '@Value' or JSR-330's '@Inject' annotation.
BeanMethodInvoker - Class in org.redisson.spring.misc
 
BeanMethodInvoker() - Constructor for class org.redisson.spring.misc.BeanMethodInvoker
 
BGREWRITEAOF - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BGSAVE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BiHashMap<K,V> - Class in org.redisson.misc
This is not a concurrent map.
BiHashMap() - Constructor for class org.redisson.misc.BiHashMap
 
binarySearch(V, Codec) - Method in class org.redisson.RedissonPriorityQueue
 
binarySearch(V, Codec) - Method in class org.redisson.RedissonSortedSet
 
BinarySearchResult(V) - Constructor for class org.redisson.RedissonPriorityQueue.BinarySearchResult
 
BinarySearchResult() - Constructor for class org.redisson.RedissonPriorityQueue.BinarySearchResult
 
BinarySearchResult(V) - Constructor for class org.redisson.RedissonSortedSet.BinarySearchResult
 
BinarySearchResult() - Constructor for class org.redisson.RedissonSortedSet.BinarySearchResult
 
bindImplementationSpecificMetrics(MeterRegistry) - Method in class org.redisson.spring.cache.RedissonCacheMetrics
 
BITCOUNT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BITOP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BITPOS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BITS_SIZE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BitSetCodec - Class in org.redisson.client.codec
 
BitSetCodec() - Constructor for class org.redisson.client.codec.BitSetCodec
 
BitsSizeReplayConvertor - Class in org.redisson.client.protocol.convertor
 
BitsSizeReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.BitsSizeReplayConvertor
 
BLOCKING_COMMAND_NAMES - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BLOCKING_COMMANDS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BLPOP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BLPOP_VALUE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BooleanAmountReplayConvertor - Class in org.redisson.client.protocol.convertor
 
BooleanAmountReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.BooleanAmountReplayConvertor
 
BooleanNotNullReplayConvertor - Class in org.redisson.client.protocol.convertor
 
BooleanNotNullReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.BooleanNotNullReplayConvertor
 
BooleanNullReplayConvertor - Class in org.redisson.client.protocol.convertor
 
BooleanNullReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.BooleanNullReplayConvertor
 
BooleanNullSafeReplayConvertor - Class in org.redisson.client.protocol.convertor
 
BooleanNullSafeReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.BooleanNullSafeReplayConvertor
 
BooleanNumberReplayConvertor - Class in org.redisson.client.protocol.convertor
 
BooleanNumberReplayConvertor(long) - Constructor for class org.redisson.client.protocol.convertor.BooleanNumberReplayConvertor
 
BooleanReplayConvertor - Class in org.redisson.client.protocol.convertor
 
BooleanReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.BooleanReplayConvertor
 
BRPOP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BRPOP_VALUE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BRPOPLPUSH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BucketCompareAndSetOperation<V> - Class in org.redisson.transaction.operation.bucket
 
BucketCompareAndSetOperation(String, String, Codec, V, V, String) - Constructor for class org.redisson.transaction.operation.bucket.BucketCompareAndSetOperation
 
BucketGetAndDeleteOperation<V> - Class in org.redisson.transaction.operation.bucket
 
BucketGetAndDeleteOperation(String, String, Codec, String) - Constructor for class org.redisson.transaction.operation.bucket.BucketGetAndDeleteOperation
 
BucketGetAndSetOperation<V> - Class in org.redisson.transaction.operation.bucket
 
BucketGetAndSetOperation(String, String, Codec, Object, long, TimeUnit, String) - Constructor for class org.redisson.transaction.operation.bucket.BucketGetAndSetOperation
 
BucketGetAndSetOperation(String, String, Codec, Object, String) - Constructor for class org.redisson.transaction.operation.bucket.BucketGetAndSetOperation
 
BucketsDecoder - Class in org.redisson.connection.decoder
 
BucketsDecoder(String) - Constructor for class org.redisson.connection.decoder.BucketsDecoder
 
BucketSetOperation<V> - Class in org.redisson.transaction.operation.bucket
 
BucketSetOperation(String, String, Codec, Object, long, TimeUnit, String) - Constructor for class org.redisson.transaction.operation.bucket.BucketSetOperation
 
BucketSetOperation(String, String, Codec, Object, String) - Constructor for class org.redisson.transaction.operation.bucket.BucketSetOperation
 
BucketsTrySetOperation - Class in org.redisson.transaction.operation.bucket
 
BucketsTrySetOperation(Codec, Map<String, Object>, String) - Constructor for class org.redisson.transaction.operation.bucket.BucketsTrySetOperation
 
BucketTrySetOperation<V> - Class in org.redisson.transaction.operation.bucket
 
BucketTrySetOperation(String, String, Codec, Object, long, TimeUnit, String) - Constructor for class org.redisson.transaction.operation.bucket.BucketTrySetOperation
 
BucketTrySetOperation(String, String, Codec, Object, String) - Constructor for class org.redisson.transaction.operation.bucket.BucketTrySetOperation
 
buildClient(String) - Method in class org.redisson.JndiRedissonFactory
 
buildExpression(String) - Method in class org.redisson.executor.CronExpression
 
ByteArrayCodec - Class in org.redisson.client.codec
 
ByteArrayCodec() - Constructor for class org.redisson.client.codec.ByteArrayCodec
 
ByteInputWrapper(ByteBuf) - Constructor for class org.redisson.codec.MarshallingCodec.ByteInputWrapper
 
ByteOutputWrapper(ByteBuf) - Constructor for class org.redisson.codec.MarshallingCodec.ByteOutputWrapper
 
BZPOPMAX_VALUE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
BZPOPMIN_VALUE - Static variable in interface org.redisson.client.protocol.RedisCommands
 

C

Cache<K,V> - Interface in org.redisson.cache
 
CacheAsync<K,V> - Interface in org.redisson.api
Asynchronous interface for JCache
CacheConfig - Class in org.redisson.spring.cache
Cache config object used for Spring cache configuration.
CacheConfig() - Constructor for class org.redisson.spring.cache.CacheConfig
Creates config object with ttl = 0 and maxIdleTime = 0.
CacheConfig(long, long) - Constructor for class org.redisson.spring.cache.CacheConfig
Creates config object.
CacheConfigSupport - Class in org.redisson.spring.cache
 
CacheConfigSupport() - Constructor for class org.redisson.spring.cache.CacheConfigSupport
 
cachedEntrySet() - Method in interface org.redisson.api.RLocalCachedMap
Returns all map entries stored in local cache
cachedEntrySet() - Method in class org.redisson.cache.LocalCacheView
 
cachedEntrySet() - Method in class org.redisson.RedissonLocalCachedMap
 
cachedEntrySet() - Method in class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
cachedKeySet() - Method in interface org.redisson.api.RLocalCachedMap
Returns all keys stored in local cache
cachedKeySet() - Method in class org.redisson.cache.LocalCacheView
 
cachedKeySet() - Method in class org.redisson.RedissonLocalCachedMap
 
cachedKeySet() - Method in class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
CachedValue<K,V> - Interface in org.redisson.cache
Created by jribble on 2/20/17.
CachedValueReference - Interface in org.redisson.cache
 
cachedValues() - Method in interface org.redisson.api.RLocalCachedMap
Returns all values stored in local cache
cachedValues() - Method in class org.redisson.cache.LocalCacheView
 
cachedValues() - Method in class org.redisson.RedissonLocalCachedMap
 
cachedValues() - Method in class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
CachedValueSoftReference<V> - Class in org.redisson.cache
 
CachedValueSoftReference(CachedValue<?, ?>, V, ReferenceQueue<? super V>) - Constructor for class org.redisson.cache.CachedValueSoftReference
 
CachedValueWeakReference<V> - Class in org.redisson.cache
 
CachedValueWeakReference(CachedValue<?, ?>, V, ReferenceQueue<? super V>) - Constructor for class org.redisson.cache.CachedValueWeakReference
 
CacheKey - Class in org.redisson.cache
 
CacheKey(byte[]) - Constructor for class org.redisson.cache.CacheKey
 
cacheProvider(LocalCachedMapOptions.CacheProvider) - Method in class org.redisson.api.LocalCachedMapOptions
Defines Cache provider used as local cache store.
CacheReactive<K,V> - Interface in org.redisson.api
Reactive interface for JCache
CacheRx<K,V> - Interface in org.redisson.api
RxJava2 interface for JCache
cacheSize(int) - Method in class org.redisson.api.LocalCachedMapOptions
Defines local cache size.
CacheValue - Class in org.redisson.cache
 
CacheValue(Object, Object) - Constructor for class org.redisson.cache.CacheValue
 
calcHash(ByteBuf) - Static method in class org.redisson.misc.Hash
 
calcLockWaitTime(long) - Method in class org.redisson.RedissonMultiLock
 
calcLockWaitTime(long) - Method in class org.redisson.RedissonRedLock
 
calcSlot(byte[]) - Method in class org.redisson.cluster.ClusterConnectionManager
 
calcSlot(String) - Method in class org.redisson.cluster.ClusterConnectionManager
 
calcSlot(String) - Method in interface org.redisson.connection.ConnectionManager
 
calcSlot(byte[]) - Method in interface org.redisson.connection.ConnectionManager
 
calcSlot(String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
calcSlot(byte[]) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
call() - Method in class org.redisson.mapreduce.CollatorTask
 
call() - Method in class org.redisson.mapreduce.CoordinatorTask
 
cancel(boolean) - Method in class org.redisson.command.BatchPromise
 
cancel(boolean) - Method in class org.redisson.misc.PromiseDelegator
 
cancel(boolean) - Method in class org.redisson.misc.RedissonPromise
 
cancelAsync(boolean) - Method in class org.redisson.executor.RemotePromise
 
cancelExecutionAsync(RequestId) - Method in class org.redisson.executor.TasksService
 
cancelRequestMapName - Variable in class org.redisson.remote.AsyncRemoteProxy
 
cancelRequestMapName - Variable in class org.redisson.remote.BaseRemoteService
 
cancelResponseMapName - Variable in class org.redisson.remote.BaseRemoteService
 
cancelTask(String) - Method in interface org.redisson.api.RExecutorService
Cancel task by id
cancelTask(String) - Method in class org.redisson.RedissonExecutorService
 
cancelTaskAsync(String) - Method in interface org.redisson.api.RExecutorServiceAsync
Cancel task by id
cancelTaskAsync(String) - Method in class org.redisson.RedissonExecutorService
 
capacity() - Method in interface org.redisson.api.RRingBuffer
Returns capacity of this queue
capacity() - Method in interface org.redisson.api.RRingBufferReactive
Returns capacity of this queue
capacity() - Method in interface org.redisson.api.RRingBufferRx
Returns capacity of this queue
capacity() - Method in class org.redisson.RedissonRingBuffer
 
capacityAsync() - Method in interface org.redisson.api.RRingBufferAsync
Returns capacity of this queue
capacityAsync() - Method in class org.redisson.RedissonRingBuffer
 
cardinality() - Method in interface org.redisson.api.RBitSet
Returns the number of bits set to one.
cardinality() - Method in interface org.redisson.api.RBitSetReactive
Returns the number of bits set to one.
cardinality() - Method in interface org.redisson.api.RBitSetRx
Returns the number of bits set to one.
cardinality() - Method in class org.redisson.RedissonBitSet
 
cardinalityAsync() - Method in interface org.redisson.api.RBitSetAsync
Returns the number of bits set to one.
cardinalityAsync() - Method in class org.redisson.RedissonBitSet
 
cause() - Method in interface org.redisson.api.RFuture
Returns the cause of the failed I/O operation if the I/O operation has failed.
cause() - Method in class org.redisson.client.protocol.BatchCommandData
 
cause() - Method in class org.redisson.client.protocol.CommandData
 
cause() - Method in class org.redisson.misc.PromiseDelegator
 
cause() - Method in class org.redisson.misc.RedissonPromise
 
CborJacksonCodec - Class in org.redisson.codec
 
CborJacksonCodec() - Constructor for class org.redisson.codec.CborJacksonCodec
 
CborJacksonCodec(ClassLoader) - Constructor for class org.redisson.codec.CborJacksonCodec
 
CborJacksonCodec(ClassLoader, CborJacksonCodec) - Constructor for class org.redisson.codec.CborJacksonCodec
 
changeMaster(int, RedisURI) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
changeMaster(RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
Freeze slave with redis(s)://host:port from slaves list.
changeMaster(InetSocketAddress, RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
 
changeType(InetSocketAddress, NodeType) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
channelActive(ChannelHandlerContext) - Method in class org.redisson.client.handler.BaseConnectionHandler
 
channelActive(ChannelHandlerContext) - Method in class org.redisson.client.handler.ConnectionWatchdog
 
channelActive(ChannelHandlerContext) - Method in class org.redisson.client.handler.PingConnectionHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.redisson.client.handler.CommandsQueue
 
channelInactive(ChannelHandlerContext) - Method in class org.redisson.client.handler.ConnectionWatchdog
 
ChannelName - Class in org.redisson.client
 
ChannelName(byte[]) - Constructor for class org.redisson.client.ChannelName
 
ChannelName(String) - Constructor for class org.redisson.client.ChannelName
 
channelRegistered(ChannelHandlerContext) - Method in class org.redisson.client.handler.BaseConnectionHandler
 
charAt(int) - Method in class org.redisson.client.ChannelName
 
checkAttemptPromise(RPromise<R>, RFuture<RedisConnection>) - Method in class org.redisson.command.RedisExecutor
 
checkKey(Object) - Method in class org.redisson.jcache.JCache
 
checkKey(Object) - Method in class org.redisson.RedissonMap
 
checkKey(Object) - Method in class org.redisson.RedissonStream
 
checkNext(int, String, int, int) - Method in class org.redisson.executor.CronExpression
 
checkSkipSlavesInit() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
checkState() - Method in class org.redisson.transaction.RedissonTransaction
 
checkState() - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
checkState() - Method in class org.redisson.transaction.RedissonTransactionalBuckets
 
checkState() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
checkState() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
checkState() - Method in class org.redisson.transaction.RedissonTransactionalSet
 
checkState() - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
checkValue(Object) - Method in class org.redisson.RedissonMap
 
checkValue(Object) - Method in class org.redisson.RedissonStream
 
claim(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStream
Transfers ownership of pending messages by id to a new consumer by name if idle time of messages is greater than defined value.
claim(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Transfers ownership of pending messages by id to a new consumer by name if idle time of messages is greater than defined value.
claim(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Transfers ownership of pending messages by id to a new consumer by name if idle time of messages is greater than defined value.
claim(String, String, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
claimAsync(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Transfers ownership of pending messages by id to a new consumer by name if idle time of messages is greater than defined value.
claimAsync(String, String, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
ClassBody(byte[], byte[], String) - Constructor for class org.redisson.RedissonExecutorService.ClassBody
 
ClassMixIn() - Constructor for class org.redisson.config.ConfigSupport.ClassMixIn
 
ClassUtils - Class in org.redisson.liveobject.misc
 
ClassUtils() - Constructor for class org.redisson.liveobject.misc.ClassUtils
 
clear() - Method in interface org.redisson.api.CacheReactive
This method empties the cache's contents, without notifying listeners or CacheWriters.
clear() - Method in interface org.redisson.api.CacheRx
This method empties the cache's contents, without notifying listeners or CacheWriters.
clear(long, long) - Method in interface org.redisson.api.RBitSet
Set all bits to zero from fromIndex (inclusive) to toIndex (exclusive)
clear(long) - Method in interface org.redisson.api.RBitSet
Set bit to zero at specified bitIndex
clear() - Method in interface org.redisson.api.RBitSet
Set all bits to zero
clear(long, long) - Method in interface org.redisson.api.RBitSetReactive
Set all bits to zero from fromIndex (inclusive) to toIndex (exclusive)
clear(long) - Method in interface org.redisson.api.RBitSetReactive
Set bit to zero at specified bitIndex
clear() - Method in interface org.redisson.api.RBitSetReactive
Set all bits to zero
clear(long, long) - Method in interface org.redisson.api.RBitSetRx
Set all bits to zero from fromIndex (inclusive) to toIndex (exclusive)
clear(long) - Method in interface org.redisson.api.RBitSetRx
Set bit to zero at specified bitIndex
clear() - Method in interface org.redisson.api.RBitSetRx
Set all bits to zero
clear() - Method in interface org.redisson.api.RMultimap
Removes all key-value pairs from the multimap, leaving it empty.
clear() - Method in interface org.redisson.api.RScoredSortedSet
Removes all elements of this sorted set.
clear() - Method in class org.redisson.cache.AbstractCacheMap
 
clear() - Method in class org.redisson.cache.LFUCacheMap
 
clear() - Method in class org.redisson.cache.LRUCacheMap
 
clear() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
clear() - Method in class org.redisson.jcache.JCache
 
clear() - Method in class org.redisson.misc.BiHashMap
 
clear(long, long) - Method in class org.redisson.RedissonBitSet
 
clear(long) - Method in class org.redisson.RedissonBitSet
 
clear() - Method in class org.redisson.RedissonBitSet
 
clear() - Method in class org.redisson.RedissonBoundedBlockingQueue
 
clear() - Method in class org.redisson.RedissonDelayedQueue
 
clear() - Method in class org.redisson.RedissonList
 
clear() - Method in class org.redisson.RedissonListMultimapValues
 
clear() - Method in class org.redisson.RedissonMap
 
clear() - Method in class org.redisson.RedissonMultimap
 
clear() - Method in class org.redisson.RedissonPriorityQueue
 
clear() - Method in class org.redisson.RedissonScoredSortedSet
 
clear() - Method in class org.redisson.RedissonSet
 
clear() - Method in class org.redisson.RedissonSetCache
 
clear() - Method in class org.redisson.RedissonSetMultimapValues
 
clear() - Method in class org.redisson.RedissonSortedSet
 
clear() - Method in class org.redisson.RedissonSubList
 
clear() - Method in class org.redisson.RedissonTransferQueue
 
clear() - Method in class org.redisson.spring.cache.RedissonCache
 
clearAsync() - Method in interface org.redisson.api.CacheAsync
This method empties the cache's contents, without notifying listeners or CacheWriters.
clearAsync(long, long) - Method in interface org.redisson.api.RBitSetAsync
Set all bits to zero from fromIndex (inclusive) to toIndex (exclusive)
clearAsync(long) - Method in interface org.redisson.api.RBitSetAsync
Set bit to zero at specified bitIndex
clearAsync() - Method in interface org.redisson.api.RBitSetAsync
Set all bits to zero
clearAsync() - Method in class org.redisson.jcache.JCache
 
clearAsync(long, long) - Method in class org.redisson.RedissonBitSet
 
clearAsync(long) - Method in class org.redisson.RedissonBitSet
 
clearAsync() - Method in class org.redisson.RedissonBitSet
 
clearAsync() - Method in class org.redisson.RedissonTransferQueue
 
clearError() - Method in class org.redisson.client.protocol.BatchCommandData
 
clearErrors() - Method in class org.redisson.command.CommandBatchService.Entry
 
clearExpire() - Method in interface org.redisson.api.RExpirable
Clear an expire timeout or expire date for object.
clearExpire() - Method in interface org.redisson.api.RExpirableReactive
Clear an expire timeout or expire date for object in mode.
clearExpire() - Method in interface org.redisson.api.RExpirableRx
Clear an expire timeout or expire date for object in mode.
clearExpire(String) - Method in interface org.redisson.api.RKeys
Clear an expire timeout or expire date for object.
clearExpire(String) - Method in interface org.redisson.api.RKeysReactive
Clear an expire timeout or expire date for object.
clearExpire(String) - Method in interface org.redisson.api.RKeysRx
Clear an expire timeout or expire date for object.
clearExpire(String) - Method in class org.redisson.RedissonKeys
 
clearExpireAsync() - Method in interface org.redisson.api.RExpirableAsync
Clear an expire timeout or expire date for object in async mode.
clearExpireAsync(String) - Method in interface org.redisson.api.RKeysAsync
Clear an expire timeout or expire date for object.
clearExpireAsync() - Method in class org.redisson.RedissonBloomFilter
 
clearExpireAsync() - Method in class org.redisson.RedissonBoundedBlockingQueue
 
clearExpireAsync() - Method in class org.redisson.RedissonDelayedQueue
 
clearExpireAsync() - Method in class org.redisson.RedissonFairLock
 
clearExpireAsync(String) - Method in class org.redisson.RedissonKeys
 
clearExpireAsync() - Method in class org.redisson.RedissonListMultimapCache
 
clearExpireAsync() - Method in class org.redisson.RedissonListMultimapValues
 
clearExpireAsync() - Method in class org.redisson.RedissonMapCache
 
clearExpireAsync() - Method in class org.redisson.RedissonMultimap
 
clearExpireAsync() - Method in class org.redisson.RedissonMultimapCache
 
clearExpireAsync() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
clearExpireAsync() - Method in class org.redisson.RedissonPriorityQueue
 
clearExpireAsync() - Method in class org.redisson.RedissonSetMultimapCache
 
clearExpireAsync() - Method in class org.redisson.RedissonSetMultimapValues
 
clearExpireAsync() - Method in class org.redisson.transaction.BaseTransactionalObject
 
clearExpireAsync() - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
clearExpireAsync() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
clearExpireAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
clearExpireAsync() - Method in class org.redisson.transaction.RedissonTransactionalSet
 
clearExpireAsync() - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
clearFastReconnect() - Method in class org.redisson.client.RedisConnection
 
clearLocalCache() - Method in interface org.redisson.api.RLocalCachedMap
Clears local cache across all instances
clearLocalCache() - Method in class org.redisson.RedissonLocalCachedMap
 
clearLocalCache() - Method in class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
clearLocalCacheAsync() - Method in interface org.redisson.api.RLocalCachedMap
Clears local cache across all instances
clearLocalCacheAsync() - Method in class org.redisson.cache.LocalCacheListener
 
clearLocalCacheAsync() - Method in class org.redisson.RedissonLocalCachedMap
 
clearLocalCacheAsync() - Method in class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
clearObjectNames() - Method in class org.redisson.mapreduce.BaseMapperTask
 
client - Variable in class org.redisson.iterator.BaseIterator
 
CLIENT_GETNAME - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLIENT_LIST - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLIENT_REPLY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLIENT_SETNAME - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ClientConnectionsEntry - Class in org.redisson.connection
 
ClientConnectionsEntry(RedisClient, int, int, int, int, ConnectionManager, NodeType) - Constructor for class org.redisson.connection.ClientConnectionsEntry
 
ClientConnectionsEntry.FreezeReason - Enum in org.redisson.connection
 
clone() - Method in class org.redisson.executor.CronExpression
Deprecated.
close() - Method in class org.redisson.codec.MarshallingCodec.ByteInputWrapper
 
close() - Method in class org.redisson.codec.MarshallingCodec.ByteOutputWrapper
 
close() - Method in class org.redisson.jcache.JCache
 
close() - Method in class org.redisson.jcache.JCacheManager
 
close() - Method in class org.redisson.jcache.JCachingProvider
 
close(ClassLoader) - Method in class org.redisson.jcache.JCachingProvider
 
close(URI, ClassLoader) - Method in class org.redisson.jcache.JCachingProvider
 
close() - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
close() - Method in class org.redisson.misc.ReclosableLatch
 
close() - Method in class org.redisson.RedissonBinaryStream.RedissonAsynchronousByteChannel
 
closeAsync() - Method in class org.redisson.client.RedisConnection
 
closeCache(JCache<?, ?>) - Method in class org.redisson.jcache.JCacheManager
 
closeNodeConnection(RedisConnection) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
closeNodeConnections() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
CLUSTER - Static variable in class org.redisson.api.redisnode.RedisNodes
 
CLUSTER_ADDSLOTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_COUNTFAILUREREPORTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_COUNTKEYSINSLOT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_DELSLOTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_FLUSHSLOTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_FORGET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_GETKEYSINSLOT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_INFO - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_MEET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_MYID - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_NODES - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_NODES_SSL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_REPLICATE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_RESET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_SETSLOT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CLUSTER_SLOTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
clusterAddSlots(int...) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Adds slots to this Redis node
clusterAddSlots(int...) - Method in class org.redisson.redisnode.RedisNode
 
clusterAddSlotsAsync(int...) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Adds slots to this Redis node
clusterAddSlotsAsync(int...) - Method in class org.redisson.redisnode.RedisNode
 
ClusterConnectionManager - Class in org.redisson.cluster
 
ClusterConnectionManager(ClusterServersConfig, Config, UUID) - Constructor for class org.redisson.cluster.ClusterConnectionManager
 
clusterCountFailureReports(String) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Returns number of failure reports for Redis node by defined id
clusterCountFailureReports(String) - Method in class org.redisson.redisnode.RedisNode
 
clusterCountFailureReportsAsync(String) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Returns number of failure reports for Redis node by defined id
clusterCountFailureReportsAsync(String) - Method in class org.redisson.redisnode.RedisNode
 
clusterCountKeysInSlot(int) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Counts keys in defined slot
clusterCountKeysInSlot(int) - Method in class org.redisson.redisnode.RedisNode
 
clusterCountKeysInSlotAsync(int) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Counts keys in defined slot
clusterCountKeysInSlotAsync(int) - Method in class org.redisson.redisnode.RedisNode
 
clusterDeleteSlots(int...) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Removes slots from this Redis node
clusterDeleteSlots(int...) - Method in class org.redisson.redisnode.RedisNode
 
clusterDeleteSlotsAsync(int...) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Removes slots from this Redis node
clusterDeleteSlotsAsync(int...) - Method in class org.redisson.redisnode.RedisNode
 
clusterFlushSlots() - Method in interface org.redisson.api.redisnode.RedisClusterNode
Removes all slots from this Redis node
clusterFlushSlots() - Method in class org.redisson.redisnode.RedisNode
 
clusterFlushSlotsAsync() - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Removes all slots from this Redis node
clusterFlushSlotsAsync() - Method in class org.redisson.redisnode.RedisNode
 
clusterForget(String) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Removes Redis node by defined id from Cluster
clusterForget(String) - Method in class org.redisson.redisnode.RedisNode
 
clusterForgetAsync(String) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Removes Redis node by defined id from Cluster
clusterForgetAsync(String) - Method in class org.redisson.redisnode.RedisNode
 
clusterGetKeysInSlot(int, int) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Returns keys in defines slot limited by count
clusterGetKeysInSlot(int, int) - Method in class org.redisson.redisnode.RedisNode
 
clusterGetKeysInSlotAsync(int, int) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Returns keys in defines slot limited by count
clusterGetKeysInSlotAsync(int, int) - Method in class org.redisson.redisnode.RedisNode
 
clusterId() - Method in interface org.redisson.api.redisnode.RedisClusterNode
Returns id of this Redis node
clusterId() - Method in class org.redisson.redisnode.RedisNode
 
clusterIdAsync() - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Returns id of this Redis node
clusterIdAsync() - Method in class org.redisson.redisnode.RedisNode
 
clusterInfo() - Method in interface org.redisson.api.ClusterNode
Deprecated.
Execute CLUSTER INFO operation.
clusterInfo() - Method in interface org.redisson.api.redisnode.RedisClusterNode
Returns cluster information reported by this Redis node
clusterInfo() - Method in class org.redisson.connection.RedisClientEntry
 
clusterInfo() - Method in class org.redisson.redisnode.RedisNode
 
clusterInfoAsync() - Method in interface org.redisson.api.NodeAsync
Deprecated.
 
clusterInfoAsync() - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Returns cluster information reported by this Redis node
clusterInfoAsync() - Method in class org.redisson.connection.RedisClientEntry
 
clusterInfoAsync() - Method in class org.redisson.redisnode.RedisNode
 
clusterMeet(String) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Joins Redis node by the defined address to Cluster Address example: redis://127.0.0.1:9233
clusterMeet(String) - Method in class org.redisson.redisnode.RedisNode
 
clusterMeetAsync(String) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Joins Redis node by the defined address to Cluster Address example: redis://127.0.0.1:9233
clusterMeetAsync(String) - Method in class org.redisson.redisnode.RedisNode
 
ClusterNode - Interface in org.redisson.api
Deprecated.
ClusterNodeInfo - Class in org.redisson.cluster
 
ClusterNodeInfo(String) - Constructor for class org.redisson.cluster.ClusterNodeInfo
 
ClusterNodeInfo.Flag - Enum in org.redisson.cluster
 
ClusterNodesDecoder - Class in org.redisson.client.protocol.decoder
 
ClusterNodesDecoder(boolean) - Constructor for class org.redisson.client.protocol.decoder.ClusterNodesDecoder
 
ClusterNodesGroup - Interface in org.redisson.api
Deprecated.
ClusterPartition - Class in org.redisson.cluster
 
ClusterPartition(String) - Constructor for class org.redisson.cluster.ClusterPartition
 
ClusterPartition.Type - Enum in org.redisson.cluster
 
clusterReplicate(String) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Reconfigures this Redis node as replica of Redis node by defined id.
clusterReplicate(String) - Method in class org.redisson.redisnode.RedisNode
 
clusterReplicateAsync(String) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Reconfigures this Redis node as replica of Redis node by defined id.
clusterReplicateAsync(String) - Method in class org.redisson.redisnode.RedisNode
 
ClusterServersConfig - Class in org.redisson.config
 
ClusterServersConfig() - Constructor for class org.redisson.config.ClusterServersConfig
 
clusterSetSlot(int, SetSlotCommand) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Sets slot to this Redis node according to defined command
clusterSetSlot(int, SetSlotCommand, String) - Method in interface org.redisson.api.redisnode.RedisClusterNode
Sets slot to this Redis node according to defined command
clusterSetSlot(int, SetSlotCommand) - Method in class org.redisson.redisnode.RedisNode
 
clusterSetSlot(int, SetSlotCommand, String) - Method in class org.redisson.redisnode.RedisNode
 
clusterSetSlotAsync(int, SetSlotCommand) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Sets slot to this Redis node according to defined command
clusterSetSlotAsync(int, SetSlotCommand, String) - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Sets slot to this Redis node according to defined command
clusterSetSlotAsync(int, SetSlotCommand) - Method in class org.redisson.redisnode.RedisNode
 
clusterSetSlotAsync(int, SetSlotCommand, String) - Method in class org.redisson.redisnode.RedisNode
 
ClusterSlotRange - Class in org.redisson.cluster
 
ClusterSlotRange(int, int) - Constructor for class org.redisson.cluster.ClusterSlotRange
 
clusterSlots() - Method in interface org.redisson.api.redisnode.RedisClusterNode
Return Redis Cluster slots mapped to Redis nodes
clusterSlots() - Method in class org.redisson.redisnode.RedisNode
 
clusterSlotsAsync() - Method in interface org.redisson.api.redisnode.RedisClusterNodeAsync
Return Redis Cluster slots mapped to Redis nodes
clusterSlotsAsync() - Method in class org.redisson.redisnode.RedisNode
 
Codec - Interface in org.redisson.client.codec
Redis codec interface.
codec - Variable in class org.redisson.codec.BaseEventCodec
 
codec - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
codec - Variable in class org.redisson.liveobject.resolver.AbstractNamingScheme
 
codec - Variable in class org.redisson.mapreduce.CoordinatorTask
 
codec - Variable in class org.redisson.RedissonBuckets
 
codec - Variable in class org.redisson.RedissonObject
 
codec - Variable in class org.redisson.remote.BaseRemoteService
 
codec - Variable in class org.redisson.transaction.operation.TransactionalOperation
 
CodecDecoder - Class in org.redisson.client.protocol.decoder
 
CodecDecoder() - Constructor for class org.redisson.client.protocol.decoder.CodecDecoder
 
CodecMethodRef() - Constructor for class org.redisson.liveobject.core.RedissonObjectBuilder.CodecMethodRef
 
collate(Map<K, V>) - Method in interface org.redisson.api.mapreduce.RCollator
Collates result map from reduce phase of MapReduce process.
CollatorTask<KOut,VOut,R> - Class in org.redisson.mapreduce
 
CollatorTask() - Constructor for class org.redisson.mapreduce.CollatorTask
 
CollatorTask(RedissonClient, RCollator<KOut, VOut, R>, String, Class<?>) - Constructor for class org.redisson.mapreduce.CollatorTask
 
CollectionMapperTask<VIn,KOut,VOut> - Class in org.redisson.mapreduce
 
CollectionMapperTask() - Constructor for class org.redisson.mapreduce.CollectionMapperTask
 
CollectionMapperTask(RCollectionMapper<VIn, KOut, VOut>, Class<?>, Class<?>) - Constructor for class org.redisson.mapreduce.CollectionMapperTask
 
Collector<K,V> - Class in org.redisson.mapreduce
 
Collector(Codec, RedissonClient, String, int, long) - Constructor for class org.redisson.mapreduce.Collector
 
collectorMapName - Variable in class org.redisson.mapreduce.BaseMapperTask
 
CommandAsyncExecutor - Interface in org.redisson.command
 
CommandAsyncService - Class in org.redisson.command
 
CommandAsyncService(ConnectionManager) - Constructor for class org.redisson.command.CommandAsyncService
 
CommandBatchEncoder - Class in org.redisson.client.handler
 
CommandBatchEncoder() - Constructor for class org.redisson.client.handler.CommandBatchEncoder
 
CommandBatchService - Class in org.redisson.command
 
CommandBatchService(ConnectionManager) - Constructor for class org.redisson.command.CommandBatchService
 
CommandBatchService(ConnectionManager, BatchOptions) - Constructor for class org.redisson.command.CommandBatchService
 
CommandBatchService.ConnectionEntry - Class in org.redisson.command
 
CommandBatchService.Entry - Class in org.redisson.command
 
CommandData<T,R> - Class in org.redisson.client.protocol
 
CommandData(RPromise<R>, Codec, RedisCommand<T>, Object[]) - Constructor for class org.redisson.client.protocol.CommandData
 
CommandData(RPromise<R>, MultiDecoder<Object>, Codec, RedisCommand<T>, Object[]) - Constructor for class org.redisson.client.protocol.CommandData
 
CommandDecoder - Class in org.redisson.client.handler
Redis protocol command decoder
CommandDecoder(ExecutorService, boolean) - Constructor for class org.redisson.client.handler.CommandDecoder
 
CommandEncoder - Class in org.redisson.client.handler
Redis protocol command encoder
CommandEncoder() - Constructor for class org.redisson.client.handler.CommandEncoder
 
CommandExecutor - Interface in org.redisson.command
 
commandExecutor - Variable in class org.redisson.RedissonBuckets
 
commandExecutor - Variable in class org.redisson.RedissonObject
 
commandExecutor - Variable in class org.redisson.RedissonReactive
 
commandExecutor - Variable in class org.redisson.RedissonRx
 
commandExecutor - Variable in class org.redisson.remote.BaseRemoteService
 
CommandPubSubDecoder - Class in org.redisson.client.handler
Redis Publish Subscribe protocol decoder
CommandPubSubDecoder(ExecutorService, boolean, boolean) - Constructor for class org.redisson.client.handler.CommandPubSubDecoder
 
CommandReactiveBatchService - Class in org.redisson.reactive
 
CommandReactiveBatchService(ConnectionManager, BatchOptions) - Constructor for class org.redisson.reactive.CommandReactiveBatchService
 
CommandReactiveExecutor - Interface in org.redisson.reactive
 
CommandReactiveService - Class in org.redisson.reactive
 
CommandReactiveService(ConnectionManager) - Constructor for class org.redisson.reactive.CommandReactiveService
 
CommandRxBatchService - Class in org.redisson.rx
 
CommandRxBatchService(ConnectionManager, BatchOptions) - Constructor for class org.redisson.rx.CommandRxBatchService
 
CommandRxExecutor - Interface in org.redisson.rx
 
CommandRxService - Class in org.redisson.rx
 
CommandRxService(ConnectionManager) - Constructor for class org.redisson.rx.CommandRxService
 
CommandsData - Class in org.redisson.client.protocol
 
CommandsData(RPromise<Void>, List<CommandData<?, ?>>, boolean) - Constructor for class org.redisson.client.protocol.CommandsData
 
CommandsData(RPromise<Void>, List<CommandData<?, ?>>, boolean, boolean, boolean) - Constructor for class org.redisson.client.protocol.CommandsData
 
CommandsData(RPromise<Void>, List<CommandData<?, ?>>, List<CommandData<?, ?>>, boolean, boolean, boolean) - Constructor for class org.redisson.client.protocol.CommandsData
 
CommandsQueue - Class in org.redisson.client.handler
 
CommandsQueue() - Constructor for class org.redisson.client.handler.CommandsQueue
 
CommandSyncExecutor - Interface in org.redisson.command
 
CommandSyncService - Class in org.redisson.command
 
CommandSyncService(ConnectionManager) - Constructor for class org.redisson.command.CommandSyncService
 
commit() - Method in interface org.redisson.api.RTransaction
Commits all changes made on this transaction.
commit() - Method in interface org.redisson.api.RTransactionReactive
Commits all changes made on this transaction.
commit() - Method in interface org.redisson.api.RTransactionRx
Commits all changes made on this transaction.
commit() - Method in class org.redisson.reactive.RedissonTransactionReactive
 
commit() - Method in class org.redisson.rx.RedissonTransactionRx
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketCompareAndSetOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketGetAndDeleteOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketGetAndSetOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketSetOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketsTrySetOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketTrySetOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.DeleteOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapAddAndGetOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapCacheFastPutIfAbsentOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapCacheFastPutOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapCachePutIfAbsentOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapCachePutOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapFastPutIfAbsentOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapFastPutOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapFastRemoveOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.map.MapOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapPutIfAbsentOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapPutOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapRemoveOperation
 
commit(RMap<Object, Object>) - Method in class org.redisson.transaction.operation.map.MapReplaceOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.AddCacheOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.AddOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.MoveOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.RemoveCacheOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.RemoveOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.TouchOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.TransactionalOperation
 
commit(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.UnlinkOperation
 
commit() - Method in class org.redisson.transaction.RedissonTransaction
 
commit(Set<String>, List<TransactionalOperation>) - Method in class org.redisson.transaction.RedissonTransaction
 
commitAsync() - Method in interface org.redisson.api.RTransaction
Commits all changes made on this transaction in async mode.
commitAsync() - Method in class org.redisson.transaction.RedissonTransaction
 
comparator() - Method in interface org.redisson.api.RPriorityQueue
Returns comparator used by this queue
comparator() - Method in class org.redisson.RedissonLexSortedSet
 
comparator() - Method in class org.redisson.RedissonPriorityQueue
 
comparator() - Method in class org.redisson.RedissonSortedSet
 
compare(InetSocketAddress, RedisURI) - Static method in class org.redisson.misc.RedisURI
 
compareAndSet(double, double) - Method in interface org.redisson.api.RAtomicDouble
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(double, double) - Method in interface org.redisson.api.RAtomicDoubleReactive
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(double, double) - Method in interface org.redisson.api.RAtomicDoubleRx
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(long, long) - Method in interface org.redisson.api.RAtomicLong
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(long, long) - Method in interface org.redisson.api.RAtomicLongReactive
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(long, long) - Method in interface org.redisson.api.RAtomicLongRx
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(V, V) - Method in interface org.redisson.api.RBucket
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.
compareAndSet(V, V) - Method in interface org.redisson.api.RBucketReactive
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.
compareAndSet(V, V) - Method in interface org.redisson.api.RBucketRx
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.
compareAndSet(double, double) - Method in class org.redisson.RedissonAtomicDouble
 
compareAndSet(long, long) - Method in class org.redisson.RedissonAtomicLong
 
compareAndSet(V, V) - Method in class org.redisson.RedissonBucket
 
compareAndSetAsync(double, double) - Method in interface org.redisson.api.RAtomicDoubleAsync
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSetAsync(long, long) - Method in interface org.redisson.api.RAtomicLongAsync
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSetAsync(V, V) - Method in interface org.redisson.api.RBucketAsync
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.
compareAndSetAsync(double, double) - Method in class org.redisson.RedissonAtomicDouble
 
compareAndSetAsync(long, long) - Method in class org.redisson.RedissonAtomicLong
 
compareAndSetAsync(V, V) - Method in class org.redisson.RedissonBucket
 
compareAndSetAsync(V, V) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
compareTo(LFUCacheMap.MapKey) - Method in class org.redisson.cache.LFUCacheMap.MapKey
 
compareTo(BatchCommandData<T, R>) - Method in class org.redisson.client.protocol.BatchCommandData
 
compareTo(Delayed) - Method in class org.redisson.executor.RedissonScheduledFuture
 
completeResponse(CommandData<Object, Object>, Object, Channel) - Method in class org.redisson.client.handler.CommandDecoder
 
completionQueue - Variable in class org.redisson.executor.RedissonCompletionService
 
CompositeCodec - Class in org.redisson.codec
 
CompositeCodec(Codec, Codec) - Constructor for class org.redisson.codec.CompositeCodec
 
CompositeCodec(Codec, Codec, Codec) - Constructor for class org.redisson.codec.CompositeCodec
 
CompositeCodec(ClassLoader, CompositeCodec) - Constructor for class org.redisson.codec.CompositeCodec
 
CompositeIterable<T> - Class in org.redisson.misc
 
CompositeIterable(List<Iterable<T>>) - Constructor for class org.redisson.misc.CompositeIterable
 
CompositeIterable(Iterable<T>...) - Constructor for class org.redisson.misc.CompositeIterable
 
CompositeIterable(CompositeIterable<T>) - Constructor for class org.redisson.misc.CompositeIterable
 
CompositeIterator<T> - Class in org.redisson.misc
 
CompositeIterator(Iterator<Iterator<T>>) - Constructor for class org.redisson.misc.CompositeIterator
 
Condition - Interface in org.redisson.api.condition
Interface for conditional object
Conditions - Class in org.redisson.api.condition
Conditions factory to search for Live Objects by fields.
Config - Class in org.redisson.config
Redisson configuration
Config() - Constructor for class org.redisson.config.Config
 
Config(Config) - Constructor for class org.redisson.config.Config
 
config - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
config - Variable in class org.redisson.Redisson
 
config - Variable in class org.redisson.RedissonReactive
 
config - Variable in class org.redisson.RedissonRx
 
CONFIG_GET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CONFIG_RESETSTAT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
CONFIG_SET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ConfigMixIn() - Constructor for class org.redisson.config.ConfigSupport.ConfigMixIn
 
ConfigSupport - Class in org.redisson.config
 
ConfigSupport() - Constructor for class org.redisson.config.ConfigSupport
 
ConfigSupport.ClassMixIn - Class in org.redisson.config
 
ConfigSupport.ConfigMixIn - Class in org.redisson.config
 
connect() - Method in class org.redisson.client.RedisClient
 
connect() - Method in class org.redisson.connection.ClientConnectionsEntry
 
connect(ClientConnectionsEntry) - Method in class org.redisson.connection.pool.PubSubConnectionPool
 
connectAsync() - Method in class org.redisson.client.RedisClient
 
ConnectionEntry() - Constructor for class org.redisson.command.CommandBatchService.ConnectionEntry
 
ConnectionEventsHub - Class in org.redisson.connection
 
ConnectionEventsHub() - Constructor for class org.redisson.connection.ConnectionEventsHub
 
ConnectionEventsHub.Status - Enum in org.redisson.connection
 
ConnectionListener - Interface in org.redisson.connection
 
ConnectionManager - Interface in org.redisson.connection
 
connectionManager - Variable in class org.redisson.Redisson
 
connectionManager - Variable in class org.redisson.RedissonReactive
 
connectionManager - Variable in class org.redisson.RedissonRx
 
connectionReadOp(NodeSource, RedisCommand<?>) - Method in interface org.redisson.connection.ConnectionManager
 
connectionReadOp(NodeSource, RedisCommand<?>) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
connectionReadOp(RedisCommand<?>) - Method in class org.redisson.connection.MasterSlaveEntry
 
connectionReadOp(RedisCommand<?>, RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
 
connectionReadOp(RedisCommand<?>, RedisClient) - Method in class org.redisson.connection.MasterSlaveEntry
 
connectionReadOp(RedisCommand<?>, RedisURI) - Method in class org.redisson.connection.SingleEntry
 
connectionReadOp(RedisCommand<?>) - Method in class org.redisson.connection.SingleEntry
 
ConnectionWatchdog - Class in org.redisson.client.handler
 
ConnectionWatchdog(Bootstrap, ChannelGroup, Timer) - Constructor for class org.redisson.client.handler.ConnectionWatchdog
 
connectionWriteOp(NodeSource, RedisCommand<?>) - Method in interface org.redisson.connection.ConnectionManager
 
connectionWriteOp(NodeSource, RedisCommand<?>) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
connectionWriteOp(RedisCommand<?>) - Method in class org.redisson.connection.MasterSlaveEntry
 
connectPubSub() - Method in class org.redisson.client.RedisClient
 
connectPubSub() - Method in class org.redisson.connection.ClientConnectionsEntry
 
connectPubSubAsync() - Method in class org.redisson.client.RedisClient
 
connectToNode(BaseMasterSlaveServersConfig<?>, RedisURI, RedisClient, String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
contains(T) - Method in interface org.redisson.api.RBloomFilter
Check for element present
contains(V) - Method in interface org.redisson.api.RCollectionReactive
Returns true if this collection contains encoded state of the specified element.
contains(V) - Method in interface org.redisson.api.RCollectionRx
Returns true if this collection contains encoded state of the specified element.
contains(Object) - Method in interface org.redisson.api.RScoredSortedSet
Returns true if this sorted set contains encoded state of the specified element.
contains(V) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns true if this sorted set contains encoded state of the specified element.
contains(V) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns true if this sorted set contains encoded state of the specified element.
contains(InetSocketAddress) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
contains(RedisURI) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
contains(RedisClient) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
contains(T) - Method in class org.redisson.RedissonBloomFilter
 
contains(Object) - Method in class org.redisson.RedissonDelayedQueue
 
contains(Object) - Method in class org.redisson.RedissonList
 
contains(Object) - Method in class org.redisson.RedissonListMultimapValues
 
contains(Object) - Method in class org.redisson.RedissonPriorityQueue
 
contains(Object) - Method in class org.redisson.RedissonScoredSortedSet
 
contains(Object) - Method in class org.redisson.RedissonSet
 
contains(Object) - Method in class org.redisson.RedissonSetCache
 
contains(Object) - Method in class org.redisson.RedissonSetMultimapValues
 
contains(Object) - Method in class org.redisson.RedissonSortedSet
 
contains(Object) - Method in class org.redisson.RedissonTransferQueue
 
containsAll(Collection<?>) - Method in interface org.redisson.api.RCollectionReactive
Returns true if this collection contains all of the elements in the specified collection.
containsAll(Collection<?>) - Method in interface org.redisson.api.RCollectionRx
Returns true if this collection contains all of the elements in the specified collection.
containsAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSet
Returns true if this sorted set contains all of the elements in encoded state in the specified collection.
containsAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns true if this sorted set contains all of the elements in encoded state in the specified collection.
containsAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns true if this sorted set contains all of the elements in encoded state in the specified collection.
containsAll(Collection<?>) - Method in class org.redisson.RedissonDelayedQueue
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonList
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonListMultimapValues
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonPriorityQueue
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonScoredSortedSet
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonSet
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonSetCache
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonSetMultimapValues
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonSortedSet
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonTransferQueue
 
containsAllAsync(Collection<?>) - Method in interface org.redisson.api.RCollectionAsync
Returns true if this collection contains all of the elements in the specified collection.
containsAllAsync(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns true if this sorted set contains all of the elements in encoded state in the specified collection.
containsAllAsync(Collection<?>) - Method in class org.redisson.RedissonDelayedQueue
 
containsAllAsync(Collection<?>) - Method in class org.redisson.RedissonList
 
containsAllAsync(Collection<?>) - Method in class org.redisson.RedissonListMultimapValues
 
containsAllAsync(Collection<?>) - Method in class org.redisson.RedissonScoredSortedSet
 
containsAllAsync(Collection<?>) - Method in class org.redisson.RedissonSet
 
containsAllAsync(Collection<?>) - Method in class org.redisson.RedissonSetCache
 
containsAllAsync(Collection<?>) - Method in class org.redisson.RedissonSetMultimapValues
 
containsAllAsync(Collection<?>) - Method in class org.redisson.RedissonSubList
 
containsAllAsync(Collection<?>) - Method in class org.redisson.RedissonTransferQueue
 
containsAllAsync(Collection<?>) - Method in class org.redisson.transaction.BaseTransactionalSet
 
containsAsync(Object) - Method in interface org.redisson.api.RCollectionAsync
Returns true if this collection contains encoded state of the specified element.
containsAsync(Object) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns true if this sorted set contains encoded state of the specified element.
containsAsync(Object) - Method in class org.redisson.RedissonDelayedQueue
 
containsAsync(Object) - Method in class org.redisson.RedissonList
 
containsAsync(Object) - Method in class org.redisson.RedissonListMultimapValues
 
containsAsync(Object) - Method in class org.redisson.RedissonScoredSortedSet
 
containsAsync(Object) - Method in class org.redisson.RedissonSet
 
containsAsync(Object) - Method in class org.redisson.RedissonSetCache
 
containsAsync(Object) - Method in class org.redisson.RedissonSetMultimapValues
 
containsAsync(Object) - Method in class org.redisson.RedissonTransferQueue
 
containsAsync(Object) - Method in class org.redisson.transaction.BaseTransactionalSet
 
containsAsync(Object) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
containsAsync(Object) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
containsEntry(Object, Object) - Method in interface org.redisson.api.RMultimap
Returns true if this multimap contains at least one key-value pair with the key key and the value value.
containsEntry(Object, Object) - Method in interface org.redisson.api.RMultimapReactive
Returns true if this multimap contains at least one key-value pair with the key key and the value value.
containsEntry(Object, Object) - Method in interface org.redisson.api.RMultimapRx
Returns true if this multimap contains at least one key-value pair with the key key and the value value.
containsEntry(Object, Object) - Method in class org.redisson.RedissonListMultimap
 
containsEntry(Object, Object) - Method in class org.redisson.RedissonMultimap
 
containsEntryAsync(Object, Object) - Method in interface org.redisson.api.RMultimapAsync
Returns true if this multimap contains at least one key-value pair with the key key and the value value.
containsEntryAsync(Object, Object) - Method in class org.redisson.RedissonListMultimap
 
containsEntryAsync(Object, Object) - Method in class org.redisson.RedissonListMultimapCache
 
containsEntryAsync(Object, Object) - Method in class org.redisson.RedissonSetMultimap
 
containsEntryAsync(Object, Object) - Method in class org.redisson.RedissonSetMultimapCache
 
containsFlag(ClusterNodeInfo.Flag) - Method in class org.redisson.cluster.ClusterNodeInfo
 
containsKey(K) - Method in interface org.redisson.api.CacheReactive
This method returns a Boolean true/false value, depending on whether the CacheReactive has a mapping for a key k such that key.equals(k).
containsKey(K) - Method in interface org.redisson.api.CacheRx
This method returns a Boolean true/false value, depending on whether the CacheRx has a mapping for a key k such that key.equals(k).
containsKey(Object) - Method in interface org.redisson.api.RMap
Returns true if this map contains map entry mapped by specified key, otherwise false
containsKey(Object) - Method in interface org.redisson.api.RMapReactive
Returns true if this map contains map entry mapped by specified key, otherwise false
containsKey(Object) - Method in interface org.redisson.api.RMapRx
Returns true if this map contains map entry mapped by specified key, otherwise false
containsKey(Object) - Method in interface org.redisson.api.RMultimap
Returns true if this multimap contains at least one key-value pair with the key key.
containsKey(Object) - Method in interface org.redisson.api.RMultimapReactive
Returns true if this multimap contains at least one key-value pair with the key key.
containsKey(Object) - Method in interface org.redisson.api.RMultimapRx
Returns true if this multimap contains at least one key-value pair with the key key.
containsKey(Object) - Method in class org.redisson.cache.AbstractCacheMap
 
containsKey(K) - Method in class org.redisson.jcache.JCache
 
containsKey(Object) - Method in class org.redisson.misc.BiHashMap
 
containsKey(Object) - Method in class org.redisson.RedissonMap
 
containsKey(Object) - Method in class org.redisson.RedissonMultimap
 
containsKeyAsync(K) - Method in interface org.redisson.api.CacheAsync
This method returns a Boolean true/false value, depending on whether the CacheAsync has a mapping for a key k such that key.equals(k).
containsKeyAsync(Object) - Method in interface org.redisson.api.RMapAsync
Returns true if this map contains map entry mapped by specified key, otherwise false
containsKeyAsync(Object) - Method in interface org.redisson.api.RMultimapAsync
Returns true if this multimap contains at least one key-value pair with the key key.
containsKeyAsync(K) - Method in class org.redisson.jcache.JCache
 
containsKeyAsync(Object) - Method in class org.redisson.RedissonListMultimap
 
containsKeyAsync(Object) - Method in class org.redisson.RedissonListMultimapCache
 
containsKeyAsync(Object) - Method in class org.redisson.RedissonLocalCachedMap
 
containsKeyAsync(Object) - Method in class org.redisson.RedissonMap
 
containsKeyAsync(Object) - Method in class org.redisson.RedissonMapCache
 
containsKeyAsync(Object) - Method in class org.redisson.RedissonSetMultimap
 
containsKeyAsync(Object) - Method in class org.redisson.RedissonSetMultimapCache
 
containsKeyAsync(Object) - Method in class org.redisson.transaction.BaseTransactionalMap
 
containsKeyAsync(Object) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
containsKeyAsync(Object) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
containsValue(Object) - Method in interface org.redisson.api.RMap
Returns true if this map contains any map entry with specified value, otherwise false
containsValue(Object) - Method in interface org.redisson.api.RMapReactive
Returns true if this map contains any map entry with specified value, otherwise false
containsValue(Object) - Method in interface org.redisson.api.RMapRx
Returns true if this map contains any map entry with specified value, otherwise false
containsValue(Object) - Method in interface org.redisson.api.RMultimap
Returns true if this multimap contains at least one key-value pair with the value value.
containsValue(Object) - Method in interface org.redisson.api.RMultimapReactive
Returns true if this multimap contains at least one key-value pair with the value value.
containsValue(Object) - Method in interface org.redisson.api.RMultimapRx
Returns true if this multimap contains at least one key-value pair with the value value.
containsValue(Object) - Method in class org.redisson.cache.AbstractCacheMap
 
containsValue(Object) - Method in class org.redisson.misc.BiHashMap
 
containsValue(Object) - Method in class org.redisson.RedissonMap
 
containsValue(Object) - Method in class org.redisson.RedissonMultimap
 
containsValueAsync(Object) - Method in interface org.redisson.api.RMapAsync
Returns true if this map contains any map entry with specified value, otherwise false
containsValueAsync(Object) - Method in interface org.redisson.api.RMultimapAsync
Returns true if this multimap contains at least one key-value pair with the value value.
containsValueAsync(Object) - Method in class org.redisson.RedissonListMultimap
 
containsValueAsync(Object) - Method in class org.redisson.RedissonListMultimapCache
 
containsValueAsync(Object) - Method in class org.redisson.RedissonLocalCachedMap
 
containsValueAsync(Object) - Method in class org.redisson.RedissonMap
 
containsValueAsync(Object) - Method in class org.redisson.RedissonMapCache
 
containsValueAsync(Object) - Method in class org.redisson.RedissonSetMultimap
 
containsValueAsync(Object) - Method in class org.redisson.RedissonSetMultimapCache
 
containsValueAsync(Object) - Method in class org.redisson.transaction.BaseTransactionalMap
 
containsValueAsync(Object) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
containsValueAsync(Object) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.BitsSizeReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.BooleanAmountReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.BooleanNotNullReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.BooleanNullReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.BooleanNullSafeReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.BooleanNumberReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.BooleanReplayConvertor
 
convert(Object) - Method in interface org.redisson.client.protocol.convertor.Convertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.DoubleNullSafeReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.DoubleReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.EmptyConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.IntegerReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.LongReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.NumberConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.StreamIdConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.StringToListConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.TrueReplayConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.TypeConvertor
 
convert(Object) - Method in class org.redisson.client.protocol.convertor.VoidReplayConvertor
 
convertException(RFuture<V>) - Method in interface org.redisson.command.CommandAsyncExecutor
 
convertException(RFuture<V>) - Method in class org.redisson.command.CommandAsyncService
 
convertException(RFuture<T>) - Method in class org.redisson.command.RedisExecutor
 
Convertor<R> - Interface in org.redisson.client.protocol.convertor
 
convertResult(RemotePromise<Object>, Class<?>) - Method in class org.redisson.remote.AsyncRemoteProxy
 
convertResult(RemotePromise<Object>, Class<?>) - Method in class org.redisson.remote.ReactiveRemoteProxy
 
convertResult(RemotePromise<Object>, Class<?>) - Method in class org.redisson.remote.RxRemoteProxy
 
CoordinatorTask<KOut,VOut> - Class in org.redisson.mapreduce
 
CoordinatorTask() - Constructor for class org.redisson.mapreduce.CoordinatorTask
 
CoordinatorTask(BaseMapperTask<KOut, VOut>, RReducer<KOut, VOut>, String, String, Class<?>, Class<?>, RCollator<KOut, VOut, Object>, long, long) - Constructor for class org.redisson.mapreduce.CoordinatorTask
 
copy(String, String, int, int, long) - Method in interface org.redisson.api.RKeys
Copy object from source Redis instance to destination Redis instance
copy(String, String, int, int, long) - Method in interface org.redisson.api.RKeysReactive
Copy object from source Redis instance to destination Redis instance
copy(String, String, int, int, long) - Method in interface org.redisson.api.RKeysRx
Copy object from source Redis instance to destination Redis instance
copy(String, int, int, long) - Method in interface org.redisson.api.RObject
Copy object from source Redis instance to destination Redis instance
copy(String, int, int, long) - Method in interface org.redisson.api.RObjectReactive
Copy object from source Redis instance to destination Redis instance
copy(String, int, int, long) - Method in interface org.redisson.api.RObjectRx
Copy object from source Redis instance to destination Redis instance
copy(ClassLoader, Codec) - Static method in class org.redisson.client.codec.BaseCodec
 
copy() - Method in class org.redisson.codec.AvroJacksonCodec.AvroExtendedMapper
 
copy() - Method in class org.redisson.liveobject.misc.AdvBeanCopy
 
copy(String, String, int, int, long) - Method in class org.redisson.RedissonKeys
 
copy(String, int, int, long) - Method in class org.redisson.RedissonObject
 
copyAsync(String, String, int, int, long) - Method in interface org.redisson.api.RKeysAsync
Copy object from source Redis instance to destination Redis instance in async mode
copyAsync(String, int, int, long) - Method in interface org.redisson.api.RObjectAsync
Copy object from source Redis instance to destination Redis instance in async mode
copyAsync(String, String, int, int, long) - Method in class org.redisson.RedissonKeys
 
copyAsync(String, int, int, long) - Method in class org.redisson.RedissonObject
 
copySlots() - Method in class org.redisson.cluster.ClusterPartition
 
count() - Method in interface org.redisson.api.RBloomFilter
Calculates probabilistic number of elements already added to Bloom filter.
count() - Method in interface org.redisson.api.RHyperLogLog
Returns approximated number of unique elements added into this structure.
count() - Method in interface org.redisson.api.RHyperLogLogReactive
Returns approximated number of unique elements added into this structure.
count() - Method in interface org.redisson.api.RHyperLogLogRx
Returns approximated number of unique elements added into this structure.
count() - Method in interface org.redisson.api.RKeys
Returns the number of keys in the currently-selected database
count() - Method in interface org.redisson.api.RKeysReactive
Returns the number of keys in the currently-selected database
count() - Method in interface org.redisson.api.RKeysRx
Returns the number of keys in the currently-selected database
count(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Returns the number of elements between fromElement and toElement.
count(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
Returns the number of elements between fromElement and toElement.
count(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetRx
Returns the number of elements between fromElement and toElement.
count(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSet
Returns the number of elements with a score between startScore and endScore.
count(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns the number of elements with a score between startScore and endScore.
count(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns the number of elements with a score between startScore and endScore.
count() - Method in class org.redisson.RedissonBloomFilter
 
count() - Method in class org.redisson.RedissonHyperLogLog
 
count() - Method in class org.redisson.RedissonKeys
 
count(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
count(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
CountableListener<T> - Class in org.redisson.misc
 
CountableListener() - Constructor for class org.redisson.misc.CountableListener
 
CountableListener(RPromise<T>, T) - Constructor for class org.redisson.misc.CountableListener
 
CountableListener(RPromise<T>, T, int) - Constructor for class org.redisson.misc.CountableListener
 
countActiveWorkers() - Method in interface org.redisson.api.RExecutorService
Returns active workers amount available for tasks execution.
countActiveWorkers() - Method in class org.redisson.RedissonExecutorService
 
countAsync() - Method in interface org.redisson.api.RHyperLogLogAsync
Returns approximated number of unique elements added into this structure.
countAsync() - Method in interface org.redisson.api.RKeysAsync
Returns the number of keys in the currently-selected database in async mode
countAsync(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns the number of elements between fromElement and toElement.
countAsync(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns the number of elements with a score between startScore and endScore.
countAsync() - Method in class org.redisson.RedissonHyperLogLog
 
countAsync() - Method in class org.redisson.RedissonKeys
 
countAsync(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
countAsync(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
countDown() - Method in interface org.redisson.api.RCountDownLatch
Decrements the counter of the latch.
countDown() - Method in interface org.redisson.api.RCountDownLatchReactive
Decrements the counter of the latch.
countDown() - Method in interface org.redisson.api.RCountDownLatchRx
Decrements the counter of the latch.
countDown() - Method in class org.redisson.RedissonCountDownLatch
 
countDownAsync() - Method in interface org.redisson.api.RCountDownLatchAsync
Decrements the counter of the latch.
countDownAsync() - Method in class org.redisson.RedissonCountDownLatch
 
CountDownLatchPubSub - Class in org.redisson.pubsub
 
CountDownLatchPubSub(PublishSubscribeService) - Constructor for class org.redisson.pubsub.CountDownLatchPubSub
 
counter - Variable in class org.redisson.misc.CountableListener
 
countExists(String...) - Method in interface org.redisson.api.RKeys
Checks if provided keys exist
countExists(String...) - Method in interface org.redisson.api.RKeysReactive
Checks if provided keys exist
countExists(String...) - Method in interface org.redisson.api.RKeysRx
Checks if provided keys exist
countExists(String...) - Method in class org.redisson.RedissonKeys
 
countExistsAsync(String...) - Method in interface org.redisson.api.RKeysAsync
Checks if provided keys exist
countExistsAsync(String...) - Method in class org.redisson.RedissonKeys
 
countHead(String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Returns the number of head values ending with toElement.
countHead(String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
Returns the number of head values ending with toElement.
countHead(String, boolean) - Method in interface org.redisson.api.RLexSortedSetRx
Returns the number of head values ending with toElement.
countHead(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
countHeadAsync(String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns the number of head values ending with toElement.
countHeadAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
countListeners() - Method in interface org.redisson.api.RTopic
Returns amount of registered listeners to this topic
countListeners(ChannelName) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
countListeners() - Method in class org.redisson.RedissonTopic
 
countSubscribers() - Method in interface org.redisson.api.RTopic
Returns amount of subscribers to this topic across all Redisson instances.
countSubscribers() - Method in interface org.redisson.api.RTopicReactive
Returns amount of subscribers to this topic across all Redisson instances.
countSubscribers() - Method in interface org.redisson.api.RTopicRx
Returns amount of subscribers to this topic across all Redisson instances.
countSubscribers() - Method in class org.redisson.RedissonTopic
 
countSubscribersAsync() - Method in interface org.redisson.api.RTopicAsync
Returns amount of subscribers to this topic across all Redisson instances.
countSubscribersAsync() - Method in class org.redisson.RedissonTopic
 
countTail(String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Returns the number of tail values starting with fromElement.
countTail(String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
Returns the number of tail values starting with fromElement.
countTail(String, boolean) - Method in interface org.redisson.api.RLexSortedSetRx
Returns the number of tail values starting with fromElement.
countTail(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
countTailAsync(String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns the number of tail values starting with fromElement.
countTailAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
countWith(String...) - Method in interface org.redisson.api.RHyperLogLog
Returns approximated number of unique elements added into this instances and other instances defined through otherLogNames.
countWith(String...) - Method in interface org.redisson.api.RHyperLogLogReactive
Returns approximated number of unique elements added into this instances and other instances defined through otherLogNames.
countWith(String...) - Method in interface org.redisson.api.RHyperLogLogRx
Returns approximated number of unique elements added into this instances and other instances defined through otherLogNames.
countWith(String...) - Method in class org.redisson.RedissonHyperLogLog
 
countWithAsync(String...) - Method in interface org.redisson.api.RHyperLogLogAsync
Returns approximated number of unique elements added into this instances and other instances defined through otherLogNames.
countWithAsync(String...) - Method in class org.redisson.RedissonHyperLogLog
 
CRC16 - Class in org.redisson.connection
 
crc16(byte[]) - Static method in class org.redisson.connection.CRC16
 
create(K, V, long, long) - Method in class org.redisson.cache.AbstractCacheMap
 
create(K, V, long, long) - Method in class org.redisson.cache.LFUCacheMap
 
create(K, V, long, long) - Method in class org.redisson.cache.ReferenceCacheMap
 
create(RedisClientConfig) - Static method in class org.redisson.client.RedisClient
 
create(Codec, RedisCommand<T>, Object...) - Method in class org.redisson.client.RedisConnection
 
create(Class<? extends DatagramChannel>, DnsServerAddressStreamProvider) - Method in interface org.redisson.connection.AddressResolverGroupFactory
 
create(Class<? extends DatagramChannel>, DnsServerAddressStreamProvider) - Method in class org.redisson.connection.DnsAddressResolverGroupFactory
 
create(BaseMasterSlaveServersConfig<?>) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
create(BaseMasterSlaveServersConfig<?>) - Method in class org.redisson.connection.ReplicatedConnectionManager
 
create(Class<? extends DatagramChannel>, DnsServerAddressStreamProvider) - Method in class org.redisson.connection.RoundRobinDnsAddressResolverGroupFactory
 
create(BaseMasterSlaveServersConfig<?>) - Method in class org.redisson.connection.SentinelConnectionManager
 
create(ProxyBuilder.Callback, Object, Object, Class<T>) - Static method in class org.redisson.misc.ProxyBuilder
 
create(CommandReactiveExecutor, Object, Class<T>) - Static method in class org.redisson.reactive.ReactiveProxyBuilder
 
create(CommandReactiveExecutor, Object, Object, Class<T>) - Static method in class org.redisson.reactive.ReactiveProxyBuilder
 
create() - Static method in class org.redisson.Redisson
Create sync/async Redisson instance with default config
create(Config) - Static method in class org.redisson.Redisson
Create sync/async Redisson instance with provided config
create(RedissonNodeConfig) - Static method in class org.redisson.RedissonNode
Create Redisson node instance with provided config
create(RedissonNodeConfig, RedissonClient) - Static method in class org.redisson.RedissonNode
Create Redisson node instance with provided config and Redisson instance
create(Class<T>, RemoteInvocationOptions, Class<?>) - Method in class org.redisson.remote.AsyncRemoteProxy
 
create(Class<T>, RemoteInvocationOptions) - Method in class org.redisson.remote.SyncRemoteProxy
 
create() - Method in class org.redisson.rx.RedissonMapRxIterator
 
create(CommandRxExecutor, Object, Class<T>) - Static method in class org.redisson.rx.RxProxyBuilder
 
create(CommandRxExecutor, Object, Object, Class<T>) - Static method in class org.redisson.rx.RxProxyBuilder
 
create() - Method in class org.redisson.rx.SetRxIterator
 
createAddOperation(V, long) - Method in class org.redisson.transaction.BaseTransactionalSet
 
createAddOperation(V, long) - Method in class org.redisson.transaction.TransactionalSet
 
createAddOperation(V, long) - Method in class org.redisson.transaction.TransactionalSetCache
 
createBatch(BatchOptions) - Method in interface org.redisson.api.RedissonClient
Creates batch object which could be executed later with collected group of commands in pipeline mode.
createBatch() - Method in interface org.redisson.api.RedissonClient
Creates batch object which could be executed later with collected group of commands in pipeline mode.
createBatch(BatchOptions) - Method in interface org.redisson.api.RedissonReactiveClient
Return batch object which executes group of command in pipeline.
createBatch() - Method in interface org.redisson.api.RedissonReactiveClient
Return batch object which executes group of command in pipeline.
createBatch(BatchOptions) - Method in interface org.redisson.api.RedissonRxClient
Return batch object which executes group of command in pipeline.
createBatch() - Method in interface org.redisson.api.RedissonRxClient
Return batch object which executes group of command in pipeline.
createBatch(BatchOptions) - Method in class org.redisson.Redisson
 
createBatch() - Method in class org.redisson.Redisson
 
createBatch(BatchOptions) - Method in class org.redisson.RedissonReactive
 
createBatch() - Method in class org.redisson.RedissonReactive
 
createBatch() - Method in class org.redisson.RedissonRx
 
createBatch(BatchOptions) - Method in class org.redisson.RedissonRx
 
createBeanDefinitionBuilder(Element, ParserContext, Class<?>) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
createBitSet(CommandBatchService) - Method in class org.redisson.RedissonBloomFilter
 
createCache(LocalCachedMapOptions<?, ?>) - Method in class org.redisson.cache.LocalCacheListener
 
createCache(String, C) - Method in class org.redisson.jcache.JCacheManager
 
createClient(NodeType, RedisURI, int, int, String) - Method in interface org.redisson.connection.ConnectionManager
 
createClient(NodeType, InetSocketAddress, RedisURI, String) - Method in interface org.redisson.connection.ConnectionManager
 
createClient(NodeType, RedisURI, String) - Method in interface org.redisson.connection.ConnectionManager
 
createClient(NodeType, RedisURI, String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
createClient(NodeType, InetSocketAddress, RedisURI, String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
createClient(NodeType, RedisURI, int, int, String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
createCommand(Object) - Method in interface org.redisson.SlotCallback
 
createConfig() - Method in class org.redisson.codec.MarshallingCodec
 
createConnectionManager(Config) - Static method in class org.redisson.config.ConfigSupport
 
createDefaultConfig() - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
 
createEntry(RPromise<RedissonCountDownLatchEntry>) - Method in class org.redisson.pubsub.CountDownLatchPubSub
 
createEntry(RPromise<RedissonLockEntry>) - Method in class org.redisson.pubsub.LockPubSub
 
createEntry(RPromise<RedissonLockEntry>) - Method in class org.redisson.pubsub.SemaphorePubSub
 
createGroup(String) - Method in interface org.redisson.api.RStream
Creates consumer group by name.
createGroup(String, StreamMessageId) - Method in interface org.redisson.api.RStream
Creates consumer group by name and Stream Message ID.
createGroup(String) - Method in interface org.redisson.api.RStreamReactive
Creates consumer group by name.
createGroup(String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Creates consumer group by name and stream id.
createGroup(String) - Method in interface org.redisson.api.RStreamRx
Creates consumer group by name.
createGroup(String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Creates consumer group by name and stream id.
createGroup(String) - Method in class org.redisson.RedissonStream
 
createGroup(String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
createGroupAsync(String) - Method in interface org.redisson.api.RStreamAsync
Creates consumer group by name.
createGroupAsync(String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Creates consumer group by name and stream id.
createGroupAsync(String) - Method in class org.redisson.RedissonStream
 
createGroupAsync(String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
createInstance(List<Class<?>>, ClassLoader) - Method in class org.redisson.codec.KryoCodec
Sub classes can customize the Kryo instance by overriding this method
createKryo(ClassLoader) - Method in class org.redisson.codec.Kryo5Codec
 
createLiveObject(Class<T>, Object) - Method in class org.redisson.RedissonLiveObjectService
 
createMasterSlaveEntry(MasterSlaveServersConfig) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
createMasterSlaveEntry(MasterSlaveServersConfig) - Method in class org.redisson.connection.SentinelConnectionManager
 
createMoveOperation(String, V, long) - Method in class org.redisson.transaction.BaseTransactionalSet
 
createMoveOperation(String, V, long) - Method in class org.redisson.transaction.TransactionalSet
 
createMoveOperation(String, V, long) - Method in class org.redisson.transaction.TransactionalSetCache
 
createNodeNotFoundFuture(NodeSource) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
createObject(Object, Class<?>, Class<?>, String) - Method in class org.redisson.liveobject.core.RedissonObjectBuilder
 
createObjectMapper(ClassLoader, ObjectMapper) - Static method in class org.redisson.codec.JsonJacksonCodec
 
createPromise() - Method in class org.redisson.command.CommandAsyncService
 
createPromise() - Method in class org.redisson.command.CommandBatchService
 
createPromise() - Method in class org.redisson.reactive.CommandReactiveBatchService
 
createPromise() - Method in class org.redisson.rx.CommandRxBatchService
 
createReactive() - Static method in class org.redisson.Redisson
Create Reactive Redisson instance with default config
createReactive(Config) - Static method in class org.redisson.Redisson
Create Reactive Redisson instance with provided config
createRedisConfig(NodeType, RedisURI, int, int, String) - Method in class org.redisson.cluster.ClusterConnectionManager
 
createRedisConfig(NodeType, RedisURI, int, int, String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
createRedisConfig(NodeType, RedisURI, int, int, String) - Method in class org.redisson.connection.SentinelConnectionManager
 
createRemoveOperation(Object, long) - Method in class org.redisson.transaction.BaseTransactionalSet
 
createRemoveOperation(Object, long) - Method in class org.redisson.transaction.TransactionalSet
 
createRemoveOperation(Object, long) - Method in class org.redisson.transaction.TransactionalSetCache
 
createRx() - Static method in class org.redisson.Redisson
Create Reactive Redisson instance with default config
createRx(Config) - Static method in class org.redisson.Redisson
Create Reactive Redisson instance with provided config
createSession() - Method in class org.redisson.spring.session.ReactiveRedissonSessionRepository
 
createSession() - Method in class org.redisson.spring.session.RedissonSessionRepository
 
createSyncMessage(ByteBuf, ByteBuf, CacheKey) - Method in class org.redisson.RedissonLocalCachedMap
 
createTask(String, RCollator<KOut, VOut, Object>) - Method in class org.redisson.mapreduce.RedissonCollectionMapReduce
 
createTask(String, RCollator<KOut, VOut, Object>) - Method in class org.redisson.mapreduce.RedissonMapReduce
 
createTaskParameters(Callable<?>) - Method in class org.redisson.RedissonExecutorService
 
createTaskParameters(Runnable) - Method in class org.redisson.RedissonExecutorService
 
createTransaction(TransactionOptions) - Method in interface org.redisson.api.RedissonClient
Creates transaction with READ_COMMITTED isolation level.
createTransaction(TransactionOptions) - Method in interface org.redisson.api.RedissonReactiveClient
Creates transaction with READ_COMMITTED isolation level.
createTransaction(TransactionOptions) - Method in interface org.redisson.api.RedissonRxClient
Creates transaction with READ_COMMITTED isolation level.
createTransaction(TransactionOptions) - Method in class org.redisson.Redisson
 
createTransaction(TransactionOptions) - Method in class org.redisson.RedissonReactive
 
createTransaction(TransactionOptions) - Method in class org.redisson.RedissonRx
 
CronExpression - Class in org.redisson.executor
 
CronExpression(String) - Constructor for class org.redisson.executor.CronExpression
Constructs a new CronExpression based on the specified parameter.
CronExpression(CronExpression) - Constructor for class org.redisson.executor.CronExpression
Constructs a new CronExpression as a copy of an existing instance.
CronSchedule - Class in org.redisson.api
Cron expression object used in RScheduledExecutorService.
CURRENT_COMMAND - Static variable in class org.redisson.client.handler.CommandsQueue
 
CustomObjectInputStream - Class in org.redisson.codec
 
CustomObjectInputStream(ClassLoader, InputStream) - Constructor for class org.redisson.codec.CustomObjectInputStream
 

D

dailyAtHourAndMinute(int, int) - Static method in class org.redisson.api.CronSchedule
Creates cron expression which schedule task execution every day at the given time
DAY_OF_MONTH - Static variable in class org.redisson.executor.CronExpression
 
DAY_OF_WEEK - Static variable in class org.redisson.executor.CronExpression
 
dayMap - Static variable in class org.redisson.executor.CronExpression
 
daysOfMonth - Variable in class org.redisson.executor.CronExpression
 
daysOfWeek - Variable in class org.redisson.executor.CronExpression
 
DBSIZE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
DEBUG - Static variable in interface org.redisson.client.protocol.RedisCommands
 
decCounter() - Method in class org.redisson.misc.CountableListener
 
decLevel() - Method in class org.redisson.client.handler.State
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.redisson.client.handler.CommandDecoder
 
decode(ByteBuf, CommandData<Object, Object>, List<Object>, Channel, boolean, List<CommandData<?, ?>>) - Method in class org.redisson.client.handler.CommandDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.convertor.TimeObjectDecoder
 
decode(ByteBuf, State) - Method in class org.redisson.client.protocol.decoder.ClusterNodesDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.CodecDecoder
 
decode(ByteBuf, State) - Method in interface org.redisson.client.protocol.Decoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.GeoDistanceDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.GeoDistanceMapDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.GeoPositionDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.GeoPositionMapDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.InetSocketAddressDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ListFirstObjectDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ListIteratorReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ListMultiDecoder2
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ListObjectDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ListResultReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ListScanResultReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.Long2MultiDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.MapCacheScanResultReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.MapScanResultReplayDecoder
 
decode(List<Object>, State) - Method in interface org.redisson.client.protocol.decoder.MultiDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ObjectDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ObjectFirstScoreReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ObjectListReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ObjectMapDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ObjectMapEntryReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ObjectMapReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ObjectMapReplayDecoder2
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ObjectSetReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.PendingEntryDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.PendingResultDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ScoredSortedSetPolledObjectDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ScoredSortedSetReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.ScoredSortedSetScanReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.SlotsDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.StreamConsumerInfoDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.StreamGroupInfoDecoder
 
decode(ByteBuf, State) - Method in class org.redisson.client.protocol.decoder.StreamIdDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.StreamIdListDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.StreamInfoDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.StreamObjectMapReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.StreamResultDecoder
 
decode(ByteBuf, State) - Method in class org.redisson.client.protocol.decoder.StringDataDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.StringListReplayDecoder
 
decode(ByteBuf, State) - Method in class org.redisson.client.protocol.decoder.StringMapDataDecoder
 
decode(ByteBuf, State) - Method in class org.redisson.client.protocol.decoder.StringReplayDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.decoder.TimeLongObjectDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.pubsub.PubSubMessageDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.pubsub.PubSubPatternMessageDecoder
 
decode(List<Object>, State) - Method in class org.redisson.client.protocol.pubsub.PubSubStatusDecoder
 
decode(ByteBuf, State, Decoder<?>) - Method in class org.redisson.codec.BaseEventCodec
 
decode(List<Object>, State) - Method in class org.redisson.connection.decoder.BucketsDecoder
 
decode(List<Object>, State) - Method in class org.redisson.connection.decoder.ListDrainToDecoder
 
decode(List<Object>, State) - Method in class org.redisson.connection.decoder.MapCacheGetAllDecoder
 
decode(List<Object>, State) - Method in class org.redisson.connection.decoder.MapGetAllDecoder
 
decodeCommand(Channel, ByteBuf, QueueCommand) - Method in class org.redisson.client.handler.CommandDecoder
 
decodeCommand(Channel, ByteBuf, QueueCommand) - Method in class org.redisson.client.handler.CommandPubSubDecoder
 
Decoder<R> - Interface in org.redisson.client.protocol
 
decodeResult(CommandData<Object, Object>, List<Object>, Channel, Object) - Method in class org.redisson.client.handler.CommandDecoder
 
decodeResult(CommandData<Object, Object>, List<Object>, Channel, Object) - Method in class org.redisson.client.handler.CommandPubSubDecoder
 
decorate(Element, ParserContext, BeanDefinitionBuilder, RedissonNamespaceParserSupport) - Method in class org.redisson.spring.support.DelayedQueueDecorator
 
decorate(Element, ParserContext, BeanDefinitionBuilder, RedissonNamespaceParserSupport) - Method in class org.redisson.spring.support.LocalCachedMapOptionsDecorator
 
decorate(Element, ParserContext, BeanDefinitionBuilder, RedissonNamespaceParserSupport) - Method in class org.redisson.spring.support.ReadWriteLockDecorator
 
decorate(Element, ParserContext, BeanDefinitionBuilder, RedissonNamespaceParserSupport) - Method in interface org.redisson.spring.support.RedissonNamespaceDecorator
 
decorate(Element, ParserContext, BeanDefinitionBuilder, RedissonNamespaceParserSupport) - Method in class org.redisson.spring.support.RedissonNamespaceDefaultDecorator
 
decorate(Element, ParserContext, BeanDefinitionBuilder, RedissonNamespaceParserSupport) - Method in class org.redisson.spring.support.RedissonNestedElementAwareDecorator
 
decorate(Element, ParserContext, BeanDefinitionBuilder, RedissonNamespaceParserSupport) - Method in class org.redisson.spring.support.RemoteInvocationOptionDecorator
 
DECR - Static variable in interface org.redisson.client.protocol.RedisCommands
 
decReference() - Method in class org.redisson.connection.MasterSlaveEntry
 
decrement() - Method in interface org.redisson.api.RDoubleAdder
Decrements value
decrement() - Method in interface org.redisson.api.RLongAdder
Decrements value
decrement() - Method in class org.redisson.RedissonDoubleAdder
 
decrement() - Method in class org.redisson.RedissonLongAdder
 
decrementAndGet() - Method in interface org.redisson.api.RAtomicDouble
Atomically decrements the current value by one.
decrementAndGet() - Method in interface org.redisson.api.RAtomicDoubleReactive
Atomically decrements the current value by one.
decrementAndGet() - Method in interface org.redisson.api.RAtomicDoubleRx
Atomically decrements the current value by one.
decrementAndGet() - Method in interface org.redisson.api.RAtomicLong
Atomically decrements the current value by one.
decrementAndGet() - Method in interface org.redisson.api.RAtomicLongReactive
Atomically decrements the current value by one.
decrementAndGet() - Method in interface org.redisson.api.RAtomicLongRx
Atomically decrements the current value by one.
decrementAndGet() - Method in class org.redisson.RedissonAtomicDouble
 
decrementAndGet() - Method in class org.redisson.RedissonAtomicLong
 
decrementAndGetAsync() - Method in interface org.redisson.api.RAtomicDoubleAsync
Atomically decrements the current value by one.
decrementAndGetAsync() - Method in interface org.redisson.api.RAtomicLongAsync
Atomically decrements the current value by one.
decrementAndGetAsync() - Method in class org.redisson.RedissonAtomicDouble
 
decrementAndGetAsync() - Method in class org.redisson.RedissonAtomicLong
 
decUsage() - Method in class org.redisson.QueueTransferTask
 
DEFAULT() - Constructor for class org.redisson.api.annotation.REntity.DEFAULT
 
DEFAULT() - Constructor for class org.redisson.api.annotation.RObjectField.DEFAULT
 
DefaultNamingScheme - Class in org.redisson.liveobject.resolver
 
DefaultNamingScheme(Codec) - Constructor for class org.redisson.liveobject.resolver.DefaultNamingScheme
 
DefaultNatMapper - Class in org.redisson.api
 
DefaultNatMapper() - Constructor for class org.redisson.api.DefaultNatMapper
 
DefaultNettyHook - Class in org.redisson.client
 
DefaultNettyHook() - Constructor for class org.redisson.client.DefaultNettyHook
 
DefaultReferenceCodecProvider - Class in org.redisson.codec
 
DefaultReferenceCodecProvider() - Constructor for class org.redisson.codec.DefaultReferenceCodecProvider
 
defaults() - Static method in class org.redisson.api.BatchOptions
 
defaults() - Static method in class org.redisson.api.ExecutorOptions
 
defaults() - Static method in class org.redisson.api.LocalCachedMapOptions
Creates a new instance of LocalCachedMapOptions with default options.
defaults() - Static method in class org.redisson.api.MapOptions
Creates a new instance of MapOptions with default options.
defaults() - Static method in class org.redisson.api.RemoteInvocationOptions
Creates a new instance of RemoteInvocationOptions with opinionated defaults.
defaults() - Static method in class org.redisson.api.TransactionOptions
 
defaults() - Static method in class org.redisson.api.WorkerOptions
 
DEL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
DEL_BOOL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
DEL_OBJECTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
DEL_VOID - Static variable in interface org.redisson.client.protocol.RedisCommands
 
DelayedQueueDecorator - Class in org.redisson.spring.support
 
DelayedQueueDecorator() - Constructor for class org.redisson.spring.support.DelayedQueueDecorator
 
delete(Collection<K>) - Method in interface org.redisson.api.map.MapWriter
 
delete(String...) - Method in interface org.redisson.api.RBuckets
Deprecated.
delete() - Method in interface org.redisson.api.RExecutorService
Deletes executor request queue and state objects
delete(RObject...) - Method in interface org.redisson.api.RKeys
Delete multiple objects
delete(String...) - Method in interface org.redisson.api.RKeys
Delete multiple objects by name
delete(String...) - Method in interface org.redisson.api.RKeysReactive
Delete multiple objects by name.
delete(String...) - Method in interface org.redisson.api.RKeysRx
Delete multiple objects by name.
delete(T) - Method in interface org.redisson.api.RLiveObjectService
Deletes attached object including all nested objects.
delete(Class<T>, Object) - Method in interface org.redisson.api.RLiveObjectService
Deletes object by class and id including all nested objects.
delete() - Method in interface org.redisson.api.RObject
Deletes the object
delete() - Method in interface org.redisson.api.RObjectReactive
Delete object in mode
delete() - Method in interface org.redisson.api.RObjectRx
Delete object in mode
delete(String...) - Method in class org.redisson.RedissonBuckets
 
delete() - Method in class org.redisson.RedissonExecutorService
 
delete(String...) - Method in class org.redisson.RedissonKeys
 
delete(RObject...) - Method in class org.redisson.RedissonKeys
 
delete(T) - Method in class org.redisson.RedissonLiveObjectService
 
delete(Class<T>, Object) - Method in class org.redisson.RedissonLiveObjectService
 
delete() - Method in class org.redisson.RedissonObject
 
deleteAsync(String...) - Method in interface org.redisson.api.RBucketsAsync
Deprecated.
deleteAsync() - Method in interface org.redisson.api.RExecutorServiceAsync
Deletes executor request queue and state objects
deleteAsync(RObject...) - Method in interface org.redisson.api.RKeysAsync
Delete multiple objects
deleteAsync(String...) - Method in interface org.redisson.api.RKeysAsync
Delete multiple objects by name
deleteAsync() - Method in interface org.redisson.api.RObjectAsync
Delete object in async mode
deleteAsync() - Method in class org.redisson.RedissonBloomFilter
 
deleteAsync() - Method in class org.redisson.RedissonBoundedBlockingQueue
 
deleteAsync(String...) - Method in class org.redisson.RedissonBuckets
 
deleteAsync() - Method in class org.redisson.RedissonCountDownLatch
 
deleteAsync() - Method in class org.redisson.RedissonDelayedQueue
 
deleteAsync() - Method in class org.redisson.RedissonExecutorService
 
deleteAsync() - Method in class org.redisson.RedissonFairLock
 
deleteAsync(RObject...) - Method in class org.redisson.RedissonKeys
 
deleteAsync(String...) - Method in class org.redisson.RedissonKeys
 
deleteAsync() - Method in class org.redisson.RedissonListMultimapCache
 
deleteAsync() - Method in class org.redisson.RedissonListMultimapValues
 
deleteAsync() - Method in class org.redisson.RedissonLocalCachedMap
 
deleteAsync() - Method in class org.redisson.RedissonLock
 
deleteAsync() - Method in class org.redisson.RedissonMapCache
 
deleteAsync() - Method in class org.redisson.RedissonMultimap
 
deleteAsync() - Method in class org.redisson.RedissonMultimapCache
 
deleteAsync() - Method in class org.redisson.RedissonObject
 
deleteAsync(String...) - Method in class org.redisson.RedissonObject
 
deleteAsync() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
deleteAsync() - Method in class org.redisson.RedissonPriorityQueue
 
deleteAsync() - Method in class org.redisson.RedissonRateLimiter
 
deleteAsync() - Method in class org.redisson.RedissonSetMultimapCache
 
deleteAsync() - Method in class org.redisson.RedissonSetMultimapValues
 
deleteAsync(CommandAsyncExecutor) - Method in class org.redisson.transaction.BaseTransactionalMap
 
deleteAsync(CommandAsyncExecutor, TransactionalOperation) - Method in class org.redisson.transaction.BaseTransactionalMap
 
deleteAsync(CommandAsyncExecutor) - Method in class org.redisson.transaction.BaseTransactionalSet
 
deleteAsync(CommandAsyncExecutor, TransactionalOperation) - Method in class org.redisson.transaction.BaseTransactionalSet
 
deleteAsync() - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
deleteAsync(String...) - Method in class org.redisson.transaction.RedissonTransactionalBuckets
 
deleteAsync() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
deleteAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
deleteById(String) - Method in class org.redisson.spring.session.ReactiveRedissonSessionRepository
 
deleteById(String) - Method in class org.redisson.spring.session.RedissonSessionRepository
 
deleteByPattern(String) - Method in interface org.redisson.api.RKeys
Delete multiple objects by a key pattern.
deleteByPattern(String) - Method in interface org.redisson.api.RKeysReactive
Delete multiple objects by a key pattern.
deleteByPattern(String) - Method in interface org.redisson.api.RKeysRx
Delete multiple objects by a key pattern.
deleteByPattern(String) - Method in class org.redisson.RedissonKeys
 
deleteByPatternAsync(String) - Method in interface org.redisson.api.RKeysAsync
Delete multiple objects by a key pattern.
deleteByPatternAsync(String) - Method in class org.redisson.RedissonKeys
 
DeletedObjectListener - Interface in org.redisson.api
Redisson Object Event listener for deleted event published by Redis.
DeleteOperation - Class in org.redisson.transaction.operation
 
DeleteOperation(String) - Constructor for class org.redisson.transaction.operation.DeleteOperation
 
DeleteOperation(String, String, String, long) - Constructor for class org.redisson.transaction.operation.DeleteOperation
 
deregister(Class<T>) - Method in interface org.redisson.api.RRemoteService
Deregister all workers for remote service
deregister(Class<T>) - Method in class org.redisson.RedissonRemoteService
 
deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class org.redisson.jcache.JCache
 
descendingIterator() - Method in interface org.redisson.api.RDequeReactive
 
descendingIterator() - Method in interface org.redisson.api.RDequeRx
 
descendingIterator() - Method in interface org.redisson.api.RListReactive
 
descendingIterator(int) - Method in interface org.redisson.api.RListReactive
 
descendingIterator() - Method in interface org.redisson.api.RListRx
 
descendingIterator(int) - Method in interface org.redisson.api.RListRx
 
descendingIterator() - Method in class org.redisson.reactive.RedissonListReactive
 
descendingIterator(int) - Method in class org.redisson.reactive.RedissonListReactive
 
descendingIterator() - Method in class org.redisson.RedissonDeque
 
descendingIterator() - Method in class org.redisson.RedissonPriorityDeque
 
descendingIterator() - Method in class org.redisson.rx.RedissonListRx
 
descendingIterator(int) - Method in class org.redisson.rx.RedissonListRx
 
descendingStream() - Method in interface org.redisson.api.RPriorityDeque
Returns stream of elements contained in this deque in reverse order
descendingStream() - Method in class org.redisson.RedissonPriorityDeque
 
destroy() - Method in interface org.redisson.api.RDestroyable
Destroys object when it's not necessary anymore.
destroy() - Method in class org.redisson.RedissonBaseAdder
 
destroy() - Method in class org.redisson.RedissonDelayedQueue
 
destroy() - Method in class org.redisson.RedissonLocalCachedMap
 
destroy() - Method in class org.redisson.RedissonMapCache
 
destroy() - Method in class org.redisson.RedissonSetCache
 
destroy() - Method in class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
destroyCache(String) - Method in class org.redisson.jcache.JCacheManager
 
detach(T) - Method in interface org.redisson.api.RLiveObjectService
Returns unproxied detached object for the attached object.
detach(T) - Method in class org.redisson.RedissonLiveObjectService
 
diff(String...) - Method in interface org.redisson.api.RSet
Diff sets specified by name and write to current set.
diff(String...) - Method in interface org.redisson.api.RSetReactive
Diff sets specified by name and write to current set.
diff(String...) - Method in interface org.redisson.api.RSetRx
Diff sets specified by name and write to current set.
diff(String...) - Method in class org.redisson.RedissonSet
 
diff(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
diffAsync(String...) - Method in interface org.redisson.api.RSetAsync
Diff sets specified by name and write to current set.
diffAsync(String...) - Method in class org.redisson.RedissonSet
 
diffAsync(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
diffAsync(String...) - Method in class org.redisson.transaction.BaseTransactionalSet
 
diffAsync(String...) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
direct() - Static method in interface org.redisson.api.NatMapper
Returns input RedisURI object.
DISABLED_ACK_SUFFIX - Static variable in class org.redisson.cache.LocalCacheListener
 
DISABLED_ACK_SUFFIX - Static variable in class org.redisson.RedissonLocalCachedMap
 
DISABLED_KEYS_SUFFIX - Static variable in class org.redisson.cache.LocalCacheListener
 
DISABLED_KEYS_SUFFIX - Static variable in class org.redisson.RedissonLocalCachedMap
 
DISCARD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
disconnectNode(RedisURI) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
disconnectNode(RedisClient) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
dist(V, V, GeoUnit) - Method in interface org.redisson.api.RGeo
Returns distance between members in GeoUnit units.
dist(V, V, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Returns distance between members in GeoUnit units.
dist(V, V, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Returns distance between members in GeoUnit units.
dist(V, V, GeoUnit) - Method in class org.redisson.RedissonGeo
 
distAsync(V, V, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Returns distance between members in GeoUnit units.
distAsync(V, V, GeoUnit) - Method in class org.redisson.RedissonGeo
 
DnsAddressResolverGroupFactory - Class in org.redisson.connection
 
DnsAddressResolverGroupFactory() - Constructor for class org.redisson.connection.DnsAddressResolverGroupFactory
 
DNSMonitor - Class in org.redisson.connection
DNS changes monitor.
DNSMonitor(ConnectionManager, RedisClient, Collection<RedisURI>, long, AddressResolverGroup<InetSocketAddress>) - Constructor for class org.redisson.connection.DNSMonitor
 
dnsMonitor - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
doBegin(TransactionSynchronizationManager, Object, TransactionDefinition) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
doBegin(Object, TransactionDefinition) - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
doCancel(boolean) - Method in class org.redisson.executor.RemotePromise
 
doCleanupAfterCompletion(TransactionSynchronizationManager, Object) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
doCleanupAfterCompletion(Object) - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
doCommit(TransactionSynchronizationManager, GenericReactiveTransaction) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
doCommit(DefaultTransactionStatus) - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
doGetTransaction(TransactionSynchronizationManager) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
doGetTransaction() - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
doParse(Element, BeanDefinitionBuilder) - Method in class org.redisson.spring.support.AbstractRedissonNamespaceDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.redisson.spring.support.AbstractRedissonNamespaceDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.redisson.spring.support.RedisDefinitionParser
 
doReset() - Method in class org.redisson.RedissonBaseAdder
 
doReset() - Method in class org.redisson.RedissonDoubleAdder
 
doReset() - Method in class org.redisson.RedissonLongAdder
 
doResume(TransactionSynchronizationManager, Object, Object) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
doResume(Object, Object) - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
doRollback(TransactionSynchronizationManager, GenericReactiveTransaction) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
doRollback(DefaultTransactionStatus) - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
doSetRollbackOnly(TransactionSynchronizationManager, GenericReactiveTransaction) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
doSuspend(TransactionSynchronizationManager, Object) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
doSuspend(Object) - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
DoubleCodec - Class in org.redisson.client.codec
 
DoubleCodec() - Constructor for class org.redisson.client.codec.DoubleCodec
 
DoubleNullSafeReplayConvertor - Class in org.redisson.client.protocol.convertor
 
DoubleNullSafeReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.DoubleNullSafeReplayConvertor
 
DoubleReplayConvertor - Class in org.redisson.client.protocol.convertor
 
DoubleReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.DoubleReplayConvertor
 
drainPermits() - Method in interface org.redisson.api.RSemaphore
Acquires and returns all permits that are immediately available.
drainPermits() - Method in interface org.redisson.api.RSemaphoreReactive
Acquires and returns all permits that are immediately available.
drainPermits() - Method in interface org.redisson.api.RSemaphoreRx
Acquires and returns all permits that are immediately available.
drainPermits() - Method in class org.redisson.RedissonSemaphore
 
drainPermitsAsync() - Method in interface org.redisson.api.RSemaphoreAsync
Acquires and returns all permits that are immediately available.
drainPermitsAsync() - Method in class org.redisson.RedissonSemaphore
 
drainTo(Collection<? super V>, int) - Method in interface org.redisson.api.RBlockingQueueReactive
Removes at most the given number of available elements from this queue and adds them to the given collection in async mode.
drainTo(Collection<? super V>) - Method in interface org.redisson.api.RBlockingQueueReactive
Removes all available elements from this queue and adds them to the given collection in async mode.
drainTo(Collection<? super V>, int) - Method in interface org.redisson.api.RBlockingQueueRx
Removes at most the given number of available elements from this queue and adds them to the given collection in async mode.
drainTo(Collection<? super V>) - Method in interface org.redisson.api.RBlockingQueueRx
Removes all available elements from this queue and adds them to the given collection in async mode.
drainTo(Collection<? super V>) - Method in class org.redisson.RedissonBlockingDeque
 
drainTo(Collection<? super V>, int) - Method in class org.redisson.RedissonBlockingDeque
 
drainTo(Collection<? super V>) - Method in class org.redisson.RedissonBlockingQueue
 
drainTo(Collection<? super V>, int) - Method in class org.redisson.RedissonBlockingQueue
 
drainTo(Collection<? super V>) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
drainTo(Collection<? super V>, int) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
drainTo(Collection<? super V>) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
drainTo(Collection<? super V>, int) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
drainTo(Collection<? super V>) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
drainTo(Collection<? super V>, int) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
drainTo(Collection<? super V>) - Method in class org.redisson.RedissonTransferQueue
 
drainTo(Collection<? super V>, int) - Method in class org.redisson.RedissonTransferQueue
 
drainToAsync(Collection<? super V>, int) - Method in interface org.redisson.api.RBlockingQueueAsync
Removes at most the given number of available elements from this queue and adds them to the given collection in async mode.
drainToAsync(Collection<? super V>) - Method in interface org.redisson.api.RBlockingQueueAsync
Removes all available elements from this queue and adds them to the given collection in async mode.
drainToAsync(Collection<? super V>) - Method in class org.redisson.RedissonBlockingDeque
 
drainToAsync(Collection<? super V>, int) - Method in class org.redisson.RedissonBlockingDeque
 
drainToAsync(Collection<? super V>) - Method in class org.redisson.RedissonBlockingQueue
 
drainToAsync(Collection<? super V>, int) - Method in class org.redisson.RedissonBlockingQueue
 
drainToAsync(Collection<? super V>) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
drainToAsync(Collection<? super V>, int) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
drainToAsync(Collection<? super V>) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
drainToAsync(Collection<? super V>, int) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
drainToAsync(Collection<? super V>) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
drainToAsync(Collection<? super V>, int) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
drainToAsync(Collection<? super V>) - Method in class org.redisson.RedissonTransferQueue
 
drainToAsync(Collection<? super V>, int) - Method in class org.redisson.RedissonTransferQueue
 
DUMMY_TIMEOUT - Static variable in class org.redisson.connection.MasterSlaveConnectionManager
 
dump() - Method in interface org.redisson.api.RObject
Returns dump of object
dump() - Method in interface org.redisson.api.RObjectReactive
Returns dump of object
dump() - Method in interface org.redisson.api.RObjectRx
Returns dump of object
DUMP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
dump() - Method in class org.redisson.RedissonObject
 
dumpAsync() - Method in interface org.redisson.api.RObjectAsync
Returns dump of object
dumpAsync() - Method in class org.redisson.RedissonObject
 

E

element() - Method in class org.redisson.RedissonDelayedQueue
 
element() - Method in class org.redisson.RedissonPriorityQueue
 
element() - Method in class org.redisson.RedissonQueue
 
element() - Method in class org.redisson.RedissonTransferQueue
 
ElementsStream - Class in org.redisson.reactive
 
ElementsStream() - Constructor for class org.redisson.reactive.ElementsStream
 
ElementsStream - Class in org.redisson.rx
 
ElementsStream() - Constructor for class org.redisson.rx.ElementsStream
 
ElementsSubscribeService - Class in org.redisson
 
ElementsSubscribeService(ConnectionManager) - Constructor for class org.redisson.ElementsSubscribeService
 
emit(K, V) - Method in interface org.redisson.api.mapreduce.RCollector
Store key/value
emit(K, V) - Method in class org.redisson.mapreduce.Collector
 
EmptyConvertor<R> - Class in org.redisson.client.protocol.convertor
 
EmptyConvertor() - Constructor for class org.redisson.client.protocol.convertor.EmptyConvertor
 
EmptyStatisticsMXBean - Class in org.redisson.jcache.bean
 
EmptyStatisticsMXBean() - Constructor for class org.redisson.jcache.bean.EmptyStatisticsMXBean
 
enableManagement(String, boolean) - Method in class org.redisson.jcache.JCacheManager
 
EnableRedissonHttpSession - Annotation Type in org.redisson.spring.session.config
Enables Redisson's Spring Session implementation backed by Redis and exposes SessionRepositoryFilter as a bean named "springSessionRepositoryFilter".
enableRedissonReferenceSupport(RedissonClient) - Method in interface org.redisson.command.CommandAsyncExecutor
 
enableRedissonReferenceSupport(RedissonReactiveClient) - Method in interface org.redisson.command.CommandAsyncExecutor
 
enableRedissonReferenceSupport(RedissonRxClient) - Method in interface org.redisson.command.CommandAsyncExecutor
 
enableRedissonReferenceSupport(RedissonClient) - Method in class org.redisson.command.CommandAsyncService
 
enableRedissonReferenceSupport(RedissonReactiveClient) - Method in class org.redisson.command.CommandAsyncService
 
enableRedissonReferenceSupport(RedissonRxClient) - Method in class org.redisson.command.CommandAsyncService
 
enableRedissonReferenceSupport(RedissonReactiveClient) - Method in class org.redisson.reactive.CommandReactiveBatchService
 
enableRedissonReferenceSupport(RedissonReactiveClient) - Method in class org.redisson.reactive.RedissonBatchReactive
 
enableRedissonReferenceSupport() - Method in class org.redisson.Redisson
 
enableRedissonReferenceSupport(Redisson) - Method in class org.redisson.RedissonBatch
 
enableRedissonReferenceSupport() - Method in class org.redisson.RedissonReactive
 
enableRedissonReferenceSupport() - Method in class org.redisson.RedissonRx
 
enableRedissonReferenceSupport(RedissonRxClient) - Method in class org.redisson.rx.CommandRxBatchService
 
enableRedissonReferenceSupport(RedissonRxClient) - Method in class org.redisson.rx.RedissonBatchRx
 
EnableRedissonWebSession - Annotation Type in org.redisson.spring.session.config
Enables Redisson's Spring Session implementation backed by Redis and exposes WebSessionManager as a bean named "webSessionManager".
enableStatistics(String, boolean) - Method in class org.redisson.jcache.JCacheManager
 
encode(ChannelHandlerContext, CommandsData, ByteBuf) - Method in class org.redisson.client.handler.CommandBatchEncoder
 
encode(ChannelHandlerContext, CommandData<?, ?>, ByteBuf) - Method in class org.redisson.client.handler.CommandEncoder
 
encode(Object) - Method in interface org.redisson.client.protocol.Encoder
 
encode(Object) - Method in class org.redisson.RedissonLocalCachedMap
 
encode(Object...) - Method in class org.redisson.RedissonObject
 
encode(Collection<?>) - Method in class org.redisson.RedissonObject
 
encode(Collection<Object>, Collection<?>) - Method in class org.redisson.RedissonObject
 
encode(Object) - Method in class org.redisson.RedissonObject
 
encode(Object) - Method in class org.redisson.RedissonTopic
 
encode(Object) - Method in class org.redisson.remote.BaseRemoteService
 
encodeMapKey(Object) - Method in class org.redisson.RedissonObject
 
encodeMapKeys(Collection<Object>, Collection<?>) - Method in class org.redisson.RedissonObject
 
encodeMapValue(Object) - Method in class org.redisson.RedissonObject
 
encodeMapValues(Collection<Object>, Collection<?>) - Method in class org.redisson.RedissonObject
 
Encoder - Interface in org.redisson.client.protocol
 
entries() - Method in interface org.redisson.api.RMultimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
entries() - Method in interface org.redisson.api.RSetMultimap
Returns a view collection of all key-value pairs contained in this multimap, as Map.Entry instances.
entries() - Method in class org.redisson.RedissonMultimap
 
entries() - Method in class org.redisson.RedissonSetMultimap
 
Entry(StreamMessageId, Map<K, V>) - Constructor for class org.redisson.api.StreamInfo.Entry
 
Entry(byte[], byte[]) - Constructor for class org.redisson.cache.LocalCachedMapUpdate.Entry
 
Entry(ByteBuf, ByteBuf) - Constructor for class org.redisson.cache.LocalCachedMapUpdate.Entry
 
Entry() - Constructor for class org.redisson.command.CommandBatchService.Entry
 
Entry(int, int, Collection<? extends RedisConnection>, AsyncSemaphore, Function<RedisConnection, Boolean>) - Constructor for class org.redisson.connection.IdleConnectionWatcher.Entry
 
Entry(int) - Constructor for class org.redisson.RedissonRemoteService.Entry
 
EntryCreatedListener<K,V> - Interface in org.redisson.api.map.event
 
EntryEvent<K,V> - Class in org.redisson.api.map.event
 
EntryEvent(RMapCache<K, V>, EntryEvent.Type, K, V, V) - Constructor for class org.redisson.api.map.event.EntryEvent
 
EntryEvent.Type - Enum in org.redisson.api.map.event
 
EntryExpiredListener<K,V> - Interface in org.redisson.api.map.event
 
entryIterator() - Method in interface org.redisson.api.RMapReactive
Returns iterator over map entries collection.
entryIterator(int) - Method in interface org.redisson.api.RMapReactive
Returns iterator over map entries collection.
entryIterator(String) - Method in interface org.redisson.api.RMapReactive
Returns iterator over map entries collection.
entryIterator(String, int) - Method in interface org.redisson.api.RMapReactive
Returns iterator over map entries collection.
entryIterator() - Method in interface org.redisson.api.RMapRx
Returns iterator over map entries collection.
entryIterator(int) - Method in interface org.redisson.api.RMapRx
Returns iterator over map entries collection.
entryIterator(String) - Method in interface org.redisson.api.RMapRx
Returns iterator over map entries collection.
entryIterator(String, int) - Method in interface org.redisson.api.RMapRx
Returns iterator over map entries collection.
entryIterator() - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
entryIterator(int) - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
entryIterator(String) - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
entryIterator(String, int) - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
entryIterator() - Method in class org.redisson.reactive.RedissonMapReactive
 
entryIterator(int) - Method in class org.redisson.reactive.RedissonMapReactive
 
entryIterator(String) - Method in class org.redisson.reactive.RedissonMapReactive
 
entryIterator(String, int) - Method in class org.redisson.reactive.RedissonMapReactive
 
entryIterator(String, int) - Method in class org.redisson.RedissonMap
 
entryIterator() - Method in class org.redisson.rx.RedissonMapCacheRx
 
entryIterator(int) - Method in class org.redisson.rx.RedissonMapCacheRx
 
entryIterator(String) - Method in class org.redisson.rx.RedissonMapCacheRx
 
entryIterator(String, int) - Method in class org.redisson.rx.RedissonMapCacheRx
 
entryIterator() - Method in class org.redisson.rx.RedissonMapRx
 
entryIterator(int) - Method in class org.redisson.rx.RedissonMapRx
 
entryIterator(String) - Method in class org.redisson.rx.RedissonMapRx
 
entryIterator(String, int) - Method in class org.redisson.rx.RedissonMapRx
 
entryRange(int, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns entries (value and its score) by rank range.
entryRange(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSet
Returns all entries (value and its score) between startScore and endScore.
entryRange(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns all entries (value and its score) between startScore and endScore.
entryRange(int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns entries (value and its score) by rank range.
entryRange(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns all entries (value and its score) between startScore and endScore.
entryRange(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns all entries (value and its score) between startScore and endScore.
entryRange(int, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns entries (value and its score) by rank range.
entryRange(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns all entries (value and its score) between startScore and endScore.
entryRange(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns all entries (value and its score) between startScore and endScore.
entryRange(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRange(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRange(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRangeAsync(int, int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns entries (value and its score) by rank range.
entryRangeAsync(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns all entries (value and its score) between startScore and endScore.
entryRangeAsync(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns all entries (value and its score) between startScore and endScore.
entryRangeAsync(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRangeAsync(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRangeAsync(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRangeReversed(int, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns entries (value and its score) by rank range in reverse order.
entryRangeReversed(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSet
Returns all entries (value and its score) between startScore and endScore in reversed order.
entryRangeReversed(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns all entries (value and its score) between startScore and endScore in reversed order.
entryRangeReversed(int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns entries (value and its score) by rank range in reverse order.
entryRangeReversed(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns all entries (value and its score) between startScore and endScore in reversed order.
entryRangeReversed(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns all entries (value and its score) between startScore and endScore in reversed order.
entryRangeReversed(int, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns entries (value and its score) by rank range in reverse order.
entryRangeReversed(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns all entries (value and its score) between startScore and endScore in reversed order.
entryRangeReversed(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns all entries (value and its score) between startScore and endScore in reversed order.
entryRangeReversed(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRangeReversed(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRangeReversed(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRangeReversedAsync(int, int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns entries (value and its score) by rank range in reverse order.
entryRangeReversedAsync(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns all entries (value and its score) between startScore and endScore in reversed order.
entryRangeReversedAsync(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns all entries (value and its score) between startScore and endScore in reversed order.
entryRangeReversedAsync(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRangeReversedAsync(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
entryRangeReversedAsync(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
EntryRemovedListener<K,V> - Interface in org.redisson.api.map.event
 
entrySet() - Method in interface org.redisson.api.RMap
Returns map entries collection.
entrySet(String) - Method in interface org.redisson.api.RMap
Returns map entries collection.
entrySet(String, int) - Method in interface org.redisson.api.RMap
Returns map entries collection.
entrySet(int) - Method in interface org.redisson.api.RMap
Returns map entries collection.
entrySet() - Method in class org.redisson.cache.AbstractCacheMap
 
entrySet() - Method in class org.redisson.misc.BiHashMap
 
entrySet() - Method in class org.redisson.RedissonMap
 
entrySet(String) - Method in class org.redisson.RedissonMap
 
entrySet(String, int) - Method in class org.redisson.RedissonMap
 
entrySet(int) - Method in class org.redisson.RedissonMap
 
EntryUpdatedListener<K,V> - Interface in org.redisson.api.map.event
 
eq(String, Object) - Static method in class org.redisson.api.condition.Conditions
Returns "EQUALS" condition which restricts property by name to defined value
EQCondition - Class in org.redisson.liveobject.condition
 
EQCondition(String, Object) - Constructor for class org.redisson.liveobject.condition.EQCondition
 
equals(Object) - Method in class org.redisson.api.GeoPosition
 
equals(Object) - Method in class org.redisson.api.StreamMessageId
 
equals(Object) - Method in class org.redisson.cache.CacheKey
 
equals(Object) - Method in class org.redisson.cache.CacheValue
 
equals(Object) - Method in class org.redisson.client.ChannelName
 
equals(Object) - Method in class org.redisson.client.handler.PubSubKey
 
equals(Object) - Method in class org.redisson.client.protocol.ScoredEntry
 
equals(Object) - Method in class org.redisson.client.protocol.Time
 
equals(Object) - Method in class org.redisson.cluster.ClusterPartition
 
equals(Object) - Method in class org.redisson.cluster.ClusterSlotRange
 
equals(Object) - Method in class org.redisson.codec.CompositeCodec
 
equals(Object) - Method in class org.redisson.connection.RedisClientEntry
 
equals(Object) - Method in class org.redisson.misc.HashValue
 
equals(Object) - Method in class org.redisson.misc.RedisURI
 
equals(Object) - Method in class org.redisson.PubSubMessageListener
 
equals(Object) - Method in class org.redisson.PubSubPatternMessageListener
 
equals(Object) - Method in class org.redisson.PubSubPatternStatusListener
 
equals(Object) - Method in class org.redisson.PubSubStatusListener
 
equals(Object) - Method in class org.redisson.redisnode.RedisNode
 
equals(Object) - Method in class org.redisson.redisnode.SentinelRedisNode
 
equals(Object) - Method in class org.redisson.RedissonList
 
equals(Object) - Method in class org.redisson.RedissonListMultimapValues
 
equals(Object) - Method in class org.redisson.RedissonMap
 
equals(Object) - Method in class org.redisson.RedissonSubList
 
equals(Object) - Method in class org.redisson.remote.RemoteServiceKey
 
equals(Object) - Method in class org.redisson.remote.RequestId
 
equals(Object) - Method in class org.redisson.transaction.HashKey
 
eval(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScript
Executes Lua script
eval(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScript
Executes Lua script
eval(RScript.Mode, String, RScript.ReturnType) - Method in interface org.redisson.api.RScript
Executes Lua script
eval(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptReactive
Executes Lua script
eval(RScript.Mode, String, RScript.ReturnType) - Method in interface org.redisson.api.RScriptReactive
Executes Lua script
eval(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptReactive
Executes Lua script
eval(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptRx
Executes Lua script
eval(RScript.Mode, String, RScript.ReturnType) - Method in interface org.redisson.api.RScriptRx
Executes Lua script
eval(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptRx
Executes Lua script
eval(RScript.Mode, String, RScript.ReturnType) - Method in class org.redisson.RedissonScript
 
eval(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in class org.redisson.RedissonScript
 
eval(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in class org.redisson.RedissonScript
 
EVAL_BOOLEAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_BOOLEAN_AMOUNT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_BOOLEAN_SAFE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_DOUBLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_FIRST_LIST - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_INTEGER - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_LIST - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_LONG - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_LONG_SAFE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_MAP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_MAP_ENTRY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_MAP_KEY_SET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_MAP_VALUE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_MAP_VALUE_LIST - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_MAP_VALUE_SET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_NULL_BOOLEAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_OBJECT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_SET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_SSCAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_STRING - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_STRING_DATA - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_VOID - Static variable in interface org.redisson.client.protocol.RedisCommands
 
EVAL_ZSCAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
evalAllAsync(boolean, RedisCommand<T>, SlotCallback<T, R>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
evalAsync(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptAsync
Executes Lua script
evalAsync(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptAsync
Executes Lua script
evalAsync(RScript.Mode, String, RScript.ReturnType) - Method in interface org.redisson.api.RScriptAsync
Executes Lua script
evalAsync(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in class org.redisson.RedissonScript
 
evalAsync(RScript.Mode, String, RScript.ReturnType) - Method in class org.redisson.RedissonScript
 
evalAsync(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in class org.redisson.RedissonScript
 
evalRead(String, RedisCommand<T>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandSyncExecutor
 
evalRead(String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandSyncExecutor
 
evalRead(String, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandSyncService
 
evalRead(String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandSyncService
 
evalReadAsync(RedisClient, String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
evalReadAsync(String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
evalReadAsync(MasterSlaveEntry, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
evalReadAsync(String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
evalReadAsync(MasterSlaveEntry, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
evalReadAsync(RedisClient, String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
evalSha(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScript
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalSha(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScript
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalSha(RScript.Mode, String, RScript.ReturnType) - Method in interface org.redisson.api.RScript
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalSha(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptReactive
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalSha(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptReactive
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalSha(RScript.Mode, String, RScript.ReturnType) - Method in interface org.redisson.api.RScriptReactive
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalSha(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptRx
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalSha(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptRx
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalSha(RScript.Mode, String, RScript.ReturnType) - Method in interface org.redisson.api.RScriptRx
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalSha(RScript.Mode, String, RScript.ReturnType) - Method in class org.redisson.RedissonScript
 
evalSha(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in class org.redisson.RedissonScript
 
evalSha(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in class org.redisson.RedissonScript
 
evalShaAsync(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptAsync
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalShaAsync(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in interface org.redisson.api.RScriptAsync
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalShaAsync(RScript.Mode, String, RScript.ReturnType) - Method in interface org.redisson.api.RScriptAsync
Executes Lua script stored in Redis scripts cache by SHA-1 digest
evalShaAsync(RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in class org.redisson.RedissonScript
 
evalShaAsync(String, RScript.Mode, Codec, String, RScript.ReturnType, List<Object>, Object...) - Method in class org.redisson.RedissonScript
 
evalShaAsync(RScript.Mode, String, RScript.ReturnType) - Method in class org.redisson.RedissonScript
 
evalShaAsync(String, RScript.Mode, String, RScript.ReturnType, List<Object>, Object...) - Method in class org.redisson.RedissonScript
 
evalWrite(String, RedisCommand<T>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandSyncExecutor
 
evalWrite(String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandSyncExecutor
 
evalWrite(String, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandSyncService
 
evalWrite(String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandSyncService
 
evalWriteAllAsync(RedisCommand<T>, SlotCallback<T, R>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
evalWriteAllAsync(RedisCommand<T>, SlotCallback<T, R>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
evalWriteAsync(String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
evalWriteAsync(MasterSlaveEntry, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
evalWriteAsync(String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
evalWriteAsync(MasterSlaveEntry, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
evalWriteAsync(String, Codec, RedisCommand<T>, String, List<Object>, Object...) - Method in class org.redisson.RedissonLock
 
evict(Object) - Method in class org.redisson.spring.cache.RedissonCache
 
evictionCount() - Method in class org.redisson.spring.cache.RedissonCacheMetrics
 
evictionPolicy(LocalCachedMapOptions.EvictionPolicy) - Method in class org.redisson.api.LocalCachedMapOptions
Defines local cache eviction policy.
EvictionScheduler - Class in org.redisson.eviction
Eviction scheduler.
EvictionScheduler(CommandAsyncExecutor) - Constructor for class org.redisson.eviction.EvictionScheduler
 
evictionScheduler - Variable in class org.redisson.Redisson
 
evictionScheduler - Variable in class org.redisson.RedissonReactive
 
evictionScheduler - Variable in class org.redisson.RedissonRx
 
exceptionally(Function<Throwable, ? extends T>) - Method in class org.redisson.misc.PromiseDelegator
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.redisson.client.handler.CommandsQueue
 
EXEC - Static variable in interface org.redisson.client.protocol.RedisCommands
 
execute() - Method in interface org.redisson.api.mapreduce.RMapReduceExecutor
Executes MapReduce process across Redisson Nodes
execute(String) - Method in interface org.redisson.api.mapreduce.RMapReduceExecutor
Executes MapReduce process across Redisson Nodes and stores result in map with resultMapName
execute(RCollator<KOut, VOut, R>) - Method in interface org.redisson.api.mapreduce.RMapReduceExecutor
Executes MapReduce process across Redisson Nodes and collides result using defined collator
execute() - Method in interface org.redisson.api.RBatch
Executes all operations accumulated during async methods invocations.
execute() - Method in interface org.redisson.api.RBatchReactive
Executes all operations accumulated during Reactive methods invocations Reactivehronously.
execute() - Method in interface org.redisson.api.RBatchRx
Executes all operations accumulated during Reactive methods invocations Reactivehronously.
execute(Runnable...) - Method in interface org.redisson.api.RExecutorService
Submits tasks batch for execution synchronously.
execute() - Method in class org.redisson.command.CommandBatchService
 
execute() - Method in class org.redisson.command.RedisBatchExecutor
 
execute() - Method in class org.redisson.command.RedisExecutor
 
execute() - Method in class org.redisson.command.RedisQueuedBatchExecutor
 
execute(Method, Object, Method, Object[]) - Method in interface org.redisson.misc.ProxyBuilder.Callback
 
execute() - Method in class org.redisson.reactive.RedissonBatchReactive
 
execute() - Method in class org.redisson.RedissonBatch
 
execute(Runnable) - Method in class org.redisson.RedissonExecutorService
 
execute(Runnable...) - Method in class org.redisson.RedissonExecutorService
 
execute() - Method in class org.redisson.rx.RedissonBatchRx
 
executeAdd() - Method in class org.redisson.executor.TasksBatchService
 
executeAddAsync() - Method in class org.redisson.executor.TasksBatchService
 
executeAsync() - Method in interface org.redisson.api.mapreduce.RMapReduceExecutor
Executes MapReduce process across Redisson Nodes in asynchronous mode
executeAsync(String) - Method in interface org.redisson.api.mapreduce.RMapReduceExecutor
Executes MapReduce process across Redisson Nodes in asynchronous mode and stores result in map with resultMapName
executeAsync(RCollator<KOut, VOut, R>) - Method in interface org.redisson.api.mapreduce.RMapReduceExecutor
Executes MapReduce process across Redisson Nodes in asynchronous mode and collides result using defined collator
executeAsync() - Method in interface org.redisson.api.RBatch
Executes all operations accumulated during async methods invocations asynchronously.
executeAsync() - Method in class org.redisson.command.CommandBatchService
 
executeAsync() - Method in class org.redisson.reactive.CommandReactiveBatchService
 
executeAsync() - Method in class org.redisson.RedissonBatch
 
executeAsync() - Method in class org.redisson.rx.CommandRxBatchService
 
executeAsyncVoid() - Method in class org.redisson.command.CommandBatchService
 
executeCallable(TaskParameters) - Method in interface org.redisson.executor.RemoteExecutorService
 
executeCallable(TaskParameters) - Method in interface org.redisson.executor.RemoteExecutorServiceAsync
 
executeCallable(TaskParameters) - Method in class org.redisson.executor.TasksRunnerService
 
executeLocked(RPromise<R>, K, Runnable) - Method in class org.redisson.transaction.BaseTransactionalMap
 
executeLocked(RPromise<R>, Runnable, RLock) - Method in class org.redisson.transaction.BaseTransactionalMap
 
executeLocked(RPromise<R>, Runnable, Collection<K>) - Method in class org.redisson.transaction.BaseTransactionalMap
 
executeLocked(RPromise<R>, Object, Runnable) - Method in class org.redisson.transaction.BaseTransactionalSet
 
executeLocked(RPromise<R>, Runnable, RLock) - Method in class org.redisson.transaction.BaseTransactionalSet
 
executeLocked(RPromise<R>, Runnable, Collection<?>) - Method in class org.redisson.transaction.BaseTransactionalSet
 
executeLocked(RPromise<R>, Runnable) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
executeLocked(RPromise<R>, Runnable, Collection<String>) - Method in class org.redisson.transaction.RedissonTransactionalBuckets
 
executeRunnable(TaskParameters) - Method in interface org.redisson.executor.RemoteExecutorService
 
executeRunnable(TaskParameters) - Method in interface org.redisson.executor.RemoteExecutorServiceAsync
 
executeRunnable(TaskParameters, boolean) - Method in class org.redisson.executor.TasksRunnerService
 
executeRunnable(TaskParameters) - Method in class org.redisson.executor.TasksRunnerService
 
executionMode(BatchOptions.ExecutionMode) - Method in class org.redisson.api.BatchOptions
Sets execution mode.
executorId - Variable in class org.redisson.remote.BaseRemoteService
 
ExecutorOptions - Class in org.redisson.api
Configuration for ExecutorService.
executorService(ExecutorService) - Method in class org.redisson.api.WorkerOptions
Defines custom ExecutorService to execute tasks.
executorService - Variable in class org.redisson.executor.RedissonCompletionService
 
EXISTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
exists() - Method in class org.redisson.jcache.JMutableEntry
 
EXISTS_LONG - Static variable in interface org.redisson.client.protocol.RedisCommands
 
expectAckWithin(long) - Method in class org.redisson.api.RemoteInvocationOptions
Defines ACK timeout
expectAckWithin(long, TimeUnit) - Method in class org.redisson.api.RemoteInvocationOptions
Defines ACK timeout
expectResultWithin(long) - Method in class org.redisson.api.RemoteInvocationOptions
Defines execution timeout
expectResultWithin(long, TimeUnit) - Method in class org.redisson.api.RemoteInvocationOptions
Defines execution timeout
ExpirableValue - Interface in org.redisson.cache
 
ExpirationEntry() - Constructor for class org.redisson.RedissonLock.ExpirationEntry
 
expire(long, TimeUnit) - Method in interface org.redisson.api.RExpirable
Set a timeout for object.
expire(long, TimeUnit) - Method in interface org.redisson.api.RExpirableReactive
Set a timeout for object in mode.
expire(long, TimeUnit) - Method in interface org.redisson.api.RExpirableRx
Set a timeout for object in mode.
expire(String, long, TimeUnit) - Method in interface org.redisson.api.RKeys
Set a timeout for object.
expire(String, long, TimeUnit) - Method in interface org.redisson.api.RKeysReactive
Set a timeout for object.
expire(String, long, TimeUnit) - Method in interface org.redisson.api.RKeysRx
Set a timeout for object.
expire(String, long, TimeUnit) - Method in class org.redisson.RedissonKeys
 
expireAsync(long, TimeUnit) - Method in interface org.redisson.api.RExpirableAsync
Set a timeout for object in async mode.
expireAsync(String, long, TimeUnit) - Method in interface org.redisson.api.RKeysAsync
Set a timeout for object.
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonBloomFilter
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonDelayedQueue
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonFairLock
 
expireAsync(String, long, TimeUnit) - Method in class org.redisson.RedissonKeys
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonListMultimapCache
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonListMultimapValues
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonMultimap
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonMultimapCache
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonPriorityQueue
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonSetMultimapCache
 
expireAsync(long, TimeUnit) - Method in class org.redisson.RedissonSetMultimapValues
 
expireAsync(long, TimeUnit) - Method in class org.redisson.transaction.BaseTransactionalObject
 
expireAsync(long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
expireAsync(long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
expireAsync(long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
expireAsync(long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
expireAsync(long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
expireAt(long) - Method in interface org.redisson.api.RExpirable
Set an expire date for object.
expireAt(Date) - Method in interface org.redisson.api.RExpirable
Set an expire date for object.
expireAt(Date) - Method in interface org.redisson.api.RExpirableReactive
Set an expire date for object in mode.
expireAt(long) - Method in interface org.redisson.api.RExpirableReactive
Set an expire date for object in mode.
expireAt(Date) - Method in interface org.redisson.api.RExpirableRx
Set an expire date for object in mode.
expireAt(long) - Method in interface org.redisson.api.RExpirableRx
Set an expire date for object in mode.
expireAt(String, long) - Method in interface org.redisson.api.RKeys
Set an expire date for object.
expireAt(String, long) - Method in interface org.redisson.api.RKeysReactive
Set an expire date for object.
expireAt(String, long) - Method in interface org.redisson.api.RKeysRx
Set an expire date for object.
expireAt(String, long) - Method in class org.redisson.RedissonKeys
 
expireAtAsync(Date) - Method in interface org.redisson.api.RExpirableAsync
Set an expire date for object in async mode.
expireAtAsync(long) - Method in interface org.redisson.api.RExpirableAsync
Set an expire date for object in async mode.
expireAtAsync(String, long) - Method in interface org.redisson.api.RKeysAsync
Set an expire date for object.
expireAtAsync(long) - Method in class org.redisson.RedissonBloomFilter
 
expireAtAsync(long) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
expireAtAsync(long) - Method in class org.redisson.RedissonDelayedQueue
 
expireAtAsync(long) - Method in class org.redisson.RedissonFairLock
 
expireAtAsync(String, long) - Method in class org.redisson.RedissonKeys
 
expireAtAsync(long) - Method in class org.redisson.RedissonListMultimapCache
 
expireAtAsync(long) - Method in class org.redisson.RedissonListMultimapValues
 
expireAtAsync(long) - Method in class org.redisson.RedissonMapCache
 
expireAtAsync(long) - Method in class org.redisson.RedissonMultimap
 
expireAtAsync(long) - Method in class org.redisson.RedissonMultimapCache
 
expireAtAsync(long) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
expireAtAsync(long) - Method in class org.redisson.RedissonPriorityQueue
 
expireAtAsync(long) - Method in class org.redisson.RedissonSetMultimapCache
 
expireAtAsync(long) - Method in class org.redisson.RedissonSetMultimapValues
 
expireAtAsync(Date) - Method in class org.redisson.transaction.BaseTransactionalObject
 
expireAtAsync(long) - Method in class org.redisson.transaction.BaseTransactionalObject
 
expireAtAsync(Date) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
expireAtAsync(long) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
expireAtAsync(Date) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
expireAtAsync(long) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
expireAtAsync(Date) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
expireAtAsync(long) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
expireAtAsync(Date) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
expireAtAsync(long) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
expireAtAsync(Date) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
expireAtAsync(long) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
ExpiredObjectListener - Interface in org.redisson.api
Redisson Object Event listener for expired event published by Redis.
expireKey(K, long, TimeUnit) - Method in interface org.redisson.api.RMultimapCache
Set a timeout for key.
expireKey(K, long, TimeUnit) - Method in class org.redisson.RedissonListMultimapCache
 
expireKey(K, long, TimeUnit) - Method in class org.redisson.RedissonSetMultimapCache
 
expireKeyAsync(K, long, TimeUnit) - Method in interface org.redisson.api.RMultimapCacheAsync
Set a timeout for key in async mode.
expireKeyAsync(K, long, TimeUnit) - Method in class org.redisson.RedissonListMultimapCache
 
expireKeyAsync(K, long, TimeUnit) - Method in class org.redisson.RedissonMultimapCache
 
expireKeyAsync(K, long, TimeUnit) - Method in class org.redisson.RedissonSetMultimapCache
 
expressionParsed - Variable in class org.redisson.executor.CronExpression
 

F

factoryInvoker(Element, String, String, Object[], ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
factoryInvoker(Element, Object, String, Object[], ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
factoryInvoker(String, String, Object[], ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
factoryInvoker(Object, String, Object[], ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
failedLocksLimit() - Method in class org.redisson.RedissonMultiLock
 
failedLocksLimit() - Method in class org.redisson.RedissonRedLock
 
failover(String) - Method in interface org.redisson.api.redisnode.RedisSentinel
Starts failover process for defined Redis master
failover(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
failoverAsync(String) - Method in interface org.redisson.api.redisnode.RedisSentinelAsync
Starts failover process for defined Redis master
failoverAsync(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
fastClaim(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStream
Transfers ownership of pending messages by id to a new consumer by name if idle time of messages is greater than defined value.
fastClaim(String, String, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
fastClaimAsync(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Transfers ownership of pending messages by id to a new consumer by name if idle time of messages is greater than defined value.
fastClaimAsync(String, String, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
fastPut(K, V) - Method in interface org.redisson.api.RMap
Stores the specified value mapped by specified key.
fastPut(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
Stores value mapped by key with specified time to live.
fastPut(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
Stores value mapped by key with specified time to live and max idle time.
fastPut(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheReactive
Stores value mapped by key with specified time to live.
fastPut(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheReactive
Stores value mapped by key with specified time to live and max idle time.
fastPut(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheRx
Stores value mapped by key with specified time to live.
fastPut(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheRx
Stores value mapped by key with specified time to live and max idle time.
fastPut(K, V) - Method in interface org.redisson.api.RMapReactive
Stores the specified value mapped by specified key.
fastPut(K, V) - Method in interface org.redisson.api.RMapRx
Stores the specified value mapped by specified key.
fastPut(K, V) - Method in class org.redisson.RedissonMap
 
fastPut(K, V, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
fastPut(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
fastPutAsync(K, V) - Method in interface org.redisson.api.RMapAsync
Stores the specified value mapped by specified key.
fastPutAsync(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheAsync
Stores value mapped by key with specified time to live.
fastPutAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheAsync
Stores value mapped by key with specified time to live and max idle time.
fastPutAsync(K, V) - Method in class org.redisson.RedissonMap
 
fastPutAsync(K, V, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
fastPutAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
fastPutIfAbsent(K, V) - Method in interface org.redisson.api.RMap
Stores the specified value mapped by specified key only if there is no value with specifiedkey stored before.
fastPutIfAbsent(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
If the specified key is not already associated with a value, associate it with the given value.
fastPutIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
If the specified key is not already associated with a value, associate it with the given value.
fastPutIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheReactive
If the specified key is not already associated with a value, associate it with the given value.
fastPutIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheRx
If the specified key is not already associated with a value, associate it with the given value.
fastPutIfAbsent(K, V) - Method in interface org.redisson.api.RMapReactive
Stores the specified value mapped by specified key only if there is no value with specifiedkey stored before.
fastPutIfAbsent(K, V) - Method in interface org.redisson.api.RMapRx
Stores the specified value mapped by specified key only if there is no value with specifiedkey stored before.
fastPutIfAbsent(K, V) - Method in class org.redisson.RedissonMap
 
fastPutIfAbsent(K, V, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
fastPutIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
fastPutIfAbsentAsync(K, V) - Method in interface org.redisson.api.RMapAsync
Stores the specified value mapped by specified key only if there is no value with specifiedkey stored before.
fastPutIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheAsync
If the specified key is not already associated with a value, associate it with the given value.
fastPutIfAbsentAsync(K, V) - Method in class org.redisson.RedissonLocalCachedMap
 
fastPutIfAbsentAsync(K, V) - Method in class org.redisson.RedissonMap
 
fastPutIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
fastPutIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.transaction.BaseTransactionalMapCache
 
fastPutIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
fastPutIfAbsentOperationAsync(K, V) - Method in class org.redisson.RedissonMap
 
fastPutIfAbsentOperationAsync(K, V) - Method in class org.redisson.RedissonMapCache
 
fastPutIfAbsentOperationAsync(K, V) - Method in class org.redisson.transaction.BaseTransactionalMap
 
fastPutIfAbsentOperationAsync(K, V, MapOperation) - Method in class org.redisson.transaction.BaseTransactionalMap
 
fastPutIfAbsentOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
fastPutIfAbsentOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
fastPutOperationAsync(K, V) - Method in class org.redisson.RedissonLocalCachedMap
 
fastPutOperationAsync(K, V) - Method in class org.redisson.RedissonMap
 
fastPutOperationAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
fastPutOperationAsync(K, V) - Method in class org.redisson.RedissonMapCache
 
fastPutOperationAsync(K, V) - Method in class org.redisson.transaction.BaseTransactionalMap
 
fastPutOperationAsync(K, V, MapOperation) - Method in class org.redisson.transaction.BaseTransactionalMap
 
fastPutOperationAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.transaction.BaseTransactionalMapCache
 
fastPutOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
fastPutOperationAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
fastPutOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
fastRemove(int) - Method in interface org.redisson.api.RList
Remove object by specified index
fastRemove(int) - Method in interface org.redisson.api.RListReactive
Remove object by specified index
fastRemove(int) - Method in interface org.redisson.api.RListRx
Remove object by specified index
fastRemove(K...) - Method in interface org.redisson.api.RMap
Removes map entries mapped by specified keys.
fastRemove(K...) - Method in interface org.redisson.api.RMapReactive
Removes map entries mapped by specified keys.
fastRemove(K...) - Method in interface org.redisson.api.RMapRx
Removes map entries mapped by specified keys.
fastRemove(K...) - Method in interface org.redisson.api.RMultimap
Removes keys from map by one operation Works faster than RMultimap.remove but not returning the value associated with key
fastRemove(K...) - Method in interface org.redisson.api.RMultimapReactive
Removes keys from map by one operation Works faster than RMultimap.remove but not returning the value associated with key
fastRemove(K...) - Method in interface org.redisson.api.RMultimapRx
Removes keys from map by one operation Works faster than RMultimap.remove but not returning the value associated with key
fastRemove(int) - Method in class org.redisson.RedissonList
 
fastRemove(int) - Method in class org.redisson.RedissonListMultimapValues
 
fastRemove(K...) - Method in class org.redisson.RedissonMap
 
fastRemove(K...) - Method in class org.redisson.RedissonMultimap
 
fastRemoveAsync(int) - Method in interface org.redisson.api.RListAsync
Removes element at index.
fastRemoveAsync(K...) - Method in interface org.redisson.api.RMapAsync
Removes map entries mapped by specified keys.
fastRemoveAsync(K...) - Method in interface org.redisson.api.RMultimapAsync
Removes keys from map by one operation Works faster than RMultimap.remove but not returning the value associated with key
fastRemoveAsync(int) - Method in class org.redisson.RedissonList
 
fastRemoveAsync(int) - Method in class org.redisson.RedissonListMultimapValues
 
fastRemoveAsync(K...) - Method in class org.redisson.RedissonMap
 
fastRemoveAsync(K...) - Method in class org.redisson.RedissonMultimap
 
fastRemoveAsync(List<Object>, List<Object>, RedisCommand<T>) - Method in class org.redisson.RedissonMultimap
 
fastRemoveOperationAsync(K...) - Method in class org.redisson.RedissonLocalCachedMap
 
fastRemoveOperationAsync(K...) - Method in class org.redisson.RedissonMap
 
fastRemoveOperationAsync(K...) - Method in class org.redisson.RedissonMapCache
 
fastRemoveOperationAsync(K...) - Method in class org.redisson.transaction.BaseTransactionalMap
 
fastRemoveOperationAsync(K...) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
fastRemoveOperationAsync(K...) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
fastRemoveOperationBatchAsync(K...) - Method in class org.redisson.RedissonLocalCachedMap
 
fastRemoveOperationBatchAsync(K...) - Method in class org.redisson.RedissonMap
 
fastRemoveOperationBatchAsync(K...) - Method in class org.redisson.RedissonMapCache
 
fastReplace(K, V) - Method in interface org.redisson.api.RMap
Replaces previous value with a new value mapped by specified key.
fastReplace(K, V) - Method in class org.redisson.RedissonMap
 
fastReplaceAsync(K, V) - Method in interface org.redisson.api.RMapAsync
Replaces previous value with a new value mapped by specified key.
fastReplaceAsync(K, V) - Method in class org.redisson.RedissonLocalCachedMap
 
fastReplaceAsync(K, V) - Method in class org.redisson.RedissonMap
 
fastReplaceOperationAsync(K, V) - Method in class org.redisson.RedissonLocalCachedMap
 
fastReplaceOperationAsync(K, V) - Method in class org.redisson.RedissonMap
 
fastReplaceOperationAsync(K, V) - Method in class org.redisson.RedissonMapCache
 
fastSet(int, V) - Method in interface org.redisson.api.RList
Set element at index.
fastSet(int, V) - Method in interface org.redisson.api.RListReactive
Set element at index.
fastSet(int, V) - Method in interface org.redisson.api.RListRx
Set element at index.
fastSet(int, V) - Method in class org.redisson.iterator.RedissonListIterator
 
fastSet(int, V) - Method in class org.redisson.RedissonList
 
fastSet(int, V) - Method in class org.redisson.RedissonListMultimapValues
 
fastSet(int, V) - Method in class org.redisson.RedissonSubList
 
fastSetAsync(int, V) - Method in interface org.redisson.api.RListAsync
Set element at index.
fastSetAsync(int, V) - Method in class org.redisson.RedissonList
 
fastSetAsync(int, V) - Method in class org.redisson.RedissonListMultimapValues
 
fastSetAsync(int, V) - Method in class org.redisson.RedissonSubList
 
FieldAccessorInterceptor - Class in org.redisson.liveobject.core
 
FieldAccessorInterceptor() - Constructor for class org.redisson.liveobject.core.FieldAccessorInterceptor
 
finalize128() - Method in class org.redisson.misc.HighwayHash
Computes the hash value after all bytes were processed.
finalize256() - Method in class org.redisson.misc.HighwayHash
Computes the hash value after all bytes were processed.
finalize64() - Method in class org.redisson.misc.HighwayHash
Computes the hash value after all bytes were processed.
find(Class<T>, Condition) - Method in interface org.redisson.api.RLiveObjectService
Finds the entities matches specified condition.
find(Class<?>, Condition) - Method in class org.redisson.liveobject.LiveObjectSearch
 
find(Class<T>, Condition) - Method in class org.redisson.RedissonLiveObjectService
 
findBuckets(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns a list of object holder instances by a key pattern
findBuckets(String) - Method in class org.redisson.RedissonReactive
 
findById(String) - Method in class org.redisson.spring.session.ReactiveRedissonSessionRepository
 
findById(String) - Method in class org.redisson.spring.session.RedissonSessionRepository
 
findByIndexNameAndIndexValue(String, String) - Method in class org.redisson.spring.session.RedissonSessionRepository
 
findNextWhiteSpace(int, String) - Method in class org.redisson.executor.CronExpression
 
fireConnect(InetSocketAddress) - Method in class org.redisson.connection.ConnectionEventsHub
 
fireConnected() - Method in class org.redisson.client.RedisConnection
 
fireDisconnect(InetSocketAddress) - Method in class org.redisson.connection.ConnectionEventsHub
 
fireDisconnected() - Method in class org.redisson.client.RedisConnection
 
fireDisconnected() - Method in class org.redisson.client.RedisPubSubConnection
 
first() - Method in interface org.redisson.api.RScoredSortedSet
Returns the head element or null if this sorted set is empty.
first() - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns the head element or null if this sorted set is empty.
first() - Method in interface org.redisson.api.RScoredSortedSetRx
Returns the head element or null if this sorted set is empty.
first() - Method in class org.redisson.RedissonScoredSortedSet
 
first() - Method in class org.redisson.RedissonSortedSet
 
firstAsync() - Method in interface org.redisson.api.RLexSortedSetAsync
Returns the first element.
firstAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns the head element or null if this sorted set is empty.
firstAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
firstScore() - Method in interface org.redisson.api.RScoredSortedSet
Returns score of the tail element or returns null if this sorted set is empty.
firstScore() - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns score of the head element or returns null if this sorted set is empty.
firstScore() - Method in interface org.redisson.api.RScoredSortedSetRx
Returns score of the head element or returns null if this sorted set is empty.
firstScore() - Method in class org.redisson.RedissonScoredSortedSet
 
firstScoreAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns score of the head element or returns null if this sorted set is empty.
firstScoreAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
flowable(Callable<RFuture<R>>) - Method in class org.redisson.rx.CommandRxBatchService
 
flowable(Callable<RFuture<R>>) - Method in interface org.redisson.rx.CommandRxExecutor
 
flowable(Callable<RFuture<R>>) - Method in class org.redisson.rx.CommandRxService
 
flush() - Method in class org.redisson.codec.MarshallingCodec.ByteOutputWrapper
 
flush() - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionObject
 
flush() - Method in class org.redisson.spring.transaction.RedissonTransactionObject
 
flushall() - Method in interface org.redisson.api.RKeys
Delete all keys of all existing databases
flushall() - Method in interface org.redisson.api.RKeysReactive
Delete all the keys of all the existing databases Uses FLUSHALL Redis command.
flushall() - Method in interface org.redisson.api.RKeysRx
Delete all the keys of all the existing databases Uses FLUSHALL Redis command.
FLUSHALL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
flushall() - Method in class org.redisson.RedissonKeys
 
FLUSHALL_ASYNC - Static variable in interface org.redisson.client.protocol.RedisCommands
 
flushallAsync() - Method in interface org.redisson.api.RKeysAsync
Delete all keys of all existing databases
flushallAsync() - Method in class org.redisson.RedissonKeys
 
flushallParallel() - Method in interface org.redisson.api.RKeys
Delete all keys of all existing databases in background without blocking server.
flushallParallel() - Method in interface org.redisson.api.RKeysReactive
Delete all keys of all existing databases in background without blocking server.
flushallParallel() - Method in interface org.redisson.api.RKeysRx
Delete all keys of all existing databases in background without blocking server.
flushallParallel() - Method in class org.redisson.RedissonKeys
 
flushallParallelAsync() - Method in interface org.redisson.api.RKeysAsync
Delete all keys of all existing databases in background without blocking server.
flushallParallelAsync() - Method in class org.redisson.RedissonKeys
 
flushdb() - Method in interface org.redisson.api.RKeys
Delete all keys of currently selected database
flushdb() - Method in interface org.redisson.api.RKeysReactive
Delete all the keys of the currently selected database Uses FLUSHDB Redis command.
flushdb() - Method in interface org.redisson.api.RKeysRx
Delete all the keys of the currently selected database Uses FLUSHDB Redis command.
FLUSHDB - Static variable in interface org.redisson.client.protocol.RedisCommands
 
flushdb() - Method in class org.redisson.RedissonKeys
 
FLUSHDB_ASYNC - Static variable in interface org.redisson.client.protocol.RedisCommands
 
flushdbAsync() - Method in interface org.redisson.api.RKeysAsync
Delete all keys of currently selected database
flushdbAsync() - Method in class org.redisson.RedissonKeys
 
flushdbParallel() - Method in interface org.redisson.api.RKeys
Delete all keys of currently selected database in background without blocking server.
flushdbParallel() - Method in interface org.redisson.api.RKeysReactive
Delete all keys of currently selected database in background without blocking server.
flushdbParallel() - Method in interface org.redisson.api.RKeysRx
Delete all keys of currently selected database in background without blocking server.
flushdbParallel() - Method in class org.redisson.RedissonKeys
 
flushdbParallelAsync() - Method in interface org.redisson.api.RKeysAsync
Delete all keys of currently selected database in background without blocking server.
flushdbParallelAsync() - Method in class org.redisson.RedissonKeys
 
forceFastReconnectAsync() - Method in class org.redisson.client.RedisConnection
 
forceUnlock() - Method in interface org.redisson.api.RLock
Unlocks the lock independently of its state
forceUnlock() - Method in interface org.redisson.api.RLockReactive
Unlocks the lock independently of its state
forceUnlock() - Method in interface org.redisson.api.RLockRx
Unlocks the lock independently of its state
forceUnlock() - Method in class org.redisson.RedissonLock
 
forceUnlock() - Method in class org.redisson.RedissonMultiLock
 
forceUnlockAsync() - Method in interface org.redisson.api.RLockAsync
Unlocks the lock independently of its state
forceUnlockAsync() - Method in class org.redisson.RedissonFairLock
 
forceUnlockAsync() - Method in class org.redisson.RedissonLock
 
forceUnlockAsync() - Method in class org.redisson.RedissonMultiLock
 
forceUnlockAsync() - Method in class org.redisson.RedissonReadLock
 
forceUnlockAsync() - Method in class org.redisson.RedissonWriteLock
 
free() - Method in class org.redisson.command.RedisCommonBatchExecutor
 
free() - Method in class org.redisson.command.RedisExecutor
 
free(Object[]) - Method in class org.redisson.command.RedisExecutor
 
freeze(RedisURI, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
freeze(InetSocketAddress, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
freeze(ClientConnectionsEntry, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
freezeMaster(ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.ClientConnectionsEntry
 
fromConfig(Config) - Static method in class org.redisson.jcache.configuration.RedissonConfiguration
 
fromConfig(Config, Configuration<K, V>) - Static method in class org.redisson.jcache.configuration.RedissonConfiguration
 
fromInstance(RedissonClient) - Static method in class org.redisson.jcache.configuration.RedissonConfiguration
 
fromInstance(RedissonClient, Configuration<K, V>) - Static method in class org.redisson.jcache.configuration.RedissonConfiguration
 
fromJSON(String) - Static method in class org.redisson.config.Config
Deprecated.
fromJSON(InputStream) - Static method in class org.redisson.config.Config
Deprecated.
fromJSON(File, ClassLoader) - Static method in class org.redisson.config.Config
Deprecated.
fromJSON(File) - Static method in class org.redisson.config.Config
Deprecated.
fromJSON(URL) - Static method in class org.redisson.config.Config
Deprecated.
fromJSON(Reader) - Static method in class org.redisson.config.Config
Deprecated.
fromJSON(String, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromJSON(File, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromJSON(File, Class<T>, ClassLoader) - Method in class org.redisson.config.ConfigSupport
 
fromJSON(URL, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromJSON(Reader, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromJSON(InputStream, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromJSON(File) - Static method in class org.redisson.config.RedissonNodeConfig
Read config object stored in JSON format from File
fromJSON(String) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in JSON format from String
fromJSON(InputStream) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in JSON format from InputStream
fromJSON(File) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in JSON format from File
fromJSON(URL) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in JSON format from URL
fromJSON(Reader) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in JSON format from Reader
fromJSON(String) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
fromJSON(File) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
fromJSON(URL) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
fromJSON(Reader) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
fromJSON(InputStream) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
fromReference(RedissonReference) - Method in class org.redisson.liveobject.core.RedissonObjectBuilder
 
fromStoreValue(Object) - Method in class org.redisson.spring.cache.RedissonCache
 
fromYAML(String) - Static method in class org.redisson.config.Config
Read config object stored in YAML format from String
fromYAML(InputStream) - Static method in class org.redisson.config.Config
Read config object stored in YAML format from InputStream
fromYAML(File) - Static method in class org.redisson.config.Config
Read config object stored in YAML format from File
fromYAML(File, ClassLoader) - Static method in class org.redisson.config.Config
 
fromYAML(URL) - Static method in class org.redisson.config.Config
Read config object stored in YAML format from URL
fromYAML(Reader) - Static method in class org.redisson.config.Config
Read config object stored in YAML format from Reader
fromYAML(String, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromYAML(File, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromYAML(File, Class<T>, ClassLoader) - Method in class org.redisson.config.ConfigSupport
 
fromYAML(URL, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromYAML(Reader, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromYAML(InputStream, Class<T>) - Method in class org.redisson.config.ConfigSupport
 
fromYAML(File) - Static method in class org.redisson.config.RedissonNodeConfig
Read config object stored in YAML format from File
fromYAML(String) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in YAML format from String
fromYAML(InputStream) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in YAML format from InputStream
fromYAML(File) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in YAML format from File
fromYAML(URL) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in YAML format from URL
fromYAML(Reader) - Static method in class org.redisson.spring.cache.CacheConfig
Read config objects stored in YAML format from Reader
fromYAML(String) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
fromYAML(File) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
fromYAML(URL) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
fromYAML(Reader) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
fromYAML(InputStream) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
FstCodec - Class in org.redisson.codec
Efficient and speedy serialization codec fully compatible with JDK Serialization codec.
FstCodec() - Constructor for class org.redisson.codec.FstCodec
 
FstCodec(ClassLoader) - Constructor for class org.redisson.codec.FstCodec
 
FstCodec(ClassLoader, FstCodec) - Constructor for class org.redisson.codec.FstCodec
 
FstCodec(FSTConfiguration) - Constructor for class org.redisson.codec.FstCodec
 
FstCodec(FSTConfiguration, boolean) - Constructor for class org.redisson.codec.FstCodec
 

G

ge(String, Number) - Static method in class org.redisson.api.condition.Conditions
Returns "GREATER THAN ON EQUAL" condition which restricts property by name to defined value
GECondition - Class in org.redisson.liveobject.condition
 
GECondition(String, Number) - Constructor for class org.redisson.liveobject.condition.GECondition
 
generateId() - Method in class org.redisson.cache.LocalCacheListener
 
generateId() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
generateId(BeanDefinitionBuilder, ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
generateId() - Static method in class org.redisson.transaction.RedissonTransaction
 
generateLogEntryId(byte[]) - Static method in class org.redisson.RedissonLocalCachedMap
 
generateRequestId() - Method in class org.redisson.executor.ScheduledTasksService
 
generateRequestId() - Method in class org.redisson.executor.TasksService
 
generateRequestId() - Method in class org.redisson.RedissonExecutorService
 
generateRequestId() - Method in class org.redisson.remote.BaseRemoteService
 
GEOADD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
GEODIST - Static variable in interface org.redisson.client.protocol.RedisCommands
 
GeoDistanceDecoder - Class in org.redisson.client.protocol.decoder
 
GeoDistanceDecoder() - Constructor for class org.redisson.client.protocol.decoder.GeoDistanceDecoder
 
GeoDistanceMapDecoder - Class in org.redisson.client.protocol.decoder
 
GeoDistanceMapDecoder(Codec) - Constructor for class org.redisson.client.protocol.decoder.GeoDistanceMapDecoder
 
GeoEntry - Class in org.redisson.api
 
GeoEntry(double, double, Object) - Constructor for class org.redisson.api.GeoEntry
 
GeoOrder - Enum in org.redisson.api
 
GeoPosition - Class in org.redisson.api
 
GeoPosition(double, double) - Constructor for class org.redisson.api.GeoPosition
 
GeoPositionDecoder - Class in org.redisson.client.protocol.decoder
 
GeoPositionDecoder() - Constructor for class org.redisson.client.protocol.decoder.GeoPositionDecoder
 
GeoPositionMapDecoder - Class in org.redisson.client.protocol.decoder
 
GeoPositionMapDecoder(List<Object>) - Constructor for class org.redisson.client.protocol.decoder.GeoPositionMapDecoder
 
GEORADIUS_RO - Static variable in interface org.redisson.client.protocol.RedisCommands
 
GEORADIUS_STORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
GEORADIUSBYMEMBER_RO - Static variable in interface org.redisson.client.protocol.RedisCommands
 
GEORADIUSBYMEMBER_STORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
GeoUnit - Enum in org.redisson.api
 
get(K) - Method in interface org.redisson.api.CacheReactive
This method retrieves an entry from the cache.
get(K) - Method in interface org.redisson.api.CacheRx
This method retrieves an entry from the cache.
get() - Method in interface org.redisson.api.RAtomicDouble
Returns current value.
get() - Method in interface org.redisson.api.RAtomicDoubleReactive
Returns current value.
get() - Method in interface org.redisson.api.RAtomicDoubleRx
Returns current value.
get() - Method in interface org.redisson.api.RAtomicLong
Returns current value.
get() - Method in interface org.redisson.api.RAtomicLongReactive
Returns current value.
get() - Method in interface org.redisson.api.RAtomicLongRx
Returns current value.
get(long) - Method in interface org.redisson.api.RBitSet
Returns true if bit set to one and false overwise.
get(long) - Method in interface org.redisson.api.RBitSetReactive
Returns true if bit set to one and false overwise.
get(long) - Method in interface org.redisson.api.RBitSetRx
Returns true if bit set to one and false overwise.
get() - Method in interface org.redisson.api.RBucket
Retrieves element stored in the holder.
get() - Method in interface org.redisson.api.RBucketReactive
Retrieves element stored in the holder.
get() - Method in interface org.redisson.api.RBucketRx
Retrieves element stored in the holder.
get(String...) - Method in interface org.redisson.api.RBuckets
Returns Redis object mapped by key.
get(String...) - Method in interface org.redisson.api.RBucketsReactive
Returns Redis object mapped by key.
get(String...) - Method in interface org.redisson.api.RBucketsRx
Returns Redis object mapped by key.
get(int...) - Method in interface org.redisson.api.RList
Loads elements by specified indexes
get(K) - Method in interface org.redisson.api.RListMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface org.redisson.api.RListMultimapReactive
Returns a view List of the values associated with key in this multimap, if any.
get(K) - Method in interface org.redisson.api.RListMultimapRx
Returns a view List of the values associated with key in this multimap, if any.
get(int...) - Method in interface org.redisson.api.RListReactive
Loads elements by specified indexes
get(int) - Method in interface org.redisson.api.RListReactive
Get element at index
get(int...) - Method in interface org.redisson.api.RListRx
Loads elements by specified indexes
get(int) - Method in interface org.redisson.api.RListRx
Get element at index
get(Class<T>, Object) - Method in interface org.redisson.api.RLiveObjectService
Finds the entity from Redis with the id.
get(Object) - Method in interface org.redisson.api.RMap
Returns the value mapped by defined key or null if value is absent.
get(K) - Method in interface org.redisson.api.RMapReactive
Returns the value mapped by defined key or null if value is absent.
get(K) - Method in interface org.redisson.api.RMapRx
Returns the value mapped by defined key or null if value is absent.
get(K) - Method in interface org.redisson.api.RMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(Class<T>) - Method in interface org.redisson.api.RRemoteService
Get remote service object for remote invocations.
get(Class<T>, long, TimeUnit) - Method in interface org.redisson.api.RRemoteService
Get remote service object for remote invocations with specified invocation timeout.
get(Class<T>, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RRemoteService
Get remote service object for remote invocations with specified invocation and ack timeouts This method is a shortcut for get(remoteInterface, RemoteInvocationOptions.defaults() .expectAckWithin(ackTimeout, ackTimeUnit) .expectResultWithin(executionTimeout, executionTimeUnit))
get(Class<T>, RemoteInvocationOptions) - Method in interface org.redisson.api.RRemoteService
Get remote service object for remote invocations with the specified options Note that when using the noResult() option, it is expected that the invoked method returns void, or else IllegalArgumentException will be thrown.
get(K) - Method in interface org.redisson.api.RSetMultimap
Returns a view collection of the values associated with key in this multimap, if any.
get(K) - Method in interface org.redisson.api.RSetMultimapReactive
Returns a view Set of the values associated with key in this multimap, if any.
get(K) - Method in interface org.redisson.api.RSetMultimapRx
Returns a view Set of the values associated with key in this multimap, if any.
get(Object) - Method in class org.redisson.cache.AbstractCacheMap
 
GET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
get() - Method in class org.redisson.codec.KryoCodec
 
get(RFuture<V>) - Method in interface org.redisson.command.CommandAsyncExecutor
 
get(RFuture<V>) - Method in class org.redisson.command.CommandAsyncService
 
get(RFuture<V>) - Method in interface org.redisson.command.CommandSyncExecutor
 
get(RedisCommand<?>) - Method in class org.redisson.connection.pool.MasterConnectionPool
 
get(RedisCommand<?>) - Method in class org.redisson.connection.pool.MasterPubSubConnectionPool
 
get() - Method in class org.redisson.connection.pool.PubSubConnectionPool
 
get(K) - Method in class org.redisson.jcache.JCache
 
get(Object) - Method in class org.redisson.misc.BiHashMap
 
get() - Method in class org.redisson.misc.PromiseDelegator
 
get(long, TimeUnit) - Method in class org.redisson.misc.PromiseDelegator
 
get(K) - Method in class org.redisson.reactive.RedissonListMultimapReactive
 
get(K) - Method in class org.redisson.reactive.RedissonSetMultimapReactive
 
get() - Method in class org.redisson.RedissonAtomicDouble
 
get() - Method in class org.redisson.RedissonAtomicLong
 
get(long) - Method in class org.redisson.RedissonBitSet
 
get() - Method in class org.redisson.RedissonBucket
 
get(String...) - Method in class org.redisson.RedissonBuckets
 
get(int...) - Method in class org.redisson.RedissonList
 
get(int) - Method in class org.redisson.RedissonList
 
get(K) - Method in class org.redisson.RedissonListMultimap
 
get(K) - Method in class org.redisson.RedissonListMultimapCache
 
get(int...) - Method in class org.redisson.RedissonListMultimapValues
 
get(int) - Method in class org.redisson.RedissonListMultimapValues
 
get(Class<T>, Object) - Method in class org.redisson.RedissonLiveObjectService
 
get(Object) - Method in class org.redisson.RedissonMap
 
get(RFuture<V>) - Method in class org.redisson.RedissonObject
 
get(K) - Method in class org.redisson.RedissonSetMultimap
 
get(K) - Method in class org.redisson.RedissonSetMultimapCache
 
get(int) - Method in class org.redisson.RedissonSubList
 
get(Class<T>) - Method in class org.redisson.remote.BaseRemoteService
 
get(Class<T>, long, TimeUnit) - Method in class org.redisson.remote.BaseRemoteService
 
get(Class<T>, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.remote.BaseRemoteService
 
get(Class<T>, RemoteInvocationOptions) - Method in class org.redisson.remote.BaseRemoteService
 
get(K) - Method in class org.redisson.rx.RedissonListMultimapRx
 
get(K) - Method in class org.redisson.rx.RedissonSetMultimapRx
 
get() - Method in class org.redisson.spring.cache.NullValue
 
get(Object) - Method in class org.redisson.spring.cache.RedissonCache
 
get(Object, Class<T>) - Method in class org.redisson.spring.cache.RedissonCache
 
get(Object, Callable<T>) - Method in class org.redisson.spring.cache.RedissonCache
 
GET_DOUBLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
GET_INTEGER - Static variable in interface org.redisson.client.protocol.RedisCommands
 
GET_LONG - Static variable in interface org.redisson.client.protocol.RedisCommands
 
getAckName(RequestId) - Method in class org.redisson.remote.BaseRemoteService
 
getAckName(String) - Method in class org.redisson.remote.BaseRemoteService
 
getAckTimeoutInMillis() - Method in class org.redisson.api.RemoteInvocationOptions
 
getAction() - Method in class org.redisson.jcache.JMutableEntry
 
getAddCommandExecutor() - Method in class org.redisson.executor.TasksBatchService
 
getAddCommandExecutor() - Method in class org.redisson.executor.TasksService
 
getAddFuture() - Method in class org.redisson.executor.RemotePromise
 
getAddr() - Method in interface org.redisson.api.Node
Deprecated.
Get Redis node address
getAddr() - Method in interface org.redisson.api.redisnode.RedisNode
Get Redis node address
getAddr() - Method in class org.redisson.client.RedisClient
 
getAddr() - Method in class org.redisson.client.RedisClientConfig
 
getAddr() - Method in class org.redisson.connection.NodeSource
 
getAddr() - Method in class org.redisson.connection.RedisClientEntry
 
getAddr() - Method in class org.redisson.redisnode.RedisNode
 
getAddr() - Method in class org.redisson.redisnode.SentinelRedisNode
 
getAddress() - Method in class org.redisson.client.RedisClientConfig
 
getAddress() - Method in class org.redisson.cluster.ClusterNodeInfo
 
getAddress() - Method in class org.redisson.config.SingleServerConfig
 
getAddressResolverGroupFactory() - Method in class org.redisson.config.Config
 
getAll(Set<? extends K>) - Method in interface org.redisson.api.CacheReactive
This method accepts a set of requested keys and retrieves a collection of entries from the CacheReactive, returning them as a Map of the associated values.
getAll(Set<? extends K>) - Method in interface org.redisson.api.CacheRx
This method accepts a set of requested keys and retrieves a collection of entries from the CacheRx, returning them as a Map of the associated values.
getAll(K) - Method in interface org.redisson.api.RListMultimap
Returns all elements at once.
getAll(K) - Method in interface org.redisson.api.RListMultimapReactive
Returns all elements at once.
getAll(K) - Method in interface org.redisson.api.RListMultimapRx
Returns all elements at once.
getAll(Set<K>) - Method in interface org.redisson.api.RMap
Returns map slice contained the mappings with defined keys.
getAll(Set<K>) - Method in interface org.redisson.api.RMapReactive
Returns map slice contained the mappings with defined keys.
getAll(Set<K>) - Method in interface org.redisson.api.RMapRx
Returns map slice contained the mappings with defined keys.
getAll(K) - Method in interface org.redisson.api.RMultimap
Returns all elements at once.
getAll(K) - Method in interface org.redisson.api.RSetMultimap
Returns all elements at once.
getAll(K) - Method in interface org.redisson.api.RSetMultimapReactive
Returns all elements at once.
getAll(K) - Method in interface org.redisson.api.RSetMultimapRx
Returns all elements at once.
getAll(Set<? extends K>) - Method in class org.redisson.jcache.JCache
 
getAll(K) - Method in class org.redisson.RedissonListMultimap
 
getAll(Set<K>) - Method in class org.redisson.RedissonMap
 
getAll(K) - Method in class org.redisson.RedissonMultimap
 
getAll(K) - Method in class org.redisson.RedissonSetMultimap
 
getAllAsync(Set<? extends K>) - Method in interface org.redisson.api.CacheAsync
This method accepts a set of requested keys and retrieves a collection of entries from the CacheAsync, returning them as a Map of the associated values.
getAllAsync(Set<K>) - Method in interface org.redisson.api.RMapAsync
Returns map slice contained the mappings with defined keys.
getAllAsync(K) - Method in interface org.redisson.api.RMultimapAsync
 
getAllAsync(Set<? extends K>) - Method in class org.redisson.jcache.JCache
 
getAllAsync(K) - Method in class org.redisson.RedissonListMultimap
 
getAllAsync(K) - Method in class org.redisson.RedissonListMultimapCache
 
getAllAsync(Set<K>) - Method in class org.redisson.RedissonLocalCachedMap
 
getAllAsync(Set<K>) - Method in class org.redisson.RedissonMap
 
getAllAsync(K) - Method in class org.redisson.RedissonSetMultimap
 
getAllAsync(K) - Method in class org.redisson.RedissonSetMultimapCache
 
getAllConnections() - Method in class org.redisson.connection.ClientConnectionsEntry
 
getAllEntries() - Method in class org.redisson.connection.MasterSlaveEntry
 
getAllFields(Class<?>) - Static method in class org.redisson.liveobject.misc.Introspectior
 
getAllOperationAsync(Set<K>) - Method in class org.redisson.RedissonMap
 
getAllOperationAsync(Set<K>) - Method in class org.redisson.RedissonMapCache
 
getAllOperationAsync(Set<K>) - Method in class org.redisson.transaction.BaseTransactionalMap
 
getAllOperationAsync(Set<K>) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
getAllOperationAsync(Set<K>) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
getAllSubscribeConnections() - Method in class org.redisson.connection.ClientConnectionsEntry
 
getAndAdd(double) - Method in interface org.redisson.api.RAtomicDouble
Atomically adds the given value to the current value.
getAndAdd(double) - Method in interface org.redisson.api.RAtomicDoubleReactive
Atomically adds the given value to the current value.
getAndAdd(double) - Method in interface org.redisson.api.RAtomicDoubleRx
Atomically adds the given value to the current value.
getAndAdd(long) - Method in interface org.redisson.api.RAtomicLong
Atomically adds the given value to the current value.
getAndAdd(long) - Method in interface org.redisson.api.RAtomicLongReactive
Atomically adds the given value to the current value.
getAndAdd(long) - Method in interface org.redisson.api.RAtomicLongRx
Atomically adds the given value to the current value.
getAndAdd(double) - Method in class org.redisson.RedissonAtomicDouble
 
getAndAdd(long) - Method in class org.redisson.RedissonAtomicLong
 
getAndAddAsync(double) - Method in interface org.redisson.api.RAtomicDoubleAsync
Atomically adds the given value to the current value.
getAndAddAsync(long) - Method in interface org.redisson.api.RAtomicLongAsync
Atomically adds the given value to the current value.
getAndAddAsync(double) - Method in class org.redisson.RedissonAtomicDouble
 
getAndAddAsync(long) - Method in class org.redisson.RedissonAtomicLong
 
getAndDecrement() - Method in interface org.redisson.api.RAtomicDouble
Atomically decrements by one the current value.
getAndDecrement() - Method in interface org.redisson.api.RAtomicDoubleReactive
Atomically decrements by one the current value.
getAndDecrement() - Method in interface org.redisson.api.RAtomicDoubleRx
Atomically decrements by one the current value.
getAndDecrement() - Method in interface org.redisson.api.RAtomicLong
Atomically decrements by one the current value.
getAndDecrement() - Method in interface org.redisson.api.RAtomicLongReactive
Atomically decrements by one the current value.
getAndDecrement() - Method in interface org.redisson.api.RAtomicLongRx
Atomically decrements by one the current value.
getAndDecrement() - Method in class org.redisson.RedissonAtomicDouble
 
getAndDecrement() - Method in class org.redisson.RedissonAtomicLong
 
getAndDecrementAsync() - Method in interface org.redisson.api.RAtomicDoubleAsync
Atomically decrements by one the current value.
getAndDecrementAsync() - Method in interface org.redisson.api.RAtomicLongAsync
Atomically decrements by one the current value.
getAndDecrementAsync() - Method in class org.redisson.RedissonAtomicDouble
 
getAndDecrementAsync() - Method in class org.redisson.RedissonAtomicLong
 
getAndDelete() - Method in interface org.redisson.api.RAtomicDouble
Returns and deletes object
getAndDelete() - Method in interface org.redisson.api.RAtomicDoubleReactive
Returns and deletes object
getAndDelete() - Method in interface org.redisson.api.RAtomicDoubleRx
Returns and deletes object
getAndDelete() - Method in interface org.redisson.api.RAtomicLong
Gets and deletes object
getAndDelete() - Method in interface org.redisson.api.RAtomicLongReactive
Returns and deletes object
getAndDelete() - Method in interface org.redisson.api.RAtomicLongRx
Returns and deletes object
getAndDelete() - Method in interface org.redisson.api.RBucket
Retrieves element in the holder and removes it.
getAndDelete() - Method in interface org.redisson.api.RBucketReactive
Retrieves element in the holder and removes it.
getAndDelete() - Method in interface org.redisson.api.RBucketRx
Retrieves element in the holder and removes it.
getAndDelete() - Method in class org.redisson.RedissonAtomicDouble
 
getAndDelete() - Method in class org.redisson.RedissonAtomicLong
 
getAndDelete() - Method in class org.redisson.RedissonBucket
 
getAndDeleteAsync() - Method in interface org.redisson.api.RAtomicDoubleAsync
Returns and deletes object
getAndDeleteAsync() - Method in interface org.redisson.api.RAtomicLongAsync
Returns and deletes object
getAndDeleteAsync() - Method in interface org.redisson.api.RBucketAsync
Retrieves element in the holder and removes it.
getAndDeleteAsync() - Method in class org.redisson.RedissonAtomicDouble
 
getAndDeleteAsync() - Method in class org.redisson.RedissonAtomicLong
 
getAndDeleteAsync() - Method in class org.redisson.RedissonBaseAdder
 
getAndDeleteAsync() - Method in class org.redisson.RedissonBucket
 
getAndDeleteAsync() - Method in class org.redisson.RedissonDoubleAdder
 
getAndDeleteAsync() - Method in class org.redisson.RedissonLongAdder
 
getAndDeleteAsync() - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
getAndIncrement() - Method in interface org.redisson.api.RAtomicDouble
Atomically increments the current value by one.
getAndIncrement() - Method in interface org.redisson.api.RAtomicDoubleReactive
Atomically increments the current value by one.
getAndIncrement() - Method in interface org.redisson.api.RAtomicDoubleRx
Atomically increments the current value by one.
getAndIncrement() - Method in interface org.redisson.api.RAtomicLong
Atomically increments the current value by one.
getAndIncrement() - Method in interface org.redisson.api.RAtomicLongReactive
Atomically increments the current value by one.
getAndIncrement() - Method in interface org.redisson.api.RAtomicLongRx
Atomically increments the current value by one.
getAndIncrement() - Method in class org.redisson.RedissonAtomicDouble
 
getAndIncrement() - Method in class org.redisson.RedissonAtomicLong
 
getAndIncrementAsync() - Method in interface org.redisson.api.RAtomicDoubleAsync
Atomically increments the current value by one.
getAndIncrementAsync() - Method in interface org.redisson.api.RAtomicLongAsync
Atomically increments the current value by one.
getAndIncrementAsync() - Method in class org.redisson.RedissonAtomicDouble
 
getAndIncrementAsync() - Method in class org.redisson.RedissonAtomicLong
 
getAndPut(K, V) - Method in interface org.redisson.api.CacheReactive
This method places the given key and value in the cache.
getAndPut(K, V) - Method in interface org.redisson.api.CacheRx
This method places the given key and value in the cache.
getAndPut(K, V) - Method in class org.redisson.jcache.JCache
 
getAndPutAsync(K, V) - Method in interface org.redisson.api.CacheAsync
This method places the given key and value in the cache.
getAndPutAsync(K, V) - Method in class org.redisson.jcache.JCache
 
getAndRemove(K) - Method in interface org.redisson.api.CacheReactive
This method atomically removes the entry for a key only if it is currently mapped to some value.
getAndRemove(K) - Method in interface org.redisson.api.CacheRx
This method atomically removes the entry for a key only if it is currently mapped to some value.
getAndRemove(K) - Method in class org.redisson.jcache.JCache
 
getAndRemoveAsync(K) - Method in interface org.redisson.api.CacheAsync
This method atomically removes the entry for a key only if it is currently mapped to some value.
getAndRemoveAsync(K) - Method in class org.redisson.jcache.JCache
 
getAndReplace(K, V) - Method in interface org.redisson.api.CacheReactive
This method atomically replaces a given key's value if and only if the key is currently mapped to a value.
getAndReplace(K, V) - Method in interface org.redisson.api.CacheRx
This method atomically replaces a given key's value if and only if the key is currently mapped to a value.
getAndReplace(K, V) - Method in class org.redisson.jcache.JCache
 
getAndReplaceAsync(K, V) - Method in interface org.redisson.api.CacheAsync
This method atomically replaces a given key's value if and only if the key is currently mapped to a value.
getAndReplaceAsync(K, V) - Method in class org.redisson.jcache.JCache
 
getAndSet(double) - Method in interface org.redisson.api.RAtomicDouble
Atomically sets the given value and returns the old value.
getAndSet(double) - Method in interface org.redisson.api.RAtomicDoubleReactive
Atomically sets the given value and returns the old value.
getAndSet(double) - Method in interface org.redisson.api.RAtomicDoubleRx
Atomically sets the given value and returns the old value.
getAndSet(long) - Method in interface org.redisson.api.RAtomicLong
Atomically sets the given value and returns the old value.
getAndSet(long) - Method in interface org.redisson.api.RAtomicLongReactive
Atomically sets the given value and returns the old value.
getAndSet(long) - Method in interface org.redisson.api.RAtomicLongRx
Atomically sets the given value and returns the old value.
getAndSet(V) - Method in interface org.redisson.api.RBucket
Retrieves current element in the holder and replaces it with newValue.
getAndSet(V, long, TimeUnit) - Method in interface org.redisson.api.RBucket
Retrieves current element in the holder and replaces it with newValue with defined timeToLive interval.
getAndSet(V) - Method in interface org.redisson.api.RBucketReactive
Retrieves current element in the holder and replaces it with newValue.
getAndSet(V, long, TimeUnit) - Method in interface org.redisson.api.RBucketReactive
Retrieves current element in the holder and replaces it with newValue with defined timeToLive interval.
getAndSet(V) - Method in interface org.redisson.api.RBucketRx
Retrieves current element in the holder and replaces it with newValue.
getAndSet(V, long, TimeUnit) - Method in interface org.redisson.api.RBucketRx
Retrieves current element in the holder and replaces it with newValue with defined timeToLive interval.
getAndSet(double) - Method in class org.redisson.RedissonAtomicDouble
 
getAndSet(long) - Method in class org.redisson.RedissonAtomicLong
 
getAndSet(V) - Method in class org.redisson.RedissonBucket
 
getAndSet(V, long, TimeUnit) - Method in class org.redisson.RedissonBucket
 
getAndSetAsync(double) - Method in interface org.redisson.api.RAtomicDoubleAsync
Atomically sets the given value and returns the old value.
getAndSetAsync(long) - Method in interface org.redisson.api.RAtomicLongAsync
Atomically sets the given value and returns the old value.
getAndSetAsync(V) - Method in interface org.redisson.api.RBucketAsync
Retrieves current element in the holder and replaces it with newValue.
getAndSetAsync(V, long, TimeUnit) - Method in interface org.redisson.api.RBucketAsync
Retrieves current element in the holder and replaces it with newValue with defined timeToLive interval.
getAndSetAsync(double) - Method in class org.redisson.RedissonAtomicDouble
 
getAndSetAsync(long) - Method in class org.redisson.RedissonAtomicLong
 
getAndSetAsync(V) - Method in class org.redisson.RedissonBucket
 
getAndSetAsync(V, long, TimeUnit) - Method in class org.redisson.RedissonBucket
 
getAndSetAsync(V, long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
getAndSetAsync(V) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
getAnnotation(Class<?>, String, Class<T>) - Static method in class org.redisson.liveobject.misc.ClassUtils
 
getAnnotation(Class<?>, Class<T>) - Static method in class org.redisson.liveobject.misc.ClassUtils
 
getArgs() - Method in class org.redisson.remote.RemoteServiceRequest
 
getAsync(K) - Method in interface org.redisson.api.CacheAsync
This method retrieves an entry from the cache.
getAsync() - Method in interface org.redisson.api.RAtomicDoubleAsync
Returns current value.
getAsync() - Method in interface org.redisson.api.RAtomicLongAsync
Returns current value.
getAsync(long) - Method in interface org.redisson.api.RBitSetAsync
Returns true if bit set to one and false overwise.
getAsync() - Method in interface org.redisson.api.RBucketAsync
Retrieves element stored in the holder.
getAsync(String...) - Method in interface org.redisson.api.RBucketsAsync
Returns Redis object mapped by key.
getAsync(int...) - Method in interface org.redisson.api.RListAsync
Loads elements by specified indexes
getAsync(int) - Method in interface org.redisson.api.RListAsync
Get element at index
getAsync(K) - Method in interface org.redisson.api.RMapAsync
Returns the value mapped by defined key or null if value is absent.
getAsync(K) - Method in class org.redisson.jcache.JCache
 
getAsync() - Method in class org.redisson.RedissonAtomicDouble
 
getAsync() - Method in class org.redisson.RedissonAtomicLong
 
getAsync(long) - Method in class org.redisson.RedissonBitSet
 
getAsync() - Method in class org.redisson.RedissonBucket
 
getAsync(String...) - Method in class org.redisson.RedissonBuckets
 
getAsync(int) - Method in class org.redisson.RedissonList
 
getAsync(int...) - Method in class org.redisson.RedissonList
 
getAsync(int...) - Method in class org.redisson.RedissonListMultimapValues
 
getAsync(int) - Method in class org.redisson.RedissonListMultimapValues
 
getAsync(Object) - Method in class org.redisson.RedissonLocalCachedMap
 
getAsync(K) - Method in class org.redisson.RedissonMap
 
getAsync(int) - Method in class org.redisson.RedissonSubList
 
getAsync() - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
getAsync(String...) - Method in class org.redisson.transaction.RedissonTransactionalBuckets
 
getAsynchronousChannel() - Method in interface org.redisson.api.RBinaryStream
Returns async channel object which allows to write and read binary stream.
getAsynchronousChannel() - Method in class org.redisson.RedissonBinaryStream
 
getAtomicDouble(String) - Method in interface org.redisson.api.RBatch
Returns atomicDouble instance by name.
getAtomicDouble(String) - Method in interface org.redisson.api.RBatchReactive
Returns atomicDouble instance by name.
getAtomicDouble(String) - Method in interface org.redisson.api.RBatchRx
Returns atomicDouble instance by name.
getAtomicDouble(String) - Method in interface org.redisson.api.RedissonClient
Returns atomicDouble instance by name.
getAtomicDouble(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns "atomic double" instance by name.
getAtomicDouble(String) - Method in interface org.redisson.api.RedissonRxClient
Returns "atomic double" instance by name.
getAtomicDouble(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getAtomicDouble(String) - Method in class org.redisson.Redisson
 
getAtomicDouble(String) - Method in class org.redisson.RedissonBatch
 
getAtomicDouble(String) - Method in class org.redisson.RedissonReactive
 
getAtomicDouble(String) - Method in class org.redisson.RedissonRx
 
getAtomicDouble(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getAtomicLong(String) - Method in interface org.redisson.api.RBatch
Returns atomicLong instance by name.
getAtomicLong(String) - Method in interface org.redisson.api.RBatchReactive
Returns "atomic long" instance by name.
getAtomicLong(String) - Method in interface org.redisson.api.RBatchRx
Returns "atomic long" instance by name.
getAtomicLong(String) - Method in interface org.redisson.api.RedissonClient
Returns atomicLong instance by name.
getAtomicLong(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns "atomic long" instance by name.
getAtomicLong(String) - Method in interface org.redisson.api.RedissonRxClient
Returns "atomic long" instance by name.
getAtomicLong(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getAtomicLong(String) - Method in class org.redisson.Redisson
 
getAtomicLong(String) - Method in class org.redisson.RedissonBatch
 
getAtomicLong(String) - Method in class org.redisson.RedissonReactive
 
getAtomicLong(String) - Method in class org.redisson.RedissonRx
 
getAtomicLong(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getAttachedCommands() - Method in class org.redisson.client.protocol.CommandsData
 
getAttribute(Element, String) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
getAvailableClients() - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
getAvailableClients() - Method in class org.redisson.connection.MasterSlaveEntry
 
getAvailableSlaves() - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
getAvailableSlaves() - Method in class org.redisson.connection.MasterSlaveEntry
 
getAverageGetTime() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getAveragePutTime() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getAverageRemoveTime() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getBatchIndex() - Method in class org.redisson.client.handler.State
 
getBean() - Method in class org.redisson.remote.RemoteServiceMethod
 
getBeanClass(Element) - Method in class org.redisson.spring.support.RedisDefinitionParser
 
getBeanClass(Element) - Method in class org.redisson.spring.support.RedissonGenericObjectDefinitionParser
 
getBeanClass(Element) - Method in class org.redisson.spring.support.RedissonLiveObjectDefinitionParser
 
getBeanClass(Element) - Method in class org.redisson.spring.support.RedissonLiveObjectRegistrationDefinitionParser
 
getBeanClass(Element) - Method in class org.redisson.spring.support.RedissonReadAndWriteLockDefinitionParser
 
getBeanClass(Element) - Method in class org.redisson.spring.support.RedissonRPCClientDefinitionParser
 
getBeanClass(Element) - Method in class org.redisson.spring.support.RedissonRPCServerDefinitionParser
 
getBeanClassName(Element) - Method in class org.redisson.spring.support.RedissonMultiLockDefinitionParser
 
getBeanFactory() - Method in class org.redisson.api.WorkerOptions
 
getBeanFactory() - Method in class org.redisson.config.RedissonNodeConfig
 
getBinaryStream(String) - Method in interface org.redisson.api.RedissonClient
Returns binary stream holder instance by name
getBinaryStream(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns binary stream holder instance by name
getBinaryStream(String) - Method in interface org.redisson.api.RedissonRxClient
Returns binary stream holder instance by name
getBinaryStream(String) - Method in class org.redisson.Redisson
 
getBinaryStream(String) - Method in class org.redisson.RedissonReactive
 
getBinaryStream(String) - Method in class org.redisson.RedissonRx
 
GETBIT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
getBitSet(String) - Method in interface org.redisson.api.RBatch
Returns bitSet instance by name.
getBitSet(String) - Method in interface org.redisson.api.RBatchReactive
Returns bitSet instance by name.
getBitSet(String) - Method in interface org.redisson.api.RBatchRx
Returns bitSet instance by name.
getBitSet(String) - Method in interface org.redisson.api.RedissonClient
Returns bitSet instance by name.
getBitSet(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns bitSet instance by name.
getBitSet(String) - Method in interface org.redisson.api.RedissonRxClient
Returns bitSet instance by name.
getBitSet(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getBitSet(String) - Method in class org.redisson.Redisson
 
getBitSet(String) - Method in class org.redisson.RedissonBatch
 
getBitSet(String) - Method in class org.redisson.RedissonReactive
 
getBitSet(String) - Method in class org.redisson.RedissonRx
 
getBitSet(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getBlockingDeque(String) - Method in interface org.redisson.api.RBatch
Returns blocking deque instance by name.
getBlockingDeque(String, Codec) - Method in interface org.redisson.api.RBatch
 
getBlockingDeque(String) - Method in interface org.redisson.api.RBatchReactive
Returns blocking deque instance by name.
getBlockingDeque(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getBlockingDeque(String) - Method in interface org.redisson.api.RBatchRx
Returns blocking deque instance by name.
getBlockingDeque(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getBlockingDeque(String) - Method in interface org.redisson.api.RedissonClient
Returns unbounded blocking deque instance by name.
getBlockingDeque(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns unbounded blocking deque instance by name using provided codec for deque objects.
getBlockingDeque(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns unbounded blocking deque instance by name.
getBlockingDeque(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns unbounded blocking deque instance by name using provided codec for deque objects.
getBlockingDeque(String) - Method in interface org.redisson.api.RedissonRxClient
Returns unbounded blocking deque instance by name.
getBlockingDeque(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns unbounded blocking deque instance by name using provided codec for deque objects.
getBlockingDeque(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getBlockingDeque(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getBlockingDeque(String) - Method in class org.redisson.Redisson
 
getBlockingDeque(String, Codec) - Method in class org.redisson.Redisson
 
getBlockingDeque(String) - Method in class org.redisson.RedissonBatch
 
getBlockingDeque(String, Codec) - Method in class org.redisson.RedissonBatch
 
getBlockingDeque(String) - Method in class org.redisson.RedissonReactive
 
getBlockingDeque(String, Codec) - Method in class org.redisson.RedissonReactive
 
getBlockingDeque(String) - Method in class org.redisson.RedissonRx
 
getBlockingDeque(String, Codec) - Method in class org.redisson.RedissonRx
 
getBlockingDeque(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getBlockingDeque(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getBlockingQueue(String) - Method in interface org.redisson.api.RBatch
Returns blocking queue instance by name.
getBlockingQueue(String, Codec) - Method in interface org.redisson.api.RBatch
 
getBlockingQueue(String) - Method in interface org.redisson.api.RBatchReactive
Returns blocking queue instance by name.
getBlockingQueue(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getBlockingQueue(String) - Method in interface org.redisson.api.RBatchRx
Returns blocking queue instance by name.
getBlockingQueue(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getBlockingQueue(String) - Method in interface org.redisson.api.RedissonClient
Returns unbounded blocking queue instance by name.
getBlockingQueue(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns unbounded blocking queue instance by name using provided codec for queue objects.
getBlockingQueue(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns blocking queue instance by name.
getBlockingQueue(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns blocking queue instance by name using provided codec for queue objects.
getBlockingQueue(String) - Method in interface org.redisson.api.RedissonRxClient
Returns blocking queue instance by name.
getBlockingQueue(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns blocking queue instance by name using provided codec for queue objects.
getBlockingQueue(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getBlockingQueue(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getBlockingQueue(String) - Method in class org.redisson.Redisson
 
getBlockingQueue(String, Codec) - Method in class org.redisson.Redisson
 
getBlockingQueue(String) - Method in class org.redisson.RedissonBatch
 
getBlockingQueue(String, Codec) - Method in class org.redisson.RedissonBatch
 
getBlockingQueue(String) - Method in class org.redisson.RedissonReactive
 
getBlockingQueue(String, Codec) - Method in class org.redisson.RedissonReactive
 
getBlockingQueue(String) - Method in class org.redisson.RedissonRx
 
getBlockingQueue(String, Codec) - Method in class org.redisson.RedissonRx
 
getBlockingQueue(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getBlockingQueue(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getBloomFilter(String) - Method in interface org.redisson.api.RedissonClient
Returns bloom filter instance by name.
getBloomFilter(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns bloom filter instance by name using provided codec for objects.
getBloomFilter(String) - Method in class org.redisson.Redisson
 
getBloomFilter(String, Codec) - Method in class org.redisson.Redisson
 
getBoundedBlockingQueue(String) - Method in interface org.redisson.api.RedissonClient
Returns bounded blocking queue instance by name.
getBoundedBlockingQueue(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns bounded blocking queue instance by name using provided codec for queue objects.
getBoundedBlockingQueue(String) - Method in class org.redisson.Redisson
 
getBoundedBlockingQueue(String, Codec) - Method in class org.redisson.Redisson
 
getBucket(String) - Method in interface org.redisson.api.RBatch
Returns object holder by name
getBucket(String, Codec) - Method in interface org.redisson.api.RBatch
 
getBucket(String) - Method in interface org.redisson.api.RBatchReactive
Returns object holder by name
getBucket(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getBucket(String) - Method in interface org.redisson.api.RBatchRx
Returns object holder by name
getBucket(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getBucket(String) - Method in interface org.redisson.api.RedissonClient
Returns object holder instance by name.
getBucket(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns object holder instance by name using provided codec for object.
getBucket(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns object holder instance by name
getBucket(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns object holder instance by name using provided codec for object.
getBucket(String) - Method in interface org.redisson.api.RedissonRxClient
Returns object holder instance by name
getBucket(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns object holder instance by name using provided codec for object.
getBucket(String) - Method in interface org.redisson.api.RTransaction
Returns transactional object holder instance by name.
getBucket(String, Codec) - Method in interface org.redisson.api.RTransaction
Returns transactional object holder instance by name using provided codec for object.
getBucket(String) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional object holder instance by name.
getBucket(String, Codec) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional object holder instance by name using provided codec for object.
getBucket(String) - Method in interface org.redisson.api.RTransactionRx
Returns transactional object holder instance by name.
getBucket(String, Codec) - Method in interface org.redisson.api.RTransactionRx
Returns transactional object holder instance by name using provided codec for object.
getBucket(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getBucket(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getBucket(String) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getBucket(String, Codec) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getBucket(String) - Method in class org.redisson.Redisson
 
getBucket(String, Codec) - Method in class org.redisson.Redisson
 
getBucket(String) - Method in class org.redisson.RedissonBatch
 
getBucket(String, Codec) - Method in class org.redisson.RedissonBatch
 
getBucket(String) - Method in class org.redisson.RedissonReactive
 
getBucket(String, Codec) - Method in class org.redisson.RedissonReactive
 
getBucket(String) - Method in class org.redisson.RedissonRx
 
getBucket(String, Codec) - Method in class org.redisson.RedissonRx
 
getBucket(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getBucket(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getBucket(String) - Method in class org.redisson.rx.RedissonTransactionRx
 
getBucket(String, Codec) - Method in class org.redisson.rx.RedissonTransactionRx
 
getBucket(String) - Method in class org.redisson.transaction.RedissonTransaction
 
getBucket(String, Codec) - Method in class org.redisson.transaction.RedissonTransaction
 
getBuckets() - Method in interface org.redisson.api.RedissonClient
Returns interface for mass operations with Bucket objects.
getBuckets(Codec) - Method in interface org.redisson.api.RedissonClient
Returns interface for mass operations with Bucket objects using provided codec for object.
getBuckets() - Method in interface org.redisson.api.RedissonReactiveClient
Returns interface for mass operations with Bucket objects.
getBuckets(Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns interface for mass operations with Bucket objects using provided codec for object.
getBuckets() - Method in interface org.redisson.api.RedissonRxClient
Returns interface for mass operations with Bucket objects.
getBuckets(Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns interface for mass operations with Bucket objects using provided codec for object.
getBuckets() - Method in interface org.redisson.api.RTransaction
Returns transactional interface for mass operations with Bucket objects.
getBuckets(Codec) - Method in interface org.redisson.api.RTransaction
Returns transactional interface for mass operations with Bucket objects using provided codec for object.
getBuckets() - Method in class org.redisson.Redisson
 
getBuckets(Codec) - Method in class org.redisson.Redisson
 
getBuckets() - Method in class org.redisson.RedissonReactive
 
getBuckets(Codec) - Method in class org.redisson.RedissonReactive
 
getBuckets() - Method in class org.redisson.RedissonRx
 
getBuckets(Codec) - Method in class org.redisson.RedissonRx
 
getBuckets() - Method in class org.redisson.transaction.RedissonTransaction
 
getBuckets(Codec) - Method in class org.redisson.transaction.RedissonTransaction
 
getCache(String, Class<K>, Class<V>) - Method in class org.redisson.jcache.JCacheManager
 
getCache(String) - Method in class org.redisson.jcache.JCacheManager
 
getCache(String) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
 
getCachedMap() - Method in interface org.redisson.api.RLocalCachedMap
Returns state of local cache
getCachedMap() - Method in class org.redisson.cache.LocalCacheView
 
getCachedMap() - Method in class org.redisson.RedissonLocalCachedMap
 
getCachedMap() - Method in class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
getCacheEntryListenerConfigurations() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
getCacheEvictions() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getCacheGets() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getCacheHitPercentage() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getCacheHits() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getCacheLoaderFactory() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
getCacheManager() - Method in class org.redisson.jcache.JCache
 
getCacheManager(URI, ClassLoader, Properties) - Method in class org.redisson.jcache.JCachingProvider
 
getCacheManager(URI, ClassLoader) - Method in class org.redisson.jcache.JCachingProvider
 
getCacheManager() - Method in class org.redisson.jcache.JCachingProvider
 
getCacheMisses() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getCacheMissPercentage() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getCacheNames() - Method in class org.redisson.jcache.JCacheManager
 
getCacheNames() - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
 
getCacheProvider() - Method in class org.redisson.api.LocalCachedMapOptions
 
getCachePuts() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getCacheRemovals() - Method in class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
getCacheSize() - Method in class org.redisson.api.LocalCachedMapOptions
 
getCacheWriterFactory() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
getCachingProvider() - Method in class org.redisson.jcache.JCacheManager
 
getCfg() - Method in interface org.redisson.connection.ConnectionManager
 
getCfg() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getChannel() - Method in interface org.redisson.api.RBinaryStream
Returns channel object which allows to write and read binary stream.
getChannel() - Method in class org.redisson.client.handler.PubSubKey
 
getChannel() - Method in interface org.redisson.client.protocol.pubsub.Message
 
getChannel() - Method in class org.redisson.client.protocol.pubsub.PubSubMessage
 
getChannel() - Method in class org.redisson.client.protocol.pubsub.PubSubPatternMessage
 
getChannel() - Method in class org.redisson.client.protocol.pubsub.PubSubStatusMessage
 
getChannel() - Method in class org.redisson.client.RedisConnection
Access to Netty channel.
getChannel() - Method in class org.redisson.RedissonBinaryStream
 
getChannelName(String) - Static method in class org.redisson.RedissonPermitExpirableSemaphore
 
getChannelName(String) - Static method in class org.redisson.RedissonSemaphore
 
getChannelNames() - Method in interface org.redisson.api.RTopic
Get topic channel names
getChannelNames() - Method in interface org.redisson.api.RTopicReactive
Get topic channel names
getChannelNames() - Method in interface org.redisson.api.RTopicRx
Get topic channel names
getChannelNames() - Method in class org.redisson.RedissonTopic
 
getChannelPromise() - Method in class org.redisson.client.protocol.QueueCommandHolder
 
getChannels() - Method in class org.redisson.client.RedisPubSubConnection
 
getClassBody() - Method in class org.redisson.executor.params.TaskParameters
 
getClassLoader() - Method in class org.redisson.client.codec.BaseCodec
 
getClassLoader() - Method in class org.redisson.client.codec.BitSetCodec
 
getClassLoader() - Method in interface org.redisson.client.codec.Codec
Returns class loader object used to load classes used in decoding process
getClassLoader() - Method in class org.redisson.codec.BaseEventCodec
 
getClassLoader() - Method in class org.redisson.codec.CompositeCodec
 
getClassLoader() - Method in class org.redisson.codec.FstCodec
 
getClassLoader() - Method in class org.redisson.codec.JsonJacksonCodec
 
getClassLoader() - Method in class org.redisson.codec.KryoCodec
 
getClassLoader() - Method in class org.redisson.codec.MarshallingCodec
 
getClassLoader() - Method in class org.redisson.codec.SerializationCodec
 
getClassLoader() - Method in class org.redisson.codec.SnappyCodec
 
getClassLoader() - Method in class org.redisson.jcache.JCacheManager
 
getClassName() - Method in class org.redisson.executor.params.TaskParameters
 
getClazz() - Method in class org.redisson.api.redisnode.RedisNodes
 
getClazz() - Method in class org.redisson.RedissonExecutorService.ClassBody
 
getClazzName() - Method in class org.redisson.RedissonExecutorService.ClassBody
 
getCleanUpKeysAmount() - Method in class org.redisson.config.Config
 
getClient() - Method in class org.redisson.connection.ClientConnectionsEntry
 
getClient() - Method in class org.redisson.connection.MasterSlaveEntry
 
getClient() - Method in class org.redisson.connection.RedisClientEntry
 
getClient() - Method in class org.redisson.redisnode.RedisNode
 
getClient() - Method in class org.redisson.redisnode.SentinelRedisNode
 
getClientName() - Method in class org.redisson.client.RedisClientConfig
 
getClientName() - Method in class org.redisson.config.BaseConfig
 
getClusterNodesGroup() - Method in interface org.redisson.api.RedissonClient
Deprecated.
getClusterNodesGroup() - Method in interface org.redisson.api.RedissonReactiveClient
Get Redis cluster nodes group for server operations
getClusterNodesGroup() - Method in interface org.redisson.api.RedissonRxClient
Get Redis cluster nodes group for server operations
getClusterNodesGroup() - Method in class org.redisson.Redisson
 
getClusterNodesGroup() - Method in class org.redisson.RedissonReactive
 
getClusterNodesGroup() - Method in class org.redisson.RedissonRx
 
getCodec() - Method in interface org.redisson.api.RObject
Returns the underlying Codec used by this RObject
getCodec() - Method in interface org.redisson.api.RObjectReactive
 
getCodec() - Method in interface org.redisson.api.RObjectRx
 
getCodec() - Method in class org.redisson.client.protocol.CommandData
 
getCodec(Class<T>) - Method in class org.redisson.codec.DefaultReferenceCodecProvider
 
getCodec(REntity, Class<?>, Config) - Method in class org.redisson.codec.DefaultReferenceCodecProvider
 
getCodec(RObjectField, Class<?>, Class<K>, String, Config) - Method in class org.redisson.codec.DefaultReferenceCodecProvider
 
getCodec(Class<T>) - Method in interface org.redisson.codec.ReferenceCodecProvider
Get codec instance by its class.
getCodec(REntity, Class<?>, Config) - Method in interface org.redisson.codec.ReferenceCodecProvider
Get a codec instance by a REntity annotation and the class annotated with it.
getCodec(RObjectField, Class<?>, Class<K>, String, Config) - Method in interface org.redisson.codec.ReferenceCodecProvider
Get a codec instance by a RObjectField annotation and the class annotated with REntity, the implementation class of RObject the field is going to be transformed into and the name of the field with this RObjectField annotation.
getCodec(Codec) - Method in class org.redisson.command.RedisExecutor
 
getCodec() - Method in class org.redisson.config.Config
 
getCodec() - Method in interface org.redisson.connection.ConnectionManager
 
getCodec() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getCodec() - Method in class org.redisson.liveobject.resolver.AbstractNamingScheme
 
getCodec() - Method in interface org.redisson.liveobject.resolver.NamingScheme
 
getCodec() - Method in class org.redisson.RedissonObject
 
getCodec() - Method in class org.redisson.RedissonReference
 
getCodec() - Method in class org.redisson.transaction.HashKey
 
getCodec() - Method in class org.redisson.transaction.operation.TransactionalOperation
 
getCodecName() - Method in class org.redisson.RedissonReference
 
getCodecType() - Method in class org.redisson.RedissonReference
 
getCommand() - Method in enum org.redisson.api.RScript.ReturnType
 
getCommand() - Method in class org.redisson.client.protocol.CommandData
 
getCommand() - Method in class org.redisson.client.protocol.QueueCommandHolder
 
getCommandExecutor() - Method in interface org.redisson.connection.ConnectionManager
 
getCommandExecutor() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getCommandExecutor() - Method in class org.redisson.Redisson
 
getCommandExecutor() - Method in class org.redisson.RedissonReactive
 
getCommands() - Method in class org.redisson.client.protocol.CommandsData
 
getCommands() - Method in class org.redisson.command.CommandBatchService.Entry
 
getCommandTimeout() - Method in class org.redisson.client.RedisClient
 
getCommandTimeout() - Method in class org.redisson.client.RedisClientConfig
 
getConditions() - Method in class org.redisson.liveobject.condition.ANDCondition
 
getConditions() - Method in class org.redisson.liveobject.condition.ORCondition
 
getConfig() - Method in interface org.redisson.api.RedissonClient
Allows to get configuration provided during Redisson instance creation.
getConfig() - Method in interface org.redisson.api.RedissonReactiveClient
Allows to get configuration provided during Redisson instance creation.
getConfig() - Method in interface org.redisson.api.RedissonRxClient
Allows to get configuration provided during Redisson instance creation.
getConfig() - Method in interface org.redisson.api.RRateLimiter
Returns current configuration of this RateLimiter object.
getConfig() - Method in class org.redisson.client.RedisClient
 
getConfig() - Method in interface org.redisson.connection.ConnectionManager
 
getConfig() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getConfig() - Method in class org.redisson.connection.MasterSlaveEntry
 
getConfig() - Method in class org.redisson.jcache.configuration.RedissonConfiguration
 
getConfig() - Method in class org.redisson.Redisson
 
getConfig() - Method in class org.redisson.RedissonRateLimiter
 
getConfig() - Method in class org.redisson.RedissonReactive
 
getConfig() - Method in class org.redisson.RedissonRx
 
getConfigAsync() - Method in interface org.redisson.api.RRateLimiterAsync
Returns current configuration of this RateLimiter object.
getConfigAsync() - Method in class org.redisson.RedissonRateLimiter
 
getConfigEndpointHostName() - Method in class org.redisson.cluster.ClusterConnectionManager
 
getConfiguration(Class<C>) - Method in class org.redisson.jcache.JCache
 
getConnection() - Method in class org.redisson.command.RedisExecutor
 
getConnection() - Method in class org.redisson.command.RedisQueuedBatchExecutor
 
getConnection(RedisCommand<?>, RedisURI) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
getConnection(RedisCommand<?>, RedisClient) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
getConnection() - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
getConnectionEventsHub() - Method in interface org.redisson.connection.ConnectionManager
 
getConnectionEventsHub() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getConnectionFuture() - Method in class org.redisson.command.CommandBatchService.ConnectionEntry
 
getConnectionManager() - Method in interface org.redisson.command.CommandAsyncExecutor
 
getConnectionManager() - Method in class org.redisson.command.CommandAsyncService
 
getConnectionManager() - Method in interface org.redisson.command.CommandSyncExecutor
 
getConnectionManager() - Method in class org.redisson.Redisson
 
getConnectionManager() - Method in class org.redisson.RedissonReactive
 
getConnectionMinimumIdleSize() - Method in class org.redisson.config.SingleServerConfig
 
getConnectionPoolSize() - Method in class org.redisson.config.SingleServerConfig
 
getConnectionPromise() - Method in class org.redisson.client.RedisConnection
 
getConnectionWatcher() - Method in interface org.redisson.connection.ConnectionManager
 
getConnectionWatcher() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getConnectTimeout() - Method in class org.redisson.client.RedisClientConfig
 
getConnectTimeout() - Method in class org.redisson.config.BaseConfig
 
getConsumerName() - Method in class org.redisson.api.PendingEntry
Returns name of consumer
getConsumerNames() - Method in class org.redisson.api.PendingResult
Pending messages amount mapped by consumer name
getConsumers() - Method in class org.redisson.api.StreamGroup
Returns current customers amount for this group
getConvertor() - Method in class org.redisson.client.protocol.RedisCommand
 
getCount() - Method in interface org.redisson.api.RCountDownLatch
Returns value of current count.
getCount() - Method in interface org.redisson.api.RCountDownLatchReactive
Returns value of current count.
getCount() - Method in interface org.redisson.api.RCountDownLatchRx
Returns value of current count.
getCount() - Method in class org.redisson.RedissonCountDownLatch
 
getCountAsync() - Method in interface org.redisson.api.RCountDownLatchAsync
Returns value of current count.
getCountAsync() - Method in class org.redisson.RedissonCountDownLatch
 
getCountDownLatch(String) - Method in interface org.redisson.api.RedissonClient
Returns countDownLatch instance by name.
getCountDownLatch(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns CountDownLatch instance by name.
getCountDownLatch(String) - Method in interface org.redisson.api.RedissonRxClient
Returns CountDownLatch instance by name.
getCountDownLatch(K) - Method in interface org.redisson.api.RMap
Returns RCountDownLatch instance associated with key
getCountDownLatch(K) - Method in interface org.redisson.api.RMultimap
Returns RCountDownLatch instance associated with key
getCountDownLatch(V) - Method in interface org.redisson.api.RSet
Returns RCountDownLatch instance associated with value
getCountDownLatch(V) - Method in interface org.redisson.api.RSetCache
Returns RCountDownLatch instance associated with value
getCountDownLatch(String) - Method in class org.redisson.Redisson
 
getCountDownLatch(K) - Method in class org.redisson.RedissonMap
 
getCountDownLatch(K) - Method in class org.redisson.RedissonMultimap
 
getCountDownLatch(String) - Method in class org.redisson.RedissonReactive
 
getCountDownLatch(String) - Method in class org.redisson.RedissonRx
 
getCountDownLatch(V) - Method in class org.redisson.RedissonSet
 
getCountDownLatch(V) - Method in class org.redisson.RedissonSetCache
 
getCountDownLatch(V) - Method in class org.redisson.RedissonSetMultimapValues
 
getCountDownLatch(K) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
getCountDownLatch(K) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
getCountDownLatch(V) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
getCountDownLatchPubSub() - Method in class org.redisson.pubsub.PublishSubscribeService
 
getCounter() - Method in class org.redisson.pubsub.AsyncSemaphore
 
getCounter() - Method in class org.redisson.RedissonRemoteService.Entry
 
getCounter() - Method in class org.redisson.transaction.HashValue
 
getCronExpression() - Method in class org.redisson.executor.CronExpression
 
getCronExpression() - Method in class org.redisson.executor.params.ScheduledCronExpressionParameters
 
getCurrentCommand() - Method in class org.redisson.client.RedisConnection
 
getCurrentTransaction() - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
getCurrentTransaction() - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
getData() - Method in class org.redisson.api.StreamInfo.Entry
Returns data stored in this stream entry
getDatabase() - Method in class org.redisson.client.RedisClientConfig
 
getDatabase() - Method in class org.redisson.config.MasterSlaveServersConfig
 
getDatabase() - Method in class org.redisson.config.ReplicatedServersConfig
 
getDatabase() - Method in class org.redisson.config.SentinelServersConfig
 
getDatabase() - Method in class org.redisson.config.SingleServerConfig
 
getDate() - Method in class org.redisson.remote.RemoteServiceRequest
 
getDayOfWeekNumber(String) - Method in class org.redisson.executor.CronExpression
 
getDeclaredField(Class<?>, String) - Static method in class org.redisson.liveobject.misc.ClassUtils
 
getDecoder() - Method in class org.redisson.client.handler.PubSubEntry
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.convertor.TimeObjectDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.CodecDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.GeoDistanceDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.GeoDistanceMapDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.GeoPositionDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.GeoPositionMapDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.InetSocketAddressDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ListFirstObjectDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ListIteratorReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ListMultiDecoder2
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ListObjectDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ListResultReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ListScanResultReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.Long2MultiDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.MapCacheScanResultReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.MapScanResultReplayDecoder
 
getDecoder(int, State) - Method in interface org.redisson.client.protocol.decoder.MultiDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ObjectDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ObjectFirstScoreReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ObjectListReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ObjectMapDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ObjectMapEntryReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ObjectMapReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ObjectMapReplayDecoder2
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ObjectSetReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.PendingEntryDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.PendingResultDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ScoredSortedSetPolledObjectDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ScoredSortedSetReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ScoredSortedSetScanDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.ScoredSortedSetScanReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.SlotsDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.StreamConsumerInfoDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.StreamGroupInfoDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.StreamIdListDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.StreamInfoDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.StreamObjectMapReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.StreamResultDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.StringListReplayDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.decoder.TimeLongObjectDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.pubsub.PubSubMessageDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.pubsub.PubSubPatternMessageDecoder
 
getDecoder(int, State) - Method in class org.redisson.client.protocol.pubsub.PubSubStatusDecoder
 
getDecoder(int, State) - Method in class org.redisson.connection.decoder.BucketsDecoder
 
getDecoder(int, State) - Method in class org.redisson.connection.decoder.ListDrainToDecoder
 
getDecoder(int, State) - Method in class org.redisson.connection.decoder.MapCacheGetAllDecoder
 
getDecoder(int, State) - Method in class org.redisson.connection.decoder.MapGetAllDecoder
 
getDefaultClassLoader() - Method in class org.redisson.jcache.JCachingProvider
 
getDefaultProperties() - Method in class org.redisson.jcache.JCachingProvider
 
getDefaultURI() - Method in class org.redisson.jcache.JCachingProvider
 
getDelay() - Method in class org.redisson.executor.params.ScheduledWithFixedDelayParameters
 
getDelay(TimeUnit) - Method in class org.redisson.executor.RedissonScheduledFuture
 
getDelayedQueue(RQueue<V>) - Method in interface org.redisson.api.RedissonClient
Returns unbounded delayed queue instance by name.
getDelayedQueue(RQueue<V>) - Method in class org.redisson.Redisson
 
getDeque(String) - Method in interface org.redisson.api.RBatch
Returns deque instance by name.
getDeque(String, Codec) - Method in interface org.redisson.api.RBatch
 
getDeque(String) - Method in interface org.redisson.api.RBatchReactive
Returns deque instance by name.
getDeque(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getDeque(String) - Method in interface org.redisson.api.RBatchRx
Returns deque instance by name.
getDeque(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getDeque(String) - Method in interface org.redisson.api.RedissonClient
Returns unbounded deque instance by name.
getDeque(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns unbounded deque instance by name using provided codec for deque objects.
getDeque(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns deque instance by name.
getDeque(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns deque instance by name using provided codec for deque objects.
getDeque(String) - Method in interface org.redisson.api.RedissonRxClient
Returns deque instance by name.
getDeque(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns deque instance by name using provided codec for deque objects.
getDeque(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getDeque(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getDeque(String) - Method in class org.redisson.Redisson
 
getDeque(String, Codec) - Method in class org.redisson.Redisson
 
getDeque(String) - Method in class org.redisson.RedissonBatch
 
getDeque(String, Codec) - Method in class org.redisson.RedissonBatch
 
getDeque(String) - Method in class org.redisson.RedissonReactive
 
getDeque(String, Codec) - Method in class org.redisson.RedissonReactive
 
getDeque(String) - Method in class org.redisson.RedissonRx
 
getDeque(String, Codec) - Method in class org.redisson.RedissonRx
 
getDeque(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getDeque(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getDestinationName() - Method in class org.redisson.transaction.operation.set.MoveOperation
 
getDnsMonitoringInterval() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getDnsMonitoringInterval() - Method in class org.redisson.config.SingleServerConfig
 
getDoubleAdder(String) - Method in interface org.redisson.api.RedissonClient
Returns DoubleAdder instances by name.
getDoubleAdder(String) - Method in class org.redisson.Redisson
 
getElement() - Method in class org.redisson.client.protocol.decoder.ListIteratorResult
 
getElementsSubscribeService() - Method in interface org.redisson.connection.ConnectionManager
 
getElementsSubscribeService() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getEndSlot() - Method in class org.redisson.cluster.ClusterSlotRange
 
getEntries() - Method in class org.redisson.cache.LocalCachedMapUpdate
 
getEntries() - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
getEntry(List<ClientConnectionsEntry>) - Method in interface org.redisson.connection.balancer.LoadBalancer
 
getEntry(RedisClient) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
getEntry(List<ClientConnectionsEntry>) - Method in class org.redisson.connection.balancer.RandomLoadBalancer
 
getEntry(List<ClientConnectionsEntry>) - Method in class org.redisson.connection.balancer.RoundRobinLoadBalancer
 
getEntry(List<ClientConnectionsEntry>) - Method in class org.redisson.connection.balancer.WeightedRoundRobinBalancer
 
getEntry(String) - Method in interface org.redisson.connection.ConnectionManager
 
getEntry(int) - Method in interface org.redisson.connection.ConnectionManager
 
getEntry(InetSocketAddress) - Method in interface org.redisson.connection.ConnectionManager
 
getEntry(RedisClient) - Method in interface org.redisson.connection.ConnectionManager
 
getEntry(InetSocketAddress) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getEntry(RedisURI) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getEntry(RedisClient) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getEntry(String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getEntry(int) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getEntry(RedisClient) - Method in class org.redisson.connection.MasterSlaveEntry
 
getEntry() - Method in class org.redisson.connection.NodeSource
 
getEntryName() - Method in class org.redisson.RedissonLock
 
getEntrySet() - Method in interface org.redisson.connection.ConnectionManager
 
getEntrySet() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getError() - Method in class org.redisson.remote.RemoteServiceResponse
 
getEventLoopGroup() - Method in class org.redisson.client.RedisClient
 
getEventLoopGroup() - Method in class org.redisson.config.Config
 
getEvictionPolicy() - Method in class org.redisson.api.LocalCachedMapOptions
 
getEvictionScheduler() - Method in class org.redisson.Redisson
 
getEvictionScheduler() - Method in class org.redisson.RedissonReactive
 
getExcludedId() - Method in class org.redisson.cache.LocalCachedMapInvalidate
 
getExecutionMode() - Method in class org.redisson.api.BatchOptions
 
getExecutionTimeoutInMillis() - Method in class org.redisson.api.RemoteInvocationOptions
 
getExecutor() - Method in class org.redisson.client.RedisClientConfig
 
getExecutor() - Method in class org.redisson.config.Config
 
getExecutor() - Method in interface org.redisson.connection.ConnectionManager
 
getExecutor() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getExecutorId() - Method in class org.redisson.executor.params.ScheduledAtFixedRateParameters
 
getExecutorId() - Method in class org.redisson.executor.params.ScheduledCronExpressionParameters
 
getExecutorId() - Method in class org.redisson.executor.params.ScheduledWithFixedDelayParameters
 
getExecutorId() - Method in class org.redisson.remote.RemoteServiceRequest
 
getExecutorService(String) - Method in interface org.redisson.api.RedissonClient
Returns ScheduledExecutorService by name
getExecutorService(String, ExecutorOptions) - Method in interface org.redisson.api.RedissonClient
Returns ScheduledExecutorService by name
getExecutorService(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns ScheduledExecutorService by name using provided codec for task, response and request serialization
getExecutorService(String, Codec, ExecutorOptions) - Method in interface org.redisson.api.RedissonClient
Returns ScheduledExecutorService by name using provided codec for task, response and request serialization
getExecutorService() - Method in class org.redisson.api.WorkerOptions
 
getExecutorService(String) - Method in class org.redisson.Redisson
 
getExecutorService(String, ExecutorOptions) - Method in class org.redisson.Redisson
 
getExecutorService(String, Codec) - Method in class org.redisson.Redisson
 
getExecutorService(String, Codec, ExecutorOptions) - Method in class org.redisson.Redisson
 
getExecutorServiceWorkers() - Method in class org.redisson.config.RedissonNodeConfig
 
getExpected() - Method in class org.redisson.transaction.operation.bucket.BucketCompareAndSetOperation
 
getExpectedInsertions() - Method in interface org.redisson.api.RBloomFilter
Returns expected amount of insertions per element.
getExpectedInsertions() - Method in class org.redisson.RedissonBloomFilter
 
getExpiryPolicy() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
getExpiryPolicyFactory() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
getExpression() - Method in class org.redisson.api.CronSchedule
 
getExpressionSetSummary(Set<Integer>) - Method in class org.redisson.executor.CronExpression
 
getExpressionSetSummary(ArrayList<Integer>) - Method in class org.redisson.executor.CronExpression
 
getExpressionSummary() - Method in class org.redisson.executor.CronExpression
 
getFailedSlaveAddresses() - Method in class org.redisson.cluster.ClusterPartition
 
getFailedSlaveCheckInterval() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getFailedSlaveReconnectionInterval() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getFairLock(String) - Method in interface org.redisson.api.RedissonClient
Returns Lock instance by name.
getFairLock(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns lock instance by name.
getFairLock(String) - Method in interface org.redisson.api.RedissonRxClient
Returns lock instance by name.
getFairLock(K) - Method in interface org.redisson.api.RMap
Returns RLock instance associated with key
getFairLock(K) - Method in interface org.redisson.api.RMapReactive
Returns RLock instance associated with key
getFairLock(K) - Method in interface org.redisson.api.RMapRx
Returns RLock instance associated with key
getFairLock(K) - Method in interface org.redisson.api.RMultimap
Returns RLock instance associated with key
getFairLock(V) - Method in interface org.redisson.api.RSet
Returns RLock instance associated with value
getFairLock(V) - Method in interface org.redisson.api.RSetCache
Returns RLock instance associated with value
getFairLock(V) - Method in interface org.redisson.api.RSetCacheReactive
Returns RLock instance associated with value
getFairLock(V) - Method in interface org.redisson.api.RSetCacheRx
Returns RLock instance associated with value
getFairLock(V) - Method in interface org.redisson.api.RSetReactive
Returns RLock instance associated with value
getFairLock(V) - Method in interface org.redisson.api.RSetRx
Returns RLock instance associated with value
getFairLock(K) - Method in class org.redisson.reactive.RedissonMapReactive
 
getFairLock(V) - Method in class org.redisson.reactive.RedissonSetCacheReactive
 
getFairLock(V) - Method in class org.redisson.reactive.RedissonSetReactive
 
getFairLock(String) - Method in class org.redisson.Redisson
 
getFairLock(K) - Method in class org.redisson.RedissonMap
 
getFairLock(K) - Method in class org.redisson.RedissonMultimap
 
getFairLock(String) - Method in class org.redisson.RedissonReactive
 
getFairLock(String) - Method in class org.redisson.RedissonRx
 
getFairLock(V) - Method in class org.redisson.RedissonSet
 
getFairLock(V) - Method in class org.redisson.RedissonSetCache
 
getFairLock(V) - Method in class org.redisson.RedissonSetMultimapValues
 
getFairLock(K) - Method in class org.redisson.rx.RedissonMapRx
 
getFairLock(V) - Method in class org.redisson.rx.RedissonSetCacheRx
 
getFairLock(V) - Method in class org.redisson.rx.RedissonSetRx
 
getFairLock(K) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
getFairLock(K) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
getFairLock(V) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
getFalseProbability() - Method in interface org.redisson.api.RBloomFilter
Returns false probability of element presence.
getFalseProbability() - Method in class org.redisson.RedissonBloomFilter
 
getField(Object, String) - Static method in class org.redisson.liveobject.misc.ClassUtils
 
getFieldDescription(Class<?>, String) - Static method in class org.redisson.liveobject.misc.Introspectior
 
getFieldReferenceName(Class<?>, Object, Class<?>, String, Object) - Method in class org.redisson.liveobject.resolver.DefaultNamingScheme
 
getFieldReferenceName(Class<?>, Object, Class<?>, String, Object) - Method in interface org.redisson.liveobject.resolver.NamingScheme
 
getFieldsDescription(Class<?>) - Static method in class org.redisson.liveobject.misc.Introspectior
 
getFieldsWithAnnotation(Class<?>, Class<? extends Annotation>) - Static method in class org.redisson.liveobject.misc.Introspectior
 
getFinalFireTime() - Method in class org.redisson.executor.CronExpression
 
getFirst() - Method in class org.redisson.RedissonPriorityQueue
 
getFirst() - Method in class org.redisson.RedissonQueue
 
getFirstEntry() - Method in class org.redisson.api.StreamInfo
Returns first stream entry
getFirstThreadId() - Method in class org.redisson.RedissonLock.ExpirationEntry
 
getFreeAmount() - Method in class org.redisson.connection.ClientConnectionsEntry
 
getFreeWorkers(Class<?>) - Method in interface org.redisson.api.RRemoteService
Returns free workers amount available for invocations
getFreeWorkers(Class<?>) - Method in class org.redisson.RedissonRemoteService
 
getFreezeReason() - Method in class org.redisson.connection.ClientConnectionsEntry
 
getFrom(Channel) - Static method in class org.redisson.client.RedisConnection
 
getFuture() - Method in class org.redisson.RedissonRemoteService.Entry
 
getGeo(String) - Method in interface org.redisson.api.RBatch
Returns geospatial items holder instance by name.
getGeo(String, Codec) - Method in interface org.redisson.api.RBatch
Returns geospatial items holder instance by name using provided codec for geospatial members.
getGeo(String) - Method in interface org.redisson.api.RBatchReactive
Returns geospatial items holder instance by name.
getGeo(String, Codec) - Method in interface org.redisson.api.RBatchReactive
Returns geospatial items holder instance by name using provided codec for geospatial members.
getGeo(String) - Method in interface org.redisson.api.RBatchRx
Returns geospatial items holder instance by name.
getGeo(String, Codec) - Method in interface org.redisson.api.RBatchRx
Returns geospatial items holder instance by name using provided codec for geospatial members.
getGeo(String) - Method in interface org.redisson.api.RedissonClient
Returns geospatial items holder instance by name.
getGeo(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns geospatial items holder instance by name using provided codec for geospatial members.
getGeo(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns geospatial items holder instance by name.
getGeo(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns geospatial items holder instance by name using provided codec for geospatial members.
getGeo(String) - Method in interface org.redisson.api.RedissonRxClient
Returns geospatial items holder instance by name.
getGeo(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns geospatial items holder instance by name using provided codec for geospatial members.
getGeo(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getGeo(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getGeo(String) - Method in class org.redisson.Redisson
 
getGeo(String, Codec) - Method in class org.redisson.Redisson
 
getGeo(String) - Method in class org.redisson.RedissonBatch
 
getGeo(String, Codec) - Method in class org.redisson.RedissonBatch
 
getGeo(String) - Method in class org.redisson.RedissonReactive
 
getGeo(String, Codec) - Method in class org.redisson.RedissonReactive
 
getGeo(String) - Method in class org.redisson.RedissonRx
 
getGeo(String, Codec) - Method in class org.redisson.RedissonRx
 
getGeo(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getGeo(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getGroup() - Method in class org.redisson.client.RedisClientConfig
 
getGroup() - Method in interface org.redisson.connection.ConnectionManager
 
getGroup() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getGroups() - Method in class org.redisson.api.StreamInfo
Returns amount of groups belonging to the stream
getHashIterations() - Method in interface org.redisson.api.RBloomFilter
Returns hash iterations amount used per element.
getHashIterations() - Method in class org.redisson.RedissonBloomFilter
 
getHighestId() - Method in class org.redisson.api.PendingResult
Highest stream id of pending messages
getHoldCount() - Method in interface org.redisson.api.RLock
Number of holds on this lock by the current thread
getHoldCount() - Method in interface org.redisson.api.RLockReactive
Number of holds on this lock by the current thread
getHoldCount() - Method in interface org.redisson.api.RLockRx
Number of holds on this lock by the current thread
getHoldCount() - Method in class org.redisson.RedissonLock
 
getHoldCount() - Method in class org.redisson.RedissonMultiLock
 
getHoldCountAsync() - Method in interface org.redisson.api.RLockAsync
Number of holds on this lock by the current thread
getHoldCountAsync() - Method in class org.redisson.RedissonLock
 
getHoldCountAsync() - Method in class org.redisson.RedissonMultiLock
 
getHost() - Method in class org.redisson.misc.RedisURI
 
getHyperLogLog(String) - Method in interface org.redisson.api.RBatch
Returns HyperLogLog object
getHyperLogLog(String, Codec) - Method in interface org.redisson.api.RBatch
 
getHyperLogLog(String) - Method in interface org.redisson.api.RBatchReactive
Returns HyperLogLog object by name
getHyperLogLog(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getHyperLogLog(String) - Method in interface org.redisson.api.RBatchRx
Returns HyperLogLog object by name
getHyperLogLog(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getHyperLogLog(String) - Method in interface org.redisson.api.RedissonClient
Returns HyperLogLog instance by name.
getHyperLogLog(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns HyperLogLog instance by name using provided codec for hll objects.
getHyperLogLog(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns HyperLogLog instance by name.
getHyperLogLog(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns HyperLogLog instance by name using provided codec for hll objects.
getHyperLogLog(String) - Method in interface org.redisson.api.RedissonRxClient
Returns HyperLogLog instance by name.
getHyperLogLog(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns HyperLogLog instance by name using provided codec for hll objects.
getHyperLogLog(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getHyperLogLog(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getHyperLogLog(String) - Method in class org.redisson.Redisson
 
getHyperLogLog(String, Codec) - Method in class org.redisson.Redisson
 
getHyperLogLog(String) - Method in class org.redisson.RedissonBatch
 
getHyperLogLog(String, Codec) - Method in class org.redisson.RedissonBatch
 
getHyperLogLog(String) - Method in class org.redisson.RedissonReactive
 
getHyperLogLog(String, Codec) - Method in class org.redisson.RedissonReactive
 
getHyperLogLog(String) - Method in class org.redisson.RedissonRx
 
getHyperLogLog(String, Codec) - Method in class org.redisson.RedissonRx
 
getHyperLogLog(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getHyperLogLog(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getId() - Method in class org.redisson.api.PendingEntry
Returns stream id of message
getId() - Method in interface org.redisson.api.RedissonClient
Returns id of this Redisson instance
getId() - Method in interface org.redisson.api.RedissonReactiveClient
Returns id of this Redisson instance
getId() - Method in interface org.redisson.api.RedissonRxClient
Returns id of this Redisson instance
getId() - Method in class org.redisson.api.StreamInfo.Entry
Returns StreamMessageId of this stream entry.
getId() - Method in interface org.redisson.connection.ConnectionManager
 
getId() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getId() - Method in class org.redisson.Redisson
 
getId() - Method in class org.redisson.RedissonNode
 
getId() - Method in class org.redisson.RedissonReactive
 
getId() - Method in class org.redisson.RedissonRx
 
getId() - Method in class org.redisson.remote.RemoteServiceAck
 
getId() - Method in class org.redisson.remote.RemoteServiceCancelResponse
 
getId() - Method in class org.redisson.remote.RemoteServiceRequest
 
getId() - Method in class org.redisson.remote.RemoteServiceResponse
 
getId() - Method in interface org.redisson.remote.RRemoteServiceResponse
 
getId(Element, BeanDefinitionBuilder, ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
getId0() - Method in class org.redisson.api.StreamMessageId
Returns first part of ID
getId1() - Method in class org.redisson.api.StreamMessageId
Returns second part of ID
getIdleConnectionTimeout() - Method in class org.redisson.config.BaseConfig
 
getIdleKeys() - Method in class org.redisson.client.protocol.decoder.MapCacheScanResult
 
getIdleTime() - Method in class org.redisson.api.PendingEntry
Returns milliseconds amount have passed since the last time the message was delivered to some consumer
getIdleTime() - Method in class org.redisson.api.StreamConsumer
Returns idle time in milliseconds since which this consumer hasn't consumed messages
getImplementationName() - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
getImplementationVendor() - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
getImplementationVersion() - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
getIndex() - Method in class org.redisson.RedissonPriorityQueue.BinarySearchResult
 
getIndex() - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
 
getIndexName(Class<?>, String) - Method in class org.redisson.liveobject.resolver.DefaultNamingScheme
 
getIndexName(Class<?>, String) - Method in interface org.redisson.liveobject.resolver.NamingScheme
 
getInfo() - Method in interface org.redisson.api.RStream
Returns information about this stream.
getInfo() - Method in interface org.redisson.api.RStreamReactive
Returns information about this stream.
getInfo() - Method in interface org.redisson.api.RStreamRx
Returns information about this stream.
getInfo() - Method in class org.redisson.RedissonStream
 
getInfoAsync() - Method in interface org.redisson.api.RStreamAsync
Returns information about this stream.
getInfoAsync() - Method in class org.redisson.RedissonStream
 
getInnerPromise() - Method in class org.redisson.misc.PromiseDelegator
 
getInputStream() - Method in interface org.redisson.api.RBinaryStream
Returns inputStream object which allows to read binary stream.
getInputStream() - Method in class org.redisson.RedissonBinaryStream
 
getInstance() - Method in interface org.redisson.api.redisnode.RedisSingle
Returns Redis node
getInstance() - Method in class org.redisson.redisnode.RedissonSingleNode
 
getInstanceId() - Method in class org.redisson.cache.LocalCacheListener
 
getInterrupted(RFuture<V>) - Method in interface org.redisson.command.CommandAsyncExecutor
 
getInterrupted(RFuture<V>) - Method in class org.redisson.command.CommandAsyncService
 
getInvalidationTopic() - Method in class org.redisson.cache.LocalCacheListener
 
getInvalidationTopicName() - Method in class org.redisson.cache.LocalCacheListener
 
getIterator(String) - Method in class org.redisson.RedissonListMultimapIterator
 
getIterator(String) - Method in class org.redisson.RedissonSetMultimapIterator
 
getJcacheConfig() - Method in class org.redisson.jcache.configuration.RedissonConfiguration
 
getKey() - Method in class org.redisson.api.map.event.EntryEvent
 
getKey() - Method in interface org.redisson.cache.CachedValue
 
getKey() - Method in class org.redisson.cache.CacheValue
 
getKey() - Method in class org.redisson.cache.LocalCachedMapUpdate.Entry
 
getKey() - Method in class org.redisson.cache.StdCachedValue
 
getKey() - Method in class org.redisson.client.protocol.decoder.KeyValueMessage
 
getKey() - Method in class org.redisson.jcache.JCacheEntry
 
getKey() - Method in class org.redisson.jcache.JCacheEntryEvent
 
getKey() - Method in class org.redisson.jcache.JMutableEntry
 
getKey() - Method in class org.redisson.RedissonMapEntry
 
getKey() - Method in class org.redisson.transaction.BaseTransactionalMap.MapEntry
 
getKey() - Method in class org.redisson.transaction.operation.map.MapOperation
 
getKeyHash() - Method in class org.redisson.cache.CacheKey
 
getKeyHashes() - Method in class org.redisson.cache.LocalCachedMapDisable
 
getKeyHashes() - Method in class org.redisson.cache.LocalCachedMapEnable
 
getKeyHashes() - Method in class org.redisson.cache.LocalCachedMapInvalidate
 
getKeyIds() - Method in class org.redisson.transaction.HashValue
 
getKeyName() - Method in class org.redisson.RedissonReference
 
getKeyPrefix(long, String) - Method in class org.redisson.RedissonReadLock
 
getKeys() - Method in interface org.redisson.api.RBatch
Returns keys operations.
getKeys() - Method in interface org.redisson.api.RBatchReactive
Returns keys operations.
getKeys() - Method in interface org.redisson.api.RBatchRx
Returns keys operations.
getKeys() - Method in interface org.redisson.api.RedissonClient
Returns interface with methods for Redis keys.
getKeys() - Method in interface org.redisson.api.RedissonReactiveClient
Returns keys operations.
getKeys() - Method in interface org.redisson.api.RedissonRxClient
Returns keys operations.
getKeys() - Method in interface org.redisson.api.RKeys
Get all keys using iterator.
getKeys(int) - Method in interface org.redisson.api.RKeys
Get all keys using iterator.
getKeys() - Method in interface org.redisson.api.RKeysReactive
Load keys in incrementally iterate mode.
getKeys(int) - Method in interface org.redisson.api.RKeysReactive
Load keys in incrementally iterate mode.
getKeys() - Method in interface org.redisson.api.RKeysRx
Load keys in incrementally iterate mode.
getKeys(int) - Method in interface org.redisson.api.RKeysRx
Load keys in incrementally iterate mode.
getKeys() - Method in class org.redisson.MapWriterTask
 
getKeys() - Method in class org.redisson.reactive.RedissonBatchReactive
 
getKeys() - Method in class org.redisson.reactive.RedissonKeysReactive
 
getKeys(int) - Method in class org.redisson.reactive.RedissonKeysReactive
 
getKeys() - Method in class org.redisson.Redisson
 
getKeys() - Method in class org.redisson.RedissonBatch
 
getKeys() - Method in class org.redisson.RedissonKeys
 
getKeys(int) - Method in class org.redisson.RedissonKeys
 
getKeys() - Method in class org.redisson.RedissonReactive
 
getKeys() - Method in class org.redisson.RedissonRx
 
getKeys() - Method in class org.redisson.rx.RedissonBatchRx
 
getKeys() - Method in class org.redisson.rx.RedissonKeysRx
 
getKeys(int) - Method in class org.redisson.rx.RedissonKeysRx
 
getKeysByPattern(String) - Method in interface org.redisson.api.RKeys
Get all keys by pattern using iterator.
getKeysByPattern(String, int) - Method in interface org.redisson.api.RKeys
Get all keys by pattern using iterator.
getKeysByPattern(String) - Method in interface org.redisson.api.RKeysReactive
Find keys by pattern and load it in incrementally iterate mode.
getKeysByPattern(String, int) - Method in interface org.redisson.api.RKeysReactive
Get all keys by pattern using iterator.
getKeysByPattern(String) - Method in interface org.redisson.api.RKeysRx
Find keys by pattern and load it in incrementally iterate mode.
getKeysByPattern(String, int) - Method in interface org.redisson.api.RKeysRx
Get all keys by pattern using iterator.
getKeysByPattern(String) - Method in class org.redisson.reactive.RedissonKeysReactive
 
getKeysByPattern(String, int) - Method in class org.redisson.reactive.RedissonKeysReactive
 
getKeysByPattern(String) - Method in class org.redisson.RedissonKeys
 
getKeysByPattern(String, int) - Method in class org.redisson.RedissonKeys
 
getKeysByPattern(String) - Method in class org.redisson.rx.RedissonKeysRx
 
getKeysByPattern(String, int) - Method in class org.redisson.rx.RedissonKeysRx
 
getKeysStream() - Method in interface org.redisson.api.RKeys
Get all keys using Stream.
getKeysStream(int) - Method in interface org.redisson.api.RKeys
Get all keys using Stream.
getKeysStream() - Method in class org.redisson.RedissonKeys
 
getKeysStream(int) - Method in class org.redisson.RedissonKeys
 
getKeysStreamByPattern(String) - Method in interface org.redisson.api.RKeys
Get all keys by pattern using Stream.
getKeysStreamByPattern(String, int) - Method in interface org.redisson.api.RKeys
Get all keys by pattern using Stream.
getKeysStreamByPattern(String) - Method in class org.redisson.RedissonKeys
 
getKeysStreamByPattern(String, int) - Method in class org.redisson.RedissonKeys
 
getKeyType() - Method in class org.redisson.jcache.bean.JCacheManagementMXBean
 
getKeyType() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
getKeyType() - Method in class org.redisson.jcache.configuration.RedissonConfiguration
 
getLambda() - Method in class org.redisson.RedissonExecutorService.ClassBody
 
getLambdaBody() - Method in class org.redisson.executor.params.TaskParameters
 
getLast() - Method in interface org.redisson.api.RDequeReactive
Returns element at the tail of this deque or null if there are no elements in deque.
getLast() - Method in interface org.redisson.api.RDequeRx
Returns element at the tail of this deque or null if there are no elements in deque.
getLast() - Method in class org.redisson.RedissonDeque
 
getLast() - Method in class org.redisson.RedissonPriorityDeque
 
getLastAsync() - Method in interface org.redisson.api.RDequeAsync
Returns element at the tail of this deque or null if there are no elements in deque.
getLastAsync() - Method in class org.redisson.RedissonDeque
 
getLastAsync() - Method in class org.redisson.RedissonPriorityDeque
 
getLastClusterNode() - Method in class org.redisson.cluster.ClusterConnectionManager
 
getLastClusterNode() - Method in interface org.redisson.connection.ConnectionManager
 
getLastClusterNode() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getLastDayOfMonth(int, int) - Method in class org.redisson.executor.CronExpression
 
getLastDeliveredId() - Method in class org.redisson.api.StreamGroup
Returns last delivered StreamMessageId for this group
getLastEntry() - Method in class org.redisson.api.StreamInfo
Returns last stream entry
getLastGeneratedId() - Method in class org.redisson.api.StreamInfo
Returns last StreamMessageId used by the stream
getLastTimeDelivered() - Method in class org.redisson.api.PendingEntry
Returns number of times that a given message was delivered
getLastUsageTime() - Method in class org.redisson.client.RedisConnection
 
getLatch() - Method in class org.redisson.RedissonCountDownLatchEntry
 
getLatch() - Method in class org.redisson.RedissonLockEntry
 
getLatitude() - Method in class org.redisson.api.GeoEntry
 
getLatitude() - Method in class org.redisson.api.GeoPosition
 
getLength() - Method in class org.redisson.api.StreamInfo
Returns length of the stream
getLevel() - Method in class org.redisson.client.handler.State
 
getLexSortedSet(String) - Method in interface org.redisson.api.RBatch
Returns String based Redis Sorted Set instance by name All elements are inserted with the same score during addition, in order to force lexicographical ordering
getLexSortedSet(String) - Method in interface org.redisson.api.RBatchReactive
Returns String based Redis Sorted Set instance by name All elements are inserted with the same score during addition, in order to force lexicographical ordering
getLexSortedSet(String) - Method in interface org.redisson.api.RBatchRx
Returns String based Redis Sorted Set instance by name All elements are inserted with the same score during addition, in order to force lexicographical ordering
getLexSortedSet(String) - Method in interface org.redisson.api.RedissonClient
Returns String based Redis Sorted Set instance by name All elements are inserted with the same score during addition, in order to force lexicographical ordering
getLexSortedSet(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns String based Redis Sorted Set instance by name All elements are inserted with the same score during addition, in order to force lexicographical ordering
getLexSortedSet(String) - Method in interface org.redisson.api.RedissonRxClient
Returns String based Redis Sorted Set instance by name All elements are inserted with the same score during addition, in order to force lexicographical ordering
getLexSortedSet(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getLexSortedSet(String) - Method in class org.redisson.Redisson
 
getLexSortedSet(String) - Method in class org.redisson.RedissonBatch
 
getLexSortedSet(String) - Method in class org.redisson.RedissonReactive
 
getLexSortedSet(String) - Method in class org.redisson.RedissonRx
 
getLexSortedSet(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getList(String) - Method in interface org.redisson.api.RBatch
Returns list instance by name.
getList(String, Codec) - Method in interface org.redisson.api.RBatch
 
getList(String) - Method in interface org.redisson.api.RBatchReactive
Returns list instance by name.
getList(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getList(String) - Method in interface org.redisson.api.RBatchRx
Returns list instance by name.
getList(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getList(String) - Method in interface org.redisson.api.RedissonClient
Returns list instance by name.
getList(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns list instance by name using provided codec for list objects.
getList(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns list instance by name.
getList(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns list instance by name using provided codec for list objects.
getList(String) - Method in interface org.redisson.api.RedissonRxClient
Returns list instance by name.
getList(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns list instance by name using provided codec for list objects.
getList(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getList(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getList(String) - Method in class org.redisson.Redisson
 
getList(String, Codec) - Method in class org.redisson.Redisson
 
getList(String) - Method in class org.redisson.RedissonBatch
 
getList(String, Codec) - Method in class org.redisson.RedissonBatch
 
getList(String) - Method in class org.redisson.RedissonReactive
 
getList(String, Codec) - Method in class org.redisson.RedissonReactive
 
getList(String) - Method in class org.redisson.RedissonRx
 
getList(String, Codec) - Method in class org.redisson.RedissonRx
 
getList(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getList(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getListener() - Method in class org.redisson.PubSubMessageListener
 
getListener() - Method in class org.redisson.PubSubPatternMessageListener
 
getListeners() - Method in class org.redisson.api.WorkerOptions
 
getListeners(ChannelName) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
getListeners() - Method in class org.redisson.RedissonCountDownLatchEntry
 
getListeners() - Method in class org.redisson.RedissonLockEntry
 
getListMultimap(String) - Method in interface org.redisson.api.RBatch
Returns List based MultiMap instance by name.
getListMultimap(String, Codec) - Method in interface org.redisson.api.RBatch
Returns List based MultiMap instance by name using provided codec for both map keys and values.
getListMultimap(String) - Method in interface org.redisson.api.RBatchReactive
Returns List based MultiMap instance by name.
getListMultimap(String, Codec) - Method in interface org.redisson.api.RBatchReactive
Returns List based MultiMap instance by name using provided codec for both map keys and values.
getListMultimap(String) - Method in interface org.redisson.api.RBatchRx
Returns List based MultiMap instance by name.
getListMultimap(String, Codec) - Method in interface org.redisson.api.RBatchRx
Returns List based MultiMap instance by name using provided codec for both map keys and values.
getListMultimap(String) - Method in interface org.redisson.api.RedissonClient
Returns List based Multimap instance by name.
getListMultimap(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns List based Multimap instance by name using provided codec for both map keys and values.
getListMultimap(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns List based Multimap instance by name.
getListMultimap(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns List based Multimap instance by name using provided codec for both map keys and values.
getListMultimap(String) - Method in interface org.redisson.api.RedissonRxClient
Returns List based Multimap instance by name.
getListMultimap(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns List based Multimap instance by name using provided codec for both map keys and values.
getListMultimap(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getListMultimap(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getListMultimap(String) - Method in class org.redisson.Redisson
 
getListMultimap(String, Codec) - Method in class org.redisson.Redisson
 
getListMultimap(String) - Method in class org.redisson.RedissonBatch
 
getListMultimap(String, Codec) - Method in class org.redisson.RedissonBatch
 
getListMultimap(String) - Method in class org.redisson.RedissonReactive
 
getListMultimap(String, Codec) - Method in class org.redisson.RedissonReactive
 
getListMultimap(String) - Method in class org.redisson.RedissonRx
 
getListMultimap(String, Codec) - Method in class org.redisson.RedissonRx
 
getListMultimap(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getListMultimap(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getListMultimapCache(String) - Method in interface org.redisson.api.RBatch
Returns List based Multimap instance by name.
getListMultimapCache(String, Codec) - Method in interface org.redisson.api.RBatch
Returns List based Multimap instance by name using provided codec for both map keys and values.
getListMultimapCache(String) - Method in interface org.redisson.api.RedissonClient
Returns List based Multimap instance by name.
getListMultimapCache(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns List based Multimap instance by name using provided codec for both map keys and values.
getListMultimapCache(String) - Method in class org.redisson.Redisson
 
getListMultimapCache(String, Codec) - Method in class org.redisson.Redisson
 
getListMultimapCache(String) - Method in class org.redisson.RedissonBatch
 
getListMultimapCache(String, Codec) - Method in class org.redisson.RedissonBatch
 
getLiveObjectId() - Method in interface org.redisson.api.RLiveObject
Returns the value of the field that has the RId annotation.
getLiveObjectService() - Method in interface org.redisson.api.RedissonClient
Returns RedissonAttachedLiveObjectService which can be used to retrieve live REntity(s)
getLiveObjectService() - Method in class org.redisson.Redisson
 
getLoadBalancer() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getLoader() - Method in class org.redisson.api.MapOptions
 
getLocalAddress() - Method in class org.redisson.RedissonNode
 
getLocalCachedMap(String, LocalCachedMapOptions<K, V>) - Method in interface org.redisson.api.RedissonClient
Returns local cached map instance by name.
getLocalCachedMap(String, Codec, LocalCachedMapOptions<K, V>) - Method in interface org.redisson.api.RedissonClient
Returns local cached map instance by name using provided codec.
getLocalCachedMap(RLocalCachedMap<K, V>) - Method in interface org.redisson.api.RTransaction
Returns transactional local cached map proxy for specified local cached map instance.
getLocalCachedMap(String, LocalCachedMapOptions<K, V>) - Method in class org.redisson.Redisson
 
getLocalCachedMap(String, Codec, LocalCachedMapOptions<K, V>) - Method in class org.redisson.Redisson
 
getLocalCachedMap(RLocalCachedMap<K, V>) - Method in class org.redisson.transaction.RedissonTransaction
 
getLocalCaches() - Method in class org.redisson.transaction.RedissonTransaction
 
getLock(String) - Method in interface org.redisson.api.RedissonClient
Returns Lock instance by name.
getLock(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns lock instance by name.
getLock(String) - Method in interface org.redisson.api.RedissonRxClient
Returns lock instance by name.
getLock(K) - Method in interface org.redisson.api.RMap
Returns RLock instance associated with key
getLock(K) - Method in interface org.redisson.api.RMapReactive
Returns RLock instance associated with key
getLock(K) - Method in interface org.redisson.api.RMapRx
Returns RLock instance associated with key
getLock(K) - Method in interface org.redisson.api.RMultimap
Returns RLock instance associated with key
getLock(V) - Method in interface org.redisson.api.RSet
Returns lock instance associated with value
getLock(V) - Method in interface org.redisson.api.RSetCache
Returns lock instance associated with value
getLock(V) - Method in interface org.redisson.api.RSetCacheReactive
Returns lock instance associated with value
getLock(V) - Method in interface org.redisson.api.RSetCacheRx
Returns lock instance associated with value
getLock(V) - Method in interface org.redisson.api.RSetReactive
Returns lock instance associated with value
getLock(V) - Method in interface org.redisson.api.RSetRx
Returns lock instance associated with value
getLock(K) - Method in class org.redisson.reactive.RedissonMapReactive
 
getLock(V) - Method in class org.redisson.reactive.RedissonSetCacheReactive
 
getLock(V) - Method in class org.redisson.reactive.RedissonSetReactive
 
getLock(String) - Method in class org.redisson.Redisson
 
getLock(K) - Method in class org.redisson.RedissonMap
 
getLock(K) - Method in class org.redisson.RedissonMultimap
 
getLock(String) - Method in class org.redisson.RedissonReactive
 
getLock(String) - Method in class org.redisson.RedissonRx
 
getLock(V) - Method in class org.redisson.RedissonSet
 
getLock(V) - Method in class org.redisson.RedissonSetCache
 
getLock(V) - Method in class org.redisson.RedissonSetMultimapValues
 
getLock(K) - Method in class org.redisson.rx.RedissonMapRx
 
getLock(V) - Method in class org.redisson.rx.RedissonSetCacheRx
 
getLock(V) - Method in class org.redisson.rx.RedissonSetRx
 
getLock(K) - Method in class org.redisson.transaction.BaseTransactionalMap
 
getLock(RCollectionAsync<V>, V) - Method in class org.redisson.transaction.BaseTransactionalSet
 
getLock(RMap<?, ?>, CommandAsyncExecutor, Object) - Method in class org.redisson.transaction.operation.map.MapOperation
 
getLock(RSetCache<?>, CommandAsyncExecutor, Object) - Method in class org.redisson.transaction.operation.set.SetOperation
 
getLock(RSet<?>, CommandAsyncExecutor, Object) - Method in class org.redisson.transaction.operation.set.SetOperation
 
getLock(K) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
getLock(K) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
getLock(V) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
getLock(RCollectionAsync<V>, V) - Method in class org.redisson.transaction.TransactionalSet
 
getLock(RCollectionAsync<V>, V) - Method in class org.redisson.transaction.TransactionalSetCache
 
getLockByMapKey(Object, String) - Method in class org.redisson.RedissonObject
 
getLockByValue(Object, String) - Method in class org.redisson.RedissonObject
 
getLockName(long) - Method in class org.redisson.RedissonLock
 
getLockName(long) - Method in class org.redisson.RedissonWriteLock
 
getLockName() - Method in class org.redisson.transaction.operation.bucket.BucketCompareAndSetOperation
 
getLockName() - Method in class org.redisson.transaction.operation.bucket.BucketGetAndDeleteOperation
 
getLockName() - Method in class org.redisson.transaction.operation.bucket.BucketGetAndSetOperation
 
getLockName() - Method in class org.redisson.transaction.operation.bucket.BucketSetOperation
 
getLockName() - Method in class org.redisson.transaction.operation.bucket.BucketTrySetOperation
 
getLockName() - Method in class org.redisson.transaction.operation.DeleteOperation
 
getLockName() - Method in class org.redisson.transaction.operation.TouchOperation
 
getLockName() - Method in class org.redisson.transaction.operation.UnlinkOperation
 
getLockName(long) - Method in class org.redisson.transaction.RedissonTransactionalLock
 
getLockPubSub() - Method in class org.redisson.pubsub.PublishSubscribeService
 
getLockWatchdogTimeout() - Method in class org.redisson.config.Config
 
getLongAdder(String) - Method in interface org.redisson.api.RedissonClient
Returns LongAdder instances by name.
getLongAdder(String) - Method in class org.redisson.Redisson
 
getLongitude() - Method in class org.redisson.api.GeoEntry
 
getLongitude() - Method in class org.redisson.api.GeoPosition
 
getLowestId() - Method in class org.redisson.api.PendingResult
Lowest stream id of pending messages
getMap(String) - Method in interface org.redisson.api.RBatch
Returns map instance by name.
getMap(String, Codec) - Method in interface org.redisson.api.RBatch
 
getMap(String) - Method in interface org.redisson.api.RBatchReactive
Returns map instance by name.
getMap(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getMap(String) - Method in interface org.redisson.api.RBatchRx
Returns map instance by name.
getMap(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getMap(String) - Method in interface org.redisson.api.RedissonClient
Returns map instance by name.
getMap(String, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonClient
Returns map instance by name.
getMap(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns map instance by name using provided codec for both map keys and values.
getMap(String, Codec, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonClient
Returns map instance by name using provided codec for both map keys and values.
getMap(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns map instance by name.
getMap(String, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonReactiveClient
Returns map instance by name.
getMap(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns map instance by name using provided codec for both map keys and values.
getMap(String, Codec, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonReactiveClient
Returns map instance by name using provided codec for both map keys and values.
getMap(String) - Method in interface org.redisson.api.RedissonRxClient
Returns map instance by name.
getMap(String, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonRxClient
Returns map instance by name.
getMap(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns map instance by name using provided codec for both map keys and values.
getMap(String, Codec, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonRxClient
Returns map instance by name using provided codec for both map keys and values.
getMap(String) - Method in interface org.redisson.api.RTransaction
Returns transactional map instance by name.
getMap(String, Codec) - Method in interface org.redisson.api.RTransaction
Returns transactional map instance by name using provided codec for both map keys and values.
getMap(String) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional map instance by name.
getMap(String, Codec) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional map instance by name using provided codec for both map keys and values.
getMap(String) - Method in interface org.redisson.api.RTransactionRx
Returns transactional map instance by name.
getMap(String, Codec) - Method in interface org.redisson.api.RTransactionRx
Returns transactional map instance by name using provided codec for both map keys and values.
getMap() - Method in class org.redisson.client.protocol.decoder.MapScanResult
 
getMap() - Method in class org.redisson.MapWriterTask
 
getMap(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getMap(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getMap(String) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getMap(String, Codec) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getMap(String) - Method in class org.redisson.Redisson
 
getMap(String, MapOptions<K, V>) - Method in class org.redisson.Redisson
 
getMap(String, Codec) - Method in class org.redisson.Redisson
 
getMap(String, Codec, MapOptions<K, V>) - Method in class org.redisson.Redisson
 
getMap(String) - Method in class org.redisson.RedissonBatch
 
getMap(String, Codec) - Method in class org.redisson.RedissonBatch
 
getMap(String) - Method in class org.redisson.RedissonReactive
 
getMap(String, Codec) - Method in class org.redisson.RedissonReactive
 
getMap(String, MapOptions<K, V>) - Method in class org.redisson.RedissonReactive
 
getMap(String, Codec, MapOptions<K, V>) - Method in class org.redisson.RedissonReactive
 
getMap(String) - Method in class org.redisson.RedissonRx
 
getMap(String, Codec) - Method in class org.redisson.RedissonRx
 
getMap(String, MapOptions<K, V>) - Method in class org.redisson.RedissonRx
 
getMap(String, Codec, MapOptions<K, V>) - Method in class org.redisson.RedissonRx
 
getMap(String) - Method in class org.redisson.remote.BaseRemoteService
 
getMap(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getMap(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getMap(String) - Method in class org.redisson.rx.RedissonTransactionRx
 
getMap(String, Codec) - Method in class org.redisson.rx.RedissonTransactionRx
 
getMap(String, CacheConfig) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
 
getMap() - Method in class org.redisson.transaction.operation.map.MapOperation
 
getMap(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.map.MapOperation
 
getMap(String) - Method in class org.redisson.transaction.RedissonTransaction
 
getMap(String, Codec) - Method in class org.redisson.transaction.RedissonTransaction
 
getMapCache(String, Codec) - Method in interface org.redisson.api.RBatch
Returns map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String) - Method in interface org.redisson.api.RBatch
Returns map-based cache instance by name.
getMapCache(String, Codec) - Method in interface org.redisson.api.RBatchReactive
Returns map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String) - Method in interface org.redisson.api.RBatchReactive
Returns map-based cache instance by name.
getMapCache(String, Codec) - Method in interface org.redisson.api.RBatchRx
Returns map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String) - Method in interface org.redisson.api.RBatchRx
Returns map-based cache instance by name.
getMapCache(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String, Codec, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonClient
Returns map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String) - Method in interface org.redisson.api.RedissonClient
Returns map-based cache instance by name.
getMapCache(String, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonClient
Returns map-based cache instance by name.
getMapCache(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String, Codec, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonReactiveClient
Returns map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns map-based cache instance by name.
getMapCache(String, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonReactiveClient
Returns map-based cache instance by name.
getMapCache(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String, Codec, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonRxClient
Returns map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String) - Method in interface org.redisson.api.RedissonRxClient
Returns map-based cache instance by name.
getMapCache(String, MapOptions<K, V>) - Method in interface org.redisson.api.RedissonRxClient
Returns map-based cache instance by name.
getMapCache(String) - Method in interface org.redisson.api.RTransaction
Returns transactional map-based cache instance by name.
getMapCache(String, Codec) - Method in interface org.redisson.api.RTransaction
Returns transactional map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional map-based cache instance by name.
getMapCache(String, Codec) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String) - Method in interface org.redisson.api.RTransactionRx
Returns transactional map-based cache instance by name.
getMapCache(String, Codec) - Method in interface org.redisson.api.RTransactionRx
Returns transactional map-based cache instance by name using provided codec for both cache keys and values.
getMapCache(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getMapCache(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getMapCache(String, Codec) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getMapCache(String) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getMapCache(String) - Method in class org.redisson.Redisson
 
getMapCache(String, MapOptions<K, V>) - Method in class org.redisson.Redisson
 
getMapCache(String, Codec) - Method in class org.redisson.Redisson
 
getMapCache(String, Codec, MapOptions<K, V>) - Method in class org.redisson.Redisson
 
getMapCache(String, Codec) - Method in class org.redisson.RedissonBatch
 
getMapCache(String) - Method in class org.redisson.RedissonBatch
 
getMapCache(String, Codec) - Method in class org.redisson.RedissonReactive
 
getMapCache(String) - Method in class org.redisson.RedissonReactive
 
getMapCache(String, Codec, MapOptions<K, V>) - Method in class org.redisson.RedissonReactive
 
getMapCache(String, MapOptions<K, V>) - Method in class org.redisson.RedissonReactive
 
getMapCache(String, Codec) - Method in class org.redisson.RedissonRx
 
getMapCache(String) - Method in class org.redisson.RedissonRx
 
getMapCache(String, Codec, MapOptions<K, V>) - Method in class org.redisson.RedissonRx
 
getMapCache(String, MapOptions<K, V>) - Method in class org.redisson.RedissonRx
 
getMapCache(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getMapCache(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getMapCache(String, Codec) - Method in class org.redisson.rx.RedissonTransactionRx
 
getMapCache(String) - Method in class org.redisson.rx.RedissonTransactionRx
 
getMapCache(String, CacheConfig) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
 
getMapCache(String) - Method in class org.redisson.transaction.RedissonTransaction
 
getMapCache(String, Codec) - Method in class org.redisson.transaction.RedissonTransaction
 
getMapKeyDecoder() - Method in class org.redisson.client.codec.BaseCodec
 
getMapKeyDecoder() - Method in class org.redisson.client.codec.BitSetCodec
 
getMapKeyDecoder() - Method in interface org.redisson.client.codec.Codec
Returns object decoder used for hash map keys in HMAP Redis structure
getMapKeyDecoder() - Method in class org.redisson.codec.BaseEventCodec
 
getMapKeyDecoder() - Method in class org.redisson.codec.CompositeCodec
 
getMapKeyDecoder() - Method in class org.redisson.codec.TypedJsonJacksonCodec
 
getMapKeyEncoder() - Method in class org.redisson.client.codec.BaseCodec
 
getMapKeyEncoder() - Method in class org.redisson.client.codec.BitSetCodec
 
getMapKeyEncoder() - Method in interface org.redisson.client.codec.Codec
Returns object encoder used for hash map keys in HMAP Redis structure
getMapKeyEncoder() - Method in class org.redisson.codec.BaseEventCodec
 
getMapKeyEncoder() - Method in class org.redisson.codec.CompositeCodec
 
getMapKeyEncoder() - Method in class org.redisson.codec.TypedJsonJacksonCodec
 
getMapReduceWorkers() - Method in class org.redisson.config.RedissonNodeConfig
 
getMapValueDecoder() - Method in class org.redisson.client.codec.BaseCodec
 
getMapValueDecoder() - Method in class org.redisson.client.codec.BitSetCodec
 
getMapValueDecoder() - Method in interface org.redisson.client.codec.Codec
Returns object decoder used for hash map values in HMAP Redis structure
getMapValueDecoder() - Method in class org.redisson.codec.BaseEventCodec
 
getMapValueDecoder() - Method in class org.redisson.codec.CompositeCodec
 
getMapValueDecoder() - Method in class org.redisson.codec.TypedJsonJacksonCodec
 
getMapValueEncoder() - Method in class org.redisson.client.codec.BaseCodec
 
getMapValueEncoder() - Method in class org.redisson.client.codec.BitSetCodec
 
getMapValueEncoder() - Method in interface org.redisson.client.codec.Codec
Returns object encoder used for hash map values in HMAP Redis structure
getMapValueEncoder() - Method in class org.redisson.codec.BaseEventCodec
 
getMapValueEncoder() - Method in class org.redisson.codec.CompositeCodec
 
getMapValueEncoder() - Method in class org.redisson.codec.TypedJsonJacksonCodec
 
getMaster(String) - Method in interface org.redisson.api.redisnode.RedisCluster
Returns Redis Master node by defined address.
getMaster() - Method in interface org.redisson.api.redisnode.RedisMasterSlave
Returns Redis Master node belong to this Redis setup.
getMaster(String) - Method in interface org.redisson.api.redisnode.RedisMasterSlave
Returns Redis Master node by defined address.
getMaster(String) - Method in interface org.redisson.api.redisnode.RedisSentinel
Returns map containing info regarding defined Redis master.
getMaster(String) - Method in class org.redisson.redisnode.RedissonClusterNodes
 
getMaster() - Method in class org.redisson.redisnode.RedissonMasterSlaveNodes
 
getMaster(String) - Method in class org.redisson.redisnode.RedissonMasterSlaveNodes
 
getMaster(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
getMasterAddr(String) - Method in interface org.redisson.api.redisnode.RedisSentinel
Returns network address of defined Redis master.
getMasterAddr(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
getMasterAddrAsync(String) - Method in interface org.redisson.api.redisnode.RedisSentinelAsync
Returns network address of defined Redis master.
getMasterAddrAsync(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
getMasterAddress() - Method in class org.redisson.cluster.ClusterPartition
 
getMasterAddress() - Method in class org.redisson.config.MasterSlaveServersConfig
 
getMasterAsync(String) - Method in interface org.redisson.api.redisnode.RedisSentinelAsync
Returns map containing info regarding defined Redis master.
getMasterAsync(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
getMasterConnectionMinimumIdleSize() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getMasterConnectionPoolSize() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getMasterName() - Method in class org.redisson.config.SentinelServersConfig
 
getMasters() - Method in interface org.redisson.api.redisnode.RedisCluster
Returns collection of Redis Master nodes belongs to this Redis Cluster.
getMasters() - Method in interface org.redisson.api.redisnode.RedisSentinel
Returns list of map containing info regarding Redis Master server monitored by current Redis Sentinel server.
getMasters() - Method in class org.redisson.redisnode.RedissonClusterNodes
 
getMasters() - Method in class org.redisson.redisnode.SentinelRedisNode
 
getMastersAsync() - Method in interface org.redisson.api.redisnode.RedisSentinelAsync
Returns list of map containing info regarding Redis Master server monitored by current Redis Sentinel server.
getMastersAsync() - Method in class org.redisson.redisnode.SentinelRedisNode
 
getMaxCleanUpDelay() - Method in class org.redisson.config.Config
 
getMaxIdleInMillis() - Method in class org.redisson.api.LocalCachedMapOptions
 
getMaxIdleTime() - Method in class org.redisson.spring.cache.CacheConfig
 
getMaxIdleTime() - Method in class org.redisson.transaction.operation.map.MapCacheFastPutIfAbsentOperation
 
getMaxIdleTime() - Method in class org.redisson.transaction.operation.map.MapCacheFastPutOperation
 
getMaxIdleTime() - Method in class org.redisson.transaction.operation.map.MapCachePutIfAbsentOperation
 
getMaxIdleTimeout() - Method in class org.redisson.transaction.operation.map.MapCachePutOperation
 
getMaxIdleUnit() - Method in class org.redisson.transaction.operation.map.MapCacheFastPutIfAbsentOperation
 
getMaxIdleUnit() - Method in class org.redisson.transaction.operation.map.MapCacheFastPutOperation
 
getMaxIdleUnit() - Method in class org.redisson.transaction.operation.map.MapCachePutIfAbsentOperation
 
getMaxIdleUnit() - Method in class org.redisson.transaction.operation.map.MapCachePutOperation
 
getMaxSize() - Method in class org.redisson.RedissonBloomFilter
 
getMaxSize() - Method in class org.redisson.spring.cache.CacheConfig
 
getMBeanServerId() - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
getMember() - Method in class org.redisson.api.GeoEntry
 
getMessageDecoder() - Method in class org.redisson.client.protocol.CommandData
 
getMessages(Class<M>) - Method in interface org.redisson.api.RTopicReactive
Returns continues stream of messages.
getMessages(Class<M>) - Method in interface org.redisson.api.RTopicRx
Returns continues stream of messages.
getMessages(Class<M>) - Method in class org.redisson.reactive.RedissonTopicReactive
 
getMessages(Class<M>) - Method in class org.redisson.rx.RedissonTopicRx
 
getMeterBinder(RedissonCache, Iterable<Tag>) - Method in class org.redisson.spring.cache.RedissonCacheMeterBinderProvider
 
getMethod() - Method in class org.redisson.remote.RemoteServiceMethod
 
getMethodDescription(Class<?>, String) - Static method in class org.redisson.liveobject.misc.Introspectior
 
getMethodName() - Method in class org.redisson.remote.RemoteServiceKey
 
getMethodName() - Method in class org.redisson.remote.RemoteServiceRequest
 
getMethodSignature(Method) - Method in class org.redisson.remote.BaseRemoteService
 
getMicroseconds() - Method in class org.redisson.client.protocol.Time
 
getMinCleanUpDelay() - Method in class org.redisson.config.Config
 
getMinimumIdleSize(ClientConnectionsEntry) - Method in class org.redisson.connection.pool.MasterConnectionPool
 
getMinimumIdleSize(ClientConnectionsEntry) - Method in class org.redisson.connection.pool.PubSubConnectionPool
 
getMinimumIdleSize(ClientConnectionsEntry) - Method in class org.redisson.connection.pool.SlaveConnectionPool
 
getMonthNumber(String) - Method in class org.redisson.executor.CronExpression
 
getMultiLock(RLock...) - Method in interface org.redisson.api.RedissonClient
Returns MultiLock instance associated with specified locks
getMultiLock(RLock...) - Method in interface org.redisson.api.RedissonReactiveClient
Returns MultiLock instance associated with specified locks
getMultiLock(RLock...) - Method in interface org.redisson.api.RedissonRxClient
Returns MultiLock instance associated with specified locks
getMultiLock(RLock...) - Method in class org.redisson.Redisson
 
getMultiLock(RLock...) - Method in class org.redisson.RedissonReactive
 
getMultiLock(RLock...) - Method in class org.redisson.RedissonRx
 
getName() - Method in interface org.redisson.api.RExecutorService
Returns executor name
getName() - Method in interface org.redisson.api.RLock
Returns name of object
getName() - Method in interface org.redisson.api.RLockReactive
Returns name of object
getName() - Method in interface org.redisson.api.RLockRx
Returns name of object
getName() - Method in interface org.redisson.api.RObject
Returns name of object
getName() - Method in interface org.redisson.api.RObjectReactive
 
getName() - Method in interface org.redisson.api.RObjectRx
 
getName() - Method in class org.redisson.api.StreamConsumer
Returns name of this consumer
getName() - Method in class org.redisson.api.StreamGroup
Returns name of this group
getName() - Method in class org.redisson.client.ChannelName
 
getName() - Method in class org.redisson.client.protocol.RedisCommand
 
getName() - Method in class org.redisson.liveobject.condition.EQCondition
 
getName() - Method in class org.redisson.liveobject.condition.GECondition
 
getName() - Method in class org.redisson.liveobject.condition.GTCondition
 
getName() - Method in class org.redisson.liveobject.condition.LECondition
 
getName() - Method in class org.redisson.liveobject.condition.LTCondition
 
getName(Class<?>, Class<?>, String, Object) - Method in class org.redisson.liveobject.resolver.DefaultNamingScheme
 
getName(Class<?>, Class<?>, String, Object) - Method in interface org.redisson.liveobject.resolver.NamingScheme
 
getName() - Method in class org.redisson.PubSubMessageListener
 
getName() - Method in class org.redisson.PubSubPatternMessageListener
 
getName() - Method in class org.redisson.PubSubPatternStatusListener
 
getName() - Method in class org.redisson.PubSubStatusListener
 
getName() - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
 
getName() - Method in class org.redisson.RedissonExecutorService
 
getName() - Method in class org.redisson.RedissonMultiLock
 
getName() - Method in class org.redisson.RedissonObject
 
getName(Object) - Method in class org.redisson.RedissonObject
 
getName() - Method in class org.redisson.rx.RedissonScoredSortedSetRx
 
getName() - Method in class org.redisson.spring.cache.RedissonCache
 
getName(Node) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
getName() - Method in class org.redisson.transaction.HashKey
 
getName() - Method in class org.redisson.transaction.operation.TransactionalOperation
 
getNamingScheme(Class<?>) - Method in class org.redisson.liveobject.core.RedissonObjectBuilder
 
getNamingScheme(Class<?>, Codec) - Method in class org.redisson.liveobject.core.RedissonObjectBuilder
 
getNativeCache() - Method in class org.redisson.spring.cache.RedissonCache
 
getNatMapper() - Method in class org.redisson.config.ClusterServersConfig
 
getNatMapper() - Method in class org.redisson.config.SentinelServersConfig
 
getNettyHook() - Method in class org.redisson.client.RedisClientConfig
 
getNettyHook() - Method in class org.redisson.config.Config
 
getNettyThreads() - Method in class org.redisson.config.Config
 
getNextInvalidTimeAfter(Date) - Method in class org.redisson.executor.CronExpression
Returns the next date/time after the given date/time which does not satisfy the expression
getNextValidTimeAfter(Date) - Method in class org.redisson.executor.CronExpression
Returns the next date/time after the given date/time which satisfies the cron expression.
getNode(String) - Method in interface org.redisson.api.NodesGroup
Deprecated.
Get Redis node by address in format: redis://host:port
getNode(String, NodeType) - Method in class org.redisson.redisnode.RedissonBaseNodes
 
getNode(String) - Method in class org.redisson.RedisNodes
Deprecated.
 
getNodeAddresses() - Method in class org.redisson.config.ClusterServersConfig
 
getNodeAddresses() - Method in class org.redisson.config.ReplicatedServersConfig
 
getNodeId() - Method in class org.redisson.cluster.ClusterNodeInfo
 
getNodeId() - Method in class org.redisson.cluster.ClusterPartition
 
getNodeInfo() - Method in class org.redisson.cluster.ClusterNodeInfo
 
getNodes(NodeType) - Method in interface org.redisson.api.NodesGroup
Deprecated.
Get all Redis nodes by type
getNodes() - Method in interface org.redisson.api.NodesGroup
Deprecated.
All Redis nodes used by Redisson.
getNodes(NodeType) - Method in class org.redisson.redisnode.RedissonBaseNodes
 
getNodes() - Method in class org.redisson.redisnode.RedissonBaseNodes
 
getNodes(NodeType) - Method in class org.redisson.RedisNodes
Deprecated.
 
getNodes() - Method in class org.redisson.RedisNodes
Deprecated.
 
getNodesGroup() - Method in interface org.redisson.api.RedissonClient
Deprecated.
getNodesGroup() - Method in interface org.redisson.api.RedissonReactiveClient
Get Redis nodes group for server operations
getNodesGroup() - Method in interface org.redisson.api.RedissonRxClient
Get Redis nodes group for server operations
getNodesGroup() - Method in class org.redisson.Redisson
 
getNodesGroup() - Method in class org.redisson.RedissonReactive
 
getNodesGroup() - Method in class org.redisson.RedissonRx
 
getNodeType() - Method in class org.redisson.connection.ClientConnectionsEntry
 
getNotificationInfo() - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
getNow() - Method in interface org.redisson.api.RFuture
Return the result without blocking.
getNow() - Method in class org.redisson.misc.PromiseDelegator
 
getNow() - Method in class org.redisson.misc.RedissonPromise
 
getNumericValue(String, int) - Method in class org.redisson.executor.CronExpression
 
getObjectBuilder() - Method in interface org.redisson.command.CommandAsyncExecutor
 
getObjectBuilder() - Method in class org.redisson.command.CommandAsyncService
 
getObjectInstance(Object, Name, Context, Hashtable<?, ?>) - Method in class org.redisson.JndiRedissonFactory
 
getObjectMapper() - Method in class org.redisson.codec.JsonJacksonCodec
 
getOldValue() - Method in class org.redisson.api.map.event.EntryEvent
 
getOldValue() - Method in class org.redisson.jcache.JCacheEntryEvent
 
getOldValue() - Method in class org.redisson.transaction.operation.map.MapOperation
 
getOperation() - Method in class org.redisson.client.handler.PubSubKey
 
getOperationAsync(K) - Method in class org.redisson.RedissonMap
 
getOperationAsync(K) - Method in class org.redisson.RedissonMapCache
 
getOperationAsync(K) - Method in class org.redisson.transaction.BaseTransactionalMap
 
getOperationAsync(K) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
getOperationAsync(K) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
getOperations() - Method in class org.redisson.transaction.RedissonTransaction
 
getOptions() - Method in class org.redisson.command.CommandBatchService
 
getOptions() - Method in class org.redisson.remote.RemoteServiceRequest
 
getOutParamType() - Method in class org.redisson.client.protocol.RedisCommand
 
getOutputStream() - Method in interface org.redisson.api.RBinaryStream
Returns outputStream object which allows to write binary stream.
getOutputStream() - Method in class org.redisson.RedissonBinaryStream
 
getOwner() - Method in interface org.redisson.cache.CachedValueReference
 
getOwner() - Method in class org.redisson.cache.CachedValueSoftReference
 
getOwner() - Method in class org.redisson.cache.CachedValueWeakReference
 
getParams() - Method in class org.redisson.client.protocol.CommandData
 
getParent() - Method in class org.redisson.cluster.ClusterPartition
 
getParts() - Method in class org.redisson.client.handler.StateLevel
 
getPassword() - Method in class org.redisson.client.RedisClientConfig
 
getPassword() - Method in class org.redisson.config.BaseConfig
 
getPattern() - Method in class org.redisson.client.protocol.pubsub.PubSubPatternMessage
 
getPatternChannels() - Method in class org.redisson.client.RedisPubSubConnection
 
getPatternNames() - Method in interface org.redisson.api.RPatternTopic
Get topic channel patterns
getPatternNames() - Method in interface org.redisson.api.RPatternTopicReactive
Get topic channel patterns
getPatternNames() - Method in interface org.redisson.api.RPatternTopicRx
Get topic channel patterns
getPatternNames() - Method in class org.redisson.RedissonPatternTopic
 
getPatternTopic(String) - Method in interface org.redisson.api.RedissonClient
Returns topic instance satisfies by pattern name.
getPatternTopic(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns topic instance satisfies by pattern name using provided codec for messages.
getPatternTopic(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns topic instance satisfies by pattern name.
getPatternTopic(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns topic instance satisfies by pattern name using provided codec for messages.
getPatternTopic(String) - Method in interface org.redisson.api.RedissonRxClient
Returns topic instance satisfies by pattern name.
getPatternTopic(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns topic instance satisfies by pattern name using provided codec for messages.
getPatternTopic(String) - Method in class org.redisson.Redisson
 
getPatternTopic(String, Codec) - Method in class org.redisson.Redisson
 
getPatternTopic(String) - Method in class org.redisson.RedissonReactive
 
getPatternTopic(String, Codec) - Method in class org.redisson.RedissonReactive
 
getPatternTopic(String) - Method in class org.redisson.RedissonRx
 
getPatternTopic(String, Codec) - Method in class org.redisson.RedissonRx
 
getPending() - Method in class org.redisson.api.StreamConsumer
Returns amount of pending messages for this consumer
getPending() - Method in class org.redisson.api.StreamGroup
Returns amount of pending messages for this group
getPendingInfo(String) - Method in interface org.redisson.api.RStream
Returns common info about pending messages by group name.
getPendingInfo(String) - Method in interface org.redisson.api.RStreamReactive
Returns common info about pending messages by group name.
getPendingInfo(String) - Method in interface org.redisson.api.RStreamRx
Returns common info about pending messages by group name.
getPendingInfo(String) - Method in class org.redisson.RedissonStream
 
getPendingInfoAsync(String) - Method in interface org.redisson.api.RStreamAsync
Returns common info about pending messages by group name.
getPendingInfoAsync(String) - Method in class org.redisson.RedissonStream
 
getPendingInvocations(Class<?>) - Method in interface org.redisson.api.RRemoteService
Returns pending invocations amount for handling in free workers.
getPendingInvocations(Class<?>) - Method in class org.redisson.RedissonRemoteService
 
getPendingInvocationsAsync(Class<?>) - Method in interface org.redisson.api.RRemoteService
Returns pending invocations amount for handling in free workers.
getPendingInvocationsAsync(Class<?>) - Method in class org.redisson.RedissonRemoteService
 
getPeriod() - Method in class org.redisson.executor.params.ScheduledAtFixedRateParameters
 
getPermitExpirableSemaphore(String) - Method in interface org.redisson.api.RedissonClient
Returns semaphore instance by name.
getPermitExpirableSemaphore(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns semaphore instance by name.
getPermitExpirableSemaphore(String) - Method in interface org.redisson.api.RedissonRxClient
Returns semaphore instance by name.
getPermitExpirableSemaphore(K) - Method in interface org.redisson.api.RMap
Returns RPermitExpirableSemaphore instance associated with key
getPermitExpirableSemaphore(K) - Method in interface org.redisson.api.RMapReactive
Returns RPermitExpirableSemaphore instance associated with key
getPermitExpirableSemaphore(K) - Method in interface org.redisson.api.RMapRx
Returns RPermitExpirableSemaphore instance associated with key
getPermitExpirableSemaphore(K) - Method in interface org.redisson.api.RMultimap
Returns RPermitExpirableSemaphore instance associated with key
getPermitExpirableSemaphore(V) - Method in interface org.redisson.api.RSet
Returns RPermitExpirableSemaphore instance associated with value
getPermitExpirableSemaphore(V) - Method in interface org.redisson.api.RSetCache
Returns RPermitExpirableSemaphore instance associated with value
getPermitExpirableSemaphore(V) - Method in interface org.redisson.api.RSetCacheReactive
Returns RPermitExpirableSemaphore instance associated with value
getPermitExpirableSemaphore(V) - Method in interface org.redisson.api.RSetCacheRx
Returns RPermitExpirableSemaphore instance associated with value
getPermitExpirableSemaphore(V) - Method in interface org.redisson.api.RSetReactive
Returns RPermitExpirableSemaphore instance associated with value
getPermitExpirableSemaphore(V) - Method in interface org.redisson.api.RSetRx
Returns RPermitExpirableSemaphore instance associated with value
getPermitExpirableSemaphore(K) - Method in class org.redisson.reactive.RedissonMapReactive
 
getPermitExpirableSemaphore(V) - Method in class org.redisson.reactive.RedissonSetCacheReactive
 
getPermitExpirableSemaphore(V) - Method in class org.redisson.reactive.RedissonSetReactive
 
getPermitExpirableSemaphore(String) - Method in class org.redisson.Redisson
 
getPermitExpirableSemaphore(K) - Method in class org.redisson.RedissonMap
 
getPermitExpirableSemaphore(K) - Method in class org.redisson.RedissonMultimap
 
getPermitExpirableSemaphore(String) - Method in class org.redisson.RedissonReactive
 
getPermitExpirableSemaphore(String) - Method in class org.redisson.RedissonRx
 
getPermitExpirableSemaphore(V) - Method in class org.redisson.RedissonSet
 
getPermitExpirableSemaphore(V) - Method in class org.redisson.RedissonSetCache
 
getPermitExpirableSemaphore(V) - Method in class org.redisson.RedissonSetMultimapValues
 
getPermitExpirableSemaphore(K) - Method in class org.redisson.rx.RedissonMapRx
 
getPermitExpirableSemaphore(V) - Method in class org.redisson.rx.RedissonSetCacheRx
 
getPermitExpirableSemaphore(V) - Method in class org.redisson.rx.RedissonSetRx
 
getPermitExpirableSemaphore(K) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
getPermitExpirableSemaphore(K) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
getPermitExpirableSemaphore(V) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
getPingConnectionInterval() - Method in class org.redisson.client.RedisClientConfig
 
getPingConnectionInterval() - Method in class org.redisson.config.BaseConfig
 
getPort() - Method in class org.redisson.misc.RedisURI
 
getPos() - Method in class org.redisson.client.protocol.decoder.ListScanResult
 
getPos() - Method in class org.redisson.client.protocol.decoder.MapScanResult
 
getPos() - Method in interface org.redisson.ScanResult
 
getPriorityBlockingDeque(String) - Method in interface org.redisson.api.RedissonClient
Returns unbounded priority blocking deque instance by name.
getPriorityBlockingDeque(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns unbounded priority blocking deque instance by name using provided codec for queue objects.
getPriorityBlockingDeque(String) - Method in class org.redisson.Redisson
 
getPriorityBlockingDeque(String, Codec) - Method in class org.redisson.Redisson
 
getPriorityBlockingQueue(String) - Method in interface org.redisson.api.RedissonClient
Returns unbounded priority blocking queue instance by name.
getPriorityBlockingQueue(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns unbounded priority blocking queue instance by name using provided codec for queue objects.
getPriorityBlockingQueue(String) - Method in class org.redisson.Redisson
 
getPriorityBlockingQueue(String, Codec) - Method in class org.redisson.Redisson
 
getPriorityDeque(String) - Method in interface org.redisson.api.RedissonClient
Returns priority unbounded deque instance by name.
getPriorityDeque(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns priority unbounded deque instance by name using provided codec for queue objects.
getPriorityDeque(String) - Method in class org.redisson.Redisson
 
getPriorityDeque(String, Codec) - Method in class org.redisson.Redisson
 
getPriorityQueue(String) - Method in interface org.redisson.api.RedissonClient
Returns priority unbounded queue instance by name.
getPriorityQueue(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns priority unbounded queue instance by name using provided codec for queue objects.
getPriorityQueue(String) - Method in class org.redisson.Redisson
 
getPriorityQueue(String, Codec) - Method in class org.redisson.Redisson
 
getPromise() - Method in class org.redisson.client.protocol.CommandData
 
getPromise() - Method in class org.redisson.client.protocol.CommandsData
 
getPromise() - Method in class org.redisson.executor.RedissonExecutorFutureReference
 
getPromise() - Method in interface org.redisson.PubSubEntry
 
getPromise() - Method in class org.redisson.RedissonCountDownLatchEntry
 
getPromise() - Method in class org.redisson.RedissonLockEntry
 
getPromise() - Method in class org.redisson.remote.ResponseEntry.Result
 
getProperties() - Method in class org.redisson.jcache.JCacheManager
 
getPubSubEntry(ChannelName) - Method in class org.redisson.pubsub.PublishSubscribeService
 
getPubSubOperations() - Method in class org.redisson.client.protocol.CommandData
 
getPubSubOperations() - Method in class org.redisson.client.protocol.CommandsData
 
getPubSubOperations() - Method in interface org.redisson.client.protocol.QueueCommand
 
getQueue(String) - Method in interface org.redisson.api.RBatch
Returns queue instance by name.
getQueue(String, Codec) - Method in interface org.redisson.api.RBatch
 
getQueue(String) - Method in interface org.redisson.api.RBatchReactive
Returns queue instance by name.
getQueue(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getQueue(String) - Method in interface org.redisson.api.RBatchRx
Returns queue instance by name.
getQueue(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getQueue(String) - Method in interface org.redisson.api.RedissonClient
Returns unbounded queue instance by name.
getQueue(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns unbounded queue instance by name using provided codec for queue objects.
getQueue(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns queue instance by name.
getQueue(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns queue instance by name using provided codec for queue objects.
getQueue(String) - Method in interface org.redisson.api.RedissonRxClient
Returns queue instance by name.
getQueue(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns queue instance by name using provided codec for queue objects.
getQueue() - Method in class org.redisson.client.handler.PubSubEntry
 
getQueue(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getQueue(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getQueue(String) - Method in class org.redisson.Redisson
 
getQueue(String, Codec) - Method in class org.redisson.Redisson
 
getQueue(String) - Method in class org.redisson.RedissonBatch
 
getQueue(String, Codec) - Method in class org.redisson.RedissonBatch
 
getQueue(String) - Method in class org.redisson.RedissonReactive
 
getQueue(String, Codec) - Method in class org.redisson.RedissonReactive
 
getQueue(String) - Method in class org.redisson.RedissonRx
 
getQueue(String, Codec) - Method in class org.redisson.RedissonRx
 
getQueue(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getQueue(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getRadixTreeKeys() - Method in class org.redisson.api.StreamInfo
Returns amount of keys allocated by Radix tree of the stream.
getRadixTreeNodes() - Method in class org.redisson.api.StreamInfo
Returns amount of nodes allocated by Radix tree of the stream.
GETRANGE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
getRate() - Method in class org.redisson.api.RateLimiterConfig
getRateInterval() - Method in class org.redisson.api.RateLimiterConfig
getRateLimiter(String) - Method in interface org.redisson.api.RedissonClient
Returns rate limiter instance by name
getRateLimiter(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns rate limiter instance by name
getRateLimiter(String) - Method in interface org.redisson.api.RedissonRxClient
Returns rate limiter instance by name
getRateLimiter(String) - Method in class org.redisson.Redisson
 
getRateLimiter(String) - Method in class org.redisson.RedissonReactive
 
getRateLimiter(String) - Method in class org.redisson.RedissonRx
 
getRateType() - Method in class org.redisson.api.RateLimiterConfig
getReactiveType() - Method in class org.redisson.RedissonReference
 
getReactiveTypeName() - Method in class org.redisson.RedissonReference
 
getReadMode() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getReadWriteLock(String) - Method in interface org.redisson.api.RedissonClient
Returns ReadWriteLock instance by name.
getReadWriteLock(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns readWriteLock instance by name.
getReadWriteLock(String) - Method in interface org.redisson.api.RedissonRxClient
Returns readWriteLock instance by name.
getReadWriteLock(K) - Method in interface org.redisson.api.RMap
Returns RReadWriteLock instance associated with key
getReadWriteLock(K) - Method in interface org.redisson.api.RMapReactive
Returns RReadWriteLock instance associated with key
getReadWriteLock(K) - Method in interface org.redisson.api.RMapRx
Returns RReadWriteLock instance associated with key
getReadWriteLock(K) - Method in interface org.redisson.api.RMultimap
Returns RReadWriteLock instance associated with key
getReadWriteLock(V) - Method in interface org.redisson.api.RSet
Returns RReadWriteLock instance associated with value
getReadWriteLock(V) - Method in interface org.redisson.api.RSetCache
Returns RReadWriteLock instance associated with value
getReadWriteLock(V) - Method in interface org.redisson.api.RSetCacheReactive
Returns RReadWriteLock instance associated with value
getReadWriteLock(V) - Method in interface org.redisson.api.RSetCacheRx
Returns RReadWriteLock instance associated with value
getReadWriteLock(V) - Method in interface org.redisson.api.RSetReactive
Returns RReadWriteLock instance associated with value
getReadWriteLock(V) - Method in interface org.redisson.api.RSetRx
Returns RReadWriteLock instance associated with value
getReadWriteLock(K) - Method in class org.redisson.reactive.RedissonMapReactive
 
getReadWriteLock(V) - Method in class org.redisson.reactive.RedissonSetCacheReactive
 
getReadWriteLock(V) - Method in class org.redisson.reactive.RedissonSetReactive
 
getReadWriteLock(String) - Method in class org.redisson.Redisson
 
getReadWriteLock(K) - Method in class org.redisson.RedissonMap
 
getReadWriteLock(K) - Method in class org.redisson.RedissonMultimap
 
getReadWriteLock(String) - Method in class org.redisson.RedissonReactive
 
getReadWriteLock(String) - Method in class org.redisson.RedissonRx
 
getReadWriteLock(V) - Method in class org.redisson.RedissonSet
 
getReadWriteLock(V) - Method in class org.redisson.RedissonSetCache
 
getReadWriteLock(V) - Method in class org.redisson.RedissonSetMultimapValues
 
getReadWriteLock(K) - Method in class org.redisson.rx.RedissonMapRx
 
getReadWriteLock(V) - Method in class org.redisson.rx.RedissonSetCacheRx
 
getReadWriteLock(V) - Method in class org.redisson.rx.RedissonSetRx
 
getReadWriteLock(K) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
getReadWriteLock(K) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
getReadWriteLock(V) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
getReconnectionStrategy() - Method in class org.redisson.api.LocalCachedMapOptions
 
getRedirect() - Method in class org.redisson.connection.NodeSource
 
getRedisClient() - Method in class org.redisson.client.protocol.decoder.ListScanResult
 
getRedisClient() - Method in class org.redisson.client.protocol.decoder.MapScanResult
 
getRedisClient() - Method in class org.redisson.client.RedisConnection
 
getRedisClient() - Method in class org.redisson.connection.NodeSource
 
getRedisClient() - Method in interface org.redisson.ScanResult
 
getRedisNodes(RedisNodes<T>) - Method in interface org.redisson.api.RedissonClient
Returns API to manage Redis nodes
getRedisNodes(RedisNodes<T>) - Method in class org.redisson.Redisson
 
getRedisson() - Method in class org.redisson.jcache.configuration.RedissonConfiguration
 
getRedisson() - Method in class org.redisson.RedissonNode
 
getRedissonNodeInitializer() - Method in class org.redisson.config.RedissonNodeConfig
 
getRedLock(RLock...) - Method in interface org.redisson.api.RedissonClient
Deprecated.
getRedLock(RLock...) - Method in interface org.redisson.api.RedissonReactiveClient
Deprecated.
getRedLock(RLock...) - Method in interface org.redisson.api.RedissonRxClient
Deprecated.
getRedLock(RLock...) - Method in class org.redisson.Redisson
 
getRedLock(RLock...) - Method in class org.redisson.RedissonReactive
 
getRedLock(RLock...) - Method in class org.redisson.RedissonRx
 
getReferenceCodecProvider() - Method in class org.redisson.liveobject.core.RedissonObjectBuilder
 
getReferences() - Method in class org.redisson.connection.MasterSlaveEntry
 
getRemoteAddress() - Method in class org.redisson.RedissonNode
 
getRemoteService() - Method in interface org.redisson.api.RedissonClient
Returns object for remote operations prefixed with the default name (redisson_remote_service)
getRemoteService(Codec) - Method in interface org.redisson.api.RedissonClient
Returns object for remote operations prefixed with the default name (redisson_remote_service) and uses provided codec for method arguments and result.
getRemoteService(String) - Method in interface org.redisson.api.RedissonClient
Returns object for remote operations prefixed with the specified name
getRemoteService(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns object for remote operations prefixed with the specified name and uses provided codec for method arguments and result.
getRemoteService() - Method in interface org.redisson.api.RedissonReactiveClient
Returns object for remote operations prefixed with the default name (redisson_remote_service)
getRemoteService(Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns object for remote operations prefixed with the default name (redisson_remote_service) and uses provided codec for method arguments and result.
getRemoteService(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns object for remote operations prefixed with the specified name
getRemoteService(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns object for remote operations prefixed with the specified name and uses provided codec for method arguments and result.
getRemoteService() - Method in interface org.redisson.api.RedissonRxClient
Returns object for remote operations prefixed with the default name (redisson_remote_service)
getRemoteService(Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns object for remote operations prefixed with the default name (redisson_remote_service) and uses provided codec for method arguments and result.
getRemoteService(String) - Method in interface org.redisson.api.RedissonRxClient
Returns object for remote operations prefixed with the specified name
getRemoteService(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns object for remote operations prefixed with the specified name and uses provided codec for method arguments and result.
getRemoteService() - Method in class org.redisson.Redisson
 
getRemoteService(String) - Method in class org.redisson.Redisson
 
getRemoteService(Codec) - Method in class org.redisson.Redisson
 
getRemoteService(String, Codec) - Method in class org.redisson.Redisson
 
getRemoteService() - Method in class org.redisson.RedissonReactive
 
getRemoteService(String) - Method in class org.redisson.RedissonReactive
 
getRemoteService(Codec) - Method in class org.redisson.RedissonReactive
 
getRemoteService(String, Codec) - Method in class org.redisson.RedissonReactive
 
getRemoteService() - Method in class org.redisson.RedissonRx
 
getRemoteService(String) - Method in class org.redisson.RedissonRx
 
getRemoteService(Codec) - Method in class org.redisson.RedissonRx
 
getRemoteService(String, Codec) - Method in class org.redisson.RedissonRx
 
getReplayDecoder() - Method in class org.redisson.client.protocol.RedisCommand
 
getReplayMultiDecoder() - Method in class org.redisson.client.protocol.RedisCommand
 
getRequestId() - Method in class org.redisson.cache.LocalCachedMapClear
 
getRequestId() - Method in class org.redisson.cache.LocalCachedMapDisable
 
getRequestId() - Method in class org.redisson.cache.LocalCachedMapDisabledKey
 
getRequestId() - Method in class org.redisson.cache.LocalCachedMapEnable
 
getRequestId() - Method in class org.redisson.executor.params.TaskParameters
 
getRequestId() - Method in class org.redisson.executor.RedissonExecutorFutureReference
 
getRequestId() - Method in class org.redisson.executor.RemotePromise
 
getRequestQueueName(Class<?>) - Method in class org.redisson.remote.BaseRemoteProxy
 
getRequestQueueName(Class<?>) - Method in class org.redisson.remote.BaseRemoteService
 
getRequestTasksMapName(Class<?>) - Method in class org.redisson.RedissonRemoteService
 
getResolverGroup() - Method in class org.redisson.client.RedisClientConfig
 
getResourceFactory() - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
getResourceHolder() - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionObject
 
getResponseQueueName(String) - Method in class org.redisson.remote.BaseRemoteService
 
getResponses() - Method in class org.redisson.api.BatchResult
Returns list of result objects for each command
getResponses() - Method in class org.redisson.remote.ResponseEntry
 
getResponseTimeout() - Method in class org.redisson.api.BatchOptions
 
getResponseTimeout() - Method in class org.redisson.api.TransactionOptions
 
getResponseTimeoutFuture() - Method in class org.redisson.remote.ResponseEntry.Result
 
getResult() - Method in class org.redisson.RedissonTransferQueue.TransferQueueServiceImpl
 
getResult() - Method in class org.redisson.remote.RemoteServiceResponse
 
getRetryAttempts() - Method in class org.redisson.api.BatchOptions
 
getRetryAttempts() - Method in class org.redisson.api.TransactionOptions
 
getRetryAttempts() - Method in class org.redisson.config.BaseConfig
 
getRetryInterval() - Method in class org.redisson.api.BatchOptions
 
getRetryInterval() - Method in class org.redisson.api.TransactionOptions
 
getRetryInterval() - Method in class org.redisson.config.BaseConfig
 
getRingBuffer(String) - Method in interface org.redisson.api.RedissonClient
Returns RingBuffer based queue.
getRingBuffer(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns RingBuffer based queue.
getRingBuffer(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns RingBuffer based queue.
getRingBuffer(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns RingBuffer based queue.
getRingBuffer(String) - Method in interface org.redisson.api.RedissonRxClient
Returns RingBuffer based queue.
getRingBuffer(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns RingBuffer based queue.
getRingBuffer(String) - Method in class org.redisson.Redisson
 
getRingBuffer(String, Codec) - Method in class org.redisson.Redisson
 
getRingBuffer(String) - Method in class org.redisson.RedissonReactive
 
getRingBuffer(String, Codec) - Method in class org.redisson.RedissonReactive
 
getRingBuffer(String) - Method in class org.redisson.RedissonRx
 
getRingBuffer(String, Codec) - Method in class org.redisson.RedissonRx
 
getScanInterval() - Method in class org.redisson.config.ClusterServersConfig
 
getScanInterval() - Method in class org.redisson.config.ReplicatedServersConfig
 
getScanInterval() - Method in class org.redisson.config.SentinelServersConfig
 
getScheme() - Method in class org.redisson.misc.RedisURI
 
getScore(V) - Method in interface org.redisson.api.RScoredSortedSet
Returns score of element or null if it doesn't exist.
getScore(V) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns score of element or null if it doesn't exist.
getScore(V) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns score of element or null if it doesn't exist.
getScore() - Method in class org.redisson.client.protocol.ScoredEntry
 
getScore(V) - Method in class org.redisson.RedissonScoredSortedSet
 
getScoreAsync(V) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns score of element or null if it doesn't exist.
getScoreAsync(V) - Method in class org.redisson.RedissonScoredSortedSet
 
getScoredSortedSet(String) - Method in interface org.redisson.api.RBatch
Returns Redis Sorted Set instance by name
getScoredSortedSet(String, Codec) - Method in interface org.redisson.api.RBatch
 
getScoredSortedSet(String) - Method in interface org.redisson.api.RBatchReactive
Returns Redis Sorted Set instance by name
getScoredSortedSet(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getScoredSortedSet(String) - Method in interface org.redisson.api.RBatchRx
Returns Redis Sorted Set instance by name
getScoredSortedSet(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getScoredSortedSet(String) - Method in interface org.redisson.api.RedissonClient
Returns Redis Sorted Set instance by name.
getScoredSortedSet(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns Redis Sorted Set instance by name using provided codec for sorted set objects.
getScoredSortedSet(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns Redis Sorted Set instance by name.
getScoredSortedSet(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns Redis Sorted Set instance by name using provided codec for sorted set objects.
getScoredSortedSet(String) - Method in interface org.redisson.api.RedissonRxClient
Returns Redis Sorted Set instance by name.
getScoredSortedSet(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns Redis Sorted Set instance by name using provided codec for sorted set objects.
getScoredSortedSet(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getScoredSortedSet(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getScoredSortedSet(String) - Method in class org.redisson.Redisson
 
getScoredSortedSet(String, Codec) - Method in class org.redisson.Redisson
 
getScoredSortedSet(String) - Method in class org.redisson.RedissonBatch
 
getScoredSortedSet(String, Codec) - Method in class org.redisson.RedissonBatch
 
getScoredSortedSet(String) - Method in class org.redisson.RedissonReactive
 
getScoredSortedSet(String, Codec) - Method in class org.redisson.RedissonReactive
 
getScoredSortedSet(String) - Method in class org.redisson.RedissonRx
 
getScoredSortedSet(String, Codec) - Method in class org.redisson.RedissonRx
 
getScoredSortedSet(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getScoredSortedSet(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getScript() - Method in interface org.redisson.api.RBatch
Returns script operations object
getScript(Codec) - Method in interface org.redisson.api.RBatch
Returns script operations object using provided codec.
getScript() - Method in interface org.redisson.api.RBatchReactive
Returns script operations object
getScript(Codec) - Method in interface org.redisson.api.RBatchReactive
Returns script operations object using provided codec.
getScript() - Method in interface org.redisson.api.RBatchRx
Returns script operations object
getScript(Codec) - Method in interface org.redisson.api.RBatchRx
Returns script operations object using provided codec.
getScript() - Method in interface org.redisson.api.RedissonClient
Returns script operations object
getScript(Codec) - Method in interface org.redisson.api.RedissonClient
Returns script operations object using provided codec.
getScript() - Method in interface org.redisson.api.RedissonReactiveClient
Returns script operations object
getScript(Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns script operations object using provided codec.
getScript() - Method in interface org.redisson.api.RedissonRxClient
Returns script operations object
getScript(Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns script operations object using provided codec.
getScript() - Method in class org.redisson.reactive.RedissonBatchReactive
 
getScript(Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getScript() - Method in class org.redisson.Redisson
 
getScript(Codec) - Method in class org.redisson.Redisson
 
getScript() - Method in class org.redisson.RedissonBatch
 
getScript(Codec) - Method in class org.redisson.RedissonBatch
 
getScript() - Method in class org.redisson.RedissonReactive
 
getScript(Codec) - Method in class org.redisson.RedissonReactive
 
getScript() - Method in class org.redisson.RedissonRx
 
getScript(Codec) - Method in class org.redisson.RedissonRx
 
getScript() - Method in class org.redisson.rx.RedissonBatchRx
 
getScript(Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getSeconds() - Method in class org.redisson.client.protocol.Time
 
getSemaphore(String) - Method in interface org.redisson.api.RedissonClient
Returns semaphore instance by name
getSemaphore(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns semaphore instance by name
getSemaphore(String) - Method in interface org.redisson.api.RedissonRxClient
Returns semaphore instance by name
getSemaphore(K) - Method in interface org.redisson.api.RMap
Returns RSemaphore instance associated with key
getSemaphore(K) - Method in interface org.redisson.api.RMapReactive
Returns RSemaphore instance associated with key
getSemaphore(K) - Method in interface org.redisson.api.RMapRx
Returns RSemaphore instance associated with key
getSemaphore(K) - Method in interface org.redisson.api.RMultimap
Returns RSemaphore instance associated with key
getSemaphore(V) - Method in interface org.redisson.api.RSet
Returns RSemaphore instance associated with value
getSemaphore(V) - Method in interface org.redisson.api.RSetCache
Returns RSemaphore instance associated with value
getSemaphore(V) - Method in interface org.redisson.api.RSetCacheReactive
Returns RSemaphore instance associated with value
getSemaphore(V) - Method in interface org.redisson.api.RSetCacheRx
Returns RSemaphore instance associated with value
getSemaphore(V) - Method in interface org.redisson.api.RSetReactive
Returns RSemaphore instance associated with value
getSemaphore(V) - Method in interface org.redisson.api.RSetRx
Returns RSemaphore instance associated with value
getSemaphore(ChannelName) - Method in class org.redisson.pubsub.PublishSubscribeService
 
getSemaphore(K) - Method in class org.redisson.reactive.RedissonMapReactive
 
getSemaphore(V) - Method in class org.redisson.reactive.RedissonSetCacheReactive
 
getSemaphore(V) - Method in class org.redisson.reactive.RedissonSetReactive
 
getSemaphore(String) - Method in class org.redisson.Redisson
 
getSemaphore(K) - Method in class org.redisson.RedissonMap
 
getSemaphore(K) - Method in class org.redisson.RedissonMultimap
 
getSemaphore(String) - Method in class org.redisson.RedissonReactive
 
getSemaphore(String) - Method in class org.redisson.RedissonRx
 
getSemaphore(V) - Method in class org.redisson.RedissonSet
 
getSemaphore(V) - Method in class org.redisson.RedissonSetCache
 
getSemaphore(V) - Method in class org.redisson.RedissonSetMultimapValues
 
getSemaphore(K) - Method in class org.redisson.rx.RedissonMapRx
 
getSemaphore(V) - Method in class org.redisson.rx.RedissonSetCacheRx
 
getSemaphore(V) - Method in class org.redisson.rx.RedissonSetRx
 
getSemaphore(K) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
getSemaphore(K) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
getSemaphore(V) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
getSemaphorePubSub() - Method in class org.redisson.pubsub.PublishSubscribeService
 
getSent() - Method in class org.redisson.client.handler.PubSubEntry
 
getSentinel(String) - Method in interface org.redisson.api.redisnode.RedisSentinelMasterSlave
Returns Redis Sentinel node by defined address.
getSentinel(String) - Method in class org.redisson.redisnode.RedissonSentinelMasterSlaveNodes
 
getSentinelAddresses() - Method in class org.redisson.config.SentinelServersConfig
 
getSentinels(String) - Method in interface org.redisson.api.redisnode.RedisSentinel
Returns list of map containing info regarding Redis Sentinel server monitoring defined master.
getSentinels() - Method in interface org.redisson.api.redisnode.RedisSentinelMasterSlave
Returns collection of Redis Sentinel nodes belongs to this Redis setup.
getSentinels() - Method in class org.redisson.connection.SentinelConnectionManager
 
getSentinels() - Method in class org.redisson.redisnode.RedissonSentinelMasterSlaveNodes
 
getSentinels(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
getSentinelsAsync(String) - Method in interface org.redisson.api.redisnode.RedisSentinelAsync
Returns list of map containing info regarding Redis Sentinel server monitoring defined master.
getSentinelsAsync(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
getSentPromise() - Method in class org.redisson.command.BatchPromise
 
getServiceInterface() - Method in class org.redisson.remote.RemoteServiceKey
 
getSet(String) - Method in interface org.redisson.api.RBatch
Returns set instance by name.
getSet(String, Codec) - Method in interface org.redisson.api.RBatch
 
getSet(String) - Method in interface org.redisson.api.RBatchReactive
Returns set instance by name.
getSet(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getSet(String) - Method in interface org.redisson.api.RBatchRx
Returns set instance by name.
getSet(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getSet(String) - Method in interface org.redisson.api.RedissonClient
Returns set instance by name.
getSet(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns set instance by name using provided codec for set objects.
getSet(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns set instance by name.
getSet(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns set instance by name using provided codec for set objects.
getSet(String) - Method in interface org.redisson.api.RedissonRxClient
Returns set instance by name.
getSet(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns set instance by name using provided codec for set objects.
getSet(String) - Method in interface org.redisson.api.RTransaction
Returns transactional set instance by name.
getSet(String, Codec) - Method in interface org.redisson.api.RTransaction
Returns transactional set instance by name using provided codec for set objects.
getSet(String) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional set instance by name.
getSet(String, Codec) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional set instance by name using provided codec for set objects.
getSet(String) - Method in interface org.redisson.api.RTransactionRx
Returns transactional set instance by name.
getSet(String, Codec) - Method in interface org.redisson.api.RTransactionRx
Returns transactional set instance by name using provided codec for set objects.
GETSET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
getSet(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getSet(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getSet(String) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getSet(String, Codec) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getSet(String) - Method in class org.redisson.Redisson
 
getSet(String, Codec) - Method in class org.redisson.Redisson
 
getSet(String) - Method in class org.redisson.RedissonBatch
 
getSet(String, Codec) - Method in class org.redisson.RedissonBatch
 
getSet(String) - Method in class org.redisson.RedissonReactive
 
getSet(String, Codec) - Method in class org.redisson.RedissonReactive
 
getSet(String) - Method in class org.redisson.RedissonRx
 
getSet(String, Codec) - Method in class org.redisson.RedissonRx
 
getSet(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getSet(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getSet(String) - Method in class org.redisson.rx.RedissonTransactionRx
 
getSet(String, Codec) - Method in class org.redisson.rx.RedissonTransactionRx
 
getSet(String) - Method in class org.redisson.transaction.RedissonTransaction
 
getSet(String, Codec) - Method in class org.redisson.transaction.RedissonTransaction
 
getSetCache(String) - Method in interface org.redisson.api.RBatch
Returns set-based cache instance by name.
getSetCache(String, Codec) - Method in interface org.redisson.api.RBatch
Returns set-based cache instance by name using provided codec for values.
getSetCache(String) - Method in interface org.redisson.api.RBatchReactive
Returns set-based cache instance by name.
getSetCache(String, Codec) - Method in interface org.redisson.api.RBatchReactive
Returns set-based cache instance by name using provided codec for values.
getSetCache(String) - Method in interface org.redisson.api.RBatchRx
Returns set-based cache instance by name.
getSetCache(String, Codec) - Method in interface org.redisson.api.RBatchRx
Returns set-based cache instance by name using provided codec for values.
getSetCache(String) - Method in interface org.redisson.api.RedissonClient
Returns set-based cache instance by name.
getSetCache(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns set-based cache instance by name.
getSetCache(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns set-based cache instance by name.
getSetCache(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns set-based cache instance by name.
getSetCache(String) - Method in interface org.redisson.api.RedissonRxClient
Returns set-based cache instance by name.
getSetCache(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns set-based cache instance by name.
getSetCache(String) - Method in interface org.redisson.api.RTransaction
Returns transactional set-based cache instance by name.
getSetCache(String, Codec) - Method in interface org.redisson.api.RTransaction
Returns transactional set-based cache instance by name.
getSetCache(String) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional set-based cache instance by name.
getSetCache(String, Codec) - Method in interface org.redisson.api.RTransactionReactive
Returns transactional set-based cache instance by name.
getSetCache(String) - Method in interface org.redisson.api.RTransactionRx
Returns transactional set-based cache instance by name.
getSetCache(String, Codec) - Method in interface org.redisson.api.RTransactionRx
Returns transactional set-based cache instance by name.
getSetCache(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getSetCache(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getSetCache(String) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getSetCache(String, Codec) - Method in class org.redisson.reactive.RedissonTransactionReactive
 
getSetCache(String) - Method in class org.redisson.Redisson
 
getSetCache(String, Codec) - Method in class org.redisson.Redisson
 
getSetCache(String) - Method in class org.redisson.RedissonBatch
 
getSetCache(String, Codec) - Method in class org.redisson.RedissonBatch
 
getSetCache(String) - Method in class org.redisson.RedissonReactive
 
getSetCache(String, Codec) - Method in class org.redisson.RedissonReactive
 
getSetCache(String) - Method in class org.redisson.RedissonRx
 
getSetCache(String, Codec) - Method in class org.redisson.RedissonRx
 
getSetCache(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getSetCache(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getSetCache(String) - Method in class org.redisson.rx.RedissonTransactionRx
 
getSetCache(String, Codec) - Method in class org.redisson.rx.RedissonTransactionRx
 
getSetCache(String) - Method in class org.redisson.transaction.RedissonTransaction
 
getSetCache(String, Codec) - Method in class org.redisson.transaction.RedissonTransaction
 
getSetMultimap(String) - Method in interface org.redisson.api.RBatch
Returns Set based MultiMap instance by name.
getSetMultimap(String, Codec) - Method in interface org.redisson.api.RBatch
Returns Set based MultiMap instance by name using provided codec for both map keys and values.
getSetMultimap(String) - Method in interface org.redisson.api.RBatchReactive
Returns Set based Multimap instance by name.
getSetMultimap(String, Codec) - Method in interface org.redisson.api.RBatchReactive
Returns Set based Multimap instance by name using provided codec for both map keys and values.
getSetMultimap(String) - Method in interface org.redisson.api.RBatchRx
Returns Set based Multimap instance by name.
getSetMultimap(String, Codec) - Method in interface org.redisson.api.RBatchRx
Returns Set based Multimap instance by name using provided codec for both map keys and values.
getSetMultimap(String) - Method in interface org.redisson.api.RedissonClient
Returns Set based Multimap instance by name.
getSetMultimap(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns Set based Multimap instance by name using provided codec for both map keys and values.
getSetMultimap(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns Set based Multimap instance by name.
getSetMultimap(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns Set based Multimap instance by name using provided codec for both map keys and values.
getSetMultimap(String) - Method in interface org.redisson.api.RedissonRxClient
Returns Set based Multimap instance by name.
getSetMultimap(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns Set based Multimap instance by name using provided codec for both map keys and values.
getSetMultimap(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getSetMultimap(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getSetMultimap(String) - Method in class org.redisson.Redisson
 
getSetMultimap(String, Codec) - Method in class org.redisson.Redisson
 
getSetMultimap(String) - Method in class org.redisson.RedissonBatch
 
getSetMultimap(String, Codec) - Method in class org.redisson.RedissonBatch
 
getSetMultimap(String) - Method in class org.redisson.RedissonReactive
 
getSetMultimap(String, Codec) - Method in class org.redisson.RedissonReactive
 
getSetMultimap(String) - Method in class org.redisson.RedissonRx
 
getSetMultimap(String, Codec) - Method in class org.redisson.RedissonRx
 
getSetMultimap(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getSetMultimap(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getSetMultimapCache(String) - Method in interface org.redisson.api.RBatch
Returns Set based Multimap instance by name.
getSetMultimapCache(String, Codec) - Method in interface org.redisson.api.RBatch
Returns Set based Multimap instance by name using provided codec for both map keys and values.
getSetMultimapCache(String) - Method in interface org.redisson.api.RedissonClient
Returns Set based Multimap instance by name.
getSetMultimapCache(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns Set based Multimap instance by name using provided codec for both map keys and values.
getSetMultimapCache(String) - Method in class org.redisson.Redisson
 
getSetMultimapCache(String, Codec) - Method in class org.redisson.Redisson
 
getSetMultimapCache(String) - Method in class org.redisson.RedissonBatch
 
getSetMultimapCache(String, Codec) - Method in class org.redisson.RedissonBatch
 
getShutdownLatch() - Method in interface org.redisson.connection.ConnectionManager
 
getShutdownLatch() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getShutdownPromise() - Method in interface org.redisson.connection.ConnectionManager
 
getShutdownPromise() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getSignature() - Method in class org.redisson.remote.RemoteServiceKey
 
getSignature() - Method in class org.redisson.remote.RemoteServiceRequest
 
getSingleElement(Element, String) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
getSize() - Method in interface org.redisson.api.RBloomFilter
Returns number of bits in Redis memory required by this instance
getSize() - Method in class org.redisson.client.handler.StateLevel
 
getSize() - Method in class org.redisson.client.protocol.decoder.ListIteratorResult
 
getSize() - Method in class org.redisson.RedissonBloomFilter
 
getSlave(String) - Method in interface org.redisson.api.redisnode.RedisCluster
Returns Redis Slave node by defined address.
getSlave(String) - Method in interface org.redisson.api.redisnode.RedisMasterSlave
Returns Redis Slave node by defined address.
getSlave(String) - Method in class org.redisson.redisnode.RedissonClusterNodes
 
getSlave(String) - Method in class org.redisson.redisnode.RedissonMasterSlaveNodes
 
getSlaveAddresses() - Method in class org.redisson.cluster.ClusterPartition
 
getSlaveAddresses() - Method in class org.redisson.config.MasterSlaveServersConfig
 
getSlaveConnectionMinimumIdleSize() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getSlaveConnectionPoolSize() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getSlaveOf() - Method in class org.redisson.cluster.ClusterNodeInfo
 
getSlaves() - Method in interface org.redisson.api.redisnode.RedisCluster
Returns collection of Redis Slave nodes belongs to this Redis Cluster.
getSlaves() - Method in interface org.redisson.api.redisnode.RedisMasterSlave
Returns collection of Redis Slave nodes belongs to this Redis setup.
getSlaves(String) - Method in interface org.redisson.api.redisnode.RedisSentinel
Returns list of map containing info regarding Redis Slave server of defined master.
getSlaves() - Method in class org.redisson.redisnode.RedissonClusterNodes
 
getSlaves() - Method in class org.redisson.redisnode.RedissonMasterSlaveNodes
 
getSlaves(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
getSlavesAsync(String) - Method in interface org.redisson.api.redisnode.RedisSentinelAsync
Returns list of map containing info regarding Redis Slave server of defined master.
getSlavesAsync(String) - Method in class org.redisson.redisnode.SentinelRedisNode
 
getSlot(String) - Method in interface org.redisson.api.RKeys
Get hash slot identifier for key.
getSlot(String) - Method in interface org.redisson.api.RKeysReactive
Get hash slot identifier for key.
getSlot(String) - Method in interface org.redisson.api.RKeysRx
Get hash slot identifier for key.
getSlot() - Method in exception org.redisson.client.RedisRedirectException
 
getSlot() - Method in class org.redisson.connection.NodeSource
 
getSlot(String) - Method in class org.redisson.RedissonKeys
 
getSlotAsync(String) - Method in interface org.redisson.api.RKeysAsync
Get hash slot identifier for key in async mode.
getSlotAsync(String) - Method in class org.redisson.RedissonKeys
 
getSlotRanges() - Method in class org.redisson.cluster.ClusterNodeInfo
 
getSlotRanges() - Method in class org.redisson.cluster.ClusterPartition
 
getSlots() - Method in class org.redisson.cluster.ClusterPartition
 
getSlotsAmount() - Method in class org.redisson.cluster.ClusterPartition
 
getSocketChannelClass() - Method in class org.redisson.client.RedisClientConfig
 
getSortedSet(String) - Method in interface org.redisson.api.RedissonClient
Returns sorted set instance by name.
getSortedSet(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns sorted set instance by name using provided codec for sorted set objects.
getSortedSet(String) - Method in class org.redisson.Redisson
 
getSortedSet(String, Codec) - Method in class org.redisson.Redisson
 
getSource() - Method in class org.redisson.api.map.event.EntryEvent
 
getSpecificationName() - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
getSpecificationVendor() - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
getSpecificationVersion() - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
getSslHostname() - Method in class org.redisson.client.RedisClientConfig
 
getSslKeystore() - Method in class org.redisson.client.RedisClientConfig
 
getSslKeystore() - Method in class org.redisson.config.BaseConfig
 
getSslKeystorePassword() - Method in class org.redisson.client.RedisClientConfig
 
getSslKeystorePassword() - Method in class org.redisson.config.BaseConfig
 
getSslProvider() - Method in class org.redisson.client.RedisClientConfig
 
getSslProvider() - Method in class org.redisson.config.BaseConfig
 
getSslTruststore() - Method in class org.redisson.client.RedisClientConfig
 
getSslTruststore() - Method in class org.redisson.config.BaseConfig
 
getSslTruststorePassword() - Method in class org.redisson.client.RedisClientConfig
 
getSslTruststorePassword() - Method in class org.redisson.config.BaseConfig
 
getStarted() - Method in class org.redisson.remote.ResponseEntry
 
getStartSlot() - Method in class org.redisson.cluster.ClusterSlotRange
 
getStartTime() - Method in class org.redisson.executor.params.ScheduledParameters
 
getStartTime() - Method in class org.redisson.QueueTransferTask.TimeoutTask
 
getStatBean(JCache<?, ?>) - Method in class org.redisson.jcache.JCacheManager
 
getState() - Method in class org.redisson.executor.params.TaskParameters
 
getStoreMode() - Method in class org.redisson.api.LocalCachedMapOptions
 
getStream(String) - Method in interface org.redisson.api.RBatch
Returns stream instance by name
getStream(String, Codec) - Method in interface org.redisson.api.RBatch
Returns stream instance by name using provided codec for entries.
getStream(String) - Method in interface org.redisson.api.RBatchReactive
Returns stream instance by name Requires Redis 5.0.0 and higher.
getStream(String, Codec) - Method in interface org.redisson.api.RBatchReactive
Returns stream instance by name using provided codec for entries.
getStream(String) - Method in interface org.redisson.api.RBatchRx
Returns stream instance by name Requires Redis 5.0.0 and higher.
getStream(String, Codec) - Method in interface org.redisson.api.RBatchRx
Returns stream instance by name using provided codec for entries.
getStream(String) - Method in interface org.redisson.api.RedissonClient
Returns stream instance by name Requires Redis 5.0.0 and higher.
getStream(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns stream instance by name using provided codec for entries.
getStream(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns stream instance by name Requires Redis 5.0.0 and higher.
getStream(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns stream instance by name using provided codec for entries.
getStream(String) - Method in interface org.redisson.api.RedissonRxClient
Returns stream instance by name Requires Redis 5.0.0 and higher.
getStream(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns stream instance by name using provided codec for entries.
getStream(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getStream(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getStream(String) - Method in class org.redisson.Redisson
 
getStream(String, Codec) - Method in class org.redisson.Redisson
 
getStream(String) - Method in class org.redisson.RedissonBatch
 
getStream(String, Codec) - Method in class org.redisson.RedissonBatch
 
getStream(String) - Method in class org.redisson.RedissonReactive
 
getStream(String, Codec) - Method in class org.redisson.RedissonReactive
 
getStream(String) - Method in class org.redisson.RedissonRx
 
getStream(String, Codec) - Method in class org.redisson.RedissonRx
 
getStream(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getStream(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getSubName() - Method in class org.redisson.client.protocol.RedisCommand
 
getSubscribeFuture(ChannelName, PubSubType) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
getSubscribeService() - Method in interface org.redisson.connection.ConnectionManager
 
getSubscribeService() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getSubscriptionConnectionMinimumIdleSize() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getSubscriptionConnectionMinimumIdleSize() - Method in class org.redisson.config.SingleServerConfig
 
getSubscriptionConnectionPoolSize() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getSubscriptionConnectionPoolSize() - Method in class org.redisson.config.SingleServerConfig
 
getSubscriptionMode() - Method in class org.redisson.config.BaseMasterSlaveServersConfig
 
getSubscriptionsPerConnection() - Method in class org.redisson.config.BaseConfig
 
getSuccessFuture() - Method in class org.redisson.client.SubscribeListener
 
getSyncedSlaves() - Method in class org.redisson.api.BatchResult
Returns amount of successfully synchronized slaves during batch execution
getSyncSlaves() - Method in class org.redisson.api.BatchOptions
 
getSyncStrategy() - Method in class org.redisson.api.LocalCachedMapOptions
 
getSyncTimeout() - Method in class org.redisson.api.BatchOptions
 
getSyncTimeout() - Method in class org.redisson.api.TransactionOptions
 
getTask(String, RMap<String, RemoteServiceRequest>) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
getTask() - Method in class org.redisson.QueueTransferTask.TimeoutTask
 
getTask(String, RMap<String, RemoteServiceRequest>) - Method in class org.redisson.RedissonRemoteService
 
getTaskCount() - Method in interface org.redisson.api.RExecutorService
Returns amount of tasks awaiting for execution and/or currently in execution.
getTaskCount() - Method in class org.redisson.RedissonExecutorService
 
getTaskCountAsync() - Method in interface org.redisson.api.RExecutorServiceAsync
Returns amount of tasks awaiting for execution and/or currently in execution.
getTaskCountAsync() - Method in class org.redisson.RedissonExecutorService
 
getTaskFutures() - Method in interface org.redisson.api.RExecutorBatchFuture
Returns list of Future objects.
getTaskFutures() - Method in class org.redisson.executor.RedissonExecutorBatchFuture
 
getTaskId() - Method in interface org.redisson.api.RExecutorFuture
Returns scheduled task's id.
getTaskId() - Method in class org.redisson.executor.RedissonExecutorFuture
 
getTaskId() - Method in class org.redisson.executor.RedissonScheduledFuture
 
getTaskIds() - Method in interface org.redisson.api.RExecutorService
Returns list of task ids awaiting for execution and/or currently in execution.
getTaskIds() - Method in class org.redisson.RedissonExecutorService
 
getTaskIdsAsync() - Method in interface org.redisson.api.RExecutorServiceAsync
Returns list of task ids awaiting for execution and/or currently in execution.
getTaskIdsAsync() - Method in class org.redisson.RedissonExecutorService
 
getTaskRetryInterval() - Method in class org.redisson.api.ExecutorOptions
 
getTaskTimeout() - Method in class org.redisson.api.WorkerOptions
 
getThreadId() - Method in class org.redisson.transaction.operation.set.MoveOperation
 
getThreads() - Method in class org.redisson.config.Config
 
getTimeAfter(Date) - Method in class org.redisson.executor.CronExpression
 
getTimeBefore(Date) - Method in class org.redisson.executor.CronExpression
 
getTimeout() - Method in class org.redisson.api.TransactionOptions
 
getTimeout() - Method in class org.redisson.cache.LocalCachedMapDisable
 
getTimeout() - Method in class org.redisson.cache.LocalCachedMapDisabledKey
 
getTimeout() - Method in class org.redisson.config.BaseConfig
 
getTimeout(Long, RemoteServiceRequest) - Method in class org.redisson.executor.ScheduledTasksService
 
getTimeout() - Method in class org.redisson.RedissonLock.ExpirationEntry
 
getTimeout(Long, RemoteServiceRequest) - Method in class org.redisson.remote.BaseRemoteService
 
getTimer() - Method in class org.redisson.client.RedisClient
 
getTimer() - Method in class org.redisson.client.RedisClientConfig
 
getTimeToLive() - Method in class org.redisson.transaction.operation.bucket.BucketSetOperation
 
getTimeToLive() - Method in class org.redisson.transaction.operation.bucket.BucketTrySetOperation
 
getTimeToLiveInMillis() - Method in class org.redisson.api.LocalCachedMapOptions
 
getTimeUnit() - Method in class org.redisson.transaction.operation.bucket.BucketSetOperation
 
getTimeUnit() - Method in class org.redisson.transaction.operation.bucket.BucketTrySetOperation
 
getTimeUnit() - Method in class org.redisson.transaction.operation.set.AddCacheOperation
 
getTimeZone() - Method in class org.redisson.executor.CronExpression
Returns the time zone for which this CronExpression will be resolved.
getTimezone() - Method in class org.redisson.executor.params.ScheduledCronExpressionParameters
 
getTopic(String) - Method in interface org.redisson.api.RBatch
Returns topic instance by name.
getTopic(String, Codec) - Method in interface org.redisson.api.RBatch
 
getTopic(String) - Method in interface org.redisson.api.RBatchReactive
Returns topic instance by name.
getTopic(String, Codec) - Method in interface org.redisson.api.RBatchReactive
 
getTopic(String) - Method in interface org.redisson.api.RBatchRx
Returns topic instance by name.
getTopic(String, Codec) - Method in interface org.redisson.api.RBatchRx
 
getTopic(String) - Method in interface org.redisson.api.RedissonClient
Returns topic instance by name.
getTopic(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns topic instance by name using provided codec for messages.
getTopic(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns topic instance by name.
getTopic(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns topic instance by name using provided codec for messages.
getTopic(String) - Method in interface org.redisson.api.RedissonRxClient
Returns topic instance by name.
getTopic(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns topic instance by name using provided codec for messages.
getTopic() - Method in class org.redisson.QueueTransferTask
 
getTopic(String) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getTopic(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
 
getTopic(String) - Method in class org.redisson.Redisson
 
getTopic(String, Codec) - Method in class org.redisson.Redisson
 
getTopic(String) - Method in class org.redisson.RedissonBatch
 
getTopic(String, Codec) - Method in class org.redisson.RedissonBatch
 
getTopic(String) - Method in class org.redisson.RedissonReactive
 
getTopic(String, Codec) - Method in class org.redisson.RedissonReactive
 
getTopic(String) - Method in class org.redisson.RedissonRx
 
getTopic(String, Codec) - Method in class org.redisson.RedissonRx
 
getTopic(String) - Method in class org.redisson.rx.RedissonBatchRx
 
getTopic(String, Codec) - Method in class org.redisson.rx.RedissonBatchRx
 
getTotal() - Method in class org.redisson.api.PendingResult
Total amount of pending messages
getTransaction() - Method in class org.redisson.spring.transaction.ReactiveRedissonResourceHolder
 
getTransaction() - Method in class org.redisson.spring.transaction.RedissonTransactionHolder
 
getTransactionHolder() - Method in class org.redisson.spring.transaction.RedissonTransactionObject
 
getTransferQueue(String) - Method in interface org.redisson.api.RedissonClient
Returns transfer queue instance by name.
getTransferQueue(String, Codec) - Method in interface org.redisson.api.RedissonClient
Returns transfer queue instance by name using provided codec for queue objects.
getTransferQueue(String) - Method in interface org.redisson.api.RedissonReactiveClient
Returns transfer queue instance by name.
getTransferQueue(String, Codec) - Method in interface org.redisson.api.RedissonReactiveClient
Returns transfer queue instance by name using provided codec for queue objects.
getTransferQueue(String) - Method in interface org.redisson.api.RedissonRxClient
Returns transfer queue instance by name.
getTransferQueue(String, Codec) - Method in interface org.redisson.api.RedissonRxClient
Returns transfer queue instance by name using provided codec for queue objects.
getTransferQueue(String) - Method in class org.redisson.Redisson
 
getTransferQueue(String, Codec) - Method in class org.redisson.Redisson
 
getTransferQueue(String) - Method in class org.redisson.RedissonReactive
 
getTransferQueue(String, Codec) - Method in class org.redisson.RedissonReactive
 
getTransferQueue(String) - Method in class org.redisson.RedissonRx
 
getTransferQueue(String, Codec) - Method in class org.redisson.RedissonRx
 
getTransportMode() - Method in class org.redisson.config.Config
 
getTtl() - Method in class org.redisson.executor.params.TaskParameters
 
getTTL() - Method in class org.redisson.spring.cache.CacheConfig
 
getTTL() - Method in class org.redisson.transaction.operation.map.MapCacheFastPutIfAbsentOperation
 
getTTL() - Method in class org.redisson.transaction.operation.map.MapCacheFastPutOperation
 
getTTL() - Method in class org.redisson.transaction.operation.map.MapCachePutIfAbsentOperation
 
getTTL() - Method in class org.redisson.transaction.operation.map.MapCachePutOperation
 
getTTL() - Method in class org.redisson.transaction.operation.set.AddCacheOperation
 
getTTLUnit() - Method in class org.redisson.transaction.operation.map.MapCacheFastPutIfAbsentOperation
 
getTTLUnit() - Method in class org.redisson.transaction.operation.map.MapCacheFastPutOperation
 
getTTLUnit() - Method in class org.redisson.transaction.operation.map.MapCachePutIfAbsentOperation
 
getTTLUnit() - Method in class org.redisson.transaction.operation.map.MapCachePutOperation
 
getType() - Method in class org.redisson.api.map.event.EntryEvent
 
getType() - Method in interface org.redisson.api.Node
Deprecated.
Returns node type
getType(String) - Method in interface org.redisson.api.RKeys
Get Redis object type by key
getType(String) - Method in interface org.redisson.api.RKeysReactive
Get Redis object type by key
getType(String) - Method in interface org.redisson.api.RKeysRx
Get Redis object type by key
getType() - Method in class org.redisson.client.protocol.pubsub.PubSubStatusMessage
 
getType() - Method in class org.redisson.cluster.ClusterPartition
 
getType() - Method in class org.redisson.connection.RedisClientEntry
 
getType(String) - Method in class org.redisson.RedissonKeys
 
getType() - Method in class org.redisson.RedissonReference
 
getTypeAsync(String) - Method in interface org.redisson.api.RKeysAsync
Get Redis object type by key
getTypeAsync(String) - Method in class org.redisson.RedissonKeys
 
getTypeDescription(Class<?>) - Static method in class org.redisson.liveobject.misc.Introspectior
 
getTypeName() - Method in class org.redisson.RedissonReference
 
getUpdatesLogName() - Method in class org.redisson.cache.LocalCacheListener
 
getURI() - Method in class org.redisson.jcache.JCacheManager
 
getUrl() - Method in exception org.redisson.client.RedisRedirectException
 
getUsername() - Method in class org.redisson.client.RedisClientConfig
 
getUsername() - Method in class org.redisson.config.BaseConfig
 
getValue() - Method in class org.redisson.api.map.event.EntryEvent
 
getValue() - Method in interface org.redisson.cache.CachedValue
 
getValue() - Method in class org.redisson.cache.CacheValue
 
getValue() - Method in class org.redisson.cache.LocalCachedMapUpdate.Entry
 
getValue() - Method in class org.redisson.cache.ReferenceCachedValue
 
getValue() - Method in class org.redisson.cache.StdCachedValue
 
getValue() - Method in class org.redisson.client.protocol.decoder.KeyValueMessage
 
getValue() - Method in class org.redisson.client.protocol.pubsub.PubSubMessage
 
getValue() - Method in class org.redisson.client.protocol.pubsub.PubSubPatternMessage
 
getValue() - Method in class org.redisson.client.protocol.ScoredEntry
 
getValue(int, String, int) - Method in class org.redisson.executor.CronExpression
 
getValue(E) - Method in class org.redisson.iterator.BaseIterator
 
getValue(Object) - Method in class org.redisson.iterator.RedissonBaseIterator
 
getValue(Map.Entry<Object, Object>) - Method in class org.redisson.iterator.RedissonBaseMapIterator
 
getValue(int) - Method in class org.redisson.iterator.RedissonListIterator
 
getValue() - Method in class org.redisson.jcache.JCacheEntry
 
getValue() - Method in class org.redisson.jcache.JCacheEntryEvent
 
getValue() - Method in class org.redisson.jcache.JMutableEntry
 
getValue() - Method in class org.redisson.liveobject.condition.EQCondition
 
getValue() - Method in class org.redisson.liveobject.condition.GECondition
 
getValue() - Method in class org.redisson.liveobject.condition.GTCondition
 
getValue() - Method in class org.redisson.liveobject.condition.LECondition
 
getValue() - Method in class org.redisson.liveobject.condition.LTCondition
 
getValue() - Method in interface org.redisson.liveobject.core.LiveObjectInterceptor.Getter
 
getValue() - Method in class org.redisson.misc.HashValue
 
getValue() - Method in class org.redisson.RedissonMapEntry
 
getValue() - Method in class org.redisson.RedissonPriorityQueue.BinarySearchResult
 
getValue() - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
 
getValue() - Method in class org.redisson.transaction.BaseTransactionalMap.MapEntry
 
getValue() - Method in class org.redisson.transaction.operation.bucket.BucketCompareAndSetOperation
 
getValue() - Method in class org.redisson.transaction.operation.bucket.BucketGetAndSetOperation
 
getValue() - Method in class org.redisson.transaction.operation.bucket.BucketSetOperation
 
getValue() - Method in class org.redisson.transaction.operation.bucket.BucketTrySetOperation
 
getValue() - Method in class org.redisson.transaction.operation.map.MapOperation
 
getValue() - Method in class org.redisson.transaction.operation.set.AddCacheOperation
 
getValue() - Method in class org.redisson.transaction.operation.set.AddOperation
 
getValue() - Method in class org.redisson.transaction.operation.set.MoveOperation
 
getValue() - Method in class org.redisson.transaction.operation.set.RemoveCacheOperation
 
getValue() - Method in class org.redisson.transaction.operation.set.RemoveOperation
 
getValueAsync(int) - Method in class org.redisson.RedissonTransferQueue
 
getValueDecoder() - Method in class org.redisson.api.annotation.REntity.DEFAULT
 
getValueDecoder() - Method in class org.redisson.api.annotation.RObjectField.DEFAULT
 
getValueDecoder() - Method in class org.redisson.cache.LocalCachedMessageCodec
 
getValueDecoder() - Method in class org.redisson.client.codec.BitSetCodec
 
getValueDecoder() - Method in class org.redisson.client.codec.ByteArrayCodec
 
getValueDecoder() - Method in interface org.redisson.client.codec.Codec
Returns object decoder used for any objects stored Redis structure except HMAP
getValueDecoder() - Method in class org.redisson.client.codec.DoubleCodec
 
getValueDecoder() - Method in class org.redisson.client.codec.IntegerCodec
 
getValueDecoder() - Method in class org.redisson.client.codec.LongCodec
 
getValueDecoder() - Method in class org.redisson.client.codec.StringCodec
 
getValueDecoder() - Method in class org.redisson.codec.CompositeCodec
 
getValueDecoder() - Method in class org.redisson.codec.FstCodec
 
getValueDecoder() - Method in class org.redisson.codec.JsonJacksonCodec
 
getValueDecoder() - Method in class org.redisson.codec.Kryo5Codec
 
getValueDecoder() - Method in class org.redisson.codec.KryoCodec
 
getValueDecoder() - Method in class org.redisson.codec.LZ4Codec
 
getValueDecoder() - Method in class org.redisson.codec.MapCacheEventCodec
 
getValueDecoder() - Method in class org.redisson.codec.MarshallingCodec
 
getValueDecoder() - Method in class org.redisson.codec.SerializationCodec
 
getValueDecoder() - Method in class org.redisson.codec.SnappyCodec
 
getValueDecoder() - Method in class org.redisson.codec.SnappyCodecV2
 
getValueDecoder() - Method in class org.redisson.codec.TypedJsonJacksonCodec
 
getValueDecoder() - Method in class org.redisson.jcache.JCacheEventCodec
 
getValueEncoder() - Method in class org.redisson.api.annotation.REntity.DEFAULT
 
getValueEncoder() - Method in class org.redisson.api.annotation.RObjectField.DEFAULT
 
getValueEncoder() - Method in class org.redisson.cache.LocalCachedMessageCodec
 
getValueEncoder() - Method in class org.redisson.client.codec.BitSetCodec
 
getValueEncoder() - Method in class org.redisson.client.codec.ByteArrayCodec
 
getValueEncoder() - Method in interface org.redisson.client.codec.Codec
Returns object encoder used for any objects stored Redis structure except HMAP
getValueEncoder() - Method in class org.redisson.client.codec.StringCodec
 
getValueEncoder() - Method in class org.redisson.codec.BaseEventCodec
 
getValueEncoder() - Method in class org.redisson.codec.CompositeCodec
 
getValueEncoder() - Method in class org.redisson.codec.FstCodec
 
getValueEncoder() - Method in class org.redisson.codec.JsonJacksonCodec
 
getValueEncoder() - Method in class org.redisson.codec.Kryo5Codec
 
getValueEncoder() - Method in class org.redisson.codec.KryoCodec
 
getValueEncoder() - Method in class org.redisson.codec.LZ4Codec
 
getValueEncoder() - Method in class org.redisson.codec.MarshallingCodec
 
getValueEncoder() - Method in class org.redisson.codec.SerializationCodec
 
getValueEncoder() - Method in class org.redisson.codec.SnappyCodec
 
getValueEncoder() - Method in class org.redisson.codec.SnappyCodecV2
 
getValueEncoder() - Method in class org.redisson.codec.TypedJsonJacksonCodec
 
getValues() - Method in class org.redisson.client.protocol.decoder.ListScanResult
 
getValues() - Method in class org.redisson.client.protocol.decoder.MapScanResult
 
getValues() - Method in interface org.redisson.ScanResult
 
getValues() - Method in class org.redisson.transaction.operation.bucket.BucketsTrySetOperation
 
getValueType() - Method in class org.redisson.jcache.bean.JCacheManagementMXBean
 
getValueType() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
getValueType() - Method in class org.redisson.jcache.configuration.RedissonConfiguration
 
getWaitingConsumerCount() - Method in class org.redisson.RedissonTransferQueue
 
getWorkers() - Method in class org.redisson.api.WorkerOptions
 
getWriteBehindBatchSize() - Method in class org.redisson.api.MapOptions
 
getWriteBehindDelay() - Method in class org.redisson.api.MapOptions
 
getWriteMode() - Method in class org.redisson.api.MapOptions
 
getWriter() - Method in class org.redisson.api.MapOptions
 
group - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
gt(String, Number) - Static method in class org.redisson.api.condition.Conditions
Returns "GREATER THAN" condition which restricts property by name to defined value
GTCondition - Class in org.redisson.liveobject.condition
 
GTCondition(String, Number) - Constructor for class org.redisson.liveobject.condition.GTCondition
 

H

handle(RPromise<Void>, AtomicInteger, RFuture<?>) - Method in class org.redisson.command.CommandBatchService
 
handle(BiFunction<? super T, Throwable, ? extends U>) - Method in class org.redisson.misc.PromiseDelegator
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>) - Method in class org.redisson.misc.PromiseDelegator
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
handleError(RFuture<RedisConnection>, Throwable) - Method in class org.redisson.command.RedisExecutor
 
handleError(RFuture<RedisConnection>, Throwable) - Method in class org.redisson.command.RedisQueuedBatchExecutor
 
handleException(RPromise<?>, Exception) - Method in class org.redisson.jcache.JCache
 
handleResult(RPromise<Void>, RFuture<RedisConnection>) - Method in class org.redisson.command.RedisCommonBatchExecutor
 
handleResult(RPromise<R>, RFuture<RedisConnection>) - Method in class org.redisson.command.RedisExecutor
 
handleSuccess(RPromise<R>, RFuture<RedisConnection>, R) - Method in class org.redisson.command.RedisExecutor
 
handleSuccess(RPromise<R>, RFuture<RedisConnection>, R) - Method in class org.redisson.command.RedisQueuedBatchExecutor
 
hasAttribute(Element, String) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
hasElement(Element, String) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
hash(V...) - Method in interface org.redisson.api.RGeo
Returns 11 characters Geohash string mapped by defined member.
hash(V...) - Method in interface org.redisson.api.RGeoReactive
Returns 11 characters Geohash string mapped by defined member.
hash(V...) - Method in interface org.redisson.api.RGeoRx
Returns 11 characters Geohash string mapped by defined member.
Hash - Class in org.redisson.misc
 
hash(V...) - Method in class org.redisson.RedissonGeo
 
hash(ByteBuf) - Method in class org.redisson.RedissonMultimap
 
hash128(ByteBuf) - Static method in class org.redisson.misc.Hash
 
hash128(byte[], int, int, long[]) - Static method in class org.redisson.misc.HighwayHash
NOTE: The 128-bit HighwayHash algorithm is not yet frozen and subject to change.
hash128toArray(ByteBuf) - Static method in class org.redisson.misc.Hash
 
hash128toBase64(ByteBuf) - Static method in class org.redisson.misc.Hash
 
hash256(byte[], int, int, long[]) - Static method in class org.redisson.misc.HighwayHash
NOTE: The 256-bit HighwayHash algorithm is not yet frozen and subject to change.
hash64(ByteBuf) - Static method in class org.redisson.misc.Hash
 
hash64(byte[], int, int, long[]) - Static method in class org.redisson.misc.HighwayHash
NOTE: The 64-bit HighwayHash algorithm is declared stable and no longer subject to change.
hashAsync(V...) - Method in interface org.redisson.api.RGeoAsync
Returns 11 characters Geohash string mapped by defined member.
hashAsync(V...) - Method in class org.redisson.RedissonGeo
 
hashCode() - Method in class org.redisson.api.GeoPosition
 
hashCode() - Method in class org.redisson.api.StreamMessageId
 
hashCode() - Method in class org.redisson.cache.CacheKey
 
hashCode() - Method in class org.redisson.client.ChannelName
 
hashCode() - Method in class org.redisson.client.handler.PubSubKey
 
hashCode() - Method in class org.redisson.client.protocol.ScoredEntry
 
hashCode() - Method in class org.redisson.client.protocol.Time
 
hashCode() - Method in class org.redisson.cluster.ClusterPartition
 
hashCode() - Method in class org.redisson.cluster.ClusterSlotRange
 
hashCode() - Method in class org.redisson.codec.CompositeCodec
 
hashCode() - Method in class org.redisson.connection.RedisClientEntry
 
hashCode() - Method in class org.redisson.misc.HashValue
 
hashCode() - Method in class org.redisson.misc.RedisURI
 
hashCode() - Method in class org.redisson.PubSubMessageListener
 
hashCode() - Method in class org.redisson.PubSubPatternMessageListener
 
hashCode() - Method in class org.redisson.PubSubPatternStatusListener
 
hashCode() - Method in class org.redisson.PubSubStatusListener
 
hashCode() - Method in class org.redisson.redisnode.RedisNode
 
hashCode() - Method in class org.redisson.redisnode.SentinelRedisNode
 
hashCode() - Method in class org.redisson.RedissonList
 
hashCode() - Method in class org.redisson.RedissonListMultimapValues
 
hashCode() - Method in class org.redisson.RedissonMap
 
hashCode() - Method in class org.redisson.RedissonSubList
 
hashCode() - Method in class org.redisson.remote.RemoteServiceKey
 
hashCode() - Method in class org.redisson.remote.RequestId
 
hashCode() - Method in class org.redisson.transaction.HashKey
 
HashKey - Class in org.redisson.transaction
 
HashKey(String, Codec) - Constructor for class org.redisson.transaction.HashKey
 
HashValue - Class in org.redisson.misc
 
HashValue(long[]) - Constructor for class org.redisson.misc.HashValue
 
HashValue - Class in org.redisson.transaction
 
HashValue() - Constructor for class org.redisson.transaction.HashValue
 
hasListeners() - Method in class org.redisson.misc.PromiseDelegator
 
hasListeners() - Method in class org.redisson.misc.RedissonPromise
 
hasListeners() - Method in interface org.redisson.misc.RPromise
 
hasListeners(ChannelName) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
hasNext() - Method in class org.redisson.iterator.BaseIterator
 
hasNext() - Method in class org.redisson.iterator.RedissonListIterator
 
hasNext() - Method in class org.redisson.misc.CompositeIterator
 
hasNoLoader() - Method in class org.redisson.RedissonMap
 
hasNoThreads() - Method in class org.redisson.RedissonLock.ExpirationEntry
 
hasNoWriter() - Method in class org.redisson.RedissonMap
 
hasPrevious() - Method in class org.redisson.iterator.RedissonListIterator
 
hasSlave(RedisClient) - Method in class org.redisson.connection.MasterSlaveEntry
 
hasSlave(InetSocketAddress) - Method in class org.redisson.connection.MasterSlaveEntry
 
hasSlave(RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
 
hasSlot(int) - Method in class org.redisson.cluster.ClusterPartition
 
hasTask(String) - Method in interface org.redisson.api.RExecutorService
Returns true if this Executor Service has task by taskId awaiting for execution and/or currently in execution
hasTask(String) - Method in class org.redisson.RedissonExecutorService
 
hasTaskAsync(String) - Method in interface org.redisson.api.RExecutorServiceAsync
Returns true if this Executor Service has task by taskId awaiting for execution and/or currently in execution
hasTaskAsync(String) - Method in class org.redisson.RedissonExecutorService
 
hasWaitingConsumer() - Method in class org.redisson.RedissonTransferQueue
 
HDEL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
headSet(String) - Method in class org.redisson.RedissonLexSortedSet
 
headSet(V) - Method in class org.redisson.RedissonSortedSet
 
helper - Variable in class org.redisson.spring.support.AbstractRedissonNamespaceDefinitionParser
 
HEXISTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HGET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HGETALL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HGETALL_ENTRY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HighwayHash - Class in org.redisson.misc
HighwayHash algorithm.
HighwayHash(long, long, long, long) - Constructor for class org.redisson.misc.HighwayHash
 
HighwayHash(long[]) - Constructor for class org.redisson.misc.HighwayHash
 
hitCount() - Method in class org.redisson.spring.cache.RedissonCacheMetrics
 
HKEYS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HLEN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HLEN_LONG - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HMSET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HostNatMapper - Class in org.redisson.api
Maps host of RedisURI object using map defined in hostsMap setting.
HostNatMapper() - Constructor for class org.redisson.api.HostNatMapper
 
HostPortNatMapper - Class in org.redisson.api
Maps host and port of RedisURI object using map defined in hostsMap setting.
HostPortNatMapper() - Constructor for class org.redisson.api.HostPortNatMapper
 
HOUR - Static variable in class org.redisson.executor.CronExpression
 
hours - Variable in class org.redisson.executor.CronExpression
 
HSCAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HSET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HSET_VOID - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HSETNX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HSTRLEN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
HVALS - Static variable in interface org.redisson.client.protocol.RedisCommands
 

I

id - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
ID_ATTRIBUTE - Static variable in class org.redisson.spring.support.RedissonDefinitionParser
 
IdleConnectionWatcher - Class in org.redisson.connection
 
IdleConnectionWatcher(ConnectionManager, MasterSlaveServersConfig) - Constructor for class org.redisson.connection.IdleConnectionWatcher
 
IdleConnectionWatcher.Entry - Class in org.redisson.connection
 
in(String, Object...) - Static method in class org.redisson.api.condition.Conditions
Returns "IN" condition for property by name and allowed set of values
in(String, Collection<?>) - Static method in class org.redisson.api.condition.Conditions
Returns "IN" condition for property by name and allowed set of values
incLevel() - Method in class org.redisson.client.handler.State
 
INCR - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INCRBY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INCRBYFLOAT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
incReference() - Method in class org.redisson.connection.MasterSlaveEntry
 
increment() - Method in interface org.redisson.api.RDoubleAdder
Increments value
increment() - Method in interface org.redisson.api.RLongAdder
Increments value
increment() - Method in class org.redisson.RedissonDoubleAdder
 
increment() - Method in class org.redisson.RedissonLongAdder
 
incrementAndGet() - Method in interface org.redisson.api.RAtomicDouble
Atomically increments the current value by one.
incrementAndGet() - Method in interface org.redisson.api.RAtomicDoubleReactive
Atomically increments the current value by one.
incrementAndGet() - Method in interface org.redisson.api.RAtomicDoubleRx
Atomically increments the current value by one.
incrementAndGet() - Method in interface org.redisson.api.RAtomicLong
Atomically increments the current value by one.
incrementAndGet() - Method in interface org.redisson.api.RAtomicLongReactive
Atomically increments the current value by one.
incrementAndGet() - Method in interface org.redisson.api.RAtomicLongRx
Atomically increments the current value by one.
incrementAndGet() - Method in class org.redisson.RedissonAtomicDouble
 
incrementAndGet() - Method in class org.redisson.RedissonAtomicLong
 
incrementAndGetAsync() - Method in interface org.redisson.api.RAtomicDoubleAsync
Atomically increments the current value by one.
incrementAndGetAsync() - Method in interface org.redisson.api.RAtomicLongAsync
Atomically increments the current value by one.
incrementAndGetAsync() - Method in class org.redisson.RedissonAtomicDouble
 
incrementAndGetAsync() - Method in class org.redisson.RedissonAtomicLong
 
incUsage() - Method in class org.redisson.QueueTransferTask
 
indexOf(Object) - Method in interface org.redisson.api.RListReactive
Returns last index of element or -1 if element isn't found
indexOf(Object) - Method in interface org.redisson.api.RListRx
Returns last index of element or -1 if element isn't found
indexOf(Object) - Method in class org.redisson.RedissonList
 
indexOf(Object) - Method in class org.redisson.RedissonListMultimapValues
 
indexOfAsync(Object) - Method in interface org.redisson.api.RListAsync
Returns last index of element or -1 if element isn't found
indexOfAsync(Object, Convertor<R>) - Method in class org.redisson.RedissonList
 
indexOfAsync(Object) - Method in class org.redisson.RedissonList
 
indexOfAsync(Object) - Method in class org.redisson.RedissonListMultimapValues
 
indexOfAsync(Object, Convertor<R>) - Method in class org.redisson.RedissonSubList
 
InetSocketAddressDecoder - Class in org.redisson.client.protocol.decoder
 
InetSocketAddressDecoder() - Constructor for class org.redisson.client.protocol.decoder.InetSocketAddressDecoder
 
InfinitySemaphoreLatch - Class in org.redisson.misc
Code parts from Manik Surtani ([email protected])
InfinitySemaphoreLatch() - Constructor for class org.redisson.misc.InfinitySemaphoreLatch
 
info(Node.InfoSection) - Method in interface org.redisson.api.Node
Deprecated.
 
info(RedisNode.InfoSection) - Method in interface org.redisson.api.redisnode.RedisNode
 
info(Node.InfoSection) - Method in class org.redisson.connection.RedisClientEntry
 
info(RedisNode.InfoSection) - Method in class org.redisson.redisnode.RedisNode
 
info(RedisNode.InfoSection) - Method in class org.redisson.redisnode.SentinelRedisNode
 
INFO_ALL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_CLIENTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_CLUSTER - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_COMMANDSTATS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_CPU - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_DEFAULT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_KEYSPACE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_MEMORY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_PERSISTENCE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_REPLICATION - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_SERVER - Static variable in interface org.redisson.client.protocol.RedisCommands
 
INFO_STATS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
infoAsync(Node.InfoSection) - Method in interface org.redisson.api.NodeAsync
Deprecated.
 
infoAsync(RedisNode.InfoSection) - Method in interface org.redisson.api.redisnode.RedisNodeAsync
 
infoAsync(Node.InfoSection) - Method in class org.redisson.connection.RedisClientEntry
 
infoAsync(RedisNode.InfoSection) - Method in class org.redisson.redisnode.RedisNode
 
infoAsync(RedisNode.InfoSection) - Method in class org.redisson.redisnode.SentinelRedisNode
 
init(ObjectMapper) - Method in class org.redisson.codec.JsonJacksonCodec
 
init() - Method in class org.redisson.spring.support.RedissonNamespaceHandlerSupport
 
initChannel(Channel) - Method in class org.redisson.client.handler.RedisChannelInitializer
 
initSingleEntry() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
initSlaveBalancer(Collection<RedisURI>) - Method in class org.redisson.connection.MasterSlaveEntry
 
initTimer(MasterSlaveServersConfig) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
initTypeInclusion(ObjectMapper) - Method in class org.redisson.codec.AvroJacksonCodec
 
initTypeInclusion(ObjectMapper) - Method in class org.redisson.codec.JsonJacksonCodec
 
initTypeInclusion(ObjectMapper) - Method in class org.redisson.codec.TypedJsonJacksonCodec
 
inject(Object, Class<T>, T) - Static method in class org.redisson.misc.Injector
 
inject(Object, RedissonClient) - Static method in class org.redisson.misc.Injector
 
Injector - Class in org.redisson.misc
 
Injector() - Constructor for class org.redisson.misc.Injector
 
INSTANCE - Static variable in class org.redisson.cache.LocalCachedMessageCodec
 
INSTANCE - Static variable in class org.redisson.client.codec.BitSetCodec
 
INSTANCE - Static variable in class org.redisson.client.codec.ByteArrayCodec
 
INSTANCE - Static variable in class org.redisson.client.codec.DoubleCodec
 
INSTANCE - Static variable in class org.redisson.client.codec.IntegerCodec
 
INSTANCE - Static variable in class org.redisson.client.codec.LongCodec
 
INSTANCE - Static variable in class org.redisson.client.codec.StringCodec
 
INSTANCE - Static variable in class org.redisson.client.handler.CommandBatchEncoder
 
INSTANCE - Static variable in class org.redisson.client.handler.CommandEncoder
 
INSTANCE - Static variable in class org.redisson.client.protocol.convertor.StreamIdConvertor
 
INSTANCE - Static variable in class org.redisson.codec.JsonJacksonCodec
 
INSTANCE - Static variable in class org.redisson.liveobject.resolver.LongGenerator
 
INSTANCE - Static variable in class org.redisson.liveobject.resolver.RequiredIdResolver
 
INSTANCE - Static variable in class org.redisson.liveobject.resolver.UUIDGenerator
 
INSTANCE - Static variable in class org.redisson.spring.cache.NullValue
 
IntegerCodec - Class in org.redisson.client.codec
 
IntegerCodec() - Constructor for class org.redisson.client.codec.IntegerCodec
 
IntegerReplayConvertor - Class in org.redisson.client.protocol.convertor
 
IntegerReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.IntegerReplayConvertor
 
IntegerReplayConvertor(Integer) - Constructor for class org.redisson.client.protocol.convertor.IntegerReplayConvertor
 
intercept(Method, Callable<?>, Object[], Object, RMap<String, Object>) - Method in class org.redisson.liveobject.core.AccessorInterceptor
 
intercept(Method, Object[], Object, RMap<?, ?>) - Static method in class org.redisson.liveobject.core.FieldAccessorInterceptor
 
intercept(Method, Object[], Object, Object, LiveObjectInterceptor.Setter, LiveObjectInterceptor.Getter, RMap<?, ?>, LiveObjectInterceptor.Setter, LiveObjectInterceptor.Getter) - Method in class org.redisson.liveobject.core.LiveObjectInterceptor
 
intercept(Method, Object[], RMap<?, ?>) - Static method in class org.redisson.liveobject.core.RExpirableInterceptor
 
intercept(Method, Object[], RMap<?, ?>) - Static method in class org.redisson.liveobject.core.RMapInterceptor
 
intercept(Method, Object[], RMap<?, ?>) - Static method in class org.redisson.liveobject.core.RObjectInterceptor
 
internalLockLeaseTime - Variable in class org.redisson.RedissonLock
 
intersection(String...) - Method in interface org.redisson.api.RScoredSortedSet
Intersect provided ScoredSortedSets and store result to current ScoredSortedSet
intersection(RScoredSortedSet.Aggregate, String...) - Method in interface org.redisson.api.RScoredSortedSet
Intersect provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSet
intersection(Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSet
Intersect provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSet
intersection(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSet
Intersect provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSet
intersection(String...) - Method in interface org.redisson.api.RScoredSortedSetReactive
Intersect provided ScoredSortedSets and store result to current ScoredSortedSet
intersection(RScoredSortedSet.Aggregate, String...) - Method in interface org.redisson.api.RScoredSortedSetReactive
Intersect provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSet
intersection(Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetReactive
Intersect provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSet
intersection(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetReactive
Intersect provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSet
intersection(String...) - Method in interface org.redisson.api.RScoredSortedSetRx
Intersect provided ScoredSortedSets and store result to current ScoredSortedSet
intersection(RScoredSortedSet.Aggregate, String...) - Method in interface org.redisson.api.RScoredSortedSetRx
Intersect provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSet
intersection(Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetRx
Intersect provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSet
intersection(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetRx
Intersect provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSet
intersection(String...) - Method in interface org.redisson.api.RSet
Intersection sets specified by name and write to current set.
intersection(String...) - Method in interface org.redisson.api.RSetReactive
Intersection sets specified by name and write to current set.
intersection(String...) - Method in interface org.redisson.api.RSetRx
Intersection sets specified by name and write to current set.
intersection(String...) - Method in class org.redisson.RedissonScoredSortedSet
 
intersection(RScoredSortedSet.Aggregate, String...) - Method in class org.redisson.RedissonScoredSortedSet
 
intersection(Map<String, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
intersection(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
intersection(String...) - Method in class org.redisson.RedissonSet
 
intersection(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
intersectionAsync(String...) - Method in interface org.redisson.api.RScoredSortedSetAsync
Intersect provided ScoredSortedSets and store result to current ScoredSortedSet
intersectionAsync(RScoredSortedSet.Aggregate, String...) - Method in interface org.redisson.api.RScoredSortedSetAsync
Intersect provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSet
intersectionAsync(Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetAsync
Intersect provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSet
intersectionAsync(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetAsync
Intersect provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSet
intersectionAsync(String...) - Method in interface org.redisson.api.RSetAsync
Intersection sets specified by name and write to current set.
intersectionAsync(String...) - Method in class org.redisson.RedissonScoredSortedSet
 
intersectionAsync(RScoredSortedSet.Aggregate, String...) - Method in class org.redisson.RedissonScoredSortedSet
 
intersectionAsync(Map<String, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
intersectionAsync(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
intersectionAsync(String...) - Method in class org.redisson.RedissonSet
 
intersectionAsync(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
intersectionAsync(String...) - Method in class org.redisson.transaction.BaseTransactionalSet
 
intersectionAsync(String...) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
Introspectior - Class in org.redisson.liveobject.misc
 
Introspectior() - Constructor for class org.redisson.liveobject.misc.Introspectior
 
invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class org.redisson.jcache.JCache
 
invoke(V) - Method in interface org.redisson.RedissonTransferQueue.TransferQueueService
 
invoke(V) - Method in interface org.redisson.RedissonTransferQueue.TransferQueueServiceAsync
 
invoke(V) - Method in class org.redisson.RedissonTransferQueue.TransferQueueServiceImpl
 
invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class org.redisson.jcache.JCache
 
invokeAll(Collection<? extends Callable<T>>) - Method in class org.redisson.RedissonExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class org.redisson.RedissonExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
invokeMethod(RemoteServiceRequest, RemoteServiceMethod, RFuture<RemoteServiceCancelRequest>, RPromise<RRemoteServiceResponse>) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
invokeMethod(RemoteServiceRequest, RemoteServiceMethod, RFuture<RemoteServiceCancelRequest>, RPromise<RRemoteServiceResponse>) - Method in class org.redisson.RedissonRemoteService
 
invoker(Element, String, String, Object[], ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
invoker(Element, Object, String, Object[], ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
invoker(String, String, Object[], ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
invoker(Object, String, Object[], ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
IonJacksonCodec - Class in org.redisson.codec
Amazon Ion codec
IonJacksonCodec() - Constructor for class org.redisson.codec.IonJacksonCodec
 
IonJacksonCodec(ClassLoader) - Constructor for class org.redisson.codec.IonJacksonCodec
 
IonJacksonCodec(ClassLoader, IonJacksonCodec) - Constructor for class org.redisson.codec.IonJacksonCodec
 
isAckExpected() - Method in class org.redisson.api.RemoteInvocationOptions
 
isActive() - Method in class org.redisson.client.RedisConnection
Check is channel connected and ready for transfer
isAnnotationPresent(Class<?>, Class<? extends Annotation>) - Static method in class org.redisson.liveobject.misc.ClassUtils
 
isAtomic() - Method in class org.redisson.client.protocol.CommandsData
 
isBlockingCommand() - Method in class org.redisson.client.protocol.CommandData
 
isBlockingCommand() - Method in class org.redisson.client.protocol.CommandsData
 
isBlockingCommand() - Method in interface org.redisson.client.protocol.QueueCommand
 
isCanceled() - Method in class org.redisson.remote.RemoteServiceCancelResponse
 
isCancelled() - Method in class org.redisson.misc.PromiseDelegator
 
isCancelled() - Method in class org.redisson.misc.RedissonPromise
 
isCheckSentinelsList() - Method in class org.redisson.config.SentinelServersConfig
 
isCheckSlotsCoverage() - Method in class org.redisson.config.ClusterServersConfig
 
isClassRegistered(Class<?>) - Method in interface org.redisson.api.RLiveObjectService
Check if the class is registered in the cache.
isClassRegistered(Class<?>) - Method in class org.redisson.RedissonLiveObjectService
 
isClosed() - Method in class org.redisson.client.RedisConnection
 
isClosed() - Method in class org.redisson.jcache.JCache
 
isClosed() - Method in class org.redisson.jcache.JCacheManager
 
isClosed() - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
isClusterConfig() - Method in class org.redisson.config.Config
 
isClusterMode() - Method in class org.redisson.cluster.ClusterConnectionManager
 
isClusterMode() - Method in interface org.redisson.connection.ConnectionManager
 
isClusterMode() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
isDecodeInExecutor() - Method in class org.redisson.client.RedisClientConfig
 
isDecodeInExecutor() - Method in class org.redisson.config.Config
 
isDisabled(Object) - Method in class org.redisson.cache.LocalCacheListener
 
isDone() - Method in class org.redisson.misc.PromiseDelegator
 
isDone() - Method in class org.redisson.misc.RedissonPromise
 
isEligibleAttribute(String) - Method in class org.redisson.spring.support.RedisDefinitionParser
 
isEligibleAttribute(Attr, ParserContext) - Method in class org.redisson.spring.support.RedisDefinitionParser
 
isEligibleAttribute(String) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
isEligibleAttribute(Attr) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
isEmpty() - Method in interface org.redisson.api.RMultimap
Check is map empty
isEmpty() - Method in interface org.redisson.api.RScoredSortedSet
Returns true if this set is empty
isEmpty() - Method in class org.redisson.cache.AbstractCacheMap
 
isEmpty() - Method in class org.redisson.misc.BiHashMap
 
isEmpty() - Method in class org.redisson.RedissonDelayedQueue
 
isEmpty() - Method in class org.redisson.RedissonList
 
isEmpty() - Method in class org.redisson.RedissonListMultimapValues
 
isEmpty() - Method in class org.redisson.RedissonMap
 
isEmpty() - Method in class org.redisson.RedissonMultimap
 
isEmpty() - Method in class org.redisson.RedissonScoredSortedSet
 
isEmpty() - Method in class org.redisson.RedissonSet
 
isEmpty() - Method in class org.redisson.RedissonSetCache
 
isEmpty() - Method in class org.redisson.RedissonSetMultimapValues
 
isEmpty() - Method in class org.redisson.RedissonSortedSet
 
isEmpty() - Method in class org.redisson.RedissonTransferQueue
 
isEvalCacheActive() - Method in class org.redisson.command.CommandAsyncService
 
isEvalCacheActive() - Method in class org.redisson.command.CommandBatchService
 
isExecuted() - Method in class org.redisson.client.protocol.CommandData
 
isExecuted() - Method in class org.redisson.client.protocol.CommandsData
 
isExecuted() - Method in interface org.redisson.client.protocol.QueueCommand
 
isExistingTransaction(Object) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
isExistingTransaction(Object) - Method in class org.redisson.spring.transaction.RedissonTransactionManager
 
isExists(T) - Method in interface org.redisson.api.RLiveObjectService
Returns true if the RLiveObject already exists in redis.
isExists() - Method in interface org.redisson.api.RObject
Check object existence
isExists() - Method in interface org.redisson.api.RObjectReactive
Check object existence
isExists() - Method in interface org.redisson.api.RObjectRx
Check object existence
isExists(T) - Method in class org.redisson.RedissonLiveObjectService
 
isExists() - Method in class org.redisson.RedissonObject
 
isExistsAsync() - Method in interface org.redisson.api.RObjectAsync
Check object existence in async mode.
isExistsAsync() - Method in class org.redisson.RedissonLock
 
isExistsAsync() - Method in class org.redisson.RedissonObject
 
isExistsAsync() - Method in class org.redisson.transaction.BaseTransactionalMap
 
isExistsAsync() - Method in class org.redisson.transaction.BaseTransactionalSet
 
isExistsAsync() - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
isExistsAsync() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
isExistsAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
isExpired() - Method in interface org.redisson.cache.ExpirableValue
 
isExpired() - Method in class org.redisson.cache.StdCachedValue
 
isFailed() - Method in class org.redisson.connection.ClientConnectionsEntry
 
isFastReconnect() - Method in class org.redisson.client.RedisConnection
 
isFirstCommand() - Method in class org.redisson.command.CommandBatchService.ConnectionEntry
 
isFreezed() - Method in class org.redisson.connection.ClientConnectionsEntry
 
isFull(K) - Method in class org.redisson.cache.AbstractCacheMap
 
isFull(K) - Method in class org.redisson.cache.ReferenceCacheMap
 
isFull() - Method in class org.redisson.client.handler.StateLevel
 
isHeldByCurrentThread() - Method in interface org.redisson.api.RLock
Checks if this lock is held by the current thread
isHeldByCurrentThread() - Method in class org.redisson.RedissonLock
 
isHeldByCurrentThread() - Method in class org.redisson.RedissonMultiLock
 
isHeldByThread(long) - Method in interface org.redisson.api.RLock
Checks if the lock is held by thread with defined threadId
isHeldByThread(long) - Method in class org.redisson.RedissonLock
 
isHeldByThread(long) - Method in class org.redisson.RedissonMultiLock
 
isKeepAlive() - Method in class org.redisson.client.RedisClientConfig
 
isKeepAlive() - Method in class org.redisson.config.BaseConfig
 
isKeepPubSubOrder() - Method in class org.redisson.client.RedisClientConfig
 
isKeepPubSubOrder() - Method in class org.redisson.config.Config
 
isLeapYear(int) - Method in class org.redisson.executor.CronExpression
 
isLiveObject(T) - Method in interface org.redisson.api.RLiveObjectService
Returns true if the instance is a instance of RLiveObject.
isLiveObject(T) - Method in class org.redisson.RedissonLiveObjectService
 
isLocked() - Method in interface org.redisson.api.RLock
Checks if the lock locked by any thread
isLocked() - Method in interface org.redisson.api.RLockReactive
Checks if the lock locked by any thread
isLocked() - Method in interface org.redisson.api.RLockRx
Checks if the lock locked by any thread
isLocked() - Method in class org.redisson.RedissonLock
 
isLocked() - Method in class org.redisson.RedissonMultiLock
 
isLocked() - Method in class org.redisson.RedissonReadLock
 
isLocked() - Method in class org.redisson.RedissonWriteLock
 
isLockedAsync() - Method in interface org.redisson.api.RLockAsync
Checks if the lock locked by any thread
isLockedAsync() - Method in class org.redisson.RedissonLock
 
isLockedAsync() - Method in class org.redisson.RedissonMultiLock
 
isManagementEnabled() - Method in class org.redisson.jcache.bean.JCacheManagementMXBean
 
isManagementEnabled() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
isMasterFail() - Method in class org.redisson.cluster.ClusterPartition
 
isMasterForRead() - Method in class org.redisson.connection.ClientConnectionsEntry
 
isMayInterruptIfRunning() - Method in class org.redisson.remote.RemoteServiceCancelRequest
 
isOldValueAvailable() - Method in class org.redisson.jcache.JCacheEntryEvent
 
isOpen() - Method in class org.redisson.client.RedisConnection
 
isOpen() - Method in class org.redisson.RedissonBinaryStream.RedissonAsynchronousByteChannel
 
isOpened() - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
isOpened() - Method in class org.redisson.misc.ReclosableLatch
 
isQueued() - Method in class org.redisson.client.protocol.CommandsData
 
isReadOnly() - Method in class org.redisson.client.RedisClientConfig
 
isReadOnlyMode() - Method in class org.redisson.command.CommandBatchService.Entry
 
isReadThrough() - Method in class org.redisson.jcache.bean.JCacheManagementMXBean
 
isReadThrough() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
isRedisBasedQueue() - Method in class org.redisson.command.CommandBatchService
 
isRedissonNS(Node) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
isRedissonReferenceSupportEnabled() - Method in interface org.redisson.command.CommandAsyncExecutor
 
isRedissonReferenceSupportEnabled() - Method in class org.redisson.command.CommandAsyncService
 
isReferenceEnabled() - Method in class org.redisson.config.Config
Config option indicate whether Redisson Reference feature is enabled.
isReleaseSemaphore() - Method in class org.redisson.cache.LocalCachedMapClear
 
isResultExpected() - Method in class org.redisson.api.RemoteInvocationOptions
 
isRollbackOnly() - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionObject
 
isRollbackOnly() - Method in class org.redisson.spring.transaction.RedissonTransactionObject
 
isSatisfiedBy(Date) - Method in class org.redisson.executor.CronExpression
Indicates whether the given date satisfies the cron expression.
isSendResponse() - Method in class org.redisson.remote.RemoteServiceCancelRequest
 
isSentinelConfig() - Method in class org.redisson.config.Config
 
isShutdown() - Method in interface org.redisson.api.RedissonClient
Returns true if this Redisson instance has been shut down.
isShutdown() - Method in interface org.redisson.api.RedissonReactiveClient
Returns true if this Redisson instance has been shut down.
isShutdown() - Method in interface org.redisson.api.RedissonRxClient
Returns true if this Redisson instance has been shut down.
isShutdown() - Method in interface org.redisson.connection.ConnectionManager
 
isShutdown() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
isShutdown() - Method in class org.redisson.Redisson
 
isShutdown() - Method in class org.redisson.RedissonExecutorService
 
isShutdown() - Method in class org.redisson.RedissonReactive
 
isShutdown() - Method in class org.redisson.RedissonRx
 
isShuttingDown() - Method in interface org.redisson.api.RedissonClient
Returns true if this Redisson instance was started to be shutdown or was shutdown RedissonClient.isShutdown() already.
isShuttingDown() - Method in interface org.redisson.api.RedissonReactiveClient
Returns true if this Redisson instance was started to be shutdown or was shutdown RedissonReactiveClient.isShutdown() already.
isShuttingDown() - Method in interface org.redisson.api.RedissonRxClient
Returns true if this Redisson instance was started to be shutdown or was shutdown RedissonRxClient.isShutdown() already.
isShuttingDown() - Method in interface org.redisson.connection.ConnectionManager
 
isShuttingDown() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
isShuttingDown() - Method in class org.redisson.Redisson
 
isShuttingDown() - Method in class org.redisson.RedissonReactive
 
isShuttingDown() - Method in class org.redisson.RedissonRx
 
isSkipResult() - Method in class org.redisson.api.BatchOptions
 
isSkipResult() - Method in class org.redisson.client.protocol.CommandsData
 
isSlaveUnfreezed(RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
 
isSsl() - Method in class org.redisson.misc.RedisURI
 
isSslEnableEndpointIdentification() - Method in class org.redisson.client.RedisClientConfig
 
isSslEnableEndpointIdentification() - Method in class org.redisson.config.BaseConfig
 
isStatisticsEnabled() - Method in class org.redisson.jcache.bean.JCacheManagementMXBean
 
isStatisticsEnabled() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
isStoreByValue() - Method in class org.redisson.jcache.bean.JCacheManagementMXBean
 
isStoreByValue() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
isStoreByValue() - Method in class org.redisson.jcache.configuration.RedissonConfiguration
 
isSuccess() - Method in interface org.redisson.api.RFuture
Returns true if and only if the I/O operation was completed successfully.
isSuccess() - Method in class org.redisson.client.protocol.BatchCommandData
 
isSuccess() - Method in class org.redisson.client.protocol.CommandData
 
isSuccess() - Method in class org.redisson.misc.PromiseDelegator
 
isSuccess() - Method in class org.redisson.misc.RedissonPromise
 
isSupported(OptionalFeature) - Method in class org.redisson.jcache.JCachingProvider
 
isTcpNoDelay() - Method in class org.redisson.client.RedisClientConfig
 
isTcpNoDelay() - Method in class org.redisson.config.BaseConfig
 
isTerminated() - Method in class org.redisson.RedissonExecutorService
 
isUnfreezed(RedisURI) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
isUseScriptCache() - Method in class org.redisson.config.Config
 
isUseThreadClassLoader() - Method in class org.redisson.config.Config
 
isValidExpression(String) - Static method in class org.redisson.executor.CronExpression
Indicates whether the specified cron expression can be parsed into a valid cron expression
isWaitCommand(CommandData<?, ?>) - Method in class org.redisson.command.CommandBatchService
 
isWaitCommand(CommandData<?, ?>) - Method in class org.redisson.command.RedisCommonBatchExecutor
 
isWriteThrough() - Method in class org.redisson.jcache.bean.JCacheManagementMXBean
 
isWriteThrough() - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
iterator() - Method in interface org.redisson.api.RCollectionReactive
Returns iterator over collection elements
iterator() - Method in interface org.redisson.api.RCollectionRx
Returns iterator over collection elements
iterator(int) - Method in interface org.redisson.api.RListReactive
 
iterator(int) - Method in interface org.redisson.api.RListRx
 
iterator(String) - Method in interface org.redisson.api.RScoredSortedSet
Returns an iterator over elements in this set.
iterator(int) - Method in interface org.redisson.api.RScoredSortedSet
Returns an iterator over elements in this set.
iterator(String, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns an iterator over elements in this set.
iterator(String) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns an iterator over elements in this set.
iterator(int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns an iterator over elements in this set.
iterator(String, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns an iterator over elements in this set.
iterator() - Method in interface org.redisson.api.RScoredSortedSetReactive
 
iterator(String) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns an iterator over elements in this set.
iterator(int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns an iterator over elements in this set.
iterator(String, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns an iterator over elements in this set.
iterator() - Method in interface org.redisson.api.RScoredSortedSetRx
 
iterator(int) - Method in interface org.redisson.api.RSet
Returns elements iterator fetches elements in a batch.
iterator(String, int) - Method in interface org.redisson.api.RSet
Returns elements iterator fetches elements in a batch.
iterator(String) - Method in interface org.redisson.api.RSet
Returns elements iterator.
iterator(int) - Method in interface org.redisson.api.RSetCache
Returns an iterator over elements in this set.
iterator(String, int) - Method in interface org.redisson.api.RSetCache
Returns an iterator over elements in this set.
iterator(String) - Method in interface org.redisson.api.RSetCache
Returns values iterator matches pattern.
iterator(int) - Method in interface org.redisson.api.RSetReactive
Returns elements iterator fetches elements in a batch.
iterator(String, int) - Method in interface org.redisson.api.RSetReactive
Returns elements iterator fetches elements in a batch.
iterator(String) - Method in interface org.redisson.api.RSetReactive
Returns elements iterator.
iterator(int) - Method in interface org.redisson.api.RSetRx
Returns elements iterator fetches elements in a batch.
iterator(String, int) - Method in interface org.redisson.api.RSetRx
Returns elements iterator fetches elements in a batch.
iterator(String) - Method in interface org.redisson.api.RSetRx
Returns elements iterator.
iterator(RedisClient, long) - Method in class org.redisson.iterator.BaseIterator
 
iterator(RedisClient, long) - Method in class org.redisson.iterator.RedissonMapIterator
 
iterator() - Method in class org.redisson.jcache.JCache
 
iterator() - Method in class org.redisson.misc.CompositeIterable
 
iterator() - Method in class org.redisson.reactive.RedissonLexSortedSetReactive
 
iterator(String) - Method in class org.redisson.reactive.RedissonLexSortedSetReactive
 
iterator(int) - Method in class org.redisson.reactive.RedissonLexSortedSetReactive
 
iterator(String, int) - Method in class org.redisson.reactive.RedissonLexSortedSetReactive
 
iterator() - Method in class org.redisson.reactive.RedissonListReactive
 
iterator(int) - Method in class org.redisson.reactive.RedissonListReactive
 
iterator() - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
 
iterator(String) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
 
iterator(int) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
 
iterator(String, int) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
 
iterator() - Method in class org.redisson.reactive.RedissonSetCacheReactive
 
iterator(int) - Method in class org.redisson.reactive.RedissonSetReactive
 
iterator(String) - Method in class org.redisson.reactive.RedissonSetReactive
 
iterator(String, int) - Method in class org.redisson.reactive.RedissonSetReactive
 
iterator() - Method in class org.redisson.reactive.RedissonSetReactive
 
iterator() - Method in class org.redisson.reactive.RedissonTransferQueueReactive
 
iterator() - Method in class org.redisson.RedissonDelayedQueue
 
iterator() - Method in class org.redisson.RedissonList
 
iterator() - Method in class org.redisson.RedissonListMultimapValues
 
iterator() - Method in class org.redisson.RedissonScoredSortedSet
 
iterator(String) - Method in class org.redisson.RedissonScoredSortedSet
 
iterator(int) - Method in class org.redisson.RedissonScoredSortedSet
 
iterator(String, int) - Method in class org.redisson.RedissonScoredSortedSet
 
iterator(int) - Method in class org.redisson.RedissonSet
 
iterator(String) - Method in class org.redisson.RedissonSet
 
iterator(String, int) - Method in class org.redisson.RedissonSet
 
iterator() - Method in class org.redisson.RedissonSet
 
iterator(int) - Method in class org.redisson.RedissonSetCache
 
iterator(String) - Method in class org.redisson.RedissonSetCache
 
iterator(String, int) - Method in class org.redisson.RedissonSetCache
 
iterator() - Method in class org.redisson.RedissonSetCache
 
iterator(int) - Method in class org.redisson.RedissonSetMultimapValues
 
iterator(String) - Method in class org.redisson.RedissonSetMultimapValues
 
iterator(String, int) - Method in class org.redisson.RedissonSetMultimapValues
 
iterator() - Method in class org.redisson.RedissonSetMultimapValues
 
iterator() - Method in class org.redisson.RedissonSortedSet
 
iterator() - Method in class org.redisson.RedissonTransferQueue
 
iterator() - Method in class org.redisson.rx.RedissonLexSortedSetRx
 
iterator(String) - Method in class org.redisson.rx.RedissonLexSortedSetRx
 
iterator(int) - Method in class org.redisson.rx.RedissonLexSortedSetRx
 
iterator(String, int) - Method in class org.redisson.rx.RedissonLexSortedSetRx
 
iterator() - Method in class org.redisson.rx.RedissonListRx
 
iterator(int) - Method in class org.redisson.rx.RedissonListRx
 
iterator() - Method in class org.redisson.rx.RedissonScoredSortedSetRx
 
iterator(String) - Method in class org.redisson.rx.RedissonScoredSortedSetRx
 
iterator(int) - Method in class org.redisson.rx.RedissonScoredSortedSetRx
 
iterator(String, int) - Method in class org.redisson.rx.RedissonScoredSortedSetRx
 
iterator() - Method in class org.redisson.rx.RedissonSetCacheRx
 
iterator(int) - Method in class org.redisson.rx.RedissonSetRx
 
iterator(String) - Method in class org.redisson.rx.RedissonSetRx
 
iterator(String, int) - Method in class org.redisson.rx.RedissonSetRx
 
iterator() - Method in class org.redisson.rx.RedissonSetRx
 
iterator() - Method in class org.redisson.rx.RedissonTransferQueueRx
 

J

JCache<K,V> - Class in org.redisson.jcache
JCache implementation
JCache(JCacheManager, Redisson, String, JCacheConfiguration<K, V>, boolean) - Constructor for class org.redisson.jcache.JCache
 
JCacheConfiguration<K,V> - Class in org.redisson.jcache.configuration
Configuration object for JCache Cache
JCacheConfiguration(Configuration<K, V>) - Constructor for class org.redisson.jcache.configuration.JCacheConfiguration
 
JCacheEntry<K,V> - Class in org.redisson.jcache
 
JCacheEntry(K, V) - Constructor for class org.redisson.jcache.JCacheEntry
 
JCacheEntryEvent<K,V> - Class in org.redisson.jcache
Entry event element passed to EventListener of JCache object
JCacheEntryEvent(Cache<K, V>, EventType, Object, Object) - Constructor for class org.redisson.jcache.JCacheEntryEvent
 
JCacheEventCodec - Class in org.redisson.jcache
 
JCacheEventCodec(Codec, BaseEventCodec.OSType, boolean) - Constructor for class org.redisson.jcache.JCacheEventCodec
 
JCacheEvictionTask - Class in org.redisson.eviction
 
JCacheEvictionTask(String, String, String, CommandAsyncExecutor) - Constructor for class org.redisson.eviction.JCacheEvictionTask
 
JCacheManagementMXBean - Class in org.redisson.jcache.bean
 
JCacheManagementMXBean(JCache<?, ?>) - Constructor for class org.redisson.jcache.bean.JCacheManagementMXBean
 
JCacheManager - Class in org.redisson.jcache
 
JCacheMBeanServerBuilder - Class in org.redisson.jcache
 
JCacheMBeanServerBuilder() - Constructor for class org.redisson.jcache.JCacheMBeanServerBuilder
 
JCacheMBeanServerBuilder.JCacheMBeanServerDelegate - Class in org.redisson.jcache
 
JCacheMBeanServerDelegate(MBeanServerDelegate) - Constructor for class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
JCacheStatisticsMXBean - Class in org.redisson.jcache.bean
 
JCacheStatisticsMXBean() - Constructor for class org.redisson.jcache.bean.JCacheStatisticsMXBean
 
JCachingProvider - Class in org.redisson.jcache
 
JCachingProvider() - Constructor for class org.redisson.jcache.JCachingProvider
 
JMutableEntry<K,V> - Class in org.redisson.jcache
 
JMutableEntry(JCache<K, V>, K, V, boolean) - Constructor for class org.redisson.jcache.JMutableEntry
 
JMutableEntry.Action - Enum in org.redisson.jcache
 
JndiRedissonFactory - Class in org.redisson
Redisson object factory used to register instance in JNDI registry.
JndiRedissonFactory() - Constructor for class org.redisson.JndiRedissonFactory
 
join() - Method in interface org.redisson.api.RFuture
Returns the result value when complete, or throws an (unchecked) exception if completed exceptionally.
join() - Method in class org.redisson.misc.PromiseDelegator
 
JsonJacksonCodec - Class in org.redisson.codec
 
JsonJacksonCodec() - Constructor for class org.redisson.codec.JsonJacksonCodec
 
JsonJacksonCodec(ClassLoader) - Constructor for class org.redisson.codec.JsonJacksonCodec
 
JsonJacksonCodec(ClassLoader, JsonJacksonCodec) - Constructor for class org.redisson.codec.JsonJacksonCodec
 
JsonJacksonCodec(ObjectMapper) - Constructor for class org.redisson.codec.JsonJacksonCodec
 
JsonJacksonCodec.ThrowableMixIn - Class in org.redisson.codec
 

K

keyHash(Object) - Method in class org.redisson.RedissonMultimap
 
keyIterator() - Method in interface org.redisson.api.RMapReactive
Returns iterator over key set of this map.
keyIterator(int) - Method in interface org.redisson.api.RMapReactive
Returns iterator over key set of this map.
keyIterator(String) - Method in interface org.redisson.api.RMapReactive
Returns iterator over key set of this map.
keyIterator(String, int) - Method in interface org.redisson.api.RMapReactive
Returns iterator over key set of this map.
keyIterator() - Method in interface org.redisson.api.RMapRx
Returns iterator over key set of this map.
keyIterator(int) - Method in interface org.redisson.api.RMapRx
Returns iterator over key set of this map.
keyIterator(String) - Method in interface org.redisson.api.RMapRx
Returns iterator over key set of this map.
keyIterator(String, int) - Method in interface org.redisson.api.RMapRx
Returns iterator over key set of this map.
keyIterator() - Method in class org.redisson.jcache.JCache
 
keyIterator() - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
keyIterator(String) - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
keyIterator(int) - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
keyIterator(String, int) - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
keyIterator() - Method in class org.redisson.reactive.RedissonMapReactive
 
keyIterator(String) - Method in class org.redisson.reactive.RedissonMapReactive
 
keyIterator(int) - Method in class org.redisson.reactive.RedissonMapReactive
 
keyIterator(String, int) - Method in class org.redisson.reactive.RedissonMapReactive
 
keyIterator(String, int) - Method in class org.redisson.RedissonMap
 
keyIterator() - Method in class org.redisson.rx.RedissonMapCacheRx
 
keyIterator(String) - Method in class org.redisson.rx.RedissonMapCacheRx
 
keyIterator(int) - Method in class org.redisson.rx.RedissonMapCacheRx
 
keyIterator(String, int) - Method in class org.redisson.rx.RedissonMapCacheRx
 
keyIterator() - Method in class org.redisson.rx.RedissonMapRx
 
keyIterator(String) - Method in class org.redisson.rx.RedissonMapRx
 
keyIterator(int) - Method in class org.redisson.rx.RedissonMapRx
 
keyIterator(String, int) - Method in class org.redisson.rx.RedissonMapRx
 
KEYS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
keys() - Method in class org.redisson.misc.BiHashMap
 
keySet() - Method in interface org.redisson.api.RMap
Returns key set of this map.
keySet(int) - Method in interface org.redisson.api.RMap
Returns key set of this map.
keySet(String, int) - Method in interface org.redisson.api.RMap
Returns key set of this map.
keySet(String) - Method in interface org.redisson.api.RMap
Returns key set of this map.
keySet() - Method in interface org.redisson.api.RMultimap
Returns a view collection of all distinct keys contained in this multimap.
keySet() - Method in class org.redisson.cache.AbstractCacheMap
 
keySet() - Method in class org.redisson.misc.BiHashMap
 
keySet() - Method in class org.redisson.RedissonMap
 
keySet(String) - Method in class org.redisson.RedissonMap
 
keySet(String, int) - Method in class org.redisson.RedissonMap
 
keySet(int) - Method in class org.redisson.RedissonMap
 
keySet() - Method in class org.redisson.RedissonMultimap
 
keySize() - Method in interface org.redisson.api.RMultimap
Returns the count of distinct keys in this multimap.
keySize() - Method in interface org.redisson.api.RMultimapReactive
Returns the number of key-value pairs in this multimap.
keySize() - Method in interface org.redisson.api.RMultimapRx
Returns the number of key-value pairs in this multimap.
keySize() - Method in class org.redisson.RedissonMultimap
 
keySizeAsync() - Method in interface org.redisson.api.RMultimapAsync
Returns the number of key-value pairs in this multimap.
keySizeAsync() - Method in class org.redisson.RedissonMultimap
 
KEYSLOT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
KeyValueMessage<K,V> - Class in org.redisson.client.protocol.decoder
 
KeyValueMessage(K, V) - Constructor for class org.redisson.client.protocol.decoder.KeyValueMessage
 
Kryo5Codec - Class in org.redisson.codec
 
Kryo5Codec() - Constructor for class org.redisson.codec.Kryo5Codec
 
Kryo5Codec(ClassLoader, Kryo5Codec) - Constructor for class org.redisson.codec.Kryo5Codec
 
Kryo5Codec(ClassLoader) - Constructor for class org.redisson.codec.Kryo5Codec
 
KryoCodec - Class in org.redisson.codec
 
KryoCodec() - Constructor for class org.redisson.codec.KryoCodec
 
KryoCodec(ClassLoader) - Constructor for class org.redisson.codec.KryoCodec
 
KryoCodec(ClassLoader, KryoCodec) - Constructor for class org.redisson.codec.KryoCodec
 
KryoCodec(List<Class<?>>) - Constructor for class org.redisson.codec.KryoCodec
 
KryoCodec(List<Class<?>>, ClassLoader) - Constructor for class org.redisson.codec.KryoCodec
 
KryoCodec.RedissonKryoCodecException - Exception in org.redisson.codec
 

L

last() - Method in interface org.redisson.api.RScoredSortedSet
Returns the tail element or null if this sorted set is empty.
last() - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns the tail element or null if this sorted set is empty.
last() - Method in interface org.redisson.api.RScoredSortedSetRx
Returns the tail element or null if this sorted set is empty.
last() - Method in class org.redisson.RedissonScoredSortedSet
 
last() - Method in class org.redisson.RedissonSortedSet
 
lastAsync() - Method in interface org.redisson.api.RLexSortedSetAsync
Returns the last element.
lastAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns the tail element or null if this sorted set is empty.
lastAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
lastdayOffset - Variable in class org.redisson.executor.CronExpression
 
lastdayOfMonth - Variable in class org.redisson.executor.CronExpression
 
lastdayOfWeek - Variable in class org.redisson.executor.CronExpression
 
lastIndexOf(Object) - Method in interface org.redisson.api.RListReactive
Returns last index of element or -1 if element isn't found
lastIndexOf(Object) - Method in interface org.redisson.api.RListRx
Returns last index of element or -1 if element isn't found
lastIndexOf(Object) - Method in class org.redisson.RedissonList
 
lastIndexOf(Object) - Method in class org.redisson.RedissonListMultimapValues
 
lastIndexOfAsync(Object) - Method in interface org.redisson.api.RListAsync
Returns last index of element or -1 if element isn't found
lastIndexOfAsync(Object) - Method in class org.redisson.RedissonList
 
lastIndexOfAsync(Object, Convertor<R>) - Method in class org.redisson.RedissonList
 
lastIndexOfAsync(Object) - Method in class org.redisson.RedissonListMultimapValues
 
lastIndexOfAsync(Object) - Method in class org.redisson.RedissonSubList
 
LASTSAVE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
lastScore() - Method in interface org.redisson.api.RScoredSortedSet
Returns score of the head element or returns null if this sorted set is empty.
lastScore() - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns score of the tail element or returns null if this sorted set is empty.
lastScore() - Method in interface org.redisson.api.RScoredSortedSetRx
Returns score of the tail element or returns null if this sorted set is empty.
lastScore() - Method in class org.redisson.RedissonScoredSortedSet
 
lastScoreAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns score of the tail element or returns null if this sorted set is empty.
lastScoreAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
LatchListener() - Constructor for class org.redisson.mapreduce.SubTasksExecutor.LatchListener
 
LatchListener(CountDownLatch) - Constructor for class org.redisson.mapreduce.SubTasksExecutor.LatchListener
 
le(String, Number) - Static method in class org.redisson.api.condition.Conditions
Returns "LESS THAN ON EQUAL" condition which restricts property by name to defined value
LECondition - Class in org.redisson.liveobject.condition
 
LECondition(String, Number) - Constructor for class org.redisson.liveobject.condition.LECondition
 
length() - Method in interface org.redisson.api.RBitSet
Returns "logical size" = index of highest set bit plus one.
length() - Method in interface org.redisson.api.RBitSetReactive
Returns "logical size" = index of highest set bit plus one.
length() - Method in interface org.redisson.api.RBitSetRx
Returns "logical size" = index of highest set bit plus one.
length() - Method in class org.redisson.client.ChannelName
 
length() - Method in class org.redisson.RedissonBitSet
 
lengthAsync() - Method in interface org.redisson.api.RBitSetAsync
Returns "logical size" = index of highest set bit plus one.
lengthAsync() - Method in class org.redisson.RedissonBitSet
 
LFUCachedValue(long, Object, Object, long, long) - Constructor for class org.redisson.cache.LFUCacheMap.LFUCachedValue
 
LFUCacheMap<K,V> - Class in org.redisson.cache
LFU (least frequently used) cache.
LFUCacheMap(int, long, long) - Constructor for class org.redisson.cache.LFUCacheMap
 
LFUCacheMap.LFUCachedValue - Class in org.redisson.cache
 
LFUCacheMap.MapKey - Class in org.redisson.cache
 
LINDEX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LINSERT_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ListAddListener - Interface in org.redisson.api.listener
Redisson Object Event listener for rpush event published by Redis.
listConsumers(String) - Method in interface org.redisson.api.RStream
Returns list of common info about group customers for specified groupName.
listConsumers(String) - Method in interface org.redisson.api.RStreamReactive
Returns list of objects with information about group customers for specified groupName.
listConsumers(String) - Method in interface org.redisson.api.RStreamRx
Returns list of objects with information about group customers for specified groupName.
listConsumers(String) - Method in class org.redisson.RedissonStream
 
listConsumersAsync(String) - Method in interface org.redisson.api.RStreamAsync
Returns list of objects with information about group customers for specified groupName.
listConsumersAsync(String) - Method in class org.redisson.RedissonStream
 
ListDrainToDecoder<V> - Class in org.redisson.connection.decoder
 
ListDrainToDecoder(Collection<Object>) - Constructor for class org.redisson.connection.decoder.ListDrainToDecoder
 
ListFirstObjectDecoder - Class in org.redisson.client.protocol.decoder
 
ListFirstObjectDecoder() - Constructor for class org.redisson.client.protocol.decoder.ListFirstObjectDecoder
 
listGroups() - Method in interface org.redisson.api.RStream
Returns list of common info about groups belonging to this stream.
listGroups() - Method in interface org.redisson.api.RStreamReactive
Returns list of objects with information about groups belonging to this stream.
listGroups() - Method in interface org.redisson.api.RStreamRx
Returns list of objects with information about groups belonging to this stream.
listGroups() - Method in class org.redisson.RedissonStream
 
listGroupsAsync() - Method in interface org.redisson.api.RStreamAsync
Returns list of objects with information about groups belonging to this stream.
listGroupsAsync() - Method in class org.redisson.RedissonStream
 
ListInsertListener - Interface in org.redisson.api.listener
Redisson Object Event listener for lset event published by Redis.
listIterator() - Method in class org.redisson.RedissonList
 
listIterator(int) - Method in class org.redisson.RedissonList
 
listIterator() - Method in class org.redisson.RedissonListMultimapValues
 
listIterator(int) - Method in class org.redisson.RedissonListMultimapValues
 
listIterator() - Method in class org.redisson.RedissonSubList
 
listIterator(int) - Method in class org.redisson.RedissonSubList
 
ListIteratorReplayDecoder - Class in org.redisson.client.protocol.decoder
 
ListIteratorReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ListIteratorReplayDecoder
 
ListIteratorResult<V> - Class in org.redisson.client.protocol.decoder
 
ListIteratorResult(V, long) - Constructor for class org.redisson.client.protocol.decoder.ListIteratorResult
 
ListMultiDecoder2<T> - Class in org.redisson.client.protocol.decoder
 
ListMultiDecoder2(MultiDecoder<?>...) - Constructor for class org.redisson.client.protocol.decoder.ListMultiDecoder2
 
ListObjectDecoder<T> - Class in org.redisson.client.protocol.decoder
 
ListObjectDecoder(int) - Constructor for class org.redisson.client.protocol.decoder.ListObjectDecoder
 
listPending(String) - Method in interface org.redisson.api.RStream
Deprecated.
listPending(String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStream
Returns list of common info about pending messages by group name.
listPending(String, String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStream
Returns list of common info about pending messages by group and consumer name.
listPending(String) - Method in interface org.redisson.api.RStreamReactive
Deprecated.
listPending(String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamReactive
Returns list of pending messages by group name.
listPending(String, String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamReactive
Returns list of pending messages by group name and consumer name.
listPending(String) - Method in interface org.redisson.api.RStreamRx
Deprecated.
listPending(String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamRx
Returns list of pending messages by group name.
listPending(String, String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamRx
Returns list of pending messages by group name and consumer name.
listPending(String) - Method in class org.redisson.RedissonStream
 
listPending(String, StreamMessageId, StreamMessageId, int) - Method in class org.redisson.RedissonStream
 
listPending(String, String, StreamMessageId, StreamMessageId, int) - Method in class org.redisson.RedissonStream
 
listPendingAsync(String) - Method in interface org.redisson.api.RStreamAsync
Deprecated.
listPendingAsync(String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamAsync
Returns list of common info about pending messages by group name.
listPendingAsync(String, String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamAsync
Returns list of common info about pending messages by group and consumer name.
listPendingAsync(String) - Method in class org.redisson.RedissonStream
 
listPendingAsync(String, String, StreamMessageId, StreamMessageId, int) - Method in class org.redisson.RedissonStream
 
listPendingAsync(String, StreamMessageId, StreamMessageId, int) - Method in class org.redisson.RedissonStream
 
ListRemoveListener - Interface in org.redisson.api.listener
Redisson Object Event listener for lrem event published by Redis.
ListResultReplayDecoder - Class in org.redisson.client.protocol.decoder
 
ListResultReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ListResultReplayDecoder
 
ListScanResult<V> - Class in org.redisson.client.protocol.decoder
 
ListScanResult(long, List<V>) - Constructor for class org.redisson.client.protocol.decoder.ListScanResult
 
ListScanResultReplayDecoder - Class in org.redisson.client.protocol.decoder
 
ListScanResultReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ListScanResultReplayDecoder
 
ListSetListener - Interface in org.redisson.api.listener
Redisson Object Event listener for lset event published by Redis.
ListTrimListener - Interface in org.redisson.api.listener
Redisson Object Event listener for ltrim event published by Redis.
liveObjectClassCache - Variable in class org.redisson.Redisson
 
LiveObjectInterceptor - Class in org.redisson.liveobject.core
 
LiveObjectInterceptor(CommandAsyncExecutor, ConnectionManager, Class<?>, String) - Constructor for class org.redisson.liveobject.core.LiveObjectInterceptor
 
LiveObjectInterceptor.Getter - Interface in org.redisson.liveobject.core
 
LiveObjectInterceptor.Setter - Interface in org.redisson.liveobject.core
 
LiveObjectSearch - Class in org.redisson.liveobject
 
LiveObjectSearch(CommandAsyncExecutor) - Constructor for class org.redisson.liveobject.LiveObjectSearch
 
LiveObjectTemplate - Class in org.redisson.liveobject
 
LiveObjectTemplate() - Constructor for class org.redisson.liveobject.LiveObjectTemplate
 
LLEN_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
load(K) - Method in interface org.redisson.api.map.MapLoader
Loads map value by key.
loadAll(boolean, int) - Method in interface org.redisson.api.RMap
Loads all map entries to this Redis map using MapLoader.
loadAll(Set<? extends K>, boolean, int) - Method in interface org.redisson.api.RMap
Loads map entries using MapLoader whose keys are listed in defined keys parameter.
loadAll(boolean, int) - Method in interface org.redisson.api.RMapReactive
Loads all map entries to this Redis map using MapLoader.
loadAll(Set<? extends K>, boolean, int) - Method in interface org.redisson.api.RMapReactive
Loads map entries using MapLoader whose keys are listed in defined keys parameter.
loadAll(boolean, int) - Method in interface org.redisson.api.RMapRx
Loads all map entries to this Redis map using MapLoader.
loadAll(Set<? extends K>, boolean, int) - Method in interface org.redisson.api.RMapRx
Loads map entries using MapLoader whose keys are listed in defined keys parameter.
loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class org.redisson.jcache.JCache
 
loadAll(boolean, int) - Method in class org.redisson.RedissonMap
 
loadAll(Set<? extends K>, boolean, int) - Method in class org.redisson.RedissonMap
 
loadAllAsync(boolean, int) - Method in interface org.redisson.api.RMapAsync
Loads all map entries to this Redis map using MapLoader.
loadAllAsync(Set<? extends K>, boolean, int) - Method in interface org.redisson.api.RMapAsync
Loads map entries using MapLoader whose keys are listed in defined keys parameter.
loadAllAsync(boolean, int) - Method in class org.redisson.RedissonMap
 
loadAllAsync(Set<? extends K>, boolean, int) - Method in class org.redisson.RedissonMap
 
loadAllAsync(boolean, int) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
loadAllAsync(Set<? extends K>, boolean, int) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
loadAllAsync(boolean, int) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
loadAllAsync(Set<? extends K>, boolean, int) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
loadAllKeys() - Method in interface org.redisson.api.map.MapLoader
Loads all keys.
LoadBalancer - Interface in org.redisson.connection.balancer
 
LoadBalancerManager - Class in org.redisson.connection.balancer
 
LoadBalancerManager(MasterSlaveServersConfig, ConnectionManager, MasterSlaveEntry) - Constructor for class org.redisson.connection.balancer.LoadBalancerManager
 
loadClass(String, byte[]) - Method in class org.redisson.executor.RedissonClassLoader
 
loader(MapLoader<K, V>) - Method in class org.redisson.api.LocalCachedMapOptions
 
loader(MapLoader<K, V>) - Method in class org.redisson.api.MapOptions
Sets MapLoader object.
LocalCachedMapClear - Class in org.redisson.cache
 
LocalCachedMapClear() - Constructor for class org.redisson.cache.LocalCachedMapClear
 
LocalCachedMapClear(byte[], boolean) - Constructor for class org.redisson.cache.LocalCachedMapClear
 
LocalCachedMapDisable - Class in org.redisson.cache
 
LocalCachedMapDisable() - Constructor for class org.redisson.cache.LocalCachedMapDisable
 
LocalCachedMapDisable(String, byte[][], long) - Constructor for class org.redisson.cache.LocalCachedMapDisable
 
LocalCachedMapDisableAck - Class in org.redisson.cache
 
LocalCachedMapDisableAck() - Constructor for class org.redisson.cache.LocalCachedMapDisableAck
 
LocalCachedMapDisabledKey - Class in org.redisson.cache
 
LocalCachedMapDisabledKey() - Constructor for class org.redisson.cache.LocalCachedMapDisabledKey
 
LocalCachedMapDisabledKey(String, long) - Constructor for class org.redisson.cache.LocalCachedMapDisabledKey
 
LocalCachedMapEnable - Class in org.redisson.cache
 
LocalCachedMapEnable() - Constructor for class org.redisson.cache.LocalCachedMapEnable
 
LocalCachedMapEnable(String, byte[][]) - Constructor for class org.redisson.cache.LocalCachedMapEnable
 
LocalCachedMapInvalidate - Class in org.redisson.cache
 
LocalCachedMapInvalidate() - Constructor for class org.redisson.cache.LocalCachedMapInvalidate
 
LocalCachedMapInvalidate(byte[], byte[]...) - Constructor for class org.redisson.cache.LocalCachedMapInvalidate
 
LocalCachedMapOptions<K,V> - Class in org.redisson.api
Configuration for LocalCachedMap object.
LocalCachedMapOptions() - Constructor for class org.redisson.api.LocalCachedMapOptions
 
LocalCachedMapOptions(LocalCachedMapOptions<K, V>) - Constructor for class org.redisson.api.LocalCachedMapOptions
 
LocalCachedMapOptions.CacheProvider - Enum in org.redisson.api
 
LocalCachedMapOptions.EvictionPolicy - Enum in org.redisson.api
 
LocalCachedMapOptions.ReconnectionStrategy - Enum in org.redisson.api
Various strategies to avoid stale objects in local cache.
LocalCachedMapOptions.StoreMode - Enum in org.redisson.api
 
LocalCachedMapOptions.SyncStrategy - Enum in org.redisson.api
 
LocalCachedMapOptionsDecorator - Class in org.redisson.spring.support
 
LocalCachedMapOptionsDecorator() - Constructor for class org.redisson.spring.support.LocalCachedMapOptionsDecorator
 
LocalCachedMapUpdate - Class in org.redisson.cache
 
LocalCachedMapUpdate() - Constructor for class org.redisson.cache.LocalCachedMapUpdate
 
LocalCachedMapUpdate(List<LocalCachedMapUpdate.Entry>) - Constructor for class org.redisson.cache.LocalCachedMapUpdate
 
LocalCachedMapUpdate(ByteBuf, ByteBuf) - Constructor for class org.redisson.cache.LocalCachedMapUpdate
 
LocalCachedMapUpdate(byte[], byte[]) - Constructor for class org.redisson.cache.LocalCachedMapUpdate
 
LocalCachedMapUpdate.Entry - Class in org.redisson.cache
 
LocalCachedMessageCodec - Class in org.redisson.cache
 
LocalCachedMessageCodec() - Constructor for class org.redisson.cache.LocalCachedMessageCodec
 
LocalCacheListener - Class in org.redisson.cache
 
LocalCacheListener(String, CommandAsyncExecutor, RObject, Codec, LocalCachedMapOptions<?, ?>, long) - Constructor for class org.redisson.cache.LocalCacheListener
 
LocalCacheView<K,V> - Class in org.redisson.cache
 
LocalCacheView(Map<CacheKey, CacheValue>, RedissonObject) - Constructor for class org.redisson.cache.LocalCacheView
 
lock(long, TimeUnit) - Method in interface org.redisson.api.RLock
Acquires the lock with defined leaseTime.
lock() - Method in interface org.redisson.api.RLockReactive
Acquires the lock.
lock(long) - Method in interface org.redisson.api.RLockReactive
Acquires the lock by thread with defined threadId.
lock(long, TimeUnit) - Method in interface org.redisson.api.RLockReactive
Acquires the lock with defined leaseTime.
lock(long, TimeUnit, long) - Method in interface org.redisson.api.RLockReactive
Acquires the lock with defined leaseTime and threadId.
lock() - Method in interface org.redisson.api.RLockRx
Acquires the lock.
lock(long) - Method in interface org.redisson.api.RLockRx
Acquires the lock by thread with defined threadId.
lock(long, TimeUnit) - Method in interface org.redisson.api.RLockRx
Acquires the lock with defined leaseTime.
lock(long, TimeUnit, long) - Method in interface org.redisson.api.RLockRx
Acquires the lock with defined leaseTime and threadId.
lock() - Method in class org.redisson.RedissonLock
 
lock(long, TimeUnit) - Method in class org.redisson.RedissonLock
 
lock() - Method in class org.redisson.RedissonMultiLock
 
lock(long, TimeUnit) - Method in class org.redisson.RedissonMultiLock
 
lockAsync() - Method in interface org.redisson.api.RLockAsync
Acquires the lock.
lockAsync(long) - Method in interface org.redisson.api.RLockAsync
Acquires the lock by thread with defined threadId.
lockAsync(long, TimeUnit) - Method in interface org.redisson.api.RLockAsync
Acquires the lock with defined leaseTime.
lockAsync(long, TimeUnit, long) - Method in interface org.redisson.api.RLockAsync
Acquires the lock with defined leaseTime and threadId.
lockAsync() - Method in class org.redisson.RedissonLock
 
lockAsync(long, TimeUnit) - Method in class org.redisson.RedissonLock
 
lockAsync(long) - Method in class org.redisson.RedissonLock
 
lockAsync(long, TimeUnit, long) - Method in class org.redisson.RedissonLock
 
lockAsync(long, TimeUnit) - Method in class org.redisson.RedissonMultiLock
 
lockAsync(long, TimeUnit, long) - Method in class org.redisson.RedissonMultiLock
 
lockAsync() - Method in class org.redisson.RedissonMultiLock
 
lockAsync(long) - Method in class org.redisson.RedissonMultiLock
 
lockInterruptibly(long, TimeUnit) - Method in interface org.redisson.api.RLock
Acquires the lock with defined leaseTime.
lockInterruptibly() - Method in class org.redisson.RedissonLock
 
lockInterruptibly(long, TimeUnit) - Method in class org.redisson.RedissonLock
 
lockInterruptibly() - Method in class org.redisson.RedissonMultiLock
 
lockInterruptibly(long, TimeUnit) - Method in class org.redisson.RedissonMultiLock
 
LockPubSub - Class in org.redisson.pubsub
 
LockPubSub(PublishSubscribeService) - Constructor for class org.redisson.pubsub.LockPubSub
 
LogHelper - Class in org.redisson.misc
 
logVersion() - Static method in class org.redisson.Version
 
Long2MultiDecoder - Class in org.redisson.client.protocol.decoder
 
Long2MultiDecoder() - Constructor for class org.redisson.client.protocol.decoder.Long2MultiDecoder
 
LongCodec - Class in org.redisson.client.codec
 
LongCodec() - Constructor for class org.redisson.client.codec.LongCodec
 
LongGenerator - Class in org.redisson.liveobject.resolver
 
LongGenerator() - Constructor for class org.redisson.liveobject.resolver.LongGenerator
 
LongReplayConvertor - Class in org.redisson.client.protocol.convertor
 
LongReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.LongReplayConvertor
 
LPOP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LPUSH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LPUSH_BOOLEAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LPUSH_VOID - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LPUSHX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LRANGE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LRANGE_SET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LREM_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LRUCacheMap<K,V> - Class in org.redisson.cache
LRU (least recently used) cache.
LRUCacheMap(int, long, long) - Constructor for class org.redisson.cache.LRUCacheMap
 
LSET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
lt(String, Number) - Static method in class org.redisson.api.condition.Conditions
Returns "LESS THAN" condition which restricts property by name to defined value
LTCondition - Class in org.redisson.liveobject.condition
 
LTCondition(String, Number) - Constructor for class org.redisson.liveobject.condition.LTCondition
 
LTRIM - Static variable in interface org.redisson.client.protocol.RedisCommands
 
LZ4Codec - Class in org.redisson.codec
LZ4 compression codec.
LZ4Codec() - Constructor for class org.redisson.codec.LZ4Codec
 
LZ4Codec(Codec) - Constructor for class org.redisson.codec.LZ4Codec
 
LZ4Codec(ClassLoader) - Constructor for class org.redisson.codec.LZ4Codec
 
LZ4Codec(ClassLoader, LZ4Codec) - Constructor for class org.redisson.codec.LZ4Codec
 

M

main(String[]) - Static method in class org.redisson.RedissonNode
 
makeImmutable() - Method in class org.redisson.misc.BiHashMap
 
map(RedisURI) - Method in class org.redisson.api.DefaultNatMapper
 
map(RedisURI) - Method in class org.redisson.api.HostNatMapper
 
map(RedisURI) - Method in class org.redisson.api.HostPortNatMapper
 
map(VIn, RCollector<KOut, VOut>) - Method in interface org.redisson.api.mapreduce.RCollectionMapper
Invoked for each Collection source entry
map(KIn, VIn, RCollector<KOut, VOut>) - Method in interface org.redisson.api.mapreduce.RMapper
Invoked for each Map source entry
map(RedisURI) - Method in interface org.redisson.api.NatMapper
Applies map function to input uri object
MapAddAndGetOperation - Class in org.redisson.transaction.operation.map
 
MapAddAndGetOperation() - Constructor for class org.redisson.transaction.operation.map.MapAddAndGetOperation
 
MapAddAndGetOperation(RMap<?, ?>, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapAddAndGetOperation
 
MapCacheEventCodec - Class in org.redisson.codec
 
MapCacheEventCodec(Codec, BaseEventCodec.OSType) - Constructor for class org.redisson.codec.MapCacheEventCodec
 
MapCacheEventCodec(ClassLoader, MapCacheEventCodec) - Constructor for class org.redisson.codec.MapCacheEventCodec
 
MapCacheEvictionTask - Class in org.redisson.eviction
 
MapCacheEvictionTask(String, String, String, String, String, CommandAsyncExecutor) - Constructor for class org.redisson.eviction.MapCacheEvictionTask
 
MapCacheFastPutIfAbsentOperation - Class in org.redisson.transaction.operation.map
 
MapCacheFastPutIfAbsentOperation(RMap<?, ?>, Object, Object, long, TimeUnit, long, TimeUnit, String, long) - Constructor for class org.redisson.transaction.operation.map.MapCacheFastPutIfAbsentOperation
 
MapCacheFastPutOperation - Class in org.redisson.transaction.operation.map
 
MapCacheFastPutOperation() - Constructor for class org.redisson.transaction.operation.map.MapCacheFastPutOperation
 
MapCacheFastPutOperation(RMap<?, ?>, Object, Object, long, TimeUnit, long, TimeUnit, String, long) - Constructor for class org.redisson.transaction.operation.map.MapCacheFastPutOperation
 
MapCacheGetAllDecoder - Class in org.redisson.connection.decoder
 
MapCacheGetAllDecoder(List<Object>, int) - Constructor for class org.redisson.connection.decoder.MapCacheGetAllDecoder
 
MapCacheGetAllDecoder(List<Object>, int, boolean) - Constructor for class org.redisson.connection.decoder.MapCacheGetAllDecoder
 
MapCachePutIfAbsentOperation - Class in org.redisson.transaction.operation.map
 
MapCachePutIfAbsentOperation() - Constructor for class org.redisson.transaction.operation.map.MapCachePutIfAbsentOperation
 
MapCachePutIfAbsentOperation(RMap<?, ?>, Object, Object, long, TimeUnit, long, TimeUnit, String, long) - Constructor for class org.redisson.transaction.operation.map.MapCachePutIfAbsentOperation
 
MapCachePutIfAbsentOperation(RMap<?, ?>, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapCachePutIfAbsentOperation
 
MapCachePutOperation - Class in org.redisson.transaction.operation.map
 
MapCachePutOperation() - Constructor for class org.redisson.transaction.operation.map.MapCachePutOperation
 
MapCachePutOperation(RMap<?, ?>, Object, Object, long, TimeUnit, long, TimeUnit, String, long) - Constructor for class org.redisson.transaction.operation.map.MapCachePutOperation
 
MapCacheScanResult<K,V> - Class in org.redisson.client.protocol.decoder
 
MapCacheScanResult(Long, Map<K, V>, List<K>) - Constructor for class org.redisson.client.protocol.decoder.MapCacheScanResult
 
MapCacheScanResultReplayDecoder - Class in org.redisson.client.protocol.decoder
 
MapCacheScanResultReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.MapCacheScanResultReplayDecoder
 
MapEntry(Object, Object) - Constructor for class org.redisson.transaction.BaseTransactionalMap.MapEntry
 
MapEntryListener - Interface in org.redisson.api.map.event
 
MapFastPutIfAbsentOperation - Class in org.redisson.transaction.operation.map
 
MapFastPutIfAbsentOperation() - Constructor for class org.redisson.transaction.operation.map.MapFastPutIfAbsentOperation
 
MapFastPutIfAbsentOperation(RMap<?, ?>, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapFastPutIfAbsentOperation
 
MapFastPutOperation - Class in org.redisson.transaction.operation.map
 
MapFastPutOperation() - Constructor for class org.redisson.transaction.operation.map.MapFastPutOperation
 
MapFastPutOperation(RMap<?, ?>, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapFastPutOperation
 
MapFastRemoveOperation - Class in org.redisson.transaction.operation.map
 
MapFastRemoveOperation() - Constructor for class org.redisson.transaction.operation.map.MapFastRemoveOperation
 
MapFastRemoveOperation(RMap<?, ?>, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapFastRemoveOperation
 
MapGetAllDecoder - Class in org.redisson.connection.decoder
 
MapGetAllDecoder(List<Object>, int) - Constructor for class org.redisson.connection.decoder.MapGetAllDecoder
 
MapGetAllDecoder(List<Object>, int, boolean) - Constructor for class org.redisson.connection.decoder.MapGetAllDecoder
 
MapKey(Long, LFUCacheMap.LFUCachedValue) - Constructor for class org.redisson.cache.LFUCacheMap.MapKey
 
MapLoader<K,V> - Interface in org.redisson.api.map
Map loader used for read-through operations or during RMap.loadAll(boolean, int) execution.
mapObjectMapper - Variable in class org.redisson.codec.JsonJacksonCodec
 
MapOperation - Class in org.redisson.transaction.operation.map
 
MapOperation() - Constructor for class org.redisson.transaction.operation.map.MapOperation
 
MapOperation(RMap<?, ?>, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapOperation
 
MapOperation(RMap<?, ?>, Object, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapOperation
 
MapOptions<K,V> - Class in org.redisson.api
Configuration for Map object.
MapOptions() - Constructor for class org.redisson.api.MapOptions
 
MapOptions(MapOptions<K, V>) - Constructor for class org.redisson.api.MapOptions
 
MapOptions.WriteMode - Enum in org.redisson.api
 
mapper(RCollectionMapper<VIn, KOut, VOut>) - Method in interface org.redisson.api.mapreduce.RCollectionMapReduce
Setup Mapper object
mapper(RMapper<KIn, VIn, KOut, VOut>) - Method in interface org.redisson.api.mapreduce.RMapReduce
Setup Mapper object
mapper - Variable in class org.redisson.mapreduce.MapperTask
 
mapper(RCollectionMapper<VIn, KOut, VOut>) - Method in class org.redisson.mapreduce.RedissonCollectionMapReduce
 
mapper(RMapper<KIn, VIn, KOut, VOut>) - Method in class org.redisson.mapreduce.RedissonMapReduce
 
MapperTask<KIn,VIn,KOut,VOut> - Class in org.redisson.mapreduce
 
MapperTask() - Constructor for class org.redisson.mapreduce.MapperTask
 
MapperTask(RMapper<KIn, VIn, KOut, VOut>, Class<?>, Class<?>) - Constructor for class org.redisson.mapreduce.MapperTask
 
MapPutIfAbsentOperation - Class in org.redisson.transaction.operation.map
 
MapPutIfAbsentOperation() - Constructor for class org.redisson.transaction.operation.map.MapPutIfAbsentOperation
 
MapPutIfAbsentOperation(RMap<?, ?>, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapPutIfAbsentOperation
 
MapPutOperation - Class in org.redisson.transaction.operation.map
 
MapPutOperation() - Constructor for class org.redisson.transaction.operation.map.MapPutOperation
 
MapPutOperation(RMap<?, ?>, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapPutOperation
 
MapReactiveIterator<K,V,M> - Class in org.redisson.reactive
 
MapReactiveIterator(RedissonMap<K, V>, String, int) - Constructor for class org.redisson.reactive.MapReactiveIterator
 
mapReduce() - Method in interface org.redisson.api.RList
Returns RMapReduce object associated with this map
mapReduce() - Method in interface org.redisson.api.RMap
Returns RMapReduce object associated with this map
mapReduce() - Method in interface org.redisson.api.RScoredSortedSet
Returns RMapReduce object associated with this object
mapReduce() - Method in interface org.redisson.api.RSet
Returns RMapReduce object associated with this object
mapReduce() - Method in interface org.redisson.api.RSetCache
Returns RMapReduce object associated with this map
mapReduce() - Method in interface org.redisson.api.RSortedSet
Returns RMapReduce object associated with this object
mapReduce() - Method in class org.redisson.RedissonList
 
mapReduce() - Method in class org.redisson.RedissonListMultimapValues
 
mapReduce() - Method in class org.redisson.RedissonMap
 
mapReduce() - Method in class org.redisson.RedissonScoredSortedSet
 
mapReduce() - Method in class org.redisson.RedissonSet
 
mapReduce() - Method in class org.redisson.RedissonSetCache
 
mapReduce() - Method in class org.redisson.RedissonSetMultimapValues
 
mapReduce() - Method in class org.redisson.RedissonSortedSet
 
mapReduce() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
mapReduce() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
mapReduce() - Method in class org.redisson.transaction.RedissonTransactionalSet
 
mapReduce() - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
MAPREDUCE_NAME - Static variable in interface org.redisson.api.RExecutorService
MapReduce's executor name
MapReduceTimeoutException - Exception in org.redisson.mapreduce
 
MapReduceTimeoutException() - Constructor for exception org.redisson.mapreduce.MapReduceTimeoutException
 
MapRemoveOperation - Class in org.redisson.transaction.operation.map
 
MapRemoveOperation() - Constructor for class org.redisson.transaction.operation.map.MapRemoveOperation
 
MapRemoveOperation(RMap<?, ?>, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapRemoveOperation
 
MapRemoveOperation(RMap<?, ?>, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapRemoveOperation
 
MapReplaceOperation - Class in org.redisson.transaction.operation.map
 
MapReplaceOperation() - Constructor for class org.redisson.transaction.operation.map.MapReplaceOperation
 
MapReplaceOperation(RMap<?, ?>, Object, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapReplaceOperation
 
MapReplaceOperation(RMap<?, ?>, Object, Object, String, long) - Constructor for class org.redisson.transaction.operation.map.MapReplaceOperation
 
MapScanResult<K,V> - Class in org.redisson.client.protocol.decoder
 
MapScanResult(long, Map<K, V>) - Constructor for class org.redisson.client.protocol.decoder.MapScanResult
 
MapScanResultReplayDecoder - Class in org.redisson.client.protocol.decoder
 
MapScanResultReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.MapScanResultReplayDecoder
 
MapWriteBehindTask - Class in org.redisson
 
MapWriteBehindTask(String, CommandAsyncExecutor, MapOptions<?, ?>) - Constructor for class org.redisson.MapWriteBehindTask
 
MapWriter<K,V> - Interface in org.redisson.api.map
Map writer used for write-through operations.
mapWriterFuture(RFuture<M>, MapWriterTask) - Method in class org.redisson.RedissonMap
 
mapWriterFuture(RFuture<M>, MapWriterTask, Function<M, Boolean>) - Method in class org.redisson.RedissonMap
 
MapWriterTask - Class in org.redisson
 
MapWriterTask() - Constructor for class org.redisson.MapWriterTask
 
MapWriterTask(Object) - Constructor for class org.redisson.MapWriterTask
 
MapWriterTask(Object, Object) - Constructor for class org.redisson.MapWriterTask
 
MapWriterTask(Map<?, ?>) - Constructor for class org.redisson.MapWriterTask
 
MapWriterTask(Collection<?>) - Constructor for class org.redisson.MapWriterTask
 
MapWriterTask.Add - Class in org.redisson
 
MapWriterTask.Remove - Class in org.redisson
 
MarshallingCodec - Class in org.redisson.codec
JBoss Marshalling codec.
MarshallingCodec() - Constructor for class org.redisson.codec.MarshallingCodec
 
MarshallingCodec(ClassLoader) - Constructor for class org.redisson.codec.MarshallingCodec
 
MarshallingCodec(ClassLoader, MarshallingCodec) - Constructor for class org.redisson.codec.MarshallingCodec
 
MarshallingCodec(MarshallingCodec.Protocol, MarshallingConfiguration) - Constructor for class org.redisson.codec.MarshallingCodec
 
MarshallingCodec.ByteInputWrapper - Class in org.redisson.codec
 
MarshallingCodec.ByteOutputWrapper - Class in org.redisson.codec
 
MarshallingCodec.Protocol - Enum in org.redisson.codec
 
MASTER_SLAVE - Static variable in class org.redisson.api.redisnode.RedisNodes
 
MasterConnectionPool - Class in org.redisson.connection.pool
Connection pool for master node
MasterConnectionPool(MasterSlaveServersConfig, ConnectionManager, MasterSlaveEntry) - Constructor for class org.redisson.connection.pool.MasterConnectionPool
 
MasterPubSubConnectionPool - Class in org.redisson.connection.pool
Connection pool for Publish/Subscribe used with single node
MasterPubSubConnectionPool(MasterSlaveServersConfig, ConnectionManager, MasterSlaveEntry) - Constructor for class org.redisson.connection.pool.MasterPubSubConnectionPool
 
MasterSlaveConnectionManager - Class in org.redisson.connection
 
MasterSlaveConnectionManager(MasterSlaveServersConfig, Config, UUID) - Constructor for class org.redisson.connection.MasterSlaveConnectionManager
 
MasterSlaveConnectionManager(Config, UUID) - Constructor for class org.redisson.connection.MasterSlaveConnectionManager
 
MasterSlaveEntry - Class in org.redisson.connection
 
MasterSlaveEntry(ConnectionManager, MasterSlaveServersConfig) - Constructor for class org.redisson.connection.MasterSlaveEntry
 
MasterSlaveServersConfig - Class in org.redisson.config
 
MasterSlaveServersConfig() - Constructor for class org.redisson.config.MasterSlaveServersConfig
 
MAX - Static variable in class org.redisson.api.StreamMessageId
Defines maximal id.
MAX_SLOT - Static variable in class org.redisson.connection.MasterSlaveConnectionManager
 
MAX_YEAR - Static variable in class org.redisson.executor.CronExpression
 
maxIdle(long) - Method in class org.redisson.api.LocalCachedMapOptions
Defines max idle time in milliseconds of each map entry in local cache.
maxIdle(long, TimeUnit) - Method in class org.redisson.api.LocalCachedMapOptions
Defines max idle time of each map entry in local cache.
MEMORY_USAGE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
merge(T) - Method in interface org.redisson.api.RLiveObjectService
Returns proxied object for the detached object.
merge(T) - Method in class org.redisson.RedissonLiveObjectService
 
mergeWith(String...) - Method in interface org.redisson.api.RHyperLogLog
Merges multiple instances into this instance.
mergeWith(String...) - Method in interface org.redisson.api.RHyperLogLogReactive
Merges multiple instances into this instance.
mergeWith(String...) - Method in interface org.redisson.api.RHyperLogLogRx
Merges multiple instances into this instance.
mergeWith(String...) - Method in class org.redisson.RedissonHyperLogLog
 
mergeWithAsync(String...) - Method in interface org.redisson.api.RHyperLogLogAsync
Merges multiple instances into this instance.
mergeWithAsync(String...) - Method in class org.redisson.RedissonHyperLogLog
 
Message - Interface in org.redisson.client.protocol.pubsub
 
messageDecoder(CommandData<Object, Object>, List<Object>) - Method in class org.redisson.client.handler.CommandDecoder
 
messageDecoder(CommandData<Object, Object>, List<Object>) - Method in class org.redisson.client.handler.CommandPubSubDecoder
 
MessageListener<M> - Interface in org.redisson.api.listener
Listener for Redis messages published via RTopic Redisson object
MGET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
migrate(String, String, int, int, long) - Method in interface org.redisson.api.RKeys
Transfer object from source Redis instance to destination Redis instance
migrate(String, String, int, int, long) - Method in interface org.redisson.api.RKeysReactive
Transfer object from source Redis instance to destination Redis instance
migrate(String, String, int, int, long) - Method in interface org.redisson.api.RKeysRx
Transfer object from source Redis instance to destination Redis instance
migrate(String, int, int, long) - Method in interface org.redisson.api.RObject
Copy object from source Redis instance to destination Redis instance
migrate(String, int, int, long) - Method in interface org.redisson.api.RObjectReactive
Transfer a object from a source Redis instance to a destination Redis instance in mode
migrate(String, int, int, long) - Method in interface org.redisson.api.RObjectRx
Transfer a object from a source Redis instance to a destination Redis instance in mode
MIGRATE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
migrate(String, String, int, int, long) - Method in class org.redisson.RedissonKeys
 
migrate(String, int, int, long) - Method in class org.redisson.RedissonObject
 
migrateAsync(String, String, int, int, long) - Method in interface org.redisson.api.RKeysAsync
Transfer object from source Redis instance to destination Redis instance
migrateAsync(String, int, int, long) - Method in interface org.redisson.api.RObjectAsync
Transfer object from source Redis instance to destination Redis instance in async mode
migrateAsync(String, String, int, int, long) - Method in class org.redisson.RedissonKeys
 
migrateAsync(String, int, int, long) - Method in class org.redisson.RedissonObject
 
migrateAsync(String, int, int) - Method in class org.redisson.transaction.BaseTransactionalObject
 
migrateAsync(String, int, int, long) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
migrateAsync(String, int, int, long) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
migrateAsync(String, int, int, long) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
migrateAsync(String, int, int, long) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
migrateAsync(String, int, int, long) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
MIN - Static variable in class org.redisson.api.StreamMessageId
Defines minimal id.
minLocksAmount(List<RLock>) - Method in class org.redisson.RedissonRedLock
 
MINUTE - Static variable in class org.redisson.executor.CronExpression
 
minutes - Variable in class org.redisson.executor.CronExpression
 
missCount() - Method in class org.redisson.spring.cache.RedissonCacheMetrics
 
monitor(MeterRegistry, RedissonCache, Iterable<Tag>) - Static method in class org.redisson.spring.cache.RedissonCacheMetrics
Record metrics on a Redisson cache.
MONTH - Static variable in class org.redisson.executor.CronExpression
 
monthlyOnDayAndHourAndMinute(int, int, int) - Static method in class org.redisson.api.CronSchedule
Creates cron expression which schedule task execution every given day of the month at the given time
monthMap - Static variable in class org.redisson.executor.CronExpression
 
months - Variable in class org.redisson.executor.CronExpression
 
move(String, int) - Method in interface org.redisson.api.RKeys
Move object to another database
move(String, int) - Method in interface org.redisson.api.RKeysReactive
Move object to another database
move(String, int) - Method in interface org.redisson.api.RKeysRx
Move object to another database
move(int) - Method in interface org.redisson.api.RObject
Move object to another database
move(int) - Method in interface org.redisson.api.RObjectReactive
Move object to another database in mode
move(int) - Method in interface org.redisson.api.RObjectRx
Move object to another database in mode
move(String, V) - Method in interface org.redisson.api.RSet
Move a member from this set to the given destination set in.
move(String, V) - Method in interface org.redisson.api.RSetReactive
Move a member from this set to the given destination set in async mode.
move(String, V) - Method in interface org.redisson.api.RSetRx
Move a member from this set to the given destination set in async mode.
MOVE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
move(String, int) - Method in class org.redisson.RedissonKeys
 
move(int) - Method in class org.redisson.RedissonObject
 
move(String, V) - Method in class org.redisson.RedissonSet
 
move(String, V) - Method in class org.redisson.RedissonSetMultimapValues
 
moveAsync(String, int) - Method in interface org.redisson.api.RKeysAsync
Move object to another database
moveAsync(int) - Method in interface org.redisson.api.RObjectAsync
Move object to another database in async mode
moveAsync(String, V) - Method in interface org.redisson.api.RSetAsync
Move a member from this set to the given destination set in async mode.
moveAsync(String, int) - Method in class org.redisson.RedissonKeys
 
moveAsync(int) - Method in class org.redisson.RedissonObject
 
moveAsync(String, V) - Method in class org.redisson.RedissonSet
 
moveAsync(String, V) - Method in class org.redisson.RedissonSetMultimapValues
 
moveAsync(int) - Method in class org.redisson.transaction.BaseTransactionalObject
 
moveAsync(String, V) - Method in class org.redisson.transaction.BaseTransactionalSet
 
moveAsync(int) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
moveAsync(int) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
moveAsync(int) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
moveAsync(int) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
moveAsync(String, V) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
moveAsync(int) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
MoveOperation - Class in org.redisson.transaction.operation.set
 
MoveOperation(RObject, String, long, Object, String) - Constructor for class org.redisson.transaction.operation.set.MoveOperation
 
MoveOperation(String, Codec, String, long, Object, String) - Constructor for class org.redisson.transaction.operation.set.MoveOperation
 
MSET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
MSETNX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
MsgPackJacksonCodec - Class in org.redisson.codec
MsgPack binary codec
MsgPackJacksonCodec() - Constructor for class org.redisson.codec.MsgPackJacksonCodec
 
MsgPackJacksonCodec(ClassLoader) - Constructor for class org.redisson.codec.MsgPackJacksonCodec
 
MsgPackJacksonCodec(ClassLoader, MsgPackJacksonCodec) - Constructor for class org.redisson.codec.MsgPackJacksonCodec
 
MULTI - Static variable in interface org.redisson.client.protocol.RedisCommands
 
MultiDecoder<T> - Interface in org.redisson.client.protocol.decoder
 
MultimapEvictionTask - Class in org.redisson.eviction
 
MultimapEvictionTask(String, String, CommandAsyncExecutor) - Constructor for class org.redisson.eviction.MultimapEvictionTask
 

N

name - Variable in class org.redisson.RedissonObject
 
name - Variable in class org.redisson.remote.BaseRemoteService
 
name - Variable in class org.redisson.transaction.operation.TransactionalOperation
 
NAME_ATTRIBUTE - Static variable in class org.redisson.spring.support.RedissonDefinitionParser
 
NamingScheme - Interface in org.redisson.liveobject.resolver
 
NatMapper - Interface in org.redisson.api
Maps RedisURI object.
nearestWeekday - Variable in class org.redisson.executor.CronExpression
 
NettyHook - Interface in org.redisson.client
This interface allows to create hooks applied after Netty Bootstrap and Channel object initialization.
NEVER_DELIVERED - Static variable in class org.redisson.api.StreamMessageId
Defines id to receive Stream entries never delivered to any other consumer.
NEW_COUNT_MESSAGE - Static variable in class org.redisson.pubsub.CountDownLatchPubSub
 
newCondition() - Method in class org.redisson.RedissonFairLock
 
newCondition() - Method in class org.redisson.RedissonLock
 
newCondition() - Method in class org.redisson.RedissonMultiLock
 
newCondition() - Method in class org.redisson.RedissonReadLock
 
newCondition() - Method in class org.redisson.RedissonWriteLock
 
NEWEST - Static variable in class org.redisson.api.StreamMessageId
Defines id to receive Stream entries added since method invocation.
newFailedFuture(Throwable) - Static method in class org.redisson.misc.RedissonPromise
 
newMBeanServer(String, MBeanServer, MBeanServerDelegate) - Method in class org.redisson.jcache.JCacheMBeanServerBuilder
 
newSucceededFuture(V) - Static method in class org.redisson.misc.RedissonPromise
 
newTimeout(TimerTask, long, TimeUnit) - Method in interface org.redisson.connection.ConnectionManager
 
newTimeout(TimerTask, long, TimeUnit) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
next() - Method in class org.redisson.iterator.BaseIterator
 
next() - Method in class org.redisson.iterator.RedissonListIterator
 
next() - Method in class org.redisson.misc.CompositeIterator
 
nextConnection(RedisCommand<?>) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
nextIndex() - Method in class org.redisson.iterator.RedissonListIterator
 
nextIterPos - Variable in class org.redisson.iterator.BaseIterator
 
nextPubSubConnection() - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
nextPubSubConnection() - Method in class org.redisson.connection.MasterSlaveEntry
 
NO_SPEC - Static variable in class org.redisson.executor.CronExpression
 
NO_SPEC_INT - Static variable in class org.redisson.executor.CronExpression
 
noAck() - Method in class org.redisson.api.RemoteInvocationOptions
Specifies to not wait for ACK reply
Node - Interface in org.redisson.api
Deprecated.
Node.InfoSection - Enum in org.redisson.api
Deprecated.
 
NodeAsync - Interface in org.redisson.api
Deprecated.
NodeListener - Interface in org.redisson.api
 
NodesGroup<N extends Node> - Interface in org.redisson.api
Deprecated.
NodeSource - Class in org.redisson.connection
 
NodeSource(MasterSlaveEntry) - Constructor for class org.redisson.connection.NodeSource
 
NodeSource(MasterSlaveEntry, Integer) - Constructor for class org.redisson.connection.NodeSource
 
NodeSource(MasterSlaveEntry, RedisClient) - Constructor for class org.redisson.connection.NodeSource
 
NodeSource(RedisClient) - Constructor for class org.redisson.connection.NodeSource
 
NodeSource(Integer, RedisClient) - Constructor for class org.redisson.connection.NodeSource
 
NodeSource(Integer, RedisURI, NodeSource.Redirect) - Constructor for class org.redisson.connection.NodeSource
 
NodeSource.Redirect - Enum in org.redisson.connection
 
NodeType - Enum in org.redisson.api
 
NoneCacheMap<K,V> - Class in org.redisson.cache
 
NoneCacheMap(long, long) - Constructor for class org.redisson.cache.NoneCacheMap
 
noResult() - Method in class org.redisson.api.RemoteInvocationOptions
Specifies to not wait for result
not() - Method in interface org.redisson.api.RBitSet
Executes NOT operation over all bits
not() - Method in interface org.redisson.api.RBitSetReactive
Executes NOT operation over all bits
not() - Method in interface org.redisson.api.RBitSetRx
Executes NOT operation over all bits
not() - Method in class org.redisson.RedissonBitSet
 
NOT_EXISTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
notAsync() - Method in interface org.redisson.api.RBitSetAsync
Executes NOT operation over all bits
notAsync() - Method in class org.redisson.RedissonBitSet
 
nthdayOfWeek - Variable in class org.redisson.executor.CronExpression
 
NULL - Static variable in class org.redisson.transaction.BaseTransactionalMap.MapEntry
 
NullValue - Class in org.redisson.spring.cache
 
NullValue() - Constructor for class org.redisson.spring.cache.NullValue
 
NumberConvertor - Class in org.redisson.client.protocol.convertor
 
NumberConvertor(Class<?>) - Constructor for class org.redisson.client.protocol.convertor.NumberConvertor
 

O

objectClass - Variable in class org.redisson.mapreduce.BaseMapperTask
 
objectClass - Variable in class org.redisson.mapreduce.CoordinatorTask
 
objectCodecClass - Variable in class org.redisson.mapreduce.BaseMapperTask
 
ObjectDecoder - Class in org.redisson.client.protocol.decoder
 
ObjectDecoder(Decoder<Object>) - Constructor for class org.redisson.client.protocol.decoder.ObjectDecoder
 
ObjectFirstScoreReplayDecoder - Class in org.redisson.client.protocol.decoder
 
ObjectFirstScoreReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ObjectFirstScoreReplayDecoder
 
ObjectListener - Interface in org.redisson.api
Redisson Object Event listener for Expired or Deleted event.
ObjectListReplayDecoder<T> - Class in org.redisson.client.protocol.decoder
 
ObjectListReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ObjectListReplayDecoder
 
ObjectListReplayDecoder(Decoder<Object>) - Constructor for class org.redisson.client.protocol.decoder.ObjectListReplayDecoder
 
ObjectMapDecoder - Class in org.redisson.client.protocol.decoder
 
ObjectMapDecoder(Codec, boolean) - Constructor for class org.redisson.client.protocol.decoder.ObjectMapDecoder
 
ObjectMapEntryReplayDecoder - Class in org.redisson.client.protocol.decoder
 
ObjectMapEntryReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ObjectMapEntryReplayDecoder
 
ObjectMapReplayDecoder - Class in org.redisson.client.protocol.decoder
 
ObjectMapReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ObjectMapReplayDecoder
 
ObjectMapReplayDecoder2 - Class in org.redisson.client.protocol.decoder
 
ObjectMapReplayDecoder2() - Constructor for class org.redisson.client.protocol.decoder.ObjectMapReplayDecoder2
 
objectName - Variable in class org.redisson.mapreduce.CoordinatorTask
 
objectNames - Variable in class org.redisson.mapreduce.BaseMapperTask
 
ObjectSetReplayDecoder<T> - Class in org.redisson.client.protocol.decoder
 
ObjectSetReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ObjectSetReplayDecoder
 
of(String) - Static method in class org.redisson.api.CronSchedule
Creates cron expression object with defined expression string
offer(V, long, TimeUnit) - Method in interface org.redisson.api.RDelayedQueue
Inserts element into this queue with specified transfer delay to destination queue.
offer(V) - Method in interface org.redisson.api.RQueueReactive
Inserts the specified element into this queue.
offer(V) - Method in interface org.redisson.api.RQueueRx
Inserts the specified element into this queue.
offer(V, long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
offer(V, long, TimeUnit) - Method in class org.redisson.RedissonBlockingQueue
 
offer(V, long, TimeUnit) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
offer(V, long, TimeUnit) - Method in class org.redisson.RedissonDelayedQueue
 
offer(V) - Method in class org.redisson.RedissonDelayedQueue
 
offer(V, long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
offer(V, long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
offer(V) - Method in class org.redisson.RedissonPriorityQueue
 
offer(V) - Method in class org.redisson.RedissonQueue
 
offer(V) - Method in class org.redisson.RedissonTransferQueue
 
offer(V, long, TimeUnit) - Method in class org.redisson.RedissonTransferQueue
 
offerAsync(V, long, TimeUnit) - Method in interface org.redisson.api.RBoundedBlockingQueueAsync
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
offerAsync(V, long, TimeUnit) - Method in interface org.redisson.api.RDelayedQueue
Inserts element into this queue with specified transfer delay to destination queue.
offerAsync(V) - Method in interface org.redisson.api.RQueueAsync
Inserts the specified element into this queue.
offerAsync(V) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
offerAsync(V, long, TimeUnit) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
offerAsync(V, long, TimeUnit) - Method in class org.redisson.RedissonDelayedQueue
 
offerAsync(V) - Method in class org.redisson.RedissonDelayedQueue
 
offerAsync(V) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
offerAsync(V) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
offerAsync(V) - Method in class org.redisson.RedissonPriorityQueue
 
offerAsync(V) - Method in class org.redisson.RedissonQueue
 
offerAsync(V) - Method in class org.redisson.RedissonTransferQueue
 
offerFirst(V) - Method in interface org.redisson.api.RDequeReactive
Adds element at the head of this deque.
offerFirst(V) - Method in interface org.redisson.api.RDequeRx
Adds element at the head of this deque.
offerFirst(V, long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
offerFirst(V) - Method in class org.redisson.RedissonDeque
 
offerFirst(V, long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
offerFirst(V) - Method in class org.redisson.RedissonPriorityDeque
 
offerFirstAsync(V) - Method in interface org.redisson.api.RDequeAsync
Adds element at the head of this deque.
offerFirstAsync(V) - Method in class org.redisson.RedissonDeque
 
offerFirstAsync(V) - Method in class org.redisson.RedissonPriorityDeque
 
offerLast(V) - Method in interface org.redisson.api.RDequeReactive
Adds element at the tail of this deque.
offerLast(V) - Method in interface org.redisson.api.RDequeRx
Adds element at the tail of this deque.
offerLast(V, long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
offerLast(V) - Method in class org.redisson.RedissonDeque
 
offerLast(V, long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
offerLast(V) - Method in class org.redisson.RedissonPriorityDeque
 
offerLastAsync(V) - Method in interface org.redisson.api.RDequeAsync
Adds element at the tail of this deque.
offerLastAsync(V) - Method in class org.redisson.RedissonDeque
 
offerLastAsync(V) - Method in class org.redisson.RedissonPriorityDeque
 
onComplete(BiConsumer<? super V, ? super Throwable>) - Method in interface org.redisson.api.RFuture
 
onComplete(BiConsumer<? super T, ? super Throwable>) - Method in class org.redisson.misc.PromiseDelegator
 
onComplete(BiConsumer<? super T, ? super Throwable>) - Method in class org.redisson.misc.RedissonPromise
 
onConnect(RedisClient) - Method in interface org.redisson.api.NodeListener
 
onConnect(InetSocketAddress) - Method in interface org.redisson.connection.ConnectionListener
This method will be triggered when Redisson connected to Redis server.
onCreated(EntryEvent<K, V>) - Method in interface org.redisson.api.map.event.EntryCreatedListener
 
onDeleted(String) - Method in interface org.redisson.api.DeletedObjectListener
Invoked on deleted event
onDisconnect(RedisClient) - Method in interface org.redisson.api.NodeListener
 
onDisconnect(InetSocketAddress) - Method in interface org.redisson.connection.ConnectionListener
This method will be triggered when Redisson discovers that Redis server in disconnected state.
onException() - Method in class org.redisson.command.RedisCommonBatchExecutor
 
onException() - Method in class org.redisson.command.RedisExecutor
 
onExpired(String) - Method in interface org.redisson.api.ExpiredObjectListener
Invoked on expired event
onExpired(EntryEvent<K, V>) - Method in interface org.redisson.api.map.event.EntryExpiredListener
 
onFailed(String, Throwable) - Method in interface org.redisson.api.executor.TaskFailureListener
Invoked when task was failed during execution
onFinish() - Method in interface org.redisson.SlotCallback
 
onFinished(String) - Method in interface org.redisson.api.executor.TaskFinishedListener
Invoked when task finished
onListAdd(String) - Method in interface org.redisson.api.listener.ListAddListener
Invoked on event of adding element to list
onListInsert(String) - Method in interface org.redisson.api.listener.ListInsertListener
Invoked on event of setting element to list
onListRemove(String) - Method in interface org.redisson.api.listener.ListRemoveListener
Invoked on event of removing element from list
onListSet(String) - Method in interface org.redisson.api.listener.ListSetListener
Invoked on event of setting element to list
onListTrim(String) - Method in interface org.redisson.api.listener.ListTrimListener
Invoked on list trimming event
onMapFull() - Method in class org.redisson.cache.AbstractCacheMap
 
onMapFull() - Method in class org.redisson.cache.LFUCacheMap
 
onMapFull() - Method in class org.redisson.cache.LRUCacheMap
 
onMapFull() - Method in class org.redisson.cache.NoneCacheMap
 
onMapFull() - Method in class org.redisson.cache.ReferenceCacheMap
 
onMessage(CharSequence, M) - Method in interface org.redisson.api.listener.MessageListener
Invokes on every message in topic
onMessage(CharSequence, CharSequence, M) - Method in interface org.redisson.api.listener.PatternMessageListener
Invokes on every message in topic
onMessage(CharSequence, Object) - Method in class org.redisson.client.BaseRedisPubSubListener
 
onMessage(PubSubStatusMessage) - Method in class org.redisson.client.RedisPubSubConnection
 
onMessage(PubSubMessage) - Method in class org.redisson.client.RedisPubSubConnection
 
onMessage(PubSubPatternMessage) - Method in class org.redisson.client.RedisPubSubConnection
 
onMessage(RedissonCountDownLatchEntry, Long) - Method in class org.redisson.pubsub.CountDownLatchPubSub
 
onMessage(RedissonLockEntry, Long) - Method in class org.redisson.pubsub.LockPubSub
 
onMessage(RedissonLockEntry, Long) - Method in class org.redisson.pubsub.SemaphorePubSub
 
onMessage(CharSequence, Object) - Method in class org.redisson.PubSubMessageListener
 
onMessage(CharSequence, V) - Method in class org.redisson.PubSubPatternMessageListener
 
onMessage(CharSequence, Object) - Method in class org.redisson.PubSubPatternStatusListener
 
onMessage(CharSequence, Object) - Method in class org.redisson.PubSubStatusListener
 
onMessage(CharSequence, CharSequence, String) - Method in class org.redisson.spring.session.RedissonSessionRepository
 
onPatternMessage(CharSequence, CharSequence, Object) - Method in class org.redisson.client.BaseRedisPubSubListener
 
onPatternMessage(CharSequence, CharSequence, V) - Method in interface org.redisson.client.RedisPubSubListener
 
onPatternMessage(CharSequence, CharSequence, Object) - Method in class org.redisson.PubSubMessageListener
 
onPatternMessage(CharSequence, CharSequence, V) - Method in class org.redisson.PubSubPatternMessageListener
 
onPatternMessage(CharSequence, CharSequence, Object) - Method in class org.redisson.PubSubPatternStatusListener
 
onPatternMessage(CharSequence, CharSequence, Object) - Method in class org.redisson.PubSubStatusListener
 
onPSubscribe(String) - Method in class org.redisson.api.listener.BasePatternStatusListener
 
onPSubscribe(String) - Method in interface org.redisson.api.listener.PatternStatusListener
 
onPUnsubscribe(String) - Method in class org.redisson.api.listener.BasePatternStatusListener
 
onPUnsubscribe(String) - Method in interface org.redisson.api.listener.PatternStatusListener
 
onRemoved(EntryEvent<K, V>) - Method in interface org.redisson.api.map.event.EntryRemovedListener
 
onSet(String) - Method in interface org.redisson.api.listener.SetObjectListener
Invoked on set object event
onSlotResult(T) - Method in interface org.redisson.SlotCallback
 
onStarted(String) - Method in interface org.redisson.api.executor.TaskStartedListener
Invoked when task was started
onStartup(RedissonNode) - Method in interface org.redisson.api.RedissonNodeInitializer
Invoked during Redisson Node startup
onStatus(PubSubType, CharSequence) - Method in class org.redisson.client.BaseRedisPubSubListener
 
onStatus(PubSubType, CharSequence) - Method in interface org.redisson.client.RedisPubSubListener
 
onStatus(PubSubType, CharSequence) - Method in class org.redisson.client.SubscribeListener
 
onStatus(PubSubType, CharSequence) - Method in class org.redisson.PubSubMessageListener
 
onStatus(PubSubType, CharSequence) - Method in class org.redisson.PubSubPatternMessageListener
 
onStatus(PubSubType, CharSequence) - Method in class org.redisson.PubSubPatternStatusListener
 
onStatus(PubSubType, CharSequence) - Method in class org.redisson.PubSubStatusListener
 
onSubscribe(String) - Method in class org.redisson.api.listener.BaseStatusListener
 
onSubscribe(String) - Method in interface org.redisson.api.listener.StatusListener
Executes then Redisson successfully subscribed to channel.
onSucceeded(String, T) - Method in interface org.redisson.api.executor.TaskSuccessListener
Invoked when task was succeeded
onSuccess(T) - Method in class org.redisson.misc.CountableListener
 
onUnsubscribe(String) - Method in class org.redisson.api.listener.BaseStatusListener
 
onUnsubscribe(String) - Method in interface org.redisson.api.listener.StatusListener
Executes then Redisson successfully unsubscribed from channel.
onUpdated(EntryEvent<K, V>) - Method in interface org.redisson.api.map.event.EntryUpdatedListener
 
onValueCreate(CachedValue<K, V>) - Method in class org.redisson.cache.AbstractCacheMap
 
onValueCreate(CachedValue) - Method in class org.redisson.cache.LFUCacheMap
 
onValueCreate(CachedValue<K, V>) - Method in class org.redisson.cache.LRUCacheMap
 
onValueRead(CachedValue<K, V>) - Method in class org.redisson.cache.AbstractCacheMap
 
onValueRead(CachedValue) - Method in class org.redisson.cache.LFUCacheMap
 
onValueRead(CachedValue<K, V>) - Method in class org.redisson.cache.LRUCacheMap
 
onValueRemove(CachedValue<K, V>) - Method in class org.redisson.cache.AbstractCacheMap
 
onValueRemove(CachedValue) - Method in class org.redisson.cache.LFUCacheMap
 
onValueRemove(CachedValue<K, V>) - Method in class org.redisson.cache.LRUCacheMap
 
open() - Method in class org.redisson.misc.ReclosableLatch
 
or(Condition...) - Static method in class org.redisson.api.condition.Conditions
Returns "OR" condition for collection of nested conditions
or(String...) - Method in interface org.redisson.api.RBitSet
Executes OR operation over this object and specified bitsets.
or(String...) - Method in interface org.redisson.api.RBitSetReactive
Executes OR operation over this object and specified bitsets.
or(String...) - Method in interface org.redisson.api.RBitSetRx
Executes OR operation over this object and specified bitsets.
or(String...) - Method in class org.redisson.RedissonBitSet
 
orAsync(String...) - Method in interface org.redisson.api.RBitSetAsync
Executes OR operation over this object and specified bitsets.
orAsync(String...) - Method in class org.redisson.RedissonBitSet
 
ORCondition - Class in org.redisson.liveobject.condition
 
ORCondition(Condition[]) - Constructor for class org.redisson.liveobject.condition.ORCondition
 
org.redisson - package org.redisson
 
org.redisson.api - package org.redisson.api
 
org.redisson.api.annotation - package org.redisson.api.annotation
 
org.redisson.api.condition - package org.redisson.api.condition
 
org.redisson.api.executor - package org.redisson.api.executor
 
org.redisson.api.listener - package org.redisson.api.listener
 
org.redisson.api.map - package org.redisson.api.map
 
org.redisson.api.map.event - package org.redisson.api.map.event
 
org.redisson.api.mapreduce - package org.redisson.api.mapreduce
 
org.redisson.api.redisnode - package org.redisson.api.redisnode
 
org.redisson.cache - package org.redisson.cache
 
org.redisson.client - package org.redisson.client
 
org.redisson.client.codec - package org.redisson.client.codec
 
org.redisson.client.handler - package org.redisson.client.handler
 
org.redisson.client.protocol - package org.redisson.client.protocol
 
org.redisson.client.protocol.convertor - package org.redisson.client.protocol.convertor
 
org.redisson.client.protocol.decoder - package org.redisson.client.protocol.decoder
 
org.redisson.client.protocol.pubsub - package org.redisson.client.protocol.pubsub
 
org.redisson.cluster - package org.redisson.cluster
 
org.redisson.codec - package org.redisson.codec
 
org.redisson.command - package org.redisson.command
 
org.redisson.config - package org.redisson.config
 
org.redisson.connection - package org.redisson.connection
 
org.redisson.connection.balancer - package org.redisson.connection.balancer
 
org.redisson.connection.decoder - package org.redisson.connection.decoder
 
org.redisson.connection.pool - package org.redisson.connection.pool
 
org.redisson.eviction - package org.redisson.eviction
 
org.redisson.executor - package org.redisson.executor
 
org.redisson.executor.params - package org.redisson.executor.params
 
org.redisson.iterator - package org.redisson.iterator
 
org.redisson.jcache - package org.redisson.jcache
 
org.redisson.jcache.bean - package org.redisson.jcache.bean
 
org.redisson.jcache.configuration - package org.redisson.jcache.configuration
 
org.redisson.liveobject - package org.redisson.liveobject
 
org.redisson.liveobject.condition - package org.redisson.liveobject.condition
 
org.redisson.liveobject.core - package org.redisson.liveobject.core
 
org.redisson.liveobject.misc - package org.redisson.liveobject.misc
 
org.redisson.liveobject.resolver - package org.redisson.liveobject.resolver
 
org.redisson.mapreduce - package org.redisson.mapreduce
 
org.redisson.misc - package org.redisson.misc
 
org.redisson.pubsub - package org.redisson.pubsub
 
org.redisson.reactive - package org.redisson.reactive
 
org.redisson.redisnode - package org.redisson.redisnode
 
org.redisson.remote - package org.redisson.remote
 
org.redisson.rx - package org.redisson.rx
 
org.redisson.spring.cache - package org.redisson.spring.cache
 
org.redisson.spring.misc - package org.redisson.spring.misc
 
org.redisson.spring.session - package org.redisson.spring.session
 
org.redisson.spring.session.config - package org.redisson.spring.session.config
 
org.redisson.spring.support - package org.redisson.spring.support
 
org.redisson.spring.transaction - package org.redisson.spring.transaction
 
org.redisson.transaction - package org.redisson.transaction
 
org.redisson.transaction.operation - package org.redisson.transaction.operation
 
org.redisson.transaction.operation.bucket - package org.redisson.transaction.operation.bucket
 
org.redisson.transaction.operation.map - package org.redisson.transaction.operation.map
 
org.redisson.transaction.operation.set - package org.redisson.transaction.operation.set
 
osType - Variable in class org.redisson.codec.BaseEventCodec
 

P

parse(Element, ParserContext) - Method in class org.redisson.spring.support.RedissonDefinitionParser
 
parseAliase(Element) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
parseAttributes(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
parseNested(Element, ParserContext, BeanDefinitionBuilder, BeanDefinition) - Method in class org.redisson.spring.support.AbstractRedissonNamespaceDefinitionParser
 
parseNested(Element, ParserContext, BeanDefinitionBuilder, BeanDefinition) - Method in class org.redisson.spring.support.RedissonGenericObjectDefinitionParser
 
parseNested(Element, ParserContext, BeanDefinitionBuilder, BeanDefinition) - Method in class org.redisson.spring.support.RedissonLiveObjectDefinitionParser
 
parseNested(Element, ParserContext, BeanDefinitionBuilder, BeanDefinition) - Method in class org.redisson.spring.support.RedissonLiveObjectRegistrationDefinitionParser
 
parseNested(Element, ParserContext, BeanDefinitionBuilder, BeanDefinition) - Method in class org.redisson.spring.support.RedissonMultiLockDefinitionParser
 
parseNested(Element, ParserContext, BeanDefinitionBuilder, BeanDefinition) - Method in class org.redisson.spring.support.RedissonReadAndWriteLockDefinitionParser
 
parseNested(Element, ParserContext, BeanDefinitionBuilder, BeanDefinition) - Method in class org.redisson.spring.support.RedissonRPCClientDefinitionParser
 
parseNested(Element, ParserContext, BeanDefinitionBuilder, BeanDefinition) - Method in class org.redisson.spring.support.RedissonRPCServerDefinitionParser
 
PatternMessageListener<M> - Interface in org.redisson.api.listener
Listener for Redis messages published via RTopic Redisson object
PatternStatusListener - Interface in org.redisson.api.listener
Listener for Redis PubSub channel status changes
peek() - Method in interface org.redisson.api.RQueueReactive
Retrieves the head of this queue in async mode.
peek() - Method in interface org.redisson.api.RQueueRx
Retrieves the head of this queue in async mode.
peek() - Method in class org.redisson.RedissonDelayedQueue
 
peek() - Method in class org.redisson.RedissonPriorityQueue
 
peek() - Method in class org.redisson.RedissonQueue
 
peek() - Method in class org.redisson.RedissonTransferQueue
 
peekAsync() - Method in interface org.redisson.api.RQueueAsync
Retrieves the head of this queue in async mode.
peekAsync() - Method in class org.redisson.RedissonDelayedQueue
 
peekAsync() - Method in class org.redisson.RedissonPriorityQueue
 
peekAsync() - Method in class org.redisson.RedissonQueue
 
peekAsync() - Method in class org.redisson.RedissonTransferQueue
 
peekFirst() - Method in interface org.redisson.api.RDequeReactive
Returns element at the head of this deque or null if there are no elements in deque.
peekFirst() - Method in interface org.redisson.api.RDequeRx
Returns element at the head of this deque or null if there are no elements in deque.
peekFirst() - Method in class org.redisson.RedissonDeque
 
peekFirst() - Method in class org.redisson.RedissonPriorityDeque
 
peekFirstAsync() - Method in interface org.redisson.api.RDequeAsync
Returns element at the head of this deque or null if there are no elements in deque.
peekFirstAsync() - Method in class org.redisson.RedissonDeque
 
peekFirstAsync() - Method in class org.redisson.RedissonPriorityDeque
 
peekLast() - Method in interface org.redisson.api.RDequeReactive
Returns element at the tail of this deque or null if there are no elements in deque.
peekLast() - Method in interface org.redisson.api.RDequeRx
Returns element at the tail of this deque or null if there are no elements in deque.
peekLast() - Method in class org.redisson.RedissonDeque
 
peekLast() - Method in class org.redisson.RedissonPriorityDeque
 
peekLastAsync() - Method in interface org.redisson.api.RDequeAsync
Returns element at the tail of this deque or null if there are no elements in deque.
peekLastAsync() - Method in class org.redisson.RedissonDeque
 
peekLastAsync() - Method in class org.redisson.RedissonPriorityDeque
 
PendingEntry - Class in org.redisson.api
Entry object for pending messages request.
PendingEntry(StreamMessageId, String, long, long) - Constructor for class org.redisson.api.PendingEntry
 
PendingEntryDecoder - Class in org.redisson.client.protocol.decoder
 
PendingEntryDecoder() - Constructor for class org.redisson.client.protocol.decoder.PendingEntryDecoder
 
pendingRange(String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStream
Returns stream data of pending messages by group name.
pendingRange(String, String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStream
Returns stream data of pending messages by group and customer name.
pendingRange(String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamReactive
Returns stream data of pending messages by group name.
pendingRange(String, String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamReactive
Returns stream data of pending messages by group and customer name.
pendingRange(String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamRx
Returns stream data of pending messages by group name.
pendingRange(String, String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamRx
Returns stream data of pending messages by group and customer name.
pendingRange(String, String, StreamMessageId, StreamMessageId, int) - Method in class org.redisson.RedissonStream
 
pendingRange(String, StreamMessageId, StreamMessageId, int) - Method in class org.redisson.RedissonStream
 
pendingRangeAsync(String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamAsync
Returns stream data of pending messages by group name.
pendingRangeAsync(String, String, StreamMessageId, StreamMessageId, int) - Method in interface org.redisson.api.RStreamAsync
Returns stream data of pending messages by group and customer name.
pendingRangeAsync(String, StreamMessageId, StreamMessageId, int) - Method in class org.redisson.RedissonStream
 
pendingRangeAsync(String, String, StreamMessageId, StreamMessageId, int) - Method in class org.redisson.RedissonStream
 
PendingResult - Class in org.redisson.api
Result object for pending messages request.
PendingResult() - Constructor for class org.redisson.api.PendingResult
 
PendingResult(long, StreamMessageId, StreamMessageId, Map<String, Long>) - Constructor for class org.redisson.api.PendingResult
 
PendingResultDecoder - Class in org.redisson.client.protocol.decoder
 
PendingResultDecoder() - Constructor for class org.redisson.client.protocol.decoder.PendingResultDecoder
 
permittedClasses() - Method in class org.redisson.remote.AsyncRemoteProxy
 
permittedClasses() - Method in class org.redisson.remote.ReactiveRemoteProxy
 
permittedClasses() - Method in class org.redisson.remote.RxRemoteProxy
 
persist(T) - Method in interface org.redisson.api.RLiveObjectService
Returns proxied attached object for the detached object.
persist(T...) - Method in interface org.redisson.api.RLiveObjectService
Returns proxied attached objects for the detached objects.
PERSIST - Static variable in interface org.redisson.client.protocol.RedisCommands
 
persist(T) - Method in class org.redisson.RedissonLiveObjectService
 
persist(T...) - Method in class org.redisson.RedissonLiveObjectService
 
PEXPIRE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
PEXPIREAT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
PFADD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
PFCOUNT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
PFMERGE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ping() - Method in interface org.redisson.api.Node
Deprecated.
Ping Redis node.
ping(long, TimeUnit) - Method in interface org.redisson.api.Node
Deprecated.
Ping Redis node with specified timeout.
ping() - Method in interface org.redisson.api.redisnode.RedisNode
Ping Redis node.
ping(long, TimeUnit) - Method in interface org.redisson.api.redisnode.RedisNode
Ping Redis node with specified timeout.
PING - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ping() - Method in class org.redisson.connection.RedisClientEntry
 
ping(long, TimeUnit) - Method in class org.redisson.connection.RedisClientEntry
 
ping() - Method in class org.redisson.redisnode.RedisNode
 
ping(long, TimeUnit) - Method in class org.redisson.redisnode.RedisNode
 
ping() - Method in class org.redisson.redisnode.SentinelRedisNode
 
ping(long, TimeUnit) - Method in class org.redisson.redisnode.SentinelRedisNode
 
PING_BOOL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
pingAll() - Method in interface org.redisson.api.NodesGroup
Deprecated.
Ping all Redis nodes.
pingAll(long, TimeUnit) - Method in interface org.redisson.api.NodesGroup
Deprecated.
Ping all Redis nodes with specified timeout per node
pingAll() - Method in interface org.redisson.api.redisnode.BaseRedisNodes
Ping all Redis nodes.
pingAll(long, TimeUnit) - Method in interface org.redisson.api.redisnode.BaseRedisNodes
Ping all Redis nodes with specified timeout per node
pingAll(long, TimeUnit) - Method in class org.redisson.redisnode.RedissonBaseNodes
 
pingAll() - Method in class org.redisson.redisnode.RedissonBaseNodes
 
pingAll(long, TimeUnit) - Method in class org.redisson.RedisNodes
Deprecated.
 
pingAll() - Method in class org.redisson.RedisNodes
Deprecated.
 
pingAsync() - Method in interface org.redisson.api.NodeAsync
Deprecated.
 
pingAsync(long, TimeUnit) - Method in interface org.redisson.api.NodeAsync
Deprecated.
Ping Redis node with specified timeout.
pingAsync() - Method in interface org.redisson.api.redisnode.RedisNodeAsync
Ping Redis node.
pingAsync(long, TimeUnit) - Method in interface org.redisson.api.redisnode.RedisNodeAsync
Ping Redis node with specified timeout.
pingAsync() - Method in class org.redisson.connection.RedisClientEntry
 
pingAsync(long, TimeUnit) - Method in class org.redisson.connection.RedisClientEntry
 
pingAsync() - Method in class org.redisson.redisnode.RedisNode
 
pingAsync(long, TimeUnit) - Method in class org.redisson.redisnode.RedisNode
 
pingAsync() - Method in class org.redisson.redisnode.SentinelRedisNode
 
pingAsync(long, TimeUnit) - Method in class org.redisson.redisnode.SentinelRedisNode
 
PingConnectionHandler - Class in org.redisson.client.handler
 
PingConnectionHandler(RedisClientConfig) - Constructor for class org.redisson.client.handler.PingConnectionHandler
 
poll(long, TimeUnit) - Method in interface org.redisson.api.RBlockingQueueReactive
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.
poll(long, TimeUnit) - Method in interface org.redisson.api.RBlockingQueueRx
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.
poll(int) - Method in interface org.redisson.api.RQueue
Retrieves and removes the head elements of this queue.
poll() - Method in interface org.redisson.api.RQueueReactive
Retrieves and removes the head of this queue in async mode.
poll(int) - Method in interface org.redisson.api.RQueueReactive
Retrieves and removes the head elements of this queue.
poll() - Method in interface org.redisson.api.RQueueRx
Retrieves and removes the head of this queue in async mode.
poll(int) - Method in interface org.redisson.api.RQueueRx
Retrieves and removes the head elements of this queue.
poll(ClientConnectionsEntry) - Method in class org.redisson.connection.pool.PubSubConnectionPool
 
poll() - Method in class org.redisson.executor.RedissonCompletionService
 
poll(long, TimeUnit) - Method in class org.redisson.executor.RedissonCompletionService
 
poll(long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
poll(long, TimeUnit) - Method in class org.redisson.RedissonBlockingQueue
 
poll(long, TimeUnit) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
poll() - Method in class org.redisson.RedissonDelayedQueue
 
poll(int) - Method in class org.redisson.RedissonDelayedQueue
 
poll(long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
poll(int) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
poll(long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
poll(int) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
poll() - Method in class org.redisson.RedissonPriorityQueue
 
poll(int) - Method in class org.redisson.RedissonPriorityQueue
 
poll(int) - Method in class org.redisson.RedissonQueue
 
poll() - Method in class org.redisson.RedissonQueue
 
poll() - Method in class org.redisson.RedissonTransferQueue
 
poll(long, TimeUnit) - Method in class org.redisson.RedissonTransferQueue
 
poll(int) - Method in class org.redisson.RedissonTransferQueue
 
pollAsync(long, TimeUnit) - Method in interface org.redisson.api.RBlockingQueueAsync
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.
pollAsync() - Method in interface org.redisson.api.RQueueAsync
Retrieves and removes the head of this queue in async mode.
pollAsync(int) - Method in interface org.redisson.api.RQueueAsync
Retrieves and removes the head elements of this queue.
pollAsync(long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
pollAsync(long, TimeUnit) - Method in class org.redisson.RedissonBlockingQueue
 
pollAsync() - Method in class org.redisson.RedissonBoundedBlockingQueue
 
pollAsync(long, TimeUnit) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
pollAsync(int) - Method in class org.redisson.RedissonDelayedQueue
 
pollAsync() - Method in class org.redisson.RedissonDelayedQueue
 
pollAsync(long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollAsync(int) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollAsync(long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
pollAsync(int) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
pollAsync() - Method in class org.redisson.RedissonPriorityQueue
 
pollAsync(int) - Method in class org.redisson.RedissonPriorityQueue
 
pollAsync() - Method in class org.redisson.RedissonQueue
 
pollAsync(int) - Method in class org.redisson.RedissonQueue
 
pollAsync() - Method in class org.redisson.RedissonTransferQueue
 
pollAsync(long, TimeUnit) - Method in class org.redisson.RedissonTransferQueue
 
pollAsync(int) - Method in class org.redisson.RedissonTransferQueue
 
pollConnection() - Method in class org.redisson.connection.ClientConnectionsEntry
 
pollFirst(long, TimeUnit) - Method in interface org.redisson.api.RBlockingDequeReactive
Retrieves and removes value at the head of queue.
pollFirst(long, TimeUnit) - Method in interface org.redisson.api.RBlockingDequeRx
Retrieves and removes value at the head of queue.
pollFirst(int) - Method in interface org.redisson.api.RDeque
Retrieves and removes the head elements of this queue.
pollFirst() - Method in interface org.redisson.api.RDequeReactive
Retrieves and removes element at the head of this deque.
pollFirst(int) - Method in interface org.redisson.api.RDequeReactive
Retrieves and removes the head elements of this queue.
pollFirst() - Method in interface org.redisson.api.RDequeRx
Retrieves and removes element at the head of this deque.
pollFirst(int) - Method in interface org.redisson.api.RDequeRx
Retrieves and removes the head elements of this queue.
pollFirst() - Method in interface org.redisson.api.RLexSortedSet
Removes and returns the head element or null if this sorted set is empty.
pollFirst(long, TimeUnit) - Method in interface org.redisson.api.RScoredSortedSet
Removes and returns the head element or null if this sorted set is empty.
pollFirst(int) - Method in interface org.redisson.api.RScoredSortedSet
Removes and returns the head elements or null if this sorted set is empty.
pollFirst() - Method in interface org.redisson.api.RScoredSortedSet
Removes and returns the head element or null if this sorted set is empty.
pollFirst(long, TimeUnit) - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes and returns the head element or null if this sorted set is empty.
pollFirst(int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes and returns the head elements or null if this sorted set is empty.
pollFirst() - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes and returns the head element or null if this sorted set is empty.
pollFirst(long, TimeUnit) - Method in interface org.redisson.api.RScoredSortedSetRx
Removes and returns the head element or null if this sorted set is empty.
pollFirst(int) - Method in interface org.redisson.api.RScoredSortedSetRx
Removes and returns the head elements or null if this sorted set is empty.
pollFirst() - Method in interface org.redisson.api.RScoredSortedSetRx
Removes and returns the head element or null if this sorted set is empty.
pollFirst(long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
pollFirst() - Method in class org.redisson.RedissonDeque
 
pollFirst(int) - Method in class org.redisson.RedissonDeque
 
pollFirst(long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollFirst(int) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollFirst() - Method in class org.redisson.RedissonPriorityDeque
 
pollFirst(int) - Method in class org.redisson.RedissonPriorityDeque
 
pollFirst() - Method in class org.redisson.RedissonScoredSortedSet
 
pollFirst(int) - Method in class org.redisson.RedissonScoredSortedSet
 
pollFirst(long, TimeUnit) - Method in class org.redisson.RedissonScoredSortedSet
 
pollFirstAsync(long, TimeUnit) - Method in interface org.redisson.api.RBlockingDequeAsync
Retrieves and removes value at the head of queue.
pollFirstAsync() - Method in interface org.redisson.api.RDequeAsync
Retrieves and removes element at the head of this deque.
pollFirstAsync(int) - Method in interface org.redisson.api.RDequeAsync
Retrieves and removes the head elements of this queue.
pollFirstAsync() - Method in interface org.redisson.api.RLexSortedSetAsync
Removes and returns the head element or null if this sorted set is empty.
pollFirstAsync(long, TimeUnit) - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes and returns the head element or null if this sorted set is empty.
pollFirstAsync(int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes and returns the head elements or null if this sorted set is empty.
pollFirstAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes and returns the head element or null if this sorted set is empty.
pollFirstAsync(long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
pollFirstAsync() - Method in class org.redisson.RedissonDeque
 
pollFirstAsync(int) - Method in class org.redisson.RedissonDeque
 
pollFirstAsync(long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollFirstAsync(int) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollFirstAsync() - Method in class org.redisson.RedissonPriorityDeque
 
pollFirstAsync(int) - Method in class org.redisson.RedissonPriorityDeque
 
pollFirstAsync(int) - Method in class org.redisson.RedissonScoredSortedSet
 
pollFirstAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
pollFirstAsync(long, TimeUnit) - Method in class org.redisson.RedissonScoredSortedSet
 
pollFirstFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingDeque
Retrieves and removes first available head element 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 own.
pollFirstFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingDequeReactive
Retrieves and removes first available head element of any queue in reactive mode, waiting up to the specified wait time if necessary for an element to become available in any of defined queues including queue own.
pollFirstFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingDequeRx
Retrieves and removes first available head element of any queue in reactive mode, waiting up to the specified wait time if necessary for an element to become available in any of defined queues including queue own.
pollFirstFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RScoredSortedSet
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.
pollFirstFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RScoredSortedSetReactive
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.
pollFirstFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RScoredSortedSetRx
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.
pollFirstFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonBlockingDeque
 
pollFirstFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollFirstFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonScoredSortedSet
 
pollFirstFromAnyAsync(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingDequeAsync
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.
pollFirstFromAnyAsync(long, TimeUnit, String...) - Method in interface org.redisson.api.RScoredSortedSetAsync
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.
pollFirstFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonBlockingDeque
 
pollFirstFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollFirstFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonScoredSortedSet
 
pollFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingQueue
Retrieves and removes first available head element 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.
pollFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingQueueReactive
Retrieves and removes first available head element 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 own.
pollFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingQueueRx
Retrieves and removes first available head element 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 own.
pollFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonBlockingDeque
 
pollFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonBlockingQueue
 
pollFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
pollFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
pollFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonTransferQueue
 
pollFromAnyAsync(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingQueueAsync
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.
pollFromAnyAsync(String, Codec, RedisCommand<Object>, long, String...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
pollFromAnyAsync(String, Codec, RedisCommand<Object>, long, String...) - Method in class org.redisson.command.CommandAsyncService
 
pollFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonBlockingDeque
 
pollFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonBlockingQueue
 
pollFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
pollFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
pollFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonTransferQueue
 
pollLast(long, TimeUnit) - Method in interface org.redisson.api.RBlockingDequeReactive
Retrieves and removes value at the tail of queue.
pollLast(long, TimeUnit) - Method in interface org.redisson.api.RBlockingDequeRx
Retrieves and removes value at the tail of queue.
pollLast(int) - Method in interface org.redisson.api.RDeque
Retrieves and removes the tail elements of this queue.
pollLast() - Method in interface org.redisson.api.RDequeReactive
Retrieves and removes element at the tail of this deque.
pollLast(int) - Method in interface org.redisson.api.RDequeReactive
Retrieves and removes the tail elements of this queue.
pollLast() - Method in interface org.redisson.api.RDequeRx
Retrieves and removes element at the tail of this deque.
pollLast(int) - Method in interface org.redisson.api.RDequeRx
Retrieves and removes the tail elements of this queue.
pollLast() - Method in interface org.redisson.api.RLexSortedSet
Removes and returns the tail element or null if this sorted set is empty.
pollLast(long, TimeUnit) - Method in interface org.redisson.api.RScoredSortedSet
Removes and returns the tail element or null if this sorted set is empty.
pollLast(int) - Method in interface org.redisson.api.RScoredSortedSet
Removes and returns the tail elements or null if this sorted set is empty.
pollLast() - Method in interface org.redisson.api.RScoredSortedSet
Removes and returns the tail element or null if this sorted set is empty.
pollLast(long, TimeUnit) - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes and returns the tail element or null if this sorted set is empty.
pollLast(int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes and returns the tail elements or null if this sorted set is empty.
pollLast() - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes and returns the tail element or null if this sorted set is empty.
pollLast(long, TimeUnit) - Method in interface org.redisson.api.RScoredSortedSetRx
Removes and returns the tail element or null if this sorted set is empty.
pollLast(int) - Method in interface org.redisson.api.RScoredSortedSetRx
Removes and returns the tail elements or null if this sorted set is empty.
pollLast() - Method in interface org.redisson.api.RScoredSortedSetRx
Removes and returns the tail element or null if this sorted set is empty.
pollLast(long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
pollLast(int) - Method in class org.redisson.RedissonDeque
 
pollLast() - Method in class org.redisson.RedissonDeque
 
pollLast(long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollLast(int) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollLast() - Method in class org.redisson.RedissonPriorityDeque
 
pollLast(int) - Method in class org.redisson.RedissonPriorityDeque
 
pollLast() - Method in class org.redisson.RedissonScoredSortedSet
 
pollLast(int) - Method in class org.redisson.RedissonScoredSortedSet
 
pollLast(long, TimeUnit) - Method in class org.redisson.RedissonScoredSortedSet
 
pollLastAndOfferFirstTo(String, long, TimeUnit) - Method in interface org.redisson.api.RBlockingQueue
Retrieves and removes last available tail element of this queue and adds it at the head of queueName, waiting up to the specified wait time if necessary for an element to become available.
pollLastAndOfferFirstTo(String, long, TimeUnit) - Method in interface org.redisson.api.RBlockingQueueReactive
Retrieves and removes last available tail element of this queue and adds it at the head of queueName, waiting up to the specified wait time if necessary for an element to become available.
pollLastAndOfferFirstTo(String, long, TimeUnit) - Method in interface org.redisson.api.RBlockingQueueRx
Retrieves and removes last available tail element of this queue and adds it at the head of queueName, waiting up to the specified wait time if necessary for an element to become available.
pollLastAndOfferFirstTo(String) - Method in interface org.redisson.api.RPriorityQueue
Retrieves and removes last available tail element of this queue queue and adds it at the head of queueName.
pollLastAndOfferFirstTo(String) - Method in interface org.redisson.api.RQueue
Retrieves and removes last available tail element of this queue queue and adds it at the head of queueName.
pollLastAndOfferFirstTo(String) - Method in interface org.redisson.api.RQueueReactive
Retrieves and removes last available tail element of this queue queue and adds it at the head of queueName.
pollLastAndOfferFirstTo(String) - Method in interface org.redisson.api.RQueueRx
Retrieves and removes last available tail element of this queue queue and adds it at the head of queueName.
pollLastAndOfferFirstTo(String, long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
pollLastAndOfferFirstTo(String, long, TimeUnit) - Method in class org.redisson.RedissonBlockingQueue
 
pollLastAndOfferFirstTo(String, long, TimeUnit) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
pollLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonDelayedQueue
 
pollLastAndOfferFirstTo(String, long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollLastAndOfferFirstTo(String, long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
pollLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonPriorityQueue
 
pollLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonQueue
 
pollLastAndOfferFirstTo(String, long, TimeUnit) - Method in class org.redisson.RedissonTransferQueue
 
pollLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonTransferQueue
 
pollLastAndOfferFirstToAsync(String, long, TimeUnit) - Method in interface org.redisson.api.RBlockingQueueAsync
Retrieves and removes last available tail element of this queue and adds it at the head of queueName, waiting up to the specified wait time if necessary for an element to become available.
pollLastAndOfferFirstToAsync(String) - Method in interface org.redisson.api.RQueueAsync
Retrieves and removes last available tail element of this queue queue and adds it at the head of queueName.
pollLastAndOfferFirstToAsync(String, long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
pollLastAndOfferFirstToAsync(String, long, TimeUnit) - Method in class org.redisson.RedissonBlockingQueue
 
pollLastAndOfferFirstToAsync(String, long, TimeUnit) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
pollLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonDelayedQueue
 
pollLastAndOfferFirstToAsync(String, long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollLastAndOfferFirstToAsync(String, long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
pollLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonPriorityQueue
 
pollLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonQueue
 
pollLastAndOfferFirstToAsync(String, long, TimeUnit) - Method in class org.redisson.RedissonTransferQueue
 
pollLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonTransferQueue
 
pollLastAsync(long, TimeUnit) - Method in interface org.redisson.api.RBlockingDequeAsync
Retrieves and removes value at the tail of queue.
pollLastAsync() - Method in interface org.redisson.api.RDequeAsync
Retrieves and removes element at the tail of this deque.
pollLastAsync(int) - Method in interface org.redisson.api.RDequeAsync
Retrieves and removes the tail elements of this queue.
pollLastAsync() - Method in interface org.redisson.api.RLexSortedSetAsync
Removes and returns the tail element or null if this sorted set is empty.
pollLastAsync(long, TimeUnit) - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes and returns the tail element or null if this sorted set is empty.
pollLastAsync(int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes and returns the tail elements or null if this sorted set is empty.
pollLastAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes and returns the tail element or null if this sorted set is empty.
pollLastAsync(long, TimeUnit) - Method in class org.redisson.RedissonBlockingDeque
 
pollLastAsync() - Method in class org.redisson.RedissonDeque
 
pollLastAsync(int) - Method in class org.redisson.RedissonDeque
 
pollLastAsync(long, TimeUnit) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollLastAsync(int) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollLastAsync() - Method in class org.redisson.RedissonPriorityDeque
 
pollLastAsync(int) - Method in class org.redisson.RedissonPriorityDeque
 
pollLastAsync(int) - Method in class org.redisson.RedissonScoredSortedSet
 
pollLastAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
pollLastAsync(long, TimeUnit) - Method in class org.redisson.RedissonScoredSortedSet
 
pollLastFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingDeque
Retrieves and removes first available tail element 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 own.
pollLastFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingDequeReactive
Retrieves and removes first available tail element of any queue in reactive mode, waiting up to the specified wait time if necessary for an element to become available in any of defined queues including queue own.
pollLastFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingDequeRx
Retrieves and removes first available tail element of any queue in reactive mode, waiting up to the specified wait time if necessary for an element to become available in any of defined queues including queue own.
pollLastFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RScoredSortedSet
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.
pollLastFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RScoredSortedSetReactive
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.
pollLastFromAny(long, TimeUnit, String...) - Method in interface org.redisson.api.RScoredSortedSetRx
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.
pollLastFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonBlockingDeque
 
pollLastFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollLastFromAny(long, TimeUnit, String...) - Method in class org.redisson.RedissonScoredSortedSet
 
pollLastFromAnyAsync(long, TimeUnit, String...) - Method in interface org.redisson.api.RBlockingDequeAsync
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.
pollLastFromAnyAsync(long, TimeUnit, String...) - Method in interface org.redisson.api.RScoredSortedSetAsync
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.
pollLastFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonBlockingDeque
 
pollLastFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
pollLastFromAnyAsync(long, TimeUnit, String...) - Method in class org.redisson.RedissonScoredSortedSet
 
pollResponse(long, RequestId, boolean) - Method in class org.redisson.remote.BaseRemoteProxy
 
pollSubscribeConnection() - Method in class org.redisson.connection.ClientConnectionsEntry
 
pop() - Method in interface org.redisson.api.RDequeReactive
Retrieves and removes element at the head of this deque.
pop() - Method in interface org.redisson.api.RDequeRx
Retrieves and removes element at the head of this deque.
pop() - Method in class org.redisson.RedissonDeque
 
pop() - Method in class org.redisson.RedissonPriorityDeque
 
popAsync() - Method in interface org.redisson.api.RDequeAsync
Retrieves and removes element at the head of this deque.
popAsync() - Method in class org.redisson.RedissonDeque
 
popAsync() - Method in class org.redisson.RedissonPriorityDeque
 
populateIdAttribute(Element, BeanDefinitionBuilder, ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
pos(V...) - Method in interface org.redisson.api.RGeo
Returns geo-position mapped by defined member.
pos(V...) - Method in interface org.redisson.api.RGeoReactive
Returns geo-position mapped by defined member.
pos(V...) - Method in interface org.redisson.api.RGeoRx
Returns geo-position mapped by defined member.
pos(V...) - Method in class org.redisson.RedissonGeo
 
posAsync(V...) - Method in interface org.redisson.api.RGeoAsync
Returns geo-position mapped by defined member.
posAsync(V...) - Method in class org.redisson.RedissonGeo
 
position() - Method in interface org.redisson.api.RBinaryStreamReactive
Returns current channel's position
position(long) - Method in interface org.redisson.api.RBinaryStreamReactive
Sets channel's position
position() - Method in interface org.redisson.api.RBinaryStreamRx
Returns current channel's position
position(long) - Method in interface org.redisson.api.RBinaryStreamRx
Sets channel's position
position() - Method in class org.redisson.reactive.RedissonBinaryStreamReactive
 
position(long) - Method in class org.redisson.reactive.RedissonBinaryStreamReactive
 
position() - Method in class org.redisson.RedissonBinaryStream.RedissonAsynchronousByteChannel
 
position(long) - Method in class org.redisson.RedissonBinaryStream.RedissonAsynchronousByteChannel
 
position() - Method in class org.redisson.rx.RedissonBinaryStreamRx
 
position(long) - Method in class org.redisson.rx.RedissonBinaryStreamRx
 
prefixName(String, String) - Static method in class org.redisson.RedissonObject
 
preloadCache() - Method in interface org.redisson.api.RLocalCachedMap
Pre-warm the cached entries.
preloadCache(int) - Method in interface org.redisson.api.RLocalCachedMap
Pre-warm the cached entries.
preloadCache() - Method in class org.redisson.RedissonLocalCachedMap
 
preloadCache(int) - Method in class org.redisson.RedissonLocalCachedMap
 
preloadCache() - Method in class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
preloadCache(int) - Method in class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
previous() - Method in class org.redisson.iterator.RedissonListIterator
 
previousIndex() - Method in class org.redisson.iterator.RedissonListIterator
 
PromiseDelegator<T> - Class in org.redisson.misc
 
PromiseDelegator(RPromise<T>) - Constructor for class org.redisson.misc.PromiseDelegator
 
ProxyBuilder - Class in org.redisson.misc
 
ProxyBuilder() - Constructor for class org.redisson.misc.ProxyBuilder
 
ProxyBuilder.Callback - Interface in org.redisson.misc
 
PSETEX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
PSUBSCRIBE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
psubscribe(Codec, ChannelName...) - Method in class org.redisson.client.RedisPubSubConnection
 
psubscribe(ChannelName, Codec, RedisPubSubListener<?>...) - Method in class org.redisson.pubsub.PublishSubscribeService
 
psubscribe(String, Codec, AsyncSemaphore, RedisPubSubListener<?>...) - Method in class org.redisson.pubsub.PublishSubscribeService
 
psubscribe(Codec, ChannelName) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
PTTL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
publish(Object) - Method in interface org.redisson.api.RTopic
Publish the message to all subscribers of this topic
publish(Object) - Method in interface org.redisson.api.RTopicReactive
Publish the message to all subscribers of this topic asynchronously
publish(Object) - Method in interface org.redisson.api.RTopicRx
Publish the message to all subscribers of this topic asynchronously
PUBLISH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
publish(Object) - Method in class org.redisson.RedissonTopic
 
publishAsync(Object) - Method in interface org.redisson.api.RTopicAsync
Publish the message to all subscribers of this topic asynchronously
publishAsync(Object) - Method in class org.redisson.RedissonTopic
 
PublisherAdder<V> - Class in org.redisson.reactive
 
PublisherAdder() - Constructor for class org.redisson.reactive.PublisherAdder
 
PublisherAdder<V> - Class in org.redisson.rx
 
PublisherAdder() - Constructor for class org.redisson.rx.PublisherAdder
 
PublishSubscribeService - Class in org.redisson.pubsub
 
PublishSubscribeService(ConnectionManager, MasterSlaveServersConfig) - Constructor for class org.redisson.pubsub.PublishSubscribeService
 
pubSub - Variable in class org.redisson.RedissonLock
 
PUBSUB_COMMANDS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
PUBSUB_NUMSUB - Static variable in interface org.redisson.client.protocol.RedisCommands
 
PubSubConnectionEntry - Class in org.redisson.pubsub
 
PubSubConnectionEntry(RedisPubSubConnection, int) - Constructor for class org.redisson.pubsub.PubSubConnectionEntry
 
PubSubConnectionPool - Class in org.redisson.connection.pool
Connection pool for Publish / Subscribe
PubSubConnectionPool(MasterSlaveServersConfig, ConnectionManager, MasterSlaveEntry) - Constructor for class org.redisson.connection.pool.PubSubConnectionPool
 
PubSubEntry - Class in org.redisson.client.handler
 
PubSubEntry(MultiDecoder<Object>) - Constructor for class org.redisson.client.handler.PubSubEntry
 
PubSubEntry<E> - Interface in org.redisson
Nikita Koksharov
PubSubKey - Class in org.redisson.client.handler
 
PubSubKey(ChannelName, String) - Constructor for class org.redisson.client.handler.PubSubKey
 
PubSubMessage - Class in org.redisson.client.protocol.pubsub
 
PubSubMessage(ChannelName, Object) - Constructor for class org.redisson.client.protocol.pubsub.PubSubMessage
 
PubSubMessageDecoder - Class in org.redisson.client.protocol.pubsub
 
PubSubMessageDecoder(Decoder<Object>) - Constructor for class org.redisson.client.protocol.pubsub.PubSubMessageDecoder
 
PubSubMessageListener<V> - Class in org.redisson
 
PubSubMessageListener(Class<V>, MessageListener<V>, String) - Constructor for class org.redisson.PubSubMessageListener
 
PubSubPatternMessage - Class in org.redisson.client.protocol.pubsub
 
PubSubPatternMessage(ChannelName, ChannelName, Object) - Constructor for class org.redisson.client.protocol.pubsub.PubSubPatternMessage
 
PubSubPatternMessageDecoder - Class in org.redisson.client.protocol.pubsub
 
PubSubPatternMessageDecoder(Decoder<Object>) - Constructor for class org.redisson.client.protocol.pubsub.PubSubPatternMessageDecoder
 
PubSubPatternMessageListener<V> - Class in org.redisson
 
PubSubPatternMessageListener(Class<V>, PatternMessageListener<V>, String) - Constructor for class org.redisson.PubSubPatternMessageListener
 
PubSubPatternStatusListener - Class in org.redisson
 
PubSubPatternStatusListener(PatternStatusListener, String) - Constructor for class org.redisson.PubSubPatternStatusListener
 
PubSubStatusDecoder - Class in org.redisson.client.protocol.pubsub
 
PubSubStatusDecoder() - Constructor for class org.redisson.client.protocol.pubsub.PubSubStatusDecoder
 
PubSubStatusListener - Class in org.redisson
 
PubSubStatusListener(StatusListener, String) - Constructor for class org.redisson.PubSubStatusListener
 
PubSubStatusMessage - Class in org.redisson.client.protocol.pubsub
 
PubSubStatusMessage(PubSubType, ChannelName) - Constructor for class org.redisson.client.protocol.pubsub.PubSubStatusMessage
 
PubSubType - Enum in org.redisson.client.protocol.pubsub
 
PUNSUBSCRIBE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
punsubscribe(ChannelName...) - Method in class org.redisson.client.RedisPubSubConnection
 
punsubscribe(ChannelName, AsyncSemaphore) - Method in class org.redisson.pubsub.PublishSubscribeService
 
punsubscribe(ChannelName, RedisPubSubListener<?>) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
push(V) - Method in interface org.redisson.api.RDequeReactive
Adds element at the head of this deque.
push(V) - Method in interface org.redisson.api.RDequeRx
Adds element at the head of this deque.
push(V) - Method in class org.redisson.RedissonDeque
 
push(V) - Method in class org.redisson.RedissonPriorityDeque
 
pushAsync(V) - Method in interface org.redisson.api.RDequeAsync
Adds element at the head of this deque.
pushAsync(V) - Method in class org.redisson.RedissonDeque
 
pushAsync(V) - Method in class org.redisson.RedissonPriorityDeque
 
pushTaskAsync() - Method in class org.redisson.QueueTransferTask
 
put(K, V) - Method in interface org.redisson.api.CacheReactive
This method places the given value V in the cache and associates it with the given key K.
put(K, V) - Method in interface org.redisson.api.CacheRx
This method places the given value V in the cache and associates it with the given key K.
put(V) - Method in interface org.redisson.api.RBlockingQueueReactive
Inserts the specified element into this queue in async mode, waiting if necessary for space to become available.
put(V) - Method in interface org.redisson.api.RBlockingQueueRx
Inserts the specified element into this queue in async mode, waiting if necessary for space to become available.
put(K, V) - Method in interface org.redisson.api.RMap
Stores the specified value mapped by specified key.
put(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
Stores value mapped by key with specified time to live.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
Stores value mapped by key with specified time to live and max idle time.
put(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheReactive
Stores value mapped by key with specified time to live.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheReactive
Stores value mapped by key with specified time to live and max idle time.
put(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheRx
Stores value mapped by key with specified time to live.
put(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheRx
Stores value mapped by key with specified time to live and max idle time.
put(K, V) - Method in interface org.redisson.api.RMapReactive
Stores the specified value mapped by specified key.
put(K, V) - Method in interface org.redisson.api.RMapRx
Stores the specified value mapped by specified key.
put(K, V) - Method in interface org.redisson.api.RMultimap
Stores a key-value pair in this multimap.
put(K, V) - Method in interface org.redisson.api.RMultimapReactive
Stores a key-value pair in this multimap.
put(K, V) - Method in interface org.redisson.api.RMultimapRx
Stores a key-value pair in this multimap.
put(K, V) - Method in class org.redisson.cache.AbstractCacheMap
 
put(Map.Entry<Object, Object>, Object) - Method in class org.redisson.iterator.RedissonBaseMapIterator
 
put(Map.Entry<Object, Object>, Object) - Method in class org.redisson.iterator.RedissonMapIterator
 
put(K, V) - Method in class org.redisson.jcache.JCache
 
put(K, V) - Method in class org.redisson.misc.BiHashMap
 
put(V) - Method in class org.redisson.RedissonBlockingDeque
 
put(V) - Method in class org.redisson.RedissonBlockingQueue
 
put(V) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
put(K, V) - Method in class org.redisson.RedissonListMultimap
 
put(K, V) - Method in class org.redisson.RedissonMap
 
put(K, V, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
put(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
put(K, V) - Method in class org.redisson.RedissonMultimap
 
put(V) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
put(V) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
put(V) - Method in class org.redisson.RedissonTransferQueue
 
put(Object, Object) - Method in class org.redisson.spring.cache.RedissonCache
 
putAll(Map<? extends K, ? extends V>) - Method in interface org.redisson.api.CacheReactive
This method copies all of the entries from the given Map to the CacheReactive.
putAll(Map<? extends K, ? extends V>) - Method in interface org.redisson.api.CacheRx
This method copies all of the entries from the given Map to the CacheRx.
putAll(Map<? extends K, ? extends V>) - Method in interface org.redisson.api.RMap
Stores map entries specified in map object in batch mode.
putAll(Map<? extends K, ? extends V>, int) - Method in interface org.redisson.api.RMap
Stores map entries specified in map object in batch mode.
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
Associates the specified value with the specified key in batch.
putAll(Map<? extends K, ? extends V>) - Method in interface org.redisson.api.RMapReactive
Stores map entries specified in map object in batch mode.
putAll(Map<? extends K, ? extends V>) - Method in interface org.redisson.api.RMapRx
Stores map entries specified in map object in batch mode.
putAll(K, Iterable<? extends V>) - Method in interface org.redisson.api.RMultimap
Stores a key-value pair in this multimap for each of values, all using the same key, key.
putAll(K, Iterable<? extends V>) - Method in interface org.redisson.api.RMultimapReactive
Stores a key-value pair in this multimap for each of values, all using the same key, key.
putAll(K, Iterable<? extends V>) - Method in interface org.redisson.api.RMultimapRx
Stores a key-value pair in this multimap for each of values, all using the same key, key.
putAll(Map<? extends K, ? extends V>) - Method in class org.redisson.cache.AbstractCacheMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.redisson.jcache.JCache
 
putAll(Map<? extends K, ? extends V>) - Method in class org.redisson.misc.BiHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.redisson.RedissonMap
 
putAll(Map<? extends K, ? extends V>, int) - Method in class org.redisson.RedissonMap
 
putAll(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
putAll(K, Iterable<? extends V>) - Method in class org.redisson.RedissonMultimap
 
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.redisson.api.CacheAsync
This method copies all of the entries from the given Map to the CacheAsync.
putAllAsync(Map<? extends K, ? extends V>) - Method in interface org.redisson.api.RMapAsync
Stores map entries specified in map object in batch mode.
putAllAsync(Map<? extends K, ? extends V>, int) - Method in interface org.redisson.api.RMapAsync
Stores map entries specified in map object in batch mode.
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
Associates the specified value with the specified key in batch.
putAllAsync(K, Iterable<? extends V>) - Method in interface org.redisson.api.RMultimapAsync
Stores a key-value pair in this multimap for each of values, all using the same key, key.
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.redisson.jcache.JCache
 
putAllAsync(K, Iterable<? extends V>) - Method in class org.redisson.RedissonListMultimap
 
putAllAsync(Map<? extends K, ? extends V>, int) - Method in class org.redisson.RedissonMap
 
putAllAsync(Map<? extends K, ? extends V>) - Method in class org.redisson.RedissonMap
 
putAllAsync(Map<? extends K, ? extends V>, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
putAllAsync(K, Iterable<? extends V>) - Method in class org.redisson.RedissonSetMultimap
 
putAllOperationAsync(Map<? extends K, ? extends V>) - Method in class org.redisson.RedissonLocalCachedMap
 
putAllOperationAsync(Map<? extends K, ? extends V>) - Method in class org.redisson.RedissonMap
 
putAllOperationAsync(Map<? extends K, ? extends V>) - Method in class org.redisson.RedissonMapCache
 
putAllOperationAsync(Map<? extends K, ? extends V>) - Method in class org.redisson.transaction.BaseTransactionalMap
 
putAllOperationAsync(Map<? extends K, ? extends V>) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
putAllOperationAsync(Map<? extends K, ? extends V>) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
putAsync(K, V) - Method in interface org.redisson.api.CacheAsync
This method places the given value V in the cache and associates it with the given key K.
putAsync(V) - Method in interface org.redisson.api.RBlockingQueueAsync
Inserts the specified element into this queue in async mode, waiting if necessary for space to become available.
putAsync(K, V) - Method in interface org.redisson.api.RMapAsync
Stores the specified value mapped by specified key.
putAsync(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheAsync
Stores value mapped by key with specified time to live.
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheAsync
Stores value mapped by key with specified time to live and max idle time.
putAsync(K, V) - Method in interface org.redisson.api.RMultimapAsync
Stores a key-value pair in this multimap.
putAsync(K, V) - Method in class org.redisson.jcache.JCache
 
putAsync(V) - Method in class org.redisson.RedissonBlockingDeque
 
putAsync(V) - Method in class org.redisson.RedissonBlockingQueue
 
putAsync(V) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
putAsync(K, V) - Method in class org.redisson.RedissonListMultimap
 
putAsync(K, V) - Method in class org.redisson.RedissonMap
 
putAsync(K, V, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
putAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
putAsync(V) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
putAsync(V) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
putAsync(K, V) - Method in class org.redisson.RedissonSetMultimap
 
putAsync(V) - Method in class org.redisson.RedissonTransferQueue
 
putCount() - Method in class org.redisson.spring.cache.RedissonCacheMetrics
 
putFirst(V) - Method in interface org.redisson.api.RBlockingDequeReactive
Adds value to the head of queue.
putFirst(V) - Method in interface org.redisson.api.RBlockingDequeRx
Adds value to the head of queue.
putFirst(V) - Method in class org.redisson.RedissonBlockingDeque
 
putFirst(V) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
putFirstAsync(V) - Method in interface org.redisson.api.RBlockingDequeAsync
Adds value to the head of queue.
putFirstAsync(V) - Method in class org.redisson.RedissonBlockingDeque
 
putFirstAsync(V) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
putIfAbsent(K, V) - Method in interface org.redisson.api.CacheReactive
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.
putIfAbsent(K, V) - Method in interface org.redisson.api.CacheRx
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.
putIfAbsent(K, V) - Method in interface org.redisson.api.RMap
Stores the specified value mapped by specified key only if there is no value with specifiedkey stored before.
putIfAbsent(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCache
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheReactive
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheReactive
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheRx
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheRx
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsent(K, V) - Method in interface org.redisson.api.RMapReactive
Stores the specified value mapped by specified key only if there is no value with specifiedkey stored before.
putIfAbsent(K, V) - Method in interface org.redisson.api.RMapRx
Stores the specified value mapped by specified key only if there is no value with specifiedkey stored before.
putIfAbsent(K, V) - Method in class org.redisson.cache.AbstractCacheMap
 
putIfAbsent(K, V) - Method in class org.redisson.jcache.JCache
 
putIfAbsent(K, V) - Method in class org.redisson.RedissonMap
 
putIfAbsent(K, V, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
putIfAbsent(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
putIfAbsent(Object, Object) - Method in class org.redisson.spring.cache.RedissonCache
 
putIfAbsentAsync(K, V) - Method in interface org.redisson.api.CacheAsync
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.
putIfAbsentAsync(K, V) - Method in interface org.redisson.api.RMapAsync
Stores the specified value mapped by specified key only if there is no value with specifiedkey stored before.
putIfAbsentAsync(K, V, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheAsync
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RMapCacheAsync
If the specified key is not already associated with a value, associate it with the given value.
putIfAbsentAsync(K, V) - Method in class org.redisson.jcache.JCache
 
putIfAbsentAsync(K, V) - Method in class org.redisson.RedissonLocalCachedMap
 
putIfAbsentAsync(K, V) - Method in class org.redisson.RedissonMap
 
putIfAbsentAsync(K, V, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonMapCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.transaction.BaseTransactionalMapCache
 
putIfAbsentAsync(K, V, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
putIfAbsentOperationAsync(K, V) - Method in class org.redisson.RedissonMap
 
putIfAbsentOperationAsync(K, V) - Method in class org.redisson.RedissonMapCache
 
putIfAbsentOperationAsync(K, V) - Method in class org.redisson.transaction.BaseTransactionalMap
 
putIfAbsentOperationAsync(K, V, MapOperation) - Method in class org.redisson.transaction.BaseTransactionalMap
 
putIfAbsentOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
putIfAbsentOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
putLast(V) - Method in interface org.redisson.api.RBlockingDequeReactive
Adds value to the tail of queue.
putLast(V) - Method in interface org.redisson.api.RBlockingDequeRx
Adds value to the tail of queue.
putLast(V) - Method in class org.redisson.RedissonBlockingDeque
 
putLast(V) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
putLastAsync(V) - Method in interface org.redisson.api.RBlockingDequeAsync
Adds value to the tail of queue.
putLastAsync(V) - Method in class org.redisson.RedissonBlockingDeque
 
putLastAsync(V) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
putOperationAsync(K, V) - Method in class org.redisson.RedissonLocalCachedMap
 
putOperationAsync(K, V) - Method in class org.redisson.RedissonMap
 
putOperationAsync(K, V) - Method in class org.redisson.RedissonMapCache
 
putOperationAsync(K, V, long, long, long) - Method in class org.redisson.RedissonMapCache
 
putOperationAsync(K, V) - Method in class org.redisson.transaction.BaseTransactionalMap
 
putOperationAsync(K, V, MapOperation) - Method in class org.redisson.transaction.BaseTransactionalMap
 
putOperationAsync(K, V, long, long, long) - Method in class org.redisson.transaction.BaseTransactionalMapCache
 
putOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
putOperationAsync(K, V, long, long, long) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
putOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 

Q

QueueCommand - Interface in org.redisson.client.protocol
 
QueueCommandHolder - Class in org.redisson.client.protocol
 
QueueCommandHolder(QueueCommand, ChannelPromise) - Constructor for class org.redisson.client.protocol.QueueCommandHolder
 
queueSize() - Method in class org.redisson.pubsub.AsyncSemaphore
 
QueueTransferService - Class in org.redisson
 
QueueTransferService() - Constructor for class org.redisson.QueueTransferService
 
queueTransferService - Variable in class org.redisson.Redisson
 
QueueTransferTask - Class in org.redisson
 
QueueTransferTask(ConnectionManager) - Constructor for class org.redisson.QueueTransferTask
 
QueueTransferTask.TimeoutTask - Class in org.redisson
 
QUIT - Static variable in interface org.redisson.client.protocol.RedisCommands
 

R

radius(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radius(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Requires Redis 3.2.10 and higher.
radius(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeo
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radius(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count Requires Redis 3.2.10 and higher.
radius(V, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radius(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count Requires Redis 3.2.10 and higher.
radius(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeo
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radius(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder and limited by count Requires Redis 3.2.10 and higher.
radius(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radius(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Requires Redis 3.2.10 and higher.
radius(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoReactive
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radius(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count Requires Redis 3.2.10 and higher.
radius(V, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radius(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count Requires Redis 3.2.10 and higher.
radius(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoReactive
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radius(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radius(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radius(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Requires Redis 3.2.10 and higher.
radius(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoRx
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radius(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count Requires Redis 3.2.10 and higher.
radius(V, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radius(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count Requires Redis 3.2.10 and higher.
radius(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoRx
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radius(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radius(double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radius(double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radius(double, double, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radius(double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radius(V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radius(V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radius(V, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radius(V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusAsync(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radiusAsync(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Requires Redis 3.2.10 and higher.
radiusAsync(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoAsync
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radiusAsync(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Returns the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count Requires Redis 3.2.10 and higher.
radiusAsync(V, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radiusAsync(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count Requires Redis 3.2.10 and higher.
radiusAsync(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoAsync
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radiusAsync(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Returns the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Requires Redis 3.2.10 and higher.
radiusAsync(double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusAsync(double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusAsync(double, double, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusAsync(double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusAsync(V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusAsync(V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusAsync(V, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusAsync(V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedTo(String, double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radiusStoreSortedTo(String, double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count.
radiusStoreSortedTo(String, double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count.
radiusStoreSortedTo(String, V, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radiusStoreSortedTo(String, V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count.
radiusStoreSortedTo(String, V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Stores result to destName sorted by distance.
radiusStoreSortedTo(String, double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radiusStoreSortedTo(String, double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Stores result to destName sorted by distance.
radiusStoreSortedTo(String, double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count.
radiusStoreSortedTo(String, V, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radiusStoreSortedTo(String, V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count.
radiusStoreSortedTo(String, V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Stores result to destName sorted by distance.
radiusStoreSortedTo(String, double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radiusStoreSortedTo(String, double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Stores result to destName sorted by distance.
radiusStoreSortedTo(String, double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count.
radiusStoreSortedTo(String, V, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radiusStoreSortedTo(String, V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count.
radiusStoreSortedTo(String, V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Stores result to destName sorted by distance.
radiusStoreSortedTo(String, double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedTo(String, double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedTo(String, double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedTo(String, V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedTo(String, V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedTo(String, V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedToAsync(String, double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radiusStoreSortedToAsync(String, double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Stores result to destName sorted by distance.
radiusStoreSortedToAsync(String, double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count.
radiusStoreSortedToAsync(String, V, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radiusStoreSortedToAsync(String, V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count.
radiusStoreSortedToAsync(String, V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Stores result to destName sorted by distance.
radiusStoreSortedToAsync(String, double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedToAsync(String, double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedToAsync(String, double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedToAsync(String, V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedToAsync(String, V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreSortedToAsync(String, V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreTo(String, double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radiusStoreTo(String, double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Stores result to destName.
radiusStoreTo(String, double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count Stores result to destName.
radiusStoreTo(String, V, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radiusStoreTo(String, V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count Stores result to destName.
radiusStoreTo(String, V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Stores result to destName.
radiusStoreTo(String, double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radiusStoreTo(String, double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Store result to destName.
radiusStoreTo(String, double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count Store result to destName.
radiusStoreTo(String, V, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radiusStoreTo(String, V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count Store result to destName.
radiusStoreTo(String, V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Store result to destName.
radiusStoreTo(String, double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radiusStoreTo(String, double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count.
radiusStoreTo(String, double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count.
radiusStoreTo(String, V, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radiusStoreTo(String, V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count.
radiusStoreTo(String, V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder.
radiusStoreTo(String, double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusStoreTo(String, double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreTo(String, double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreTo(String, V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusStoreTo(String, V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreTo(String, V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreToAsync(String, double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units.
radiusStoreToAsync(String, double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units and limited by count Stores result to destName.
radiusStoreToAsync(String, double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the center location and the maximum distance from the center (the radius) in GeoUnit units with GeoOrder and limited by count.
radiusStoreToAsync(String, V, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units.
radiusStoreToAsync(String, V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units and limited by count.
radiusStoreToAsync(String, V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Finds the members of a sorted set, which are within the borders of the area specified with the defined member location and the maximum distance from the defined member location (the radius) in GeoUnit units with GeoOrder Stores result to destName.
radiusStoreToAsync(String, double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusStoreToAsync(String, double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreToAsync(String, double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreToAsync(String, V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusStoreToAsync(String, V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusStoreToAsync(String, V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusWithDistance(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeo
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(V, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeo
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoReactive
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(V, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoReactive
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoRx
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Returns the distance mapped by member, distance between member and the location.
radiusWithDistance(V, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoRx
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistance(double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusWithDistance(double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusWithDistance(double, double, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusWithDistance(double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusWithDistance(V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusWithDistance(V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusWithDistance(V, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusWithDistance(V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusWithDistanceAsync(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Returns the distance mapped by member, distance between member and the location.
radiusWithDistanceAsync(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Returns the distance mapped by member, distance between member and the location.
radiusWithDistanceAsync(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoAsync
Returns the distance mapped by member, distance between member and the location.
radiusWithDistanceAsync(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Returns the distance mapped by member, distance between member and the location.
radiusWithDistanceAsync(V, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistanceAsync(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistanceAsync(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoAsync
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistanceAsync(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Returns the distance mapped by member, distance between member and the defined member location.
radiusWithDistanceAsync(double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusWithDistanceAsync(double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusWithDistanceAsync(double, double, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusWithDistanceAsync(double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusWithDistanceAsync(V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusWithDistanceAsync(V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusWithDistanceAsync(V, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusWithDistanceAsync(V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusWithPosition(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeo
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit) - Method in interface org.redisson.api.RGeo
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeo
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeo
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeo
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoReactive
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit) - Method in interface org.redisson.api.RGeoReactive
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoReactive
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoReactive
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoReactive
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoRx
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit) - Method in interface org.redisson.api.RGeoRx
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoRx
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoRx
Returns the geo-position mapped by member.
radiusWithPosition(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoRx
Returns the geo-position mapped by member.
radiusWithPosition(double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusWithPosition(double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusWithPosition(double, double, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusWithPosition(double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusWithPosition(V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusWithPosition(V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusWithPosition(V, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusWithPosition(V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusWithPositionAsync(double, double, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Returns the geo-position mapped by member.
radiusWithPositionAsync(double, double, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Returns the geo-position mapped by member.
radiusWithPositionAsync(double, double, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoAsync
Returns the geo-position mapped by member.
radiusWithPositionAsync(double, double, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Returns the geo-position mapped by member.
radiusWithPositionAsync(V, double, GeoUnit) - Method in interface org.redisson.api.RGeoAsync
Returns the geo-position mapped by member.
radiusWithPositionAsync(V, double, GeoUnit, int) - Method in interface org.redisson.api.RGeoAsync
Returns the geo-position mapped by member.
radiusWithPositionAsync(V, double, GeoUnit, GeoOrder) - Method in interface org.redisson.api.RGeoAsync
Returns the geo-position mapped by member.
radiusWithPositionAsync(V, double, GeoUnit, GeoOrder, int) - Method in interface org.redisson.api.RGeoAsync
Returns the geo-position mapped by member.
radiusWithPositionAsync(double, double, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusWithPositionAsync(double, double, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusWithPositionAsync(double, double, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusWithPositionAsync(double, double, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
radiusWithPositionAsync(V, double, GeoUnit) - Method in class org.redisson.RedissonGeo
 
radiusWithPositionAsync(V, double, GeoUnit, int) - Method in class org.redisson.RedissonGeo
 
radiusWithPositionAsync(V, double, GeoUnit, GeoOrder) - Method in class org.redisson.RedissonGeo
 
radiusWithPositionAsync(V, double, GeoUnit, GeoOrder, int) - Method in class org.redisson.RedissonGeo
 
random() - Method in interface org.redisson.api.RSet
Returns random element
random(int) - Method in interface org.redisson.api.RSet
Returns random elements from set limited by count
random() - Method in interface org.redisson.api.RSetReactive
Returns random element
random(int) - Method in interface org.redisson.api.RSetReactive
Returns random elements from set limited by count
random() - Method in interface org.redisson.api.RSetRx
Returns random element
random(int) - Method in interface org.redisson.api.RSetRx
Returns random elements from set limited by count
random() - Method in class org.redisson.RedissonSet
 
random(int) - Method in class org.redisson.RedissonSet
 
random() - Method in class org.redisson.RedissonSetMultimapValues
 
random(int) - Method in class org.redisson.RedissonSetMultimapValues
 
RANDOM_KEY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
randomAsync() - Method in interface org.redisson.api.RSetAsync
Returns random element from set in async mode
randomAsync(int) - Method in interface org.redisson.api.RSetAsync
Returns random elements from set limited by count
randomAsync() - Method in class org.redisson.RedissonSet
 
randomAsync(int) - Method in class org.redisson.RedissonSet
 
randomAsync() - Method in class org.redisson.RedissonSetMultimapValues
 
randomAsync(int) - Method in class org.redisson.RedissonSetMultimapValues
 
randomKey() - Method in interface org.redisson.api.RKeys
Get random key
randomKey() - Method in interface org.redisson.api.RKeysReactive
Get random key Uses RANDOM_KEY Redis command.
randomKey() - Method in interface org.redisson.api.RKeysRx
Get random key Uses RANDOM_KEY Redis command.
randomKey() - Method in class org.redisson.RedissonKeys
 
randomKeyAsync() - Method in interface org.redisson.api.RKeysAsync
Get random key in async mode
randomKeyAsync() - Method in class org.redisson.RedissonKeys
 
RandomLoadBalancer - Class in org.redisson.connection.balancer
 
RandomLoadBalancer() - Constructor for class org.redisson.connection.balancer.RandomLoadBalancer
 
range(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Returns values range starting with fromElement and ending with toElement.
range(String, boolean, String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSet
Returns values range starting with fromElement and ending with toElement.
range(int, int) - Method in interface org.redisson.api.RLexSortedSet
Returns values by rank range.
range(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
Returns values range starting with fromElement and ending with toElement.
range(String, boolean, String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetReactive
Returns values range starting with fromElement and ending with toElement.
range(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetRx
Returns values range starting with fromElement and ending with toElement.
range(String, boolean, String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetRx
Returns values range starting with fromElement and ending with toElement.
range(int) - Method in interface org.redisson.api.RList
Returns range of values from 0 index to toIndex.
range(int, int) - Method in interface org.redisson.api.RList
Returns range of values from fromIndex to toIndex index including.
range(int) - Method in interface org.redisson.api.RListReactive
Returns range of values from 0 index to toIndex.
range(int, int) - Method in interface org.redisson.api.RListReactive
Returns range of values from fromIndex to toIndex index including.
range(int) - Method in interface org.redisson.api.RListRx
Returns range of values from 0 index to toIndex.
range(int, int) - Method in interface org.redisson.api.RListRx
Returns range of values from fromIndex to toIndex index including.
range(StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStream
Returns stream data in range by specified start Stream Message ID (included) and end Stream Message ID (included).
range(int, StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStream
Returns stream data in range by specified start Stream Message ID (included) and end Stream Message ID (included).
range(StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Returns stream data in range by specified start Stream ID (included) and end Stream ID (included).
range(int, StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Returns stream data in range by specified start Stream ID (included) and end Stream ID (included).
range(StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Returns stream data in range by specified start Stream ID (included) and end Stream ID (included).
range(int, StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Returns stream data in range by specified start Stream ID (included) and end Stream ID (included).
range(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
range(String, boolean, String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
range(int, int) - Method in class org.redisson.RedissonLexSortedSet
 
range(int) - Method in class org.redisson.RedissonList
 
range(int, int) - Method in class org.redisson.RedissonList
 
range(int) - Method in class org.redisson.RedissonListMultimapValues
 
range(int, int) - Method in class org.redisson.RedissonListMultimapValues
 
range(int, StreamMessageId, StreamMessageId) - Method in class org.redisson.RedissonStream
 
range(StreamMessageId, StreamMessageId) - Method in class org.redisson.RedissonStream
 
rangeAsync(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns values range starting with fromElement and ending with toElement.
rangeAsync(String, boolean, String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns values range starting with fromElement and ending with toElement.
rangeAsync(int, int) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns values by rank range.
rangeAsync(int) - Method in interface org.redisson.api.RListAsync
Returns range of values from 0 index to toIndex.
rangeAsync(int, int) - Method in interface org.redisson.api.RListAsync
Returns range of values from fromIndex to toIndex index including.
rangeAsync(StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Returns stream data in range by specified start Stream ID (included) and end Stream ID (included).
rangeAsync(int, StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Returns stream data in range by specified start Stream ID (included) and end Stream ID (included).
rangeAsync(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeAsync(String, boolean, String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeAsync(int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeAsync(int) - Method in class org.redisson.RedissonList
 
rangeAsync(int, int) - Method in class org.redisson.RedissonList
 
rangeAsync(int) - Method in class org.redisson.RedissonListMultimapValues
 
rangeAsync(int, int) - Method in class org.redisson.RedissonListMultimapValues
 
rangeAsync(int, StreamMessageId, StreamMessageId) - Method in class org.redisson.RedissonStream
 
rangeAsync(StreamMessageId, StreamMessageId) - Method in class org.redisson.RedissonStream
 
rangeHead(String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Returns head values range ending with toElement.
rangeHead(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSet
Returns head values range ending with toElement.
rangeHead(String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
Returns head values range ending with toElement.
rangeHead(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetReactive
Returns head values range ending with toElement.
rangeHead(String, boolean) - Method in interface org.redisson.api.RLexSortedSetRx
Returns head values range ending with toElement.
rangeHead(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetRx
Returns head values range ending with toElement.
rangeHead(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeHead(String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeHeadAsync(String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns head values range ending with toElement.
rangeHeadAsync(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns head values range ending with toElement.
rangeHeadAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeHeadAsync(String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeHeadReversed(String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Returns head values range in reverse order ending with toElement.
rangeHeadReversed(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSet
Returns head values range in reverse order ending with toElement.
rangeHeadReversed(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeHeadReversed(String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeHeadReversedAsync(String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns head values range in reverse order ending with toElement.
rangeHeadReversedAsync(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns head values range in reverse order ending with toElement.
rangeHeadReversedAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeHeadReversedAsync(String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeReversed(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Returns values range in reverse order starting with fromElement and ending with toElement.
rangeReversed(String, boolean, String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSet
Returns values range in reverse order starting with fromElement and ending with toElement.
rangeReversed(StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStream
Returns stream data in reverse order in range by specified start Stream Message ID (included) and end Stream Message ID (included).
rangeReversed(int, StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStream
Returns stream data in reverse order in range by specified start Stream Message ID (included) and end Stream Message ID (included).
rangeReversed(StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Returns stream data in reverse order in range by specified start Stream ID (included) and end Stream ID (included).
rangeReversed(int, StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Returns stream data in reverse order in range by specified start Stream ID (included) and end Stream ID (included).
rangeReversed(StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Returns stream data in reverse order in range by specified start Stream ID (included) and end Stream ID (included).
rangeReversed(int, StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Returns stream data in reverse order in range by specified start Stream ID (included) and end Stream ID (included).
rangeReversed(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeReversed(String, boolean, String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeReversed(int, StreamMessageId, StreamMessageId) - Method in class org.redisson.RedissonStream
 
rangeReversed(StreamMessageId, StreamMessageId) - Method in class org.redisson.RedissonStream
 
rangeReversedAsync(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns values range in reverse order starting with fromElement and ending with toElement.
rangeReversedAsync(String, boolean, String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns values range in reverse order starting with fromElement and ending with toElement.
rangeReversedAsync(StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Returns stream data in reverse order in range by specified start Stream ID (included) and end Stream ID (included).
rangeReversedAsync(int, StreamMessageId, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Returns stream data in reverse order in range by specified start Stream ID (included) and end Stream ID (included).
rangeReversedAsync(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeReversedAsync(String, boolean, String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeReversedAsync(int, StreamMessageId, StreamMessageId) - Method in class org.redisson.RedissonStream
 
rangeReversedAsync(StreamMessageId, StreamMessageId) - Method in class org.redisson.RedissonStream
 
rangeTail(String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Returns tail values range starting with fromElement.
rangeTail(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSet
Returns tail values range starting with fromElement.
rangeTail(String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
Returns tail values range starting with fromElement.
rangeTail(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetReactive
Returns tail values range starting with fromElement.
rangeTail(String, boolean) - Method in interface org.redisson.api.RLexSortedSetRx
Returns tail values range starting with fromElement.
rangeTail(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetRx
Returns tail values range starting with fromElement.
rangeTail(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeTail(String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeTailAsync(String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns tail values range starting with fromElement.
rangeTailAsync(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns tail values range starting with fromElement.
rangeTailAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeTailAsync(String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeTailReversed(String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Returns tail values range in reverse order starting with fromElement.
rangeTailReversed(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSet
Returns tail values range in reverse order starting with fromElement.
rangeTailReversed(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeTailReversed(String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rangeTailReversedAsync(String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns tail values range in reverse order starting with fromElement.
rangeTailReversedAsync(String, boolean, int, int) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns tail values range in reverse order starting with fromElement.
rangeTailReversedAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
rangeTailReversedAsync(String, boolean, int, int) - Method in class org.redisson.RedissonLexSortedSet
 
rank(String) - Method in interface org.redisson.api.RLexSortedSet
Returns rank of the element
rank(V) - Method in interface org.redisson.api.RScoredSortedSet
Returns rank of value, with the scores ordered from low to high.
rank(V) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns rank of value, with the scores ordered from low to high.
rank(V) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns rank of value, with the scores ordered from low to high.
rank(V) - Method in class org.redisson.RedissonScoredSortedSet
 
rankAsync(String) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns rank of the element
rankAsync(V) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns rank of value, with the scores ordered from low to high.
rankAsync(V) - Method in class org.redisson.RedissonScoredSortedSet
 
RateIntervalUnit - Enum in org.redisson.api
 
RateLimiterConfig - Class in org.redisson.api
 
RateLimiterConfig(RateType, Long, Long) - Constructor for class org.redisson.api.RateLimiterConfig
 
RateType - Enum in org.redisson.api
 
RAtomicDouble - Interface in org.redisson.api
Distributed implementation to the AtomicDouble
RAtomicDoubleAsync - Interface in org.redisson.api
Distributed implementation to the AtomicDouble
RAtomicDoubleReactive - Interface in org.redisson.api
Reactive interface for AtomicDouble object
RAtomicDoubleRx - Interface in org.redisson.api
Reactive interface for AtomicDouble object
RAtomicLong - Interface in org.redisson.api
Distributed implementation of AtomicLong
RAtomicLongAsync - Interface in org.redisson.api
Distributed async implementation of AtomicLong
RAtomicLongReactive - Interface in org.redisson.api
Reactive interface for AtomicLong object
RAtomicLongRx - Interface in org.redisson.api
RxJava2 interface for AtomicLong object
RBatch - Interface in org.redisson.api
Interface for using Redis pipeline feature.
RBatchReactive - Interface in org.redisson.api
Reactive interface for Redis pipeline feature.
RBatchRx - Interface in org.redisson.api
RxJava2 interface for Redis pipeline feature.
RBinaryStream - Interface in org.redisson.api
Binary stream holder stores a sequence of bytes.
RBinaryStreamReactive - Interface in org.redisson.api
Binary stream holder stores a sequence of bytes.
RBinaryStreamRx - Interface in org.redisson.api
Binary stream holder stores a sequence of bytes.
RBitSet - Interface in org.redisson.api
Vector of bits that grows as needed.
RBitSetAsync - Interface in org.redisson.api
Vector of bits that grows as needed.
RBitSetReactive - Interface in org.redisson.api
Reactive interface for BitSet object
RBitSetRx - Interface in org.redisson.api
RxJava2 interface for BitSet object
RBlockingDeque<V> - Interface in org.redisson.api
BlockingDeque backed by Redis
RBlockingDequeAsync<V> - Interface in org.redisson.api
Distributed async implementation of BlockingDeque
RBlockingDequeReactive<V> - Interface in org.redisson.api
Reactive interface for Redis based BlockingDeque object
RBlockingDequeRx<V> - Interface in org.redisson.api
RxJava2 interface for Redis based BlockingDeque object
RBlockingQueue<V> - Interface in org.redisson.api
Distributed implementation of BlockingQueue
RBlockingQueueAsync<V> - Interface in org.redisson.api
Distributed async implementation of BlockingQueue
RBlockingQueueReactive<V> - Interface in org.redisson.api
Reactive interface for BlockingQueue object
RBlockingQueueRx<V> - Interface in org.redisson.api
RxJava2 interface for BlockingQueue
RBloomFilter<T> - Interface in org.redisson.api
Distributed implementation of Bloom filter based on Highway 128-bit hash.
RBoundedBlockingQueue<V> - Interface in org.redisson.api
Distributed implementation of bounded BlockingQueue
RBoundedBlockingQueueAsync<V> - Interface in org.redisson.api
Distributed async implementation of bounded BlockingQueue
RBucket<V> - Interface in org.redisson.api
Object holder.
RBucketAsync<V> - Interface in org.redisson.api
Async implementation of object holder.
RBucketReactive<V> - Interface in org.redisson.api
Reactive implementation of object holder.
RBucketRx<V> - Interface in org.redisson.api
Reactive implementation of object holder.
RBuckets - Interface in org.redisson.api
Operations over multiple Bucket objects.
RBucketsAsync - Interface in org.redisson.api
Operations over multiple Bucket objects.
RBucketsReactive - Interface in org.redisson.api
Operations over multiple Bucket objects.
RBucketsRx - Interface in org.redisson.api
Operations over multiple Bucket objects.
RCascade - Annotation Type in org.redisson.api.annotation
Specifies that the defined cascade types are applied to the object/objects contained in Live Object field.
RCascadeType - Enum in org.redisson.api
Live Object cascade type.
RCollator<K,V,R> - Interface in org.redisson.api.mapreduce
Collates result from RReducer tasks and produces a single result object.
RCollectionAsync<V> - Interface in org.redisson.api
Common async interface for collection object
RCollectionMapper<VIn,KOut,VOut> - Interface in org.redisson.api.mapreduce
Mapper task invoked during map phase of MapReduce process and launched across Redisson Nodes.
RCollectionMapReduce<VIn,KOut,VOut> - Interface in org.redisson.api.mapreduce
MapReduce allows to process large amount of data stored in RSet, RList, RSetCache, RScoredSortedSet, RSortedSet and others using Mapper, Reducer and/or Collator tasks launched across Redisson Nodes.
RCollectionReactive<V> - Interface in org.redisson.api
Common reactive interface for collection object
RCollectionRx<V> - Interface in org.redisson.api
Common RxJava2 interface for collection object
RCollector<K,V> - Interface in org.redisson.api.mapreduce
Stores each key/value mapping during map phase of MapReduce process.
RCountDownLatch - Interface in org.redisson.api
Redis based implementation of CountDownLatch It has an advantage over CountDownLatch -- count can be set via RCountDownLatch.trySetCount(long) method.
RCountDownLatchAsync - Interface in org.redisson.api
Async interface of Redis based CountDownLatch It has an advantage over CountDownLatch -- count can be set via RCountDownLatchAsync.trySetCountAsync(long) method.
RCountDownLatchReactive - Interface in org.redisson.api
Reactive interface of Redis based CountDownLatch It has an advantage over CountDownLatch -- count can be set via RCountDownLatchReactive.trySetCount(long) method.
RCountDownLatchRx - Interface in org.redisson.api
RxJava2 interface of Redis based CountDownLatch It has an advantage over CountDownLatch -- count can be set via RCountDownLatchRx.trySetCount(long) method.
RDelayedQueue<V> - Interface in org.redisson.api
Distributed implementation of delayed queue.
RDeque<V> - Interface in org.redisson.api
Distributed implementation of Deque
RDequeAsync<V> - Interface in org.redisson.api
Distributed async implementation of Deque
RDequeReactive<V> - Interface in org.redisson.api
Reactive interface for Deque object
RDequeRx<V> - Interface in org.redisson.api
RxJava2 interface for Deque object
RDestroyable - Interface in org.redisson.api
All objects that implement this interface should be destroyed via RDestroyable.destroy() method.
RDoubleAdder - Interface in org.redisson.api
Distributed implementation of DoubleAdder Internal state maintained on client side.
reactive(Callable<RFuture<R>>) - Method in class org.redisson.reactive.CommandReactiveBatchService
 
reactive(Callable<RFuture<R>>) - Method in interface org.redisson.reactive.CommandReactiveExecutor
 
reactive(Callable<RFuture<R>>) - Method in class org.redisson.reactive.CommandReactiveService
 
ReactiveProxyBuilder - Class in org.redisson.reactive
 
ReactiveProxyBuilder() - Constructor for class org.redisson.reactive.ReactiveProxyBuilder
 
ReactiveRedissonResourceHolder - Class in org.redisson.spring.transaction
 
ReactiveRedissonResourceHolder() - Constructor for class org.redisson.spring.transaction.ReactiveRedissonResourceHolder
 
ReactiveRedissonSessionRepository - Class in org.redisson.spring.session
 
ReactiveRedissonSessionRepository(RedissonClient, ApplicationEventPublisher, String) - Constructor for class org.redisson.spring.session.ReactiveRedissonSessionRepository
 
ReactiveRedissonTransactionManager - Class in org.redisson.spring.transaction
 
ReactiveRedissonTransactionManager(RedissonReactiveClient) - Constructor for class org.redisson.spring.transaction.ReactiveRedissonTransactionManager
 
ReactiveRedissonTransactionObject - Class in org.redisson.spring.transaction
 
ReactiveRedissonTransactionObject() - Constructor for class org.redisson.spring.transaction.ReactiveRedissonTransactionObject
 
ReactiveRemoteProxy - Class in org.redisson.remote
 
ReactiveRemoteProxy(CommandAsyncExecutor, String, String, ConcurrentMap<String, ResponseEntry>, Codec, String, String, BaseRemoteService) - Constructor for class org.redisson.remote.ReactiveRemoteProxy
 
read(ByteBuffer) - Method in interface org.redisson.api.RBinaryStreamReactive
Reads a sequence of bytes into defined buffer.
read(ByteBuffer) - Method in interface org.redisson.api.RBinaryStreamRx
Reads a sequence of bytes into defined buffer.
read(StreamMessageId...) - Method in interface org.redisson.api.RStream
Read stream data by specified collection of Stream Message IDs.
read(int, StreamMessageId...) - Method in interface org.redisson.api.RStream
Read stream data by specified collection of Stream Message IDs.
read(long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStream
Read stream data by specified collection of Stream Message IDs.
read(int, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStream
Read stream data by specified collection of Stream Message IDs.
read(StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data by specified stream name including this stream.
read(StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data by specified stream names including this stream.
read(StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStream
Read stream data by specified Stream Message ID mapped by name including this stream.
read(int, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data by specified stream name including this stream.
read(int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data by specified stream names including this stream.
read(int, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStream
Read stream data by specified Stream Message ID mapped by name including this stream.
read(long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data by specified stream name including this stream.
read(long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data by specified stream names including this stream.
read(long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStream
Read stream data by specified Stream Message ID mapped by name including this stream.
read(int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data by specified stream name including this stream.
read(int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data by specified stream names including this stream.
read(int, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStream
Read stream data by specified Stream Message ID mapped by name including this stream.
read(StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified collection of Stream IDs.
read(int, StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified collection of Stream IDs.
read(long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified collection of Stream IDs.
read(int, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified collection of Stream IDs.
read(StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream name including this stream.
read(StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream names including this stream.
read(StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream id mapped by name including this stream.
read(int, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream name including this stream.
read(int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream names including this stream.
read(int, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream id mapped by name including this stream.
read(long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream name including this stream.
read(long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream names including this stream.
read(long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream id mapped by name including this stream.
read(int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream name including this stream.
read(int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream names including this stream.
read(int, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamReactive
Read stream data by specified stream id mapped by name including this stream.
read(StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified collection of Stream IDs.
read(int, StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified collection of Stream IDs.
read(long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified collection of Stream IDs.
read(int, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified collection of Stream IDs.
read(StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream name including this stream.
read(StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream names including this stream.
read(StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream id mapped by name including this stream.
read(int, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream name including this stream.
read(int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream names including this stream.
read(int, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream id mapped by name including this stream.
read(long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream name including this stream.
read(long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream names including this stream.
read(long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream id mapped by name including this stream.
read(int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream name including this stream.
read(int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream names including this stream.
read(int, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamRx
Read stream data by specified stream id mapped by name including this stream.
read() - Method in class org.redisson.codec.MarshallingCodec.ByteInputWrapper
 
read(byte[]) - Method in class org.redisson.codec.MarshallingCodec.ByteInputWrapper
 
read(byte[], int, int) - Method in class org.redisson.codec.MarshallingCodec.ByteInputWrapper
 
read(String, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandSyncExecutor
 
read(String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandSyncExecutor
 
read(String, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandSyncService
 
read(String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandSyncService
 
read(ByteBuffer) - Method in class org.redisson.reactive.RedissonBinaryStreamReactive
 
read(ByteBuffer, A, CompletionHandler<Integer, ? super A>) - Method in class org.redisson.RedissonBinaryStream.RedissonAsynchronousByteChannel
 
read(ByteBuffer) - Method in class org.redisson.RedissonBinaryStream.RedissonAsynchronousByteChannel
 
read(StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
read(int, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
read(int, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
read(long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
read(StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
read(StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
read(int, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
read(int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
read(long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
read(long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
read(int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
read(int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
read(int, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
read(int, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
read(StreamMessageId...) - Method in class org.redisson.RedissonStream
 
read(long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
read(ByteBuffer) - Method in class org.redisson.rx.RedissonBinaryStreamRx
 
READ_UNLOCK_MESSAGE - Static variable in class org.redisson.pubsub.LockPubSub
 
readAll() - Method in interface org.redisson.api.RList
Read all elements at once
readAll() - Method in interface org.redisson.api.RListReactive
Read all elements at once
readAll() - Method in interface org.redisson.api.RListRx
Read all elements at once
readAll() - Method in interface org.redisson.api.RPriorityQueue
Returns all queue elements at once
readAll() - Method in interface org.redisson.api.RQueue
Returns all queue elements at once
readAll() - Method in interface org.redisson.api.RQueueReactive
Returns all queue elements at once
readAll() - Method in interface org.redisson.api.RQueueRx
Returns all queue elements at once
readAll() - Method in interface org.redisson.api.RScoredSortedSet
Read all values at once.
readAll() - Method in interface org.redisson.api.RScoredSortedSetReactive
Read all values at once.
readAll() - Method in interface org.redisson.api.RScoredSortedSetRx
Read all values at once.
readAll() - Method in interface org.redisson.api.RSet
Read all elements at once
readAll() - Method in interface org.redisson.api.RSetCache
Read all elements at once
readAll() - Method in interface org.redisson.api.RSetCacheReactive
Read all elements at once
readAll() - Method in interface org.redisson.api.RSetCacheRx
Read all elements at once
readAll() - Method in interface org.redisson.api.RSetReactive
Read all elements at once
readAll() - Method in interface org.redisson.api.RSetRx
Read all elements at once
readAll() - Method in interface org.redisson.api.RSortedSet
 
readAll() - Method in interface org.redisson.api.RTransferQueue
Returns all queue elements at once
readAll() - Method in interface org.redisson.api.RTransferQueueAsync
Returns all queue elements at once
readAll() - Method in class org.redisson.RedissonDelayedQueue
 
readAll() - Method in class org.redisson.RedissonList
 
readAll() - Method in class org.redisson.RedissonListMultimapValues
 
readAll() - Method in class org.redisson.RedissonScoredSortedSet
 
readAll() - Method in class org.redisson.RedissonSet
 
readAll() - Method in class org.redisson.RedissonSetCache
 
readAll() - Method in class org.redisson.RedissonSetMultimapValues
 
readAll() - Method in class org.redisson.RedissonSortedSet
 
readAll() - Method in class org.redisson.RedissonTransferQueue
 
readAllAsync() - Method in interface org.redisson.api.RLexSortedSetAsync
Read all values at once.
readAllAsync() - Method in interface org.redisson.api.RListAsync
Read all elements at once
readAllAsync() - Method in interface org.redisson.api.RQueueAsync
Returns all queue elements at once
readAllAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Read all values at once.
readAllAsync() - Method in interface org.redisson.api.RSetAsync
Read all elements at once
readAllAsync() - Method in interface org.redisson.api.RSetCacheAsync
Read all elements at once
readAllAsync() - Method in interface org.redisson.api.RSortedSet
 
readAllAsync(Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAllAsync(RedisCommand<T>, SlotCallback<T, R>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAllAsync(Collection<R>, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAllAsync(RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAllAsync(Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAllAsync(RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAllAsync(Collection<R>, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAllAsync(RedisCommand<T>, SlotCallback<T, R>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAllAsync() - Method in class org.redisson.RedissonDelayedQueue
 
readAllAsync() - Method in class org.redisson.RedissonList
 
readAllAsync() - Method in class org.redisson.RedissonListMultimapValues
 
readAllAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
readAllAsync() - Method in class org.redisson.RedissonSet
 
readAllAsync() - Method in class org.redisson.RedissonSetCache
 
readAllAsync() - Method in class org.redisson.RedissonSetMultimapValues
 
readAllAsync() - Method in class org.redisson.RedissonSortedSet
 
readAllAsync() - Method in class org.redisson.RedissonSubList
 
readAllAsync() - Method in class org.redisson.RedissonTransferQueue
 
readAllAsync() - Method in class org.redisson.transaction.BaseTransactionalSet
 
readAllAsync() - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readAllAsync() - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
readAllAsyncSource() - Method in class org.redisson.transaction.BaseTransactionalSet
 
readAllAsyncSource() - Method in class org.redisson.transaction.TransactionalSet
 
readAllAsyncSource() - Method in class org.redisson.transaction.TransactionalSetCache
 
readAllEntrySet() - Method in interface org.redisson.api.RMap
Read all map entries at once
readAllEntrySet() - Method in interface org.redisson.api.RMapReactive
Read all map entries at once
readAllEntrySet() - Method in interface org.redisson.api.RMapRx
Read all map entries at once
readAllEntrySet() - Method in class org.redisson.RedissonMap
 
readAllEntrySetAsync() - Method in interface org.redisson.api.RMapAsync
Read all map entries at once
readAllEntrySetAsync() - Method in class org.redisson.RedissonLocalCachedMap
 
readAllEntrySetAsync() - Method in class org.redisson.RedissonMap
 
readAllEntrySetAsync() - Method in class org.redisson.RedissonMapCache
 
readAllEntrySetAsync() - Method in class org.redisson.transaction.BaseTransactionalMap
 
readAllEntrySetAsync() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
readAllEntrySetAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
readAllKeySet() - Method in interface org.redisson.api.RMap
Read all keys at once
readAllKeySet() - Method in interface org.redisson.api.RMapReactive
Read all keys at once
readAllKeySet() - Method in interface org.redisson.api.RMapRx
Read all keys at once
readAllKeySet() - Method in interface org.redisson.api.RMultimap
Read all keys at once
readAllKeySet() - Method in interface org.redisson.api.RMultimapReactive
Read all keys at once
readAllKeySet() - Method in interface org.redisson.api.RMultimapRx
Read all keys at once
readAllKeySet() - Method in class org.redisson.RedissonMap
 
readAllKeySet() - Method in class org.redisson.RedissonMultimap
 
readAllKeySetAsync() - Method in interface org.redisson.api.RMapAsync
Read all keys at once
readAllKeySetAsync() - Method in interface org.redisson.api.RMultimapAsync
Read all keys at once
readAllKeySetAsync() - Method in class org.redisson.RedissonMap
 
readAllKeySetAsync() - Method in class org.redisson.RedissonMapCache
 
readAllKeySetAsync() - Method in class org.redisson.RedissonMultimap
 
readAllKeySetAsync() - Method in class org.redisson.transaction.BaseTransactionalMap
 
readAllKeySetAsync() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
readAllKeySetAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
readAllMap() - Method in interface org.redisson.api.RMap
Read all map as local instance at once
readAllMap() - Method in interface org.redisson.api.RMapReactive
Read all map as local instance at once
readAllMap() - Method in interface org.redisson.api.RMapRx
Read all map as local instance at once
readAllMap() - Method in class org.redisson.RedissonMap
 
readAllMapAsync() - Method in interface org.redisson.api.RMapAsync
Read all map as local instance at once
readAllMapAsync() - Method in class org.redisson.RedissonLocalCachedMap
 
readAllMapAsync() - Method in class org.redisson.RedissonMap
 
readAllMapAsync() - Method in class org.redisson.RedissonMapCache
 
readAllMapAsync() - Method in class org.redisson.transaction.BaseTransactionalMap
 
readAllMapAsync() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
readAllMapAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
readAllValues() - Method in interface org.redisson.api.RMap
Read all values at once
readAllValues() - Method in interface org.redisson.api.RMapReactive
Read all values at once
readAllValues() - Method in interface org.redisson.api.RMapRx
Read all values at once
readAllValues() - Method in class org.redisson.RedissonMap
 
readAllValuesAsync() - Method in interface org.redisson.api.RMapAsync
Read all values at once
readAllValuesAsync() - Method in class org.redisson.RedissonLocalCachedMap
 
readAllValuesAsync() - Method in class org.redisson.RedissonMap
 
readAllValuesAsync() - Method in class org.redisson.RedissonMapCache
 
readAllValuesAsync() - Method in class org.redisson.transaction.BaseTransactionalMap
 
readAllValuesAsync() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
readAllValuesAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
readAsync(StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified collection of Stream IDs.
readAsync(int, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified collection of Stream IDs.
readAsync(long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified collection of Stream IDs.
readAsync(int, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified collection of Stream IDs.
readAsync(StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream name including this stream.
readAsync(StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream names including this stream.
readAsync(StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream id mapped by name including this stream.
readAsync(int, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream name including this stream.
readAsync(int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream names including this stream.
readAsync(int, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream id mapped by name including this stream.
readAsync(long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream name including this stream.
readAsync(long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream names including this stream.
readAsync(long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream id mapped by name including this stream.
readAsync(int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream name including this stream.
readAsync(int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream names including this stream.
readAsync(int, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamAsync
Read stream data by specified stream id mapped by name including this stream.
readAsync(RedisClient, MasterSlaveEntry, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAsync(RedisClient, String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAsync(RedisClient, byte[], Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAsync(RedisClient, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAsync(byte[], Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAsync(String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAsync(String, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAsync(MasterSlaveEntry, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readAsync(RedisClient, MasterSlaveEntry, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAsync(RedisClient, String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAsync(RedisClient, byte[], Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAsync(RedisClient, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAsync(String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAsync(byte[], Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAsync(MasterSlaveEntry, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAsync(String, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readAsync(StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readAsync(int, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readAsync(int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readAsync(int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readAsync(long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readAsync(StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readAsync(StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readAsync(int, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readAsync(int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readAsync(long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readAsync(long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readAsync(int, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readAsync(int, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readAsync(int, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readAsync(StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readAsync(long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readBatchedAsync(Codec, RedisCommand<T>, SlotCallback<T, R>, String...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readBatchedAsync(Codec, RedisCommand<T>, SlotCallback<T, R>, String...) - Method in class org.redisson.command.CommandAsyncService
 
readDiff(String...) - Method in interface org.redisson.api.RSet
Diff sets specified by name with current set.
readDiff(String...) - Method in interface org.redisson.api.RSetReactive
Diff sets specified by name with current set.
readDiff(String...) - Method in interface org.redisson.api.RSetRx
Diff sets specified by name with current set.
readDiff(String...) - Method in class org.redisson.RedissonSet
 
readDiff(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
readDiffAsync(String...) - Method in interface org.redisson.api.RSetAsync
Diff sets specified by name with current set.
readDiffAsync(String...) - Method in class org.redisson.RedissonSet
 
readDiffAsync(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
readDiffAsync(String...) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readDiffAsync(String...) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readGroup(String, String, StreamMessageId...) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName and specified collection of Stream Message IDs.
readGroup(String, String, int, StreamMessageId...) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName and specified collection of Stream Message IDs.
readGroup(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName and specified collection of Stream Message IDs.
readGroup(String, String, int, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName and specified collection of Stream Message IDs.
readGroup(String, String, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStream
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroup(String, String, int, StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroup(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroup(String, String, int, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroup(String, String, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroup(String, String, int, StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroup(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroup(String, String, int, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroup(String, String, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroup(String, String, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, int, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, int, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, int, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, int, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readGroup(String, String, int, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroupAsync(String, String, int, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroupAsync(String, String, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroupAsync(String, String, int, long, TimeUnit, StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName and specified collection of Stream IDs.
readGroupAsync(String, String, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, int, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, int, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Read stream data from groupName by consumerName, starting by specified message ids for this and other streams.
readGroupAsync(String, String, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, int, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, int, long, TimeUnit, StreamMessageId...) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, int, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, int, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, int, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, int, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, long, TimeUnit, StreamMessageId, String, StreamMessageId, String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
readGroupAsync(String, String, int, long, TimeUnit, StreamMessageId, Map<String, StreamMessageId>) - Method in class org.redisson.RedissonStream
 
readIntersection(String...) - Method in interface org.redisson.api.RSet
Intersection sets specified by name with current set without current set state change.
readIntersection(String...) - Method in interface org.redisson.api.RSetReactive
Intersection sets specified by name with current set.
readIntersection(String...) - Method in interface org.redisson.api.RSetRx
Intersection sets specified by name with current set.
readIntersection(String...) - Method in class org.redisson.RedissonSet
 
readIntersection(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
readIntersectionAsync(String...) - Method in interface org.redisson.api.RSetAsync
Intersection sets specified by name with current set.
readIntersectionAsync(String...) - Method in class org.redisson.RedissonSet
 
readIntersectionAsync(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
readIntersectionAsync(String...) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readIntersectionAsync(String...) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readLock() - Method in interface org.redisson.api.RReadWriteLock
Returns the lock used for reading.
readLock() - Method in interface org.redisson.api.RReadWriteLockReactive
Returns the lock used for reading.
readLock() - Method in interface org.redisson.api.RReadWriteLockRx
Returns the lock used for reading.
readLock() - Method in class org.redisson.reactive.RedissonReadWriteLockReactive
 
readLock() - Method in class org.redisson.RedissonReadWriteLock
 
readLock() - Method in class org.redisson.rx.RedissonReadWriteLockRx
 
ReadMode - Enum in org.redisson.config
 
READONLY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
readRandomAsync(Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readRandomAsync(MasterSlaveEntry, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
readRandomAsync(Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readRandomAsync(MasterSlaveEntry, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
readSort(SortOrder) - Method in interface org.redisson.api.RSortable
Read data in sorted view
readSort(SortOrder, int, int) - Method in interface org.redisson.api.RSortable
Read data in sorted view
readSort(String, SortOrder) - Method in interface org.redisson.api.RSortable
Read data in sorted view
readSort(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortable
Read data in sorted view
readSort(String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortable
Read data in sorted view
readSort(String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortable
Read data in sorted view
readSort(SortOrder) - Method in class org.redisson.RedissonList
 
readSort(SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSort(String, SortOrder) - Method in class org.redisson.RedissonList
 
readSort(String, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSort(String, List<String>, SortOrder) - Method in class org.redisson.RedissonList
 
readSort(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSort(SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSort(SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSort(String, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSort(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSort(String, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSort(String, List<String>, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSort(SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSort(SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSort(String, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSort(String, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSort(String, List<String>, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSort(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSort(SortOrder) - Method in class org.redisson.RedissonSet
 
readSort(SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSort(String, SortOrder) - Method in class org.redisson.RedissonSet
 
readSort(String, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSort(String, List<String>, SortOrder) - Method in class org.redisson.RedissonSet
 
readSort(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSort(SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSort(SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSort(String, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSort(String, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSort(String, List<String>, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSort(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlpha(SortOrder) - Method in interface org.redisson.api.RSortable
Read data in sorted view lexicographically
readSortAlpha(SortOrder, int, int) - Method in interface org.redisson.api.RSortable
Read data in sorted view lexicographically
readSortAlpha(String, SortOrder) - Method in interface org.redisson.api.RSortable
Read data in sorted view lexicographically
readSortAlpha(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortable
Read data in sorted view lexicographically
readSortAlpha(String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortable
Read data in sorted view lexicographically
readSortAlpha(String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortable
Read data in sorted view lexicographically
readSortAlpha(SortOrder) - Method in class org.redisson.RedissonList
 
readSortAlpha(SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSortAlpha(String, SortOrder) - Method in class org.redisson.RedissonList
 
readSortAlpha(String, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSortAlpha(String, List<String>, SortOrder) - Method in class org.redisson.RedissonList
 
readSortAlpha(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSortAlpha(SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlpha(SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlpha(String, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlpha(String, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlpha(String, List<String>, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlpha(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlpha(SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlpha(SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlpha(String, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlpha(String, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlpha(String, List<String>, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlpha(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlpha(SortOrder) - Method in class org.redisson.RedissonSet
 
readSortAlpha(SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSortAlpha(String, SortOrder) - Method in class org.redisson.RedissonSet
 
readSortAlpha(String, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSortAlpha(String, List<String>, SortOrder) - Method in class org.redisson.RedissonSet
 
readSortAlpha(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSortAlpha(SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlpha(SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlpha(String, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlpha(String, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlpha(String, List<String>, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlpha(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlphaAsync(SortOrder) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view lexicographically
readSortAlphaAsync(SortOrder, int, int) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view lexicographically
readSortAlphaAsync(String, SortOrder) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view lexicographically
readSortAlphaAsync(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view lexicographically
readSortAlphaAsync(String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view lexicographically
readSortAlphaAsync(String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view lexicographically
readSortAlphaAsync(SortOrder) - Method in class org.redisson.RedissonList
 
readSortAlphaAsync(SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSortAlphaAsync(String, SortOrder) - Method in class org.redisson.RedissonList
 
readSortAlphaAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSortAlphaAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonList
 
readSortAlphaAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSortAlphaAsync(SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlphaAsync(SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlphaAsync(String, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlphaAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlphaAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlphaAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAlphaAsync(SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlphaAsync(SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlphaAsync(String, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlphaAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlphaAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlphaAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAlphaAsync(SortOrder) - Method in class org.redisson.RedissonSet
 
readSortAlphaAsync(SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSortAlphaAsync(String, SortOrder) - Method in class org.redisson.RedissonSet
 
readSortAlphaAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSortAlphaAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonSet
 
readSortAlphaAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSortAlphaAsync(SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlphaAsync(SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlphaAsync(String, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlphaAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlphaAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlphaAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAlphaAsync(SortOrder) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAlphaAsync(SortOrder, int, int) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAlphaAsync(String, SortOrder) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAlphaAsync(String, SortOrder, int, int) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAlphaAsync(String, List<String>, SortOrder) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAlphaAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAlphaAsync(SortOrder) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSortAlphaAsync(SortOrder, int, int) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSortAlphaAsync(String, SortOrder) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSortAlphaAsync(String, SortOrder, int, int) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSortAlphaAsync(String, List<String>, SortOrder) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSortAlphaAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSortAsync(SortOrder) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view
readSortAsync(SortOrder, int, int) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view
readSortAsync(String, SortOrder) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view
readSortAsync(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view
readSortAsync(String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view
readSortAsync(String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortableAsync
Read data in sorted view
readSortAsync(SortOrder) - Method in class org.redisson.RedissonList
 
readSortAsync(SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSortAsync(String, SortOrder) - Method in class org.redisson.RedissonList
 
readSortAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSortAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonList
 
readSortAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
readSortAsync(SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAsync(SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAsync(String, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
readSortAsync(SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAsync(SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAsync(String, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
readSortAsync(SortOrder) - Method in class org.redisson.RedissonSet
 
readSortAsync(SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSortAsync(String, SortOrder) - Method in class org.redisson.RedissonSet
 
readSortAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSortAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonSet
 
readSortAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
readSortAsync(SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAsync(SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAsync(String, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAsync(String, List<String>, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
readSortAsync(SortOrder) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAsync(SortOrder, int, int) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAsync(String, SortOrder) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readSortAsync(SortOrder) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSortAsync(SortOrder, int, int) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSortAsync(String, SortOrder) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSortAsync(String, List<String>, SortOrder, int, int) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readSorted(SortOrder) - Method in interface org.redisson.api.RSortableReactive
Read data in sorted view
readSorted(SortOrder, int, int) - Method in interface org.redisson.api.RSortableReactive
Read data in sorted view
readSorted(String, SortOrder) - Method in interface org.redisson.api.RSortableReactive
Read data in sorted view
readSorted(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableReactive
Read data in sorted view
readSorted(String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortableReactive
Read data in sorted view
readSorted(String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortableReactive
Read data in sorted view
readSorted(SortOrder) - Method in interface org.redisson.api.RSortableRx
Read data in sorted view
readSorted(SortOrder, int, int) - Method in interface org.redisson.api.RSortableRx
Read data in sorted view
readSorted(String, SortOrder) - Method in interface org.redisson.api.RSortableRx
Read data in sorted view
readSorted(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableRx
Read data in sorted view
readSorted(String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortableRx
Read data in sorted view
readSorted(String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortableRx
Read data in sorted view
readUnion(String...) - Method in interface org.redisson.api.RSet
Union sets specified by name with current set without current set state change.
readUnion(String...) - Method in interface org.redisson.api.RSetReactive
Union sets specified by name with current set.
readUnion(String...) - Method in interface org.redisson.api.RSetRx
Union sets specified by name with current set.
readUnion(String...) - Method in class org.redisson.RedissonSet
 
readUnion(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
readUnionAsync(String...) - Method in interface org.redisson.api.RSetAsync
Union sets specified by name with current set.
readUnionAsync(String...) - Method in class org.redisson.RedissonSet
 
readUnionAsync(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
readUnionAsync(String...) - Method in class org.redisson.transaction.BaseTransactionalSet
 
readUnionAsync(String...) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
readValue(CachedValue<K, V>) - Method in class org.redisson.cache.AbstractCacheMap
 
readValue(InputStream, Class<T>) - Method in class org.redisson.codec.AvroJacksonCodec.AvroExtendedMapper
 
ReadWriteLockDecorator - Class in org.redisson.spring.support
 
ReadWriteLockDecorator() - Constructor for class org.redisson.spring.support.ReadWriteLockDecorator
 
reattachPubSub(RedisPubSubConnection) - Method in class org.redisson.pubsub.PublishSubscribeService
 
ReclosableLatch - Class in org.redisson.misc
A thread gate, that uses an AbstractQueuedSynchronizer.
ReclosableLatch() - Constructor for class org.redisson.misc.ReclosableLatch
 
ReclosableLatch(boolean) - Constructor for class org.redisson.misc.ReclosableLatch
 
reconnectionStrategy(LocalCachedMapOptions.ReconnectionStrategy) - Method in class org.redisson.api.LocalCachedMapOptions
 
redirectedConnectionWriteOp(RedisCommand<?>, RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
 
RedisAskException - Exception in org.redisson.client
 
RedisAskException(int, String) - Constructor for exception org.redisson.client.RedisAskException
 
RedisAuthRequiredException - Exception in org.redisson.client
This error occurs when Redis requires authentication.
RedisAuthRequiredException(String) - Constructor for exception org.redisson.client.RedisAuthRequiredException
 
RedisBatchExecutor<V,R> - Class in org.redisson.command
 
RedisBatchExecutor(boolean, NodeSource, Codec, RedisCommand<V>, Object[], RPromise<R>, boolean, ConnectionManager, RedissonObjectBuilder, ConcurrentMap<MasterSlaveEntry, CommandBatchService.Entry>, BatchOptions, AtomicInteger, AtomicBoolean) - Constructor for class org.redisson.command.RedisBatchExecutor
 
RedisChannelInitializer - Class in org.redisson.client.handler
 
RedisChannelInitializer(Bootstrap, RedisClientConfig, RedisClient, ChannelGroup, RedisChannelInitializer.Type) - Constructor for class org.redisson.client.handler.RedisChannelInitializer
 
RedisChannelInitializer.Type - Enum in org.redisson.client.handler
 
RedisClient - Class in org.redisson.client
Low-level Redis client
RedisClientConfig - Class in org.redisson.client
 
RedisClientConfig() - Constructor for class org.redisson.client.RedisClientConfig
 
RedisClientEntry - Class in org.redisson.connection
 
RedisClientEntry(RedisClient, CommandSyncService, NodeType) - Constructor for class org.redisson.connection.RedisClientEntry
 
RedisCluster - Interface in org.redisson.api.redisnode
Redis Cluster nodes API interface
RedisClusterMaster - Interface in org.redisson.api.redisnode
Redis Cluster Master node API interface
RedisClusterMasterAsync - Interface in org.redisson.api.redisnode
Redis Cluster Master node API interface
RedisClusterNode - Interface in org.redisson.api.redisnode
Base Redis Cluster node API interface
RedisClusterNodeAsync - Interface in org.redisson.api.redisnode
Base Redis Cluster node API interface
RedisClusterNodes - Class in org.redisson
Deprecated.
RedisClusterNodes(ConnectionManager) - Constructor for class org.redisson.RedisClusterNodes
Deprecated.
 
RedisClusterSlave - Interface in org.redisson.api.redisnode
Redis Cluster Salve node API interface
RedisClusterSlaveAsync - Interface in org.redisson.api.redisnode
 
RedisCommand<R> - Class in org.redisson.client.protocol
 
RedisCommand(RedisCommand<R>, String) - Constructor for class org.redisson.client.protocol.RedisCommand
Copy command and change name
RedisCommand(RedisCommand<R>, String, Convertor<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, RedisCommand.ValueType, Convertor<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, String) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, String, Convertor<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, Convertor<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, Decoder<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, String, MultiDecoder<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, MultiDecoder<R>, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, MultiDecoder<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand(String, MultiDecoder<R>, Convertor<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
 
RedisCommand.ValueType - Enum in org.redisson.client.protocol
 
RedisCommands - Interface in org.redisson.client.protocol
 
RedisCommonBatchExecutor - Class in org.redisson.command
 
RedisCommonBatchExecutor(NodeSource, RPromise<Void>, ConnectionManager, BatchOptions, CommandBatchService.Entry, AtomicInteger) - Constructor for class org.redisson.command.RedisCommonBatchExecutor
 
RedisConnection - Class in org.redisson.client
 
RedisConnection(RedisClient, Channel, RPromise<C>) - Constructor for class org.redisson.client.RedisConnection
 
RedisConnection(RedisClient) - Constructor for class org.redisson.client.RedisConnection
 
RedisConnectionException - Exception in org.redisson.client
 
RedisConnectionException(String) - Constructor for exception org.redisson.client.RedisConnectionException
 
RedisConnectionException(String, Throwable) - Constructor for exception org.redisson.client.RedisConnectionException
 
RedisConnectionHandler - Class in org.redisson.client.handler
 
RedisConnectionHandler(RedisClient) - Constructor for class org.redisson.client.handler.RedisConnectionHandler
 
RedisDefinitionParser - Class in org.redisson.spring.support
 
RedisDefinitionParser(RedissonNamespaceParserSupport) - Constructor for class org.redisson.spring.support.RedisDefinitionParser
 
RedisException - Exception in org.redisson.client
 
RedisException() - Constructor for exception org.redisson.client.RedisException
 
RedisException(String, Throwable) - Constructor for exception org.redisson.client.RedisException
 
RedisException(String) - Constructor for exception org.redisson.client.RedisException
 
RedisExecutor<V,R> - Class in org.redisson.command
 
RedisExecutor(boolean, NodeSource, Codec, RedisCommand<V>, Object[], RPromise<R>, boolean, ConnectionManager, RedissonObjectBuilder) - Constructor for class org.redisson.command.RedisExecutor
 
RedisLoadingException - Exception in org.redisson.client
 
RedisLoadingException(String) - Constructor for exception org.redisson.client.RedisLoadingException
 
RedisMaster - Interface in org.redisson.api.redisnode
Redis Master node API interface
RedisMasterAsync - Interface in org.redisson.api.redisnode
Redis Master node API interface
RedisMasterSlave - Interface in org.redisson.api.redisnode
Redis Master Slave nodes API interface
RedisMovedException - Exception in org.redisson.client
 
RedisMovedException(int, String) - Constructor for exception org.redisson.client.RedisMovedException
 
RedisNode - Interface in org.redisson.api.redisnode
Base Redis node API interface
RedisNode - Class in org.redisson.redisnode
 
RedisNode(RedisClient, CommandSyncService, NodeType) - Constructor for class org.redisson.redisnode.RedisNode
 
RedisNode.InfoSection - Enum in org.redisson.api.redisnode
 
RedisNodeAsync - Interface in org.redisson.api.redisnode
Base Redis node API interface
RedisNodeNotFoundException - Exception in org.redisson.client
 
RedisNodeNotFoundException(String) - Constructor for exception org.redisson.client.RedisNodeNotFoundException
 
RedisNodes<T extends BaseRedisNodes> - Class in org.redisson.api.redisnode
 
RedisNodes<N extends Node> - Class in org.redisson
Deprecated.
RedisNodes(ConnectionManager) - Constructor for class org.redisson.RedisNodes
Deprecated.
 
RedisOutOfMemoryException - Exception in org.redisson.client
This error occurs in case when Redis server free memory has been exhausted.
RedisOutOfMemoryException(String) - Constructor for exception org.redisson.client.RedisOutOfMemoryException
 
RedisPubSubConnection - Class in org.redisson.client
 
RedisPubSubConnection(RedisClient, Channel, RPromise<RedisPubSubConnection>) - Constructor for class org.redisson.client.RedisPubSubConnection
 
RedisPubSubConnectionHandler - Class in org.redisson.client.handler
 
RedisPubSubConnectionHandler(RedisClient) - Constructor for class org.redisson.client.handler.RedisPubSubConnectionHandler
 
RedisPubSubListener<V> - Interface in org.redisson.client
 
RedisQueuedBatchExecutor<V,R> - Class in org.redisson.command
 
RedisQueuedBatchExecutor(boolean, NodeSource, Codec, RedisCommand<V>, Object[], RPromise<R>, boolean, ConnectionManager, RedissonObjectBuilder, ConcurrentMap<MasterSlaveEntry, CommandBatchService.Entry>, ConcurrentMap<MasterSlaveEntry, CommandBatchService.ConnectionEntry>, BatchOptions, AtomicInteger, AtomicBoolean, AsyncSemaphore) - Constructor for class org.redisson.command.RedisQueuedBatchExecutor
 
RedisRedirectException - Exception in org.redisson.client
 
RedisRedirectException(int, String) - Constructor for exception org.redisson.client.RedisRedirectException
 
RedisResponseTimeoutException - Exception in org.redisson.client
 
RedisResponseTimeoutException(String) - Constructor for exception org.redisson.client.RedisResponseTimeoutException
 
RedisSentinel - Interface in org.redisson.api.redisnode
Redis Sentinel node API interface
RedisSentinelAsync - Interface in org.redisson.api.redisnode
Redis Sentinel node API interface
RedisSentinelMasterSlave - Interface in org.redisson.api.redisnode
Redis Sentinel Master Slave nodes API interface
RedisSingle - Interface in org.redisson.api.redisnode
Redis Single node API interface
RedisSlave - Interface in org.redisson.api.redisnode
Redis Slave node API interface
RedisSlaveAsync - Interface in org.redisson.api.redisnode
Redis Slave node API interface
redisson - Variable in class org.redisson.mapreduce.BaseMapperTask
 
redisson - Variable in class org.redisson.mapreduce.CoordinatorTask
 
Redisson - Class in org.redisson
Main infrastructure class allows to get access to all Redisson objects on top of Redis server.
Redisson(Config) - Constructor for class org.redisson.Redisson
 
REDISSON_NAMESPACE - Static variable in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
RedissonAsynchronousByteChannel() - Constructor for class org.redisson.RedissonBinaryStream.RedissonAsynchronousByteChannel
 
RedissonAtomicDouble - Class in org.redisson
Distributed alternative to the AtomicLong
RedissonAtomicDouble(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonAtomicDouble
 
RedissonAtomicLong - Class in org.redisson
Distributed alternative to the AtomicLong
RedissonAtomicLong(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonAtomicLong
 
RedissonBaseAdder<T extends Number> - Class in org.redisson
 
RedissonBaseAdder(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonBaseAdder
 
RedissonBaseIterator<V> - Class in org.redisson.iterator
 
RedissonBaseIterator() - Constructor for class org.redisson.iterator.RedissonBaseIterator
 
RedissonBaseMapIterator<V> - Class in org.redisson.iterator
 
RedissonBaseMapIterator() - Constructor for class org.redisson.iterator.RedissonBaseMapIterator
 
RedissonBaseNodes - Class in org.redisson.redisnode
 
RedissonBaseNodes(ConnectionManager) - Constructor for class org.redisson.redisnode.RedissonBaseNodes
 
RedissonBatch - Class in org.redisson
 
RedissonBatch(EvictionScheduler, ConnectionManager, BatchOptions) - Constructor for class org.redisson.RedissonBatch
 
RedissonBatchReactive - Class in org.redisson.reactive
 
RedissonBatchReactive(EvictionScheduler, ConnectionManager, CommandReactiveService, BatchOptions) - Constructor for class org.redisson.reactive.RedissonBatchReactive
 
RedissonBatchRx - Class in org.redisson.rx
 
RedissonBatchRx(EvictionScheduler, ConnectionManager, CommandRxExecutor, BatchOptions) - Constructor for class org.redisson.rx.RedissonBatchRx
 
RedissonBinaryStream - Class in org.redisson
 
RedissonBinaryStream(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonBinaryStream
 
RedissonBinaryStream.RedissonAsynchronousByteChannel - Class in org.redisson
 
RedissonBinaryStreamReactive - Class in org.redisson.reactive
 
RedissonBinaryStreamReactive(CommandReactiveExecutor, RBinaryStream) - Constructor for class org.redisson.reactive.RedissonBinaryStreamReactive
 
RedissonBinaryStreamRx - Class in org.redisson.rx
 
RedissonBinaryStreamRx(CommandRxExecutor, RBinaryStream) - Constructor for class org.redisson.rx.RedissonBinaryStreamRx
 
RedissonBitSet - Class in org.redisson
 
RedissonBitSet(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonBitSet
 
RedissonBlockingDeque<V> - Class in org.redisson
Distributed and concurrent implementation of BlockingDeque.
RedissonBlockingDeque(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonBlockingDeque
 
RedissonBlockingDeque(Codec, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonBlockingDeque
 
RedissonBlockingDequeReactive<V> - Class in org.redisson.reactive
 
RedissonBlockingDequeReactive(RedissonBlockingDeque<V>) - Constructor for class org.redisson.reactive.RedissonBlockingDequeReactive
 
RedissonBlockingDequeRx<V> - Class in org.redisson.rx
 
RedissonBlockingDequeRx(RedissonBlockingDeque<V>) - Constructor for class org.redisson.rx.RedissonBlockingDequeRx
 
RedissonBlockingQueue<V> - Class in org.redisson
Distributed and concurrent implementation of BlockingQueue.
RedissonBlockingQueue(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonBlockingQueue
 
RedissonBlockingQueue(Codec, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonBlockingQueue
 
RedissonBlockingQueueReactive<V> - Class in org.redisson.reactive
 
RedissonBlockingQueueReactive(RBlockingQueue<V>) - Constructor for class org.redisson.reactive.RedissonBlockingQueueReactive
 
RedissonBlockingQueueRx<V> - Class in org.redisson.rx
 
RedissonBlockingQueueRx(RBlockingQueueAsync<V>) - Constructor for class org.redisson.rx.RedissonBlockingQueueRx
 
RedissonBloomFilter<T> - Class in org.redisson
Bloom filter based on Highway 128-bit hash.
RedissonBloomFilter(CommandExecutor, String) - Constructor for class org.redisson.RedissonBloomFilter
 
RedissonBloomFilter(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonBloomFilter
 
RedissonBoundedBlockingQueue<V> - Class in org.redisson
Distributed and concurrent implementation of bounded BlockingQueue.
RedissonBoundedBlockingQueue(CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonBoundedBlockingQueue
 
RedissonBoundedBlockingQueue(Codec, CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonBoundedBlockingQueue
 
RedissonBucket<V> - Class in org.redisson
 
RedissonBucket(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonBucket
 
RedissonBucket(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonBucket
 
RedissonBuckets - Class in org.redisson
 
RedissonBuckets(CommandAsyncExecutor) - Constructor for class org.redisson.RedissonBuckets
 
RedissonBuckets(Codec, CommandAsyncExecutor) - Constructor for class org.redisson.RedissonBuckets
 
RedissonCache - Class in org.redisson.spring.cache
 
RedissonCache(RMapCache<Object, Object>, CacheConfig, boolean) - Constructor for class org.redisson.spring.cache.RedissonCache
 
RedissonCache(RMap<Object, Object>, boolean) - Constructor for class org.redisson.spring.cache.RedissonCache
 
RedissonCacheMeterBinderProvider - Class in org.redisson.spring.cache
 
RedissonCacheMeterBinderProvider() - Constructor for class org.redisson.spring.cache.RedissonCacheMeterBinderProvider
 
redissonCacheMeterBinderProvider() - Method in class org.redisson.spring.cache.RedissonCacheStatisticsAutoConfiguration
 
RedissonCacheMetrics - Class in org.redisson.spring.cache
 
RedissonCacheMetrics(RedissonCache, Iterable<Tag>) - Constructor for class org.redisson.spring.cache.RedissonCacheMetrics
 
RedissonCacheStatisticsAutoConfiguration - Class in org.redisson.spring.cache
 
RedissonCacheStatisticsAutoConfiguration() - Constructor for class org.redisson.spring.cache.RedissonCacheStatisticsAutoConfiguration
 
RedissonClassLoader - Class in org.redisson.executor
 
RedissonClassLoader(ClassLoader) - Constructor for class org.redisson.executor.RedissonClassLoader
 
RedissonClient - Interface in org.redisson.api
Main Redisson interface for access to all redisson objects with sync/async interface.
RedissonClusterNodes - Class in org.redisson.redisnode
 
RedissonClusterNodes(ConnectionManager) - Constructor for class org.redisson.redisnode.RedissonClusterNodes
 
RedissonCollectionMapReduce<VIn,KOut,VOut> - Class in org.redisson.mapreduce
 
RedissonCollectionMapReduce(RObject, RedissonClient, ConnectionManager) - Constructor for class org.redisson.mapreduce.RedissonCollectionMapReduce
 
RedissonCompletionService<V> - Class in org.redisson.executor
A CompletionService that uses a supplied Executor to execute tasks.
RedissonCompletionService(RScheduledExecutorService) - Constructor for class org.redisson.executor.RedissonCompletionService
 
RedissonCompletionService(RScheduledExecutorService, BlockingQueue<RFuture<V>>) - Constructor for class org.redisson.executor.RedissonCompletionService
 
RedissonConfiguration<K,V> - Class in org.redisson.jcache.configuration
 
RedissonCountDownLatch - Class in org.redisson
Distributed alternative to the CountDownLatch It has a advantage over CountDownLatch -- count can be reset via RedissonCountDownLatch.trySetCount(long).
RedissonCountDownLatch(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonCountDownLatch
 
RedissonCountDownLatchEntry - Class in org.redisson
 
RedissonCountDownLatchEntry(RPromise<RedissonCountDownLatchEntry>) - Constructor for class org.redisson.RedissonCountDownLatchEntry
 
RedissonDefinitionParser - Class in org.redisson.spring.support
 
RedissonDelayedQueue<V> - Class in org.redisson
 
RedissonDelayedQueue(QueueTransferService, Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonDelayedQueue
 
RedissonDeque<V> - Class in org.redisson
Distributed and concurrent implementation of Queue
RedissonDeque(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonDeque
 
RedissonDeque(Codec, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonDeque
 
RedissonDoubleAdder - Class in org.redisson
 
RedissonDoubleAdder(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonDoubleAdder
 
RedissonExecutorBatchFuture - Class in org.redisson.executor
 
RedissonExecutorBatchFuture(List<RExecutorFuture<?>>) - Constructor for class org.redisson.executor.RedissonExecutorBatchFuture
 
RedissonExecutorFuture<V> - Class in org.redisson.executor
 
RedissonExecutorFuture(RemotePromise<V>) - Constructor for class org.redisson.executor.RedissonExecutorFuture
 
RedissonExecutorFuture(RPromise<V>, RequestId) - Constructor for class org.redisson.executor.RedissonExecutorFuture
 
RedissonExecutorFutureReference - Class in org.redisson.executor
 
RedissonExecutorFutureReference(RequestId, RExecutorFuture<?>, ReferenceQueue<? super RExecutorFuture<?>>, RPromise<?>) - Constructor for class org.redisson.executor.RedissonExecutorFutureReference
 
RedissonExecutorRemoteService - Class in org.redisson.executor
 
RedissonExecutorRemoteService(Codec, String, CommandAsyncService, String, ConcurrentMap<String, ResponseEntry>) - Constructor for class org.redisson.executor.RedissonExecutorRemoteService
 
RedissonExecutorService - Class in org.redisson
 
RedissonExecutorService(Codec, CommandExecutor, Redisson, String, QueueTransferService, ConcurrentMap<String, ResponseEntry>, ExecutorOptions) - Constructor for class org.redisson.RedissonExecutorService
 
RedissonExecutorService.ClassBody - Class in org.redisson
 
RedissonFairLock - Class in org.redisson
Distributed implementation of Lock Implements reentrant lock.
RedissonFairLock(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonFairLock
 
RedissonFairLock(CommandAsyncExecutor, String, long) - Constructor for class org.redisson.RedissonFairLock
 
RedissonGenericObjectDefinitionParser - Class in org.redisson.spring.support
 
RedissonGeo<V> - Class in org.redisson
Geospatial items holder
RedissonGeo(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonGeo
 
RedissonGeo(Codec, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonGeo
 
RedissonHttpSessionConfiguration - Class in org.redisson.spring.session.config
Exposes the SessionRepositoryFilter as the bean named "springSessionRepositoryFilter".
RedissonHttpSessionConfiguration() - Constructor for class org.redisson.spring.session.config.RedissonHttpSessionConfiguration
 
RedissonHyperLogLog<V> - Class in org.redisson
 
RedissonHyperLogLog(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonHyperLogLog
 
RedissonHyperLogLog(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonHyperLogLog
 
RedissonKeys - Class in org.redisson
 
RedissonKeys(CommandAsyncExecutor) - Constructor for class org.redisson.RedissonKeys
 
RedissonKeysReactive - Class in org.redisson.reactive
 
RedissonKeysReactive(CommandReactiveExecutor) - Constructor for class org.redisson.reactive.RedissonKeysReactive
 
RedissonKeysRx - Class in org.redisson.rx
 
RedissonKeysRx(CommandRxExecutor) - Constructor for class org.redisson.rx.RedissonKeysRx
 
RedissonKryoCodecException(Throwable) - Constructor for exception org.redisson.codec.KryoCodec.RedissonKryoCodecException
 
RedissonLexSortedSet - Class in org.redisson
Sorted set contained values of String type
RedissonLexSortedSet(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonLexSortedSet
 
RedissonLexSortedSetReactive - Class in org.redisson.reactive
 
RedissonLexSortedSetReactive(RLexSortedSet) - Constructor for class org.redisson.reactive.RedissonLexSortedSetReactive
 
RedissonLexSortedSetRx - Class in org.redisson.rx
 
RedissonLexSortedSetRx(RLexSortedSet) - Constructor for class org.redisson.rx.RedissonLexSortedSetRx
 
RedissonList<V> - Class in org.redisson
Distributed and concurrent implementation of List
RedissonList(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonList
 
RedissonList(Codec, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonList
 
RedissonListIterator<V> - Class in org.redisson.iterator
 
RedissonListIterator(int) - Constructor for class org.redisson.iterator.RedissonListIterator
 
RedissonListMultimap<K,V> - Class in org.redisson
 
RedissonListMultimap(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonListMultimap
 
RedissonListMultimap(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonListMultimap
 
RedissonListMultimapCache<K,V> - Class in org.redisson
 
RedissonListMultimapCache(EvictionScheduler, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonListMultimapCache
 
RedissonListMultimapCache(EvictionScheduler, Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonListMultimapCache
 
RedissonListMultimapIterator<K,V,M> - Class in org.redisson
 
RedissonListMultimapIterator(RedissonMultimap<K, V>, CommandAsyncExecutor, Codec) - Constructor for class org.redisson.RedissonListMultimapIterator
 
RedissonListMultimapReactive<K,V> - Class in org.redisson.reactive
 
RedissonListMultimapReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonListMultimapReactive
 
RedissonListMultimapReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonListMultimapReactive
 
RedissonListMultimapRx<K,V> - Class in org.redisson.rx
 
RedissonListMultimapRx(CommandRxExecutor, String) - Constructor for class org.redisson.rx.RedissonListMultimapRx
 
RedissonListMultimapRx(Codec, CommandRxExecutor, String) - Constructor for class org.redisson.rx.RedissonListMultimapRx
 
RedissonListMultimapValues<V> - Class in org.redisson
List based Multimap Cache values holder
RedissonListMultimapValues(Codec, CommandAsyncExecutor, String, String, Object) - Constructor for class org.redisson.RedissonListMultimapValues
 
RedissonListReactive<V> - Class in org.redisson.reactive
Distributed and concurrent implementation of List
RedissonListReactive(RListAsync<V>) - Constructor for class org.redisson.reactive.RedissonListReactive
 
RedissonListReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonListReactive
 
RedissonListReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonListReactive
 
RedissonListRx<V> - Class in org.redisson.rx
Distributed and concurrent implementation of List
RedissonListRx(RListAsync<V>) - Constructor for class org.redisson.rx.RedissonListRx
 
RedissonLiveObjectDefinitionParser - Class in org.redisson.spring.support
 
RedissonLiveObjectDefinitionParser(RedissonNamespaceParserSupport) - Constructor for class org.redisson.spring.support.RedissonLiveObjectDefinitionParser
 
RedissonLiveObjectRegistrationDefinitionParser - Class in org.redisson.spring.support
 
RedissonLiveObjectRegistrationDefinitionParser(RedissonNamespaceParserSupport) - Constructor for class org.redisson.spring.support.RedissonLiveObjectRegistrationDefinitionParser
 
RedissonLiveObjectService - Class in org.redisson
 
RedissonLiveObjectService(ConcurrentMap<Class<?>, Class<?>>, ConnectionManager) - Constructor for class org.redisson.RedissonLiveObjectService
 
RedissonLocalCachedMap<K,V> - Class in org.redisson
 
RedissonLocalCachedMap(CommandAsyncExecutor, String, LocalCachedMapOptions<K, V>, EvictionScheduler, RedissonClient, WriteBehindService) - Constructor for class org.redisson.RedissonLocalCachedMap
 
RedissonLocalCachedMap(Codec, CommandAsyncExecutor, String, LocalCachedMapOptions<K, V>, EvictionScheduler, RedissonClient, WriteBehindService) - Constructor for class org.redisson.RedissonLocalCachedMap
 
RedissonLock - Class in org.redisson
Distributed implementation of Lock Implements reentrant lock.
RedissonLock(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonLock
 
RedissonLock.ExpirationEntry - Class in org.redisson
 
RedissonLockEntry - Class in org.redisson
 
RedissonLockEntry(RPromise<RedissonLockEntry>) - Constructor for class org.redisson.RedissonLockEntry
 
RedissonLongAdder - Class in org.redisson
 
RedissonLongAdder(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonLongAdder
 
RedissonMap<K,V> - Class in org.redisson
Distributed and concurrent implementation of ConcurrentMap and Map
RedissonMap(CommandAsyncExecutor, String, RedissonClient, MapOptions<K, V>, WriteBehindService) - Constructor for class org.redisson.RedissonMap
 
RedissonMap(Codec, CommandAsyncExecutor, String, RedissonClient, MapOptions<K, V>, WriteBehindService) - Constructor for class org.redisson.RedissonMap
 
RedissonMapCache<K,V> - Class in org.redisson
RedissonMapCache(EvictionScheduler, CommandAsyncExecutor, String, RedissonClient, MapOptions<K, V>, WriteBehindService) - Constructor for class org.redisson.RedissonMapCache
 
RedissonMapCache(Codec, EvictionScheduler, CommandAsyncExecutor, String, RedissonClient, MapOptions<K, V>, WriteBehindService) - Constructor for class org.redisson.RedissonMapCache
 
RedissonMapCacheReactive<K,V> - Class in org.redisson.reactive
 
RedissonMapCacheReactive(RMapCache<K, V>) - Constructor for class org.redisson.reactive.RedissonMapCacheReactive
 
RedissonMapCacheRx<K,V> - Class in org.redisson.rx
 
RedissonMapCacheRx(RMapCache<K, V>) - Constructor for class org.redisson.rx.RedissonMapCacheRx
 
RedissonMapEntry<K,V> - Class in org.redisson
 
RedissonMapEntry(K, V) - Constructor for class org.redisson.RedissonMapEntry
 
RedissonMapIterator<M> - Class in org.redisson.iterator
 
RedissonMapIterator(RedissonMap, String, int) - Constructor for class org.redisson.iterator.RedissonMapIterator
 
RedissonMapReactive<K,V> - Class in org.redisson.reactive
Distributed and concurrent implementation of ConcurrentMap and Map
RedissonMapReactive(RMap<K, V>, RedissonReactiveClient) - Constructor for class org.redisson.reactive.RedissonMapReactive
 
RedissonMapReduce<KIn,VIn,KOut,VOut> - Class in org.redisson.mapreduce
 
RedissonMapReduce(RObject, RedissonClient, ConnectionManager) - Constructor for class org.redisson.mapreduce.RedissonMapReduce
 
RedissonMapRx<K,V> - Class in org.redisson.rx
Distributed and concurrent implementation of ConcurrentMap and Map
RedissonMapRx(RMap<K, V>, RedissonRx) - Constructor for class org.redisson.rx.RedissonMapRx
 
RedissonMapRxIterator<K,V,M> - Class in org.redisson.rx
 
RedissonMapRxIterator(RedissonMap<K, V>, String, int) - Constructor for class org.redisson.rx.RedissonMapRxIterator
 
RedissonMasterSlaveNodes - Class in org.redisson.redisnode
 
RedissonMasterSlaveNodes(ConnectionManager) - Constructor for class org.redisson.redisnode.RedissonMasterSlaveNodes
 
RedissonMultiLock - Class in org.redisson
Groups multiple independent locks and manages them as one lock.
RedissonMultiLock(RLock...) - Constructor for class org.redisson.RedissonMultiLock
Creates instance with multiple RLock objects.
RedissonMultiLockDefinitionParser - Class in org.redisson.spring.support
 
RedissonMultiLockDefinitionParser(RedissonNamespaceParserSupport) - Constructor for class org.redisson.spring.support.RedissonMultiLockDefinitionParser
 
RedissonMultimap<K,V> - Class in org.redisson
 
RedissonMultimapCache<K> - Class in org.redisson
 
RedissonMultimapCache(CommandAsyncExecutor, RObject, String, String) - Constructor for class org.redisson.RedissonMultimapCache
 
RedissonNamespaceDecorator - Interface in org.redisson.spring.support
 
RedissonNamespaceDefaultDecorator - Class in org.redisson.spring.support
 
RedissonNamespaceDefaultDecorator() - Constructor for class org.redisson.spring.support.RedissonNamespaceDefaultDecorator
 
RedissonNamespaceHandlerSupport - Class in org.redisson.spring.support
 
RedissonNamespaceHandlerSupport() - Constructor for class org.redisson.spring.support.RedissonNamespaceHandlerSupport
 
RedissonNamespaceParserSupport - Class in org.redisson.spring.support
 
RedissonNamespaceParserSupport() - Constructor for class org.redisson.spring.support.RedissonNamespaceParserSupport
 
RedissonNestedElementAwareDecorator - Class in org.redisson.spring.support
 
RedissonNestedElementAwareDecorator(String[], String) - Constructor for class org.redisson.spring.support.RedissonNestedElementAwareDecorator
 
RedissonNode - Class in org.redisson
 
RedissonNodeConfig - Class in org.redisson.config
Redisson Node configuration
RedissonNodeConfig() - Constructor for class org.redisson.config.RedissonNodeConfig
 
RedissonNodeConfig(Config) - Constructor for class org.redisson.config.RedissonNodeConfig
 
RedissonNodeConfig(RedissonNodeConfig) - Constructor for class org.redisson.config.RedissonNodeConfig
 
RedissonNodeInitializer - Interface in org.redisson.api
Node initializer callback interface.
RedissonObject - Class in org.redisson
Base Redisson object
RedissonObject(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonObject
 
RedissonObject(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonObject
 
RedissonObjectBuilder - Class in org.redisson.liveobject.core
 
RedissonObjectBuilder(Config, RedissonClient, RedissonReactiveClient, RedissonRxClient) - Constructor for class org.redisson.liveobject.core.RedissonObjectBuilder
 
RedissonObjectBuilder.CodecMethodRef - Class in org.redisson.liveobject.core
 
RedissonPatternTopic - Class in org.redisson
Distributed topic implementation.
RedissonPatternTopic(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonPatternTopic
 
RedissonPatternTopic(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonPatternTopic
 
RedissonPermitExpirableSemaphore - Class in org.redisson
 
RedissonPermitExpirableSemaphore(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonPermitExpirableSemaphore
 
RedissonPriorityBlockingDeque<V> - Class in org.redisson
Distributed and concurrent implementation of priority blocking deque.
RedissonPriorityBlockingDeque(CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonPriorityBlockingDeque
 
RedissonPriorityBlockingDeque(Codec, CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonPriorityBlockingDeque
 
RedissonPriorityBlockingQueue<V> - Class in org.redisson
Distributed and concurrent implementation of PriorityBlockingQueue.
RedissonPriorityBlockingQueue(CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonPriorityBlockingQueue
 
RedissonPriorityBlockingQueue(Codec, CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonPriorityBlockingQueue
 
RedissonPriorityDeque<V> - Class in org.redisson
Distributed and concurrent implementation of Queue
RedissonPriorityDeque(CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonPriorityDeque
 
RedissonPriorityDeque(Codec, CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonPriorityDeque
 
RedissonPriorityQueue<V> - Class in org.redisson
 
RedissonPriorityQueue(CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonPriorityQueue
 
RedissonPriorityQueue(Codec, CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonPriorityQueue
 
RedissonPriorityQueue.BinarySearchResult<V> - Class in org.redisson
 
RedissonPromise<T> - Class in org.redisson.misc
 
RedissonPromise() - Constructor for class org.redisson.misc.RedissonPromise
 
RedissonQueue<V> - Class in org.redisson
Distributed and concurrent implementation of Queue
RedissonQueue(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonQueue
 
RedissonQueue(Codec, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonQueue
 
RedissonQueueSemaphore - Class in org.redisson
 
RedissonQueueSemaphore(CommandExecutor, String) - Constructor for class org.redisson.RedissonQueueSemaphore
 
RedissonRateLimiter - Class in org.redisson
 
RedissonRateLimiter(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonRateLimiter
 
RedissonReactive - Class in org.redisson
Main infrastructure class allows to get access to all Redisson objects on top of Redis server.
RedissonReactive(Config) - Constructor for class org.redisson.RedissonReactive
 
RedissonReactiveClient - Interface in org.redisson.api
Main Redisson interface for access to all redisson objects with Reactive interface.
RedissonReadAndWriteLockDefinitionParser - Class in org.redisson.spring.support
 
RedissonReadAndWriteLockDefinitionParser(RedissonNamespaceParserSupport) - Constructor for class org.redisson.spring.support.RedissonReadAndWriteLockDefinitionParser
 
RedissonReadLock - Class in org.redisson
Lock will be removed automatically if client disconnects.
RedissonReadLock(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonReadLock
 
RedissonReadWriteLock - Class in org.redisson
A ReadWriteLock maintains a pair of associated locks, one for read-only operations and one for writing.
RedissonReadWriteLock(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonReadWriteLock
 
RedissonReadWriteLockReactive - Class in org.redisson.reactive
 
RedissonReadWriteLockReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonReadWriteLockReactive
 
RedissonReadWriteLockRx - Class in org.redisson.rx
 
RedissonReadWriteLockRx(CommandRxExecutor, String) - Constructor for class org.redisson.rx.RedissonReadWriteLockRx
 
RedissonRedLock - Class in org.redisson
RedLock locking algorithm implementation for multiple locks.
RedissonRedLock(RLock...) - Constructor for class org.redisson.RedissonRedLock
Creates instance with multiple RLock objects.
RedissonReference - Class in org.redisson
 
RedissonReference() - Constructor for class org.redisson.RedissonReference
 
RedissonReference(Class<?>, String) - Constructor for class org.redisson.RedissonReference
 
RedissonReference(Class<?>, String, Codec) - Constructor for class org.redisson.RedissonReference
 
RedissonRemoteService - Class in org.redisson
 
RedissonRemoteService(Codec, String, CommandAsyncExecutor, String, ConcurrentMap<String, ResponseEntry>) - Constructor for class org.redisson.RedissonRemoteService
 
RedissonRemoteService.Entry - Class in org.redisson
 
RedissonRingBuffer<V> - Class in org.redisson
 
RedissonRingBuffer(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonRingBuffer
 
RedissonRingBuffer(Codec, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonRingBuffer
 
RedissonRPCClientDefinitionParser - Class in org.redisson.spring.support
 
RedissonRPCClientDefinitionParser(RedissonNamespaceParserSupport, RedissonNamespaceDecorator) - Constructor for class org.redisson.spring.support.RedissonRPCClientDefinitionParser
 
RedissonRPCServerDefinitionParser - Class in org.redisson.spring.support
 
RedissonRPCServerDefinitionParser(RedissonNamespaceParserSupport) - Constructor for class org.redisson.spring.support.RedissonRPCServerDefinitionParser
 
RedissonRx - Class in org.redisson
Main infrastructure class allows to get access to all Redisson objects on top of Redis server.
RedissonRx(Config) - Constructor for class org.redisson.RedissonRx
 
RedissonRxClient - Interface in org.redisson.api
Main Redisson interface for access to all redisson objects with RxJava2 interface.
RedissonScheduledFuture<V> - Class in org.redisson.executor
 
RedissonScheduledFuture(RemotePromise<V>, long) - Constructor for class org.redisson.executor.RedissonScheduledFuture
 
RedissonScoredSortedSet<V> - Class in org.redisson
 
RedissonScoredSortedSet(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonScoredSortedSet
 
RedissonScoredSortedSet(Codec, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonScoredSortedSet
 
RedissonScoredSortedSetReactive<V> - Class in org.redisson.reactive
 
RedissonScoredSortedSetReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonScoredSortedSetReactive
 
RedissonScoredSortedSetReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonScoredSortedSetReactive
 
RedissonScoredSortedSetRx<V> - Class in org.redisson.rx
 
RedissonScoredSortedSetRx(RScoredSortedSetAsync<V>) - Constructor for class org.redisson.rx.RedissonScoredSortedSetRx
 
RedissonScript - Class in org.redisson
 
RedissonScript(CommandAsyncExecutor) - Constructor for class org.redisson.RedissonScript
 
RedissonScript(CommandAsyncExecutor, Codec) - Constructor for class org.redisson.RedissonScript
 
RedissonSemaphore - Class in org.redisson
Distributed and concurrent implementation of Semaphore.
RedissonSemaphore(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonSemaphore
 
RedissonSentinelMasterSlaveNodes - Class in org.redisson.redisnode
 
RedissonSentinelMasterSlaveNodes(ConnectionManager) - Constructor for class org.redisson.redisnode.RedissonSentinelMasterSlaveNodes
 
RedissonSessionRepository - Class in org.redisson.spring.session
 
RedissonSessionRepository(RedissonClient, ApplicationEventPublisher, String) - Constructor for class org.redisson.spring.session.RedissonSessionRepository
 
RedissonSessionRepository(RedissonClient, ApplicationEventPublisher) - Constructor for class org.redisson.spring.session.RedissonSessionRepository
 
RedissonSet<V> - Class in org.redisson
Distributed and concurrent implementation of Set
RedissonSet(CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonSet
 
RedissonSet(Codec, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonSet
 
RedissonSetCache<V> - Class in org.redisson
Set-based cache with ability to set TTL for each entry via RSetCache.add(Object, long, TimeUnit) method.
RedissonSetCache(EvictionScheduler, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonSetCache
 
RedissonSetCache(Codec, EvictionScheduler, CommandAsyncExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonSetCache
 
RedissonSetCacheReactive<V> - Class in org.redisson.reactive
 
RedissonSetCacheReactive(RSetCache<V>, RedissonReactiveClient) - Constructor for class org.redisson.reactive.RedissonSetCacheReactive
 
RedissonSetCacheRx<V> - Class in org.redisson.rx
 
RedissonSetCacheRx(RSetCache<V>, RedissonRxClient) - Constructor for class org.redisson.rx.RedissonSetCacheRx
 
RedissonSetMultimap<K,V> - Class in org.redisson
 
RedissonSetMultimap(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonSetMultimap
 
RedissonSetMultimap(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonSetMultimap
 
RedissonSetMultimapCache<K,V> - Class in org.redisson
 
RedissonSetMultimapIterator<K,V,M> - Class in org.redisson
 
RedissonSetMultimapIterator(RedissonMultimap<K, V>, CommandAsyncExecutor, Codec) - Constructor for class org.redisson.RedissonSetMultimapIterator
 
RedissonSetMultimapReactive<K,V> - Class in org.redisson.reactive
 
RedissonSetMultimapReactive(CommandReactiveExecutor, String, RedissonReactiveClient) - Constructor for class org.redisson.reactive.RedissonSetMultimapReactive
 
RedissonSetMultimapReactive(Codec, CommandReactiveExecutor, String, RedissonReactiveClient) - Constructor for class org.redisson.reactive.RedissonSetMultimapReactive
 
RedissonSetMultimapRx<K,V> - Class in org.redisson.rx
 
RedissonSetMultimapRx(CommandRxExecutor, String, RedissonRxClient) - Constructor for class org.redisson.rx.RedissonSetMultimapRx
 
RedissonSetMultimapRx(Codec, CommandRxExecutor, String, RedissonRxClient) - Constructor for class org.redisson.rx.RedissonSetMultimapRx
 
RedissonSetMultimapValues<V> - Class in org.redisson
Set based Multimap Cache values holder
RedissonSetMultimapValues(Codec, CommandAsyncExecutor, String, String, Object) - Constructor for class org.redisson.RedissonSetMultimapValues
 
RedissonSetReactive<V> - Class in org.redisson.reactive
Distributed and concurrent implementation of Set
RedissonSetReactive(RSet<V>, RedissonReactiveClient) - Constructor for class org.redisson.reactive.RedissonSetReactive
 
RedissonSetRx<V> - Class in org.redisson.rx
Distributed and concurrent implementation of Set
RedissonSetRx(RSet<V>, RedissonRxClient) - Constructor for class org.redisson.rx.RedissonSetRx
 
RedissonShutdownException - Exception in org.redisson
 
RedissonShutdownException(String) - Constructor for exception org.redisson.RedissonShutdownException
 
RedissonSingleNode - Class in org.redisson.redisnode
 
RedissonSingleNode(ConnectionManager) - Constructor for class org.redisson.redisnode.RedissonSingleNode
 
RedissonSortedSet<V> - Class in org.redisson
 
RedissonSortedSet(CommandExecutor, String, RedissonClient) - Constructor for class org.redisson.RedissonSortedSet
 
RedissonSortedSet(Codec, CommandExecutor, String, Redisson) - Constructor for class org.redisson.RedissonSortedSet
 
RedissonSortedSet.BinarySearchResult<V> - Class in org.redisson
 
RedissonSpringCacheManager - Class in org.redisson.spring.cache
A CacheManager implementation backed by Redisson instance.
RedissonSpringCacheManager(RedissonClient) - Constructor for class org.redisson.spring.cache.RedissonSpringCacheManager
Creates CacheManager supplied by Redisson instance
RedissonSpringCacheManager(RedissonClient, Map<String, ? extends CacheConfig>) - Constructor for class org.redisson.spring.cache.RedissonSpringCacheManager
Creates CacheManager supplied by Redisson instance and Cache config mapped by Cache name
RedissonSpringCacheManager(RedissonClient, Map<String, ? extends CacheConfig>, Codec) - Constructor for class org.redisson.spring.cache.RedissonSpringCacheManager
Creates CacheManager supplied by Redisson instance, Codec instance and Cache config mapped by Cache name.
RedissonSpringCacheManager(RedissonClient, String) - Constructor for class org.redisson.spring.cache.RedissonSpringCacheManager
Creates CacheManager supplied by Redisson instance and Cache config mapped by Cache name.
RedissonSpringCacheManager(RedissonClient, String, Codec) - Constructor for class org.redisson.spring.cache.RedissonSpringCacheManager
Creates CacheManager supplied by Redisson instance, Codec instance and Config location path.
RedissonStream<K,V> - Class in org.redisson
 
RedissonStream(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonStream
 
RedissonStream(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonStream
 
RedissonSubList<V> - Class in org.redisson
Distributed and concurrent implementation of List
RedissonSubList(Codec, CommandAsyncExecutor, String, int, int) - Constructor for class org.redisson.RedissonSubList
 
RedissonTopic - Class in org.redisson
Distributed topic implementation.
RedissonTopic(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonTopic
 
RedissonTopic(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonTopic
 
RedissonTopicReactive - Class in org.redisson.reactive
 
RedissonTopicReactive(RTopic) - Constructor for class org.redisson.reactive.RedissonTopicReactive
 
RedissonTopicRx - Class in org.redisson.rx
 
RedissonTopicRx(RTopic) - Constructor for class org.redisson.rx.RedissonTopicRx
 
RedissonTransaction - Class in org.redisson.transaction
 
RedissonTransaction(CommandAsyncExecutor, TransactionOptions) - Constructor for class org.redisson.transaction.RedissonTransaction
 
RedissonTransaction(CommandAsyncExecutor, TransactionOptions, List<TransactionalOperation>, Set<String>) - Constructor for class org.redisson.transaction.RedissonTransaction
 
RedissonTransactionalBucket<V> - Class in org.redisson.transaction
 
RedissonTransactionalBucket(CommandAsyncExecutor, long, String, List<TransactionalOperation>, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalBucket
 
RedissonTransactionalBucket(Codec, CommandAsyncExecutor, long, String, List<TransactionalOperation>, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalBucket
 
RedissonTransactionalBuckets - Class in org.redisson.transaction
 
RedissonTransactionalBuckets(CommandAsyncExecutor, long, List<TransactionalOperation>, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalBuckets
 
RedissonTransactionalBuckets(Codec, CommandAsyncExecutor, long, List<TransactionalOperation>, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalBuckets
 
RedissonTransactionalLocalCachedMap<K,V> - Class in org.redisson.transaction
 
RedissonTransactionalLocalCachedMap(CommandAsyncExecutor, List<TransactionalOperation>, long, AtomicBoolean, RLocalCachedMap<K, V>, String) - Constructor for class org.redisson.transaction.RedissonTransactionalLocalCachedMap
 
RedissonTransactionalLock - Class in org.redisson.transaction
 
RedissonTransactionalLock(CommandAsyncExecutor, String, String) - Constructor for class org.redisson.transaction.RedissonTransactionalLock
 
RedissonTransactionalMap<K,V> - Class in org.redisson.transaction
 
RedissonTransactionalMap(CommandAsyncExecutor, List<TransactionalOperation>, long, AtomicBoolean, RMap<K, V>, String) - Constructor for class org.redisson.transaction.RedissonTransactionalMap
 
RedissonTransactionalMap(CommandAsyncExecutor, String, List<TransactionalOperation>, long, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalMap
 
RedissonTransactionalMap(Codec, CommandAsyncExecutor, String, List<TransactionalOperation>, long, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalMap
 
RedissonTransactionalMapCache<K,V> - Class in org.redisson.transaction
 
RedissonTransactionalMapCache(CommandAsyncExecutor, String, List<TransactionalOperation>, long, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalMapCache
 
RedissonTransactionalMapCache(Codec, CommandAsyncExecutor, String, List<TransactionalOperation>, long, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalMapCache
 
RedissonTransactionalSet<V> - Class in org.redisson.transaction
 
RedissonTransactionalSet(CommandAsyncExecutor, String, List<TransactionalOperation>, long, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalSet
 
RedissonTransactionalSet(Codec, CommandAsyncExecutor, String, List<TransactionalOperation>, long, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalSet
 
RedissonTransactionalSetCache<V> - Class in org.redisson.transaction
 
RedissonTransactionalSetCache(CommandAsyncExecutor, String, List<TransactionalOperation>, long, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalSetCache
 
RedissonTransactionalSetCache(Codec, CommandAsyncExecutor, String, List<TransactionalOperation>, long, AtomicBoolean, String) - Constructor for class org.redisson.transaction.RedissonTransactionalSetCache
 
RedissonTransactionHolder - Class in org.redisson.spring.transaction
 
RedissonTransactionHolder() - Constructor for class org.redisson.spring.transaction.RedissonTransactionHolder
 
RedissonTransactionManager - Class in org.redisson.spring.transaction
 
RedissonTransactionManager(RedissonClient) - Constructor for class org.redisson.spring.transaction.RedissonTransactionManager
 
RedissonTransactionObject - Class in org.redisson.spring.transaction
 
RedissonTransactionObject() - Constructor for class org.redisson.spring.transaction.RedissonTransactionObject
 
RedissonTransactionReactive - Class in org.redisson.reactive
 
RedissonTransactionReactive(CommandReactiveExecutor, TransactionOptions) - Constructor for class org.redisson.reactive.RedissonTransactionReactive
 
RedissonTransactionRx - Class in org.redisson.rx
 
RedissonTransactionRx(CommandRxExecutor, TransactionOptions) - Constructor for class org.redisson.rx.RedissonTransactionRx
 
RedissonTransferQueue<V> - Class in org.redisson
 
RedissonTransferQueue(Codec, CommandAsyncExecutor, String, RRemoteService) - Constructor for class org.redisson.RedissonTransferQueue
 
RedissonTransferQueue(CommandAsyncExecutor, String, RRemoteService) - Constructor for class org.redisson.RedissonTransferQueue
 
RedissonTransferQueue.TransferQueueService - Interface in org.redisson
 
RedissonTransferQueue.TransferQueueServiceAsync - Interface in org.redisson
 
RedissonTransferQueue.TransferQueueServiceImpl - Class in org.redisson
 
RedissonTransferQueueReactive<V> - Class in org.redisson.reactive
 
RedissonTransferQueueReactive(RedissonTransferQueue<V>) - Constructor for class org.redisson.reactive.RedissonTransferQueueReactive
 
RedissonTransferQueueRx<V> - Class in org.redisson.rx
 
RedissonTransferQueueRx(RedissonTransferQueue<V>) - Constructor for class org.redisson.rx.RedissonTransferQueueRx
 
RedissonWebSessionConfiguration - Class in org.redisson.spring.session.config
Exposes the WebSessionManager as the bean named "webSessionManager".
RedissonWebSessionConfiguration() - Constructor for class org.redisson.spring.session.config.RedissonWebSessionConfiguration
 
RedissonWriteLock - Class in org.redisson
Lock will be removed automatically if client disconnects.
RedissonWriteLock(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonWriteLock
 
RedisStrictCommand<T> - Class in org.redisson.client.protocol
 
RedisStrictCommand(String, MultiDecoder<T>) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
 
RedisStrictCommand(String, String, MultiDecoder<T>) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
 
RedisStrictCommand(String) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
 
RedisStrictCommand(String, Convertor<T>) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
 
RedisStrictCommand(String, String) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
 
RedisStrictCommand(String, String, Convertor<T>) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
 
RedisStrictCommand(String, String, MultiDecoder<T>, Convertor) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
 
RedisStrictCommand(String, String, Decoder<T>) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
 
RedisStrictCommand(String, Decoder<T>) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
 
RedisTimeoutException - Exception in org.redisson.client
 
RedisTimeoutException() - Constructor for exception org.redisson.client.RedisTimeoutException
 
RedisTimeoutException(String) - Constructor for exception org.redisson.client.RedisTimeoutException
 
RedisTryAgainException - Exception in org.redisson.client
 
RedisTryAgainException(String) - Constructor for exception org.redisson.client.RedisTryAgainException
 
RedisURI - Class in org.redisson.misc
 
RedisURI(String, String, int) - Constructor for class org.redisson.misc.RedisURI
 
RedisURI(String) - Constructor for class org.redisson.misc.RedisURI
 
reduce(K, Iterator<V>) - Method in interface org.redisson.api.mapreduce.RReducer
Invoked for each key
reducePermits(int) - Method in interface org.redisson.api.RSemaphore
Deprecated.
reducePermits(int) - Method in interface org.redisson.api.RSemaphoreReactive
Deprecated.
reducePermits(int) - Method in interface org.redisson.api.RSemaphoreRx
Deprecated.
reducePermits(int) - Method in class org.redisson.RedissonSemaphore
 
reducePermitsAsync(int) - Method in interface org.redisson.api.RSemaphoreAsync
Deprecated.
reducePermitsAsync(int) - Method in class org.redisson.RedissonSemaphore
 
reducer(RReducer<KOut, VOut>) - Method in interface org.redisson.api.mapreduce.RCollectionMapReduce
Setup Reducer object
reducer(RReducer<KOut, VOut>) - Method in interface org.redisson.api.mapreduce.RMapReduce
Setup Reducer object
reducer(RReducer<KOut, VOut>) - Method in class org.redisson.mapreduce.RedissonCollectionMapReduce
 
reducer(RReducer<KOut, VOut>) - Method in class org.redisson.mapreduce.RedissonMapReduce
 
ReducerTask<KOut,VOut> - Class in org.redisson.mapreduce
 
ReducerTask() - Constructor for class org.redisson.mapreduce.ReducerTask
 
ReducerTask(String, RReducer<KOut, VOut>, Class<?>, String, long) - Constructor for class org.redisson.mapreduce.ReducerTask
 
ReferenceCachedValue<K,V> - Class in org.redisson.cache
Created by jribble on 2/20/17.
ReferenceCachedValue(K, V, long, long, ReferenceQueue<V>, ReferenceCachedValue.Type) - Constructor for class org.redisson.cache.ReferenceCachedValue
 
ReferenceCachedValue.Type - Enum in org.redisson.cache
 
ReferenceCacheMap<K,V> - Class in org.redisson.cache
 
ReferenceCodecProvider - Interface in org.redisson.codec
 
register(Class<T>, T) - Method in interface org.redisson.api.RRemoteService
Register remote service with single worker
register(Class<T>, T, int) - Method in interface org.redisson.api.RRemoteService
Register remote service with custom workers amount
register(Class<T>, T, int, ExecutorService) - Method in interface org.redisson.api.RRemoteService
Register remote service with custom workers amount and executor for running them
register(Class<T>, T) - Method in class org.redisson.RedissonRemoteService
 
register(Class<T>, T, int) - Method in class org.redisson.RedissonRemoteService
 
register(Class<T>, T, int, ExecutorService) - Method in class org.redisson.RedissonRemoteService
 
registerBeanDefinition(BeanDefinitionBuilder, String, String[], ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
registerBeanDefinition(BeanDefinitionBuilder, Element, ParserContext) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class org.redisson.jcache.JCache
 
registerClass(Class<?>) - Method in interface org.redisson.api.RLiveObjectService
Pre register the class with the service, registering all the classes on startup can speed up the instance creation.
registerClass(Class<?>) - Method in class org.redisson.RedissonLiveObjectService
 
registerCodec(Class<T>, T) - Method in class org.redisson.codec.DefaultReferenceCodecProvider
 
registerCodec(Class<T>, T) - Method in interface org.redisson.codec.ReferenceCodecProvider
Register a codec by its class or super class.
registerWorkers(int) - Method in interface org.redisson.api.RExecutorService
Deprecated.
registerWorkers(int, ExecutorService) - Method in interface org.redisson.api.RExecutorService
Deprecated.
registerWorkers(WorkerOptions) - Method in interface org.redisson.api.RExecutorService
Register workers
registerWorkers(int) - Method in class org.redisson.RedissonExecutorService
 
registerWorkers(WorkerOptions) - Method in class org.redisson.RedissonExecutorService
 
registerWorkers(int, ExecutorService) - Method in class org.redisson.RedissonExecutorService
 
release(String) - Method in interface org.redisson.api.RPermitExpirableSemaphore
Releases a permit by its id.
release(String) - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Releases a permit by its id.
release(String) - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Releases a permit by its id, returning it to the semaphore.
release() - Method in interface org.redisson.api.RSemaphore
Releases a permit.
release(int) - Method in interface org.redisson.api.RSemaphore
Releases defined amount of permits.
release() - Method in interface org.redisson.api.RSemaphoreReactive
Releases a permit.
release(int) - Method in interface org.redisson.api.RSemaphoreReactive
Releases defined amount of permits.
release() - Method in interface org.redisson.api.RSemaphoreRx
Releases a permit.
release(int) - Method in interface org.redisson.api.RSemaphoreRx
Releases defined amount of permits.
release() - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
release() - Method in class org.redisson.pubsub.AsyncSemaphore
 
release() - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
release() - Method in interface org.redisson.PubSubEntry
 
release() - Method in class org.redisson.RedissonCountDownLatchEntry
 
release() - Method in class org.redisson.RedissonLockEntry
 
release(String) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
release() - Method in class org.redisson.RedissonSemaphore
 
release(int) - Method in class org.redisson.RedissonSemaphore
 
releaseAsync(String) - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Releases a permit by its id.
releaseAsync() - Method in interface org.redisson.api.RSemaphoreAsync
Releases a permit.
releaseAsync(int) - Method in interface org.redisson.api.RSemaphoreAsync
Releases defined amount of permits.
releaseAsync(String) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
releaseAsync() - Method in class org.redisson.RedissonSemaphore
 
releaseAsync(int) - Method in class org.redisson.RedissonSemaphore
 
releaseConnection(RPromise<R>, RFuture<RedisConnection>) - Method in class org.redisson.command.RedisExecutor
 
releaseConnection(RPromise<R>, RFuture<RedisConnection>) - Method in class org.redisson.command.RedisQueuedBatchExecutor
 
releaseConnection() - Method in class org.redisson.connection.ClientConnectionsEntry
 
releaseConnection(RedisConnection) - Method in class org.redisson.connection.ClientConnectionsEntry
 
releaseConnection(ClientConnectionsEntry) - Method in class org.redisson.connection.pool.PubSubConnectionPool
 
releaseConnection(ClientConnectionsEntry, RedisPubSubConnection) - Method in class org.redisson.connection.pool.PubSubConnectionPool
 
releaseRead(NodeSource, RedisConnection) - Method in interface org.redisson.connection.ConnectionManager
 
releaseRead(NodeSource, RedisConnection) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
releaseRead(RedisConnection) - Method in class org.redisson.connection.MasterSlaveEntry
 
releaseRead(RedisConnection) - Method in class org.redisson.connection.SingleEntry
 
releaseSubscribeConnection(RedisPubSubConnection) - Method in class org.redisson.connection.ClientConnectionsEntry
 
releaseSubscribeConnection() - Method in class org.redisson.connection.ClientConnectionsEntry
 
releaseWrite(NodeSource, RedisConnection) - Method in interface org.redisson.connection.ConnectionManager
 
releaseWrite(NodeSource, RedisConnection) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
releaseWrite(RedisConnection) - Method in class org.redisson.connection.MasterSlaveEntry
 
remainingCapacity() - Method in interface org.redisson.api.RRingBuffer
Returns remaining capacity of this queue
remainingCapacity() - Method in interface org.redisson.api.RRingBufferReactive
Returns remaining capacity of this queue
remainingCapacity() - Method in interface org.redisson.api.RRingBufferRx
Returns remaining capacity of this queue
remainingCapacity() - Method in class org.redisson.RedissonBlockingDeque
 
remainingCapacity() - Method in class org.redisson.RedissonBlockingQueue
 
remainingCapacity() - Method in class org.redisson.RedissonBoundedBlockingQueue
 
remainingCapacity() - Method in class org.redisson.RedissonPriorityBlockingDeque
 
remainingCapacity() - Method in class org.redisson.RedissonPriorityBlockingQueue
 
remainingCapacity() - Method in class org.redisson.RedissonRingBuffer
 
remainingCapacity() - Method in class org.redisson.RedissonTransferQueue
 
remainingCapacityAsync() - Method in interface org.redisson.api.RRingBufferAsync
Returns remaining capacity of this queue
remainingCapacityAsync() - Method in class org.redisson.RedissonRingBuffer
 
remainTimeToLive() - Method in interface org.redisson.api.RExpirable
Remaining time to live of Redisson object that has a timeout
remainTimeToLive() - Method in interface org.redisson.api.RExpirableReactive
Get remaining time to live of object in milliseconds.
remainTimeToLive() - Method in interface org.redisson.api.RExpirableRx
Get remaining time to live of object in milliseconds.
remainTimeToLive(String) - Method in interface org.redisson.api.RKeys
Remaining time to live of Redisson object that has a timeout
remainTimeToLive(String) - Method in interface org.redisson.api.RKeysReactive
Remaining time to live of Redisson object that has a timeout
remainTimeToLive(String) - Method in interface org.redisson.api.RKeysRx
Remaining time to live of Redisson object that has a timeout
remainTimeToLive() - Method in interface org.redisson.api.RLock
Remaining time to live of the lock
remainTimeToLive() - Method in interface org.redisson.api.RLockReactive
Remaining time to live of the lock
remainTimeToLive() - Method in interface org.redisson.api.RLockRx
Remaining time to live of the lock
remainTimeToLive(K) - Method in interface org.redisson.api.RMapCache
Remaining time to live of map entry associated with a key.
remainTimeToLive(K) - Method in interface org.redisson.api.RMapCacheReactive
Remaining time to live of map entry associated with a key.
remainTimeToLive(K) - Method in interface org.redisson.api.RMapCacheRx
Remaining time to live of map entry associated with a key.
remainTimeToLive(String) - Method in class org.redisson.RedissonKeys
 
remainTimeToLive(K) - Method in class org.redisson.RedissonMapCache
 
remainTimeToLive() - Method in class org.redisson.RedissonMultiLock
 
remainTimeToLiveAsync() - Method in interface org.redisson.api.RExpirableAsync
Remaining time to live of Redisson object that has a timeout
remainTimeToLiveAsync(String) - Method in interface org.redisson.api.RKeysAsync
Remaining time to live of Redisson object that has a timeout
remainTimeToLiveAsync() - Method in interface org.redisson.api.RLockAsync
Remaining time to live of the lock
remainTimeToLiveAsync(K) - Method in interface org.redisson.api.RMapCacheAsync
Remaining time to live of map entry associated with a key.
remainTimeToLiveAsync(String) - Method in class org.redisson.RedissonKeys
 
remainTimeToLiveAsync() - Method in class org.redisson.RedissonListMultimapValues
 
remainTimeToLiveAsync(K) - Method in class org.redisson.RedissonMapCache
 
remainTimeToLiveAsync() - Method in class org.redisson.RedissonMultiLock
 
remainTimeToLiveAsync() - Method in class org.redisson.RedissonSetMultimapValues
 
remainTimeToLiveAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
RemoteExecutorService - Interface in org.redisson.executor
 
RemoteExecutorServiceAsync - Interface in org.redisson.executor
 
RemoteInvocationOptionDecorator - Class in org.redisson.spring.support
 
RemoteInvocationOptionDecorator() - Constructor for class org.redisson.spring.support.RemoteInvocationOptionDecorator
 
RemoteInvocationOptions - Class in org.redisson.api
RRemoteService invocation options.
RemoteInvocationOptions(RemoteInvocationOptions) - Constructor for class org.redisson.api.RemoteInvocationOptions
 
RemotePromise<T> - Class in org.redisson.executor
 
RemotePromise(RequestId) - Constructor for class org.redisson.executor.RemotePromise
 
RemoteServiceAck - Class in org.redisson.remote
Worker sends this message when it has received a RemoteServiceRequest.
RemoteServiceAck() - Constructor for class org.redisson.remote.RemoteServiceAck
 
RemoteServiceAck(String) - Constructor for class org.redisson.remote.RemoteServiceAck
 
RemoteServiceAckTimeoutException - Exception in org.redisson.remote
Rises when remote method executor has not answered within Ack timeout.
RemoteServiceAckTimeoutException(String) - Constructor for exception org.redisson.remote.RemoteServiceAckTimeoutException
 
RemoteServiceCancelRequest - Class in org.redisson.remote
 
RemoteServiceCancelRequest() - Constructor for class org.redisson.remote.RemoteServiceCancelRequest
 
RemoteServiceCancelRequest(boolean, boolean) - Constructor for class org.redisson.remote.RemoteServiceCancelRequest
 
RemoteServiceCancelResponse - Class in org.redisson.remote
 
RemoteServiceCancelResponse() - Constructor for class org.redisson.remote.RemoteServiceCancelResponse
 
RemoteServiceCancelResponse(String, boolean) - Constructor for class org.redisson.remote.RemoteServiceCancelResponse
 
RemoteServiceKey - Class in org.redisson.remote
 
RemoteServiceKey(Class<?>, String, long[]) - Constructor for class org.redisson.remote.RemoteServiceKey
 
RemoteServiceMethod - Class in org.redisson.remote
 
RemoteServiceMethod(Method, Object) - Constructor for class org.redisson.remote.RemoteServiceMethod
 
RemoteServiceRequest - Class in org.redisson.remote
 
RemoteServiceRequest() - Constructor for class org.redisson.remote.RemoteServiceRequest
 
RemoteServiceRequest(String) - Constructor for class org.redisson.remote.RemoteServiceRequest
 
RemoteServiceRequest(String, String, String, long[], Object[], RemoteInvocationOptions, long) - Constructor for class org.redisson.remote.RemoteServiceRequest
 
RemoteServiceResponse - Class in org.redisson.remote
 
RemoteServiceResponse() - Constructor for class org.redisson.remote.RemoteServiceResponse
 
RemoteServiceResponse(String, Object) - Constructor for class org.redisson.remote.RemoteServiceResponse
 
RemoteServiceResponse(String, Throwable) - Constructor for class org.redisson.remote.RemoteServiceResponse
 
RemoteServiceTimeoutException - Exception in org.redisson.remote
Rises when invocation timeout has been occurred
RemoteServiceTimeoutException(String) - Constructor for exception org.redisson.remote.RemoteServiceTimeoutException
 
remove(K) - Method in interface org.redisson.api.CacheReactive
This method deletes the mapping for a given key from the cache, if it is present.
remove(K, V) - Method in interface org.redisson.api.CacheReactive
This method atomically removes a key's mapping only if it is currently mapped to the provided value.
remove(K) - Method in interface org.redisson.api.CacheRx
This method deletes the mapping for a given key from the cache, if it is present.
remove(K, V) - Method in interface org.redisson.api.CacheRx
This method atomically removes a key's mapping only if it is currently mapped to the provided value.
remove(V) - Method in interface org.redisson.api.RCollectionReactive
Removes a single instance of the specified element from this collection, if it is present (optional operation).
remove(V) - Method in interface org.redisson.api.RCollectionRx
Removes a single instance of the specified element from this collection, if it is present (optional operation).
remove(Object, int) - Method in interface org.redisson.api.RList
Removes up to count occurrences of element
remove(int) - Method in interface org.redisson.api.RListReactive
Removes element at index.
remove(int) - Method in interface org.redisson.api.RListRx
Removes element at index.
remove(Object) - Method in interface org.redisson.api.RMap
Removes map entry by specified key and returns value.
remove(Object, Object) - Method in interface org.redisson.api.RMap
Removes map entry only if it exists with specified key and value.
remove(K) - Method in interface org.redisson.api.RMapReactive
Removes map entry by specified key and returns value.
remove(Object, Object) - Method in interface org.redisson.api.RMapReactive
Removes map entry only if it exists with specified key and value.
remove(K) - Method in interface org.redisson.api.RMapRx
Removes map entry by specified key and returns value.
remove(Object, Object) - Method in interface org.redisson.api.RMapRx
Removes map entry only if it exists with specified key and value.
remove(Object, Object) - Method in interface org.redisson.api.RMultimap
Removes a single key-value pair with the key key and the value value from this multimap, if such exists.
remove(Object, Object) - Method in interface org.redisson.api.RMultimapReactive
Removes a single key-value pair with the key key and the value value from this multimap, if such exists.
remove(Object, Object) - Method in interface org.redisson.api.RMultimapRx
Removes a single key-value pair with the key key and the value value from this multimap, if such exists.
remove(Object) - Method in interface org.redisson.api.RScoredSortedSet
Removes a single instance of the specified element from this sorted set, if it is present.
remove(V) - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes a single instance of the specified element from this sorted set, if it is present.
remove(V) - Method in interface org.redisson.api.RScoredSortedSetRx
Removes a single instance of the specified element from this sorted set, if it is present.
remove(StreamMessageId...) - Method in interface org.redisson.api.RStream
Removes messages by id.
remove(StreamMessageId...) - Method in interface org.redisson.api.RStreamReactive
Removes messages by id.
remove(StreamMessageId...) - Method in interface org.redisson.api.RStreamRx
Removes messages by id.
remove(Object) - Method in class org.redisson.cache.AbstractCacheMap
 
remove(Object, Object) - Method in class org.redisson.cache.AbstractCacheMap
 
remove() - Method in class org.redisson.cache.LocalCacheListener
 
remove(ClientConnectionsEntry) - Method in class org.redisson.connection.pool.MasterConnectionPool
 
remove(ClientConnectionsEntry) - Method in class org.redisson.connection.pool.MasterPubSubConnectionPool
 
remove(String) - Method in class org.redisson.eviction.EvictionScheduler
 
remove() - Method in class org.redisson.iterator.BaseIterator
 
remove(E) - Method in class org.redisson.iterator.BaseIterator
 
remove(int) - Method in class org.redisson.iterator.RedissonListIterator
 
remove() - Method in class org.redisson.iterator.RedissonListIterator
 
remove(Map.Entry<Object, Object>) - Method in class org.redisson.iterator.RedissonMapIterator
 
remove(K) - Method in class org.redisson.jcache.JCache
 
remove(K, V) - Method in class org.redisson.jcache.JCache
 
remove() - Method in class org.redisson.jcache.JMutableEntry
 
Remove() - Constructor for class org.redisson.MapWriterTask.Remove
 
Remove(Collection<?>) - Constructor for class org.redisson.MapWriterTask.Remove
 
Remove(Object) - Constructor for class org.redisson.MapWriterTask.Remove
 
remove(Object) - Method in class org.redisson.misc.BiHashMap
 
remove() - Method in class org.redisson.misc.CompositeIterator
 
remove(Runnable) - Method in class org.redisson.pubsub.AsyncSemaphore
 
remove(String) - Method in class org.redisson.QueueTransferService
 
remove() - Method in class org.redisson.RedissonDelayedQueue
 
remove(Object) - Method in class org.redisson.RedissonDelayedQueue
 
remove(Object) - Method in class org.redisson.RedissonList
 
remove(Object, int) - Method in class org.redisson.RedissonList
 
remove(int) - Method in class org.redisson.RedissonList
 
remove(Object) - Method in class org.redisson.RedissonListMultimapValues
 
remove(Object, int) - Method in class org.redisson.RedissonListMultimapValues
 
remove(int) - Method in class org.redisson.RedissonListMultimapValues
 
remove(Object) - Method in class org.redisson.RedissonMap
 
remove(Object, Object) - Method in class org.redisson.RedissonMap
 
remove(Object, Object) - Method in class org.redisson.RedissonMultimap
 
remove(Object) - Method in class org.redisson.RedissonPriorityQueue
 
remove() - Method in class org.redisson.RedissonPriorityQueue
 
remove() - Method in class org.redisson.RedissonQueue
 
remove(Object) - Method in class org.redisson.RedissonScoredSortedSet
 
remove(Object) - Method in class org.redisson.RedissonSet
 
remove(Object) - Method in class org.redisson.RedissonSetCache
 
remove(Object) - Method in class org.redisson.RedissonSetMultimapValues
 
remove(Object) - Method in class org.redisson.RedissonSortedSet
 
remove(StreamMessageId...) - Method in class org.redisson.RedissonStream
 
remove(int) - Method in class org.redisson.RedissonSubList
 
remove() - Method in class org.redisson.RedissonTransferQueue
 
remove(Object) - Method in class org.redisson.RedissonTransferQueue
 
remove(Object) - Method in interface org.redisson.ScanIterator
 
removeAll(Set<? extends K>) - Method in interface org.redisson.api.CacheReactive
This method deletes the entries for the given keys.
removeAll(Set<? extends K>) - Method in interface org.redisson.api.CacheRx
This method deletes the entries for the given keys.
removeAll(Collection<?>) - Method in interface org.redisson.api.RCollectionReactive
Removes all of this collection's elements that are also contained in the specified collection (optional operation).
removeAll(Collection<?>) - Method in interface org.redisson.api.RCollectionRx
Removes all of this collection's elements that are also contained in the specified collection (optional operation).
removeAll(Object) - Method in interface org.redisson.api.RListMultimap
Removes all values associated with the key key.
removeAll(Object) - Method in interface org.redisson.api.RListMultimapReactive
Removes all values associated with the key key.
removeAll(Object) - Method in interface org.redisson.api.RListMultimapRx
Removes all values associated with the key key.
removeAll(Object) - Method in interface org.redisson.api.RMultimap
Removes all values associated with the key key.
removeAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSet
Removes all of this sorted set's elements that are also contained in the specified collection.
removeAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes all of this sorted set's elements that are also contained in the specified collection.
removeAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetRx
Removes all of this sorted set's elements that are also contained in the specified collection.
removeAll(Object) - Method in interface org.redisson.api.RSetMultimap
Removes all values associated with the key key.
removeAll(Object) - Method in interface org.redisson.api.RSetMultimapReactive
Removes all values associated with the key key.
removeAll(Object) - Method in interface org.redisson.api.RSetMultimapRx
Removes all values associated with the key key.
removeAll(Set<? extends K>) - Method in class org.redisson.jcache.JCache
 
removeAll() - Method in class org.redisson.jcache.JCache
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonDelayedQueue
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonList
 
removeAll(Object) - Method in class org.redisson.RedissonListMultimap
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonListMultimapValues
 
removeAll(Object) - Method in class org.redisson.RedissonMultimap
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonPriorityQueue
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonScoredSortedSet
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonSet
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonSetCache
 
removeAll(Object) - Method in class org.redisson.RedissonSetMultimap
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonSetMultimapValues
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonSortedSet
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonTransferQueue
 
removeAllAsync(Set<? extends K>) - Method in interface org.redisson.api.CacheAsync
This method deletes the entries for the given keys.
removeAllAsync(Collection<?>) - Method in interface org.redisson.api.RCollectionAsync
Removes all of this collection's elements that are also contained in the specified collection.
removeAllAsync(Object) - Method in interface org.redisson.api.RMultimapAsync
Removes all values associated with the key key.
removeAllAsync(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes all of this sorted set's elements that are also contained in the specified collection.
removeAllAsync(Set<? extends K>) - Method in class org.redisson.jcache.JCache
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonDelayedQueue
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonList
 
removeAllAsync(Object) - Method in class org.redisson.RedissonListMultimap
 
removeAllAsync(Object) - Method in class org.redisson.RedissonListMultimapCache
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonListMultimapValues
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonScoredSortedSet
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonSet
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonSetCache
 
removeAllAsync(Object) - Method in class org.redisson.RedissonSetMultimap
 
removeAllAsync(Object) - Method in class org.redisson.RedissonSetMultimapCache
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonSetMultimapValues
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonSubList
 
removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonTransferQueue
 
removeAllAsync(Collection<?>) - Method in class org.redisson.transaction.BaseTransactionalSet
 
removeAllAsync(Collection<?>) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
removeAllAsync(Collection<?>) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
removeAllListeners() - Method in interface org.redisson.api.RPatternTopic
Removes all listeners from this topic
removeAllListeners() - Method in interface org.redisson.api.RTopic
Removes all listeners from this topic
removeAllListeners(ChannelName) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
removeAllListeners() - Method in class org.redisson.RedissonPatternTopic
 
removeAllListeners() - Method in class org.redisson.RedissonTopic
 
removeAsync(K) - Method in interface org.redisson.api.CacheAsync
This method deletes the mapping for a given key from the cache, if it is present.
removeAsync(K, V) - Method in interface org.redisson.api.CacheAsync
This method atomically removes a key's mapping only if it is currently mapped to the provided value.
removeAsync(Object) - Method in interface org.redisson.api.RCollectionAsync
Removes a single instance of the specified element from this collection, if it is present.
removeAsync(int) - Method in interface org.redisson.api.RListAsync
Removes element at index.
removeAsync(Object, int) - Method in interface org.redisson.api.RListAsync
Removes up to count occurrences of element
removeAsync(K) - Method in interface org.redisson.api.RMapAsync
Removes map entry by specified key and returns value.
removeAsync(Object, Object) - Method in interface org.redisson.api.RMapAsync
Removes map entry only if it exists with specified key and value.
removeAsync(Object, Object) - Method in interface org.redisson.api.RMultimapAsync
Removes a single key-value pair with the key key and the value value from this multimap, if such exists.
removeAsync(V) - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes a single instance of the specified element from this sorted set, if it is present.
removeAsync(Object) - Method in interface org.redisson.api.RSortedSet
 
removeAsync(StreamMessageId...) - Method in interface org.redisson.api.RStreamAsync
Removes messages by id.
removeAsync(String, RequestId) - Method in class org.redisson.executor.ScheduledTasksService
 
removeAsync(String, RequestId) - Method in class org.redisson.executor.TasksService
 
removeAsync(K) - Method in class org.redisson.jcache.JCache
 
removeAsync(K, V) - Method in class org.redisson.jcache.JCache
 
removeAsync(Object) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
removeAsync(Object) - Method in class org.redisson.RedissonDelayedQueue
 
removeAsync(Object, int) - Method in class org.redisson.RedissonDelayedQueue
 
removeAsync(Object) - Method in class org.redisson.RedissonList
 
removeAsync(Object, int) - Method in class org.redisson.RedissonList
 
removeAsync(int) - Method in class org.redisson.RedissonList
 
removeAsync(Object, Object) - Method in class org.redisson.RedissonListMultimap
 
removeAsync(Object) - Method in class org.redisson.RedissonListMultimapValues
 
removeAsync(Object, int) - Method in class org.redisson.RedissonListMultimapValues
 
removeAsync(int) - Method in class org.redisson.RedissonListMultimapValues
 
removeAsync(Object, Object) - Method in class org.redisson.RedissonLocalCachedMap
 
removeAsync(Object, Object) - Method in class org.redisson.RedissonMap
 
removeAsync(K) - Method in class org.redisson.RedissonMap
 
removeAsync(Object, int) - Method in class org.redisson.RedissonPriorityDeque
 
removeAsync(String, RequestId) - Method in class org.redisson.RedissonRemoteService
 
removeAsync(Object) - Method in class org.redisson.RedissonScoredSortedSet
 
removeAsync(Object) - Method in class org.redisson.RedissonSet
 
removeAsync(Object) - Method in class org.redisson.RedissonSetCache
 
removeAsync(Object, Object) - Method in class org.redisson.RedissonSetMultimap
 
removeAsync(Object) - Method in class org.redisson.RedissonSetMultimapValues
 
removeAsync(Object) - Method in class org.redisson.RedissonSortedSet
 
removeAsync(StreamMessageId...) - Method in class org.redisson.RedissonStream
 
removeAsync(Object) - Method in class org.redisson.RedissonSubList
 
removeAsync(Object) - Method in class org.redisson.RedissonTransferQueue
 
removeAsync(String, RequestId) - Method in class org.redisson.remote.BaseRemoteService
 
removeAsync(Object) - Method in class org.redisson.transaction.BaseTransactionalSet
 
removeAsync(Object) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
removeAsync(Object) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
RemoveCacheOperation - Class in org.redisson.transaction.operation.set
 
RemoveCacheOperation(RObject, Object, String, long) - Constructor for class org.redisson.transaction.operation.set.RemoveCacheOperation
 
RemoveCacheOperation(String, Codec, Object, String, long) - Constructor for class org.redisson.transaction.operation.set.RemoveCacheOperation
 
removeConnection(Runnable) - Method in class org.redisson.connection.ClientConnectionsEntry
 
removeConnectionListener(int) - Method in interface org.redisson.api.NodesGroup
Deprecated.
Removes connection listener by id
removeConnectionListener(int) - Method in class org.redisson.RedisNodes
Deprecated.
 
removeConsumer(String, String) - Method in interface org.redisson.api.RStream
Removes consumer of the group by name.
removeConsumer(String, String) - Method in interface org.redisson.api.RStreamReactive
Removes consumer of the group by name.
removeConsumer(String, String) - Method in interface org.redisson.api.RStreamRx
Removes consumer of the group by name.
removeConsumer(String, String) - Method in class org.redisson.RedissonStream
 
removeConsumerAsync(String, String) - Method in interface org.redisson.api.RStreamAsync
Removes consumer of the group by name.
removeConsumerAsync(String, String) - Method in class org.redisson.RedissonStream
 
removeDisconnectListener(ChannelName) - Method in class org.redisson.client.RedisPubSubConnection
 
removeEntry(Integer) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
removeExpiredEntries() - Method in class org.redisson.cache.AbstractCacheMap
 
removeExpiredEntries() - Method in class org.redisson.cache.ReferenceCacheMap
 
removeFailedSlaveAddress(RedisURI) - Method in class org.redisson.cluster.ClusterPartition
 
removeFirst() - Method in interface org.redisson.api.RDequeReactive
Retrieves and removes the first element of deque.
removeFirst() - Method in interface org.redisson.api.RDequeRx
Retrieves and removes the first element of deque.
removeFirst() - Method in class org.redisson.RedissonPriorityQueue
 
removeFirst() - Method in class org.redisson.RedissonQueue
 
removeFirstAsync() - Method in interface org.redisson.api.RDequeAsync
Retrieves and removes the first element of deque.
removeFirstAsync() - Method in class org.redisson.RedissonDeque
 
removeFirstAsync() - Method in class org.redisson.RedissonPriorityDeque
 
removeFirstOccurrence(Object) - Method in interface org.redisson.api.RDequeReactive
Removes first occurrence of element o
removeFirstOccurrence(Object) - Method in interface org.redisson.api.RDequeRx
Removes first occurrence of element o
removeFirstOccurrence(Object) - Method in class org.redisson.RedissonDeque
 
removeFirstOccurrence(Object) - Method in class org.redisson.RedissonPriorityDeque
 
removeFirstOccurrenceAsync(Object) - Method in interface org.redisson.api.RDequeAsync
Removes first occurrence of element o
removeFirstOccurrenceAsync(Object) - Method in class org.redisson.RedissonDeque
 
removeFirstOccurrenceAsync(Object) - Method in class org.redisson.RedissonPriorityDeque
 
removeGroup(String) - Method in interface org.redisson.api.RStream
Removes group by name.
removeGroup(String) - Method in interface org.redisson.api.RStreamReactive
Removes group by name.
removeGroup(String) - Method in interface org.redisson.api.RStreamRx
Removes group by name.
removeGroup(String) - Method in class org.redisson.RedissonStream
 
removeGroupAsync(String) - Method in interface org.redisson.api.RStreamAsync
Removes group by name.
removeGroupAsync(String) - Method in class org.redisson.RedissonStream
 
removeLast() - Method in interface org.redisson.api.RDequeReactive
Retrieves and removes the last element of deque.
removeLast() - Method in interface org.redisson.api.RDequeRx
Retrieves and removes the last element of deque.
removeLast() - Method in class org.redisson.RedissonDeque
 
removeLast() - Method in class org.redisson.RedissonPriorityDeque
 
removeLastAsync() - Method in interface org.redisson.api.RDequeAsync
Retrieves and removes the last element of deque.
removeLastAsync() - Method in class org.redisson.RedissonDeque
 
removeLastAsync() - Method in class org.redisson.RedissonPriorityDeque
 
removeLastOccurrence(Object) - Method in interface org.redisson.api.RDequeReactive
Removes last occurrence of element o
removeLastOccurrence(Object) - Method in interface org.redisson.api.RDequeRx
Removes last occurrence of element o
removeLastOccurrence(Object) - Method in class org.redisson.RedissonDeque
 
removeLastOccurrence(Object) - Method in class org.redisson.RedissonPriorityDeque
 
removeLastOccurrenceAsync(Object) - Method in interface org.redisson.api.RDequeAsync
Removes last occurrence of element o
removeLastOccurrenceAsync(Object) - Method in class org.redisson.RedissonDeque
 
removeLastOccurrenceAsync(Object) - Method in class org.redisson.RedissonPriorityDeque
 
removeListener(int) - Method in interface org.redisson.api.RMapCache
Removes map entry listener
removeListener(int) - Method in interface org.redisson.api.RObject
Removes object event listener
removeListener(int) - Method in interface org.redisson.api.RObjectReactive
Removes object event listener
removeListener(int) - Method in interface org.redisson.api.RObjectRx
Removes object event listener
removeListener(int) - Method in interface org.redisson.api.RPatternTopic
Removes the listener by id for listening this topic
removeListener(PatternMessageListener<?>) - Method in interface org.redisson.api.RPatternTopic
Removes the listener by its instance
removeListener(int) - Method in interface org.redisson.api.RPatternTopicReactive
Removes the listener by id for listening this topic
removeListener(int) - Method in interface org.redisson.api.RPatternTopicRx
Removes the listener by id for listening this topic
removeListener(MessageListener<?>) - Method in interface org.redisson.api.RTopic
Removes the listener by its instance
removeListener(Integer...) - Method in interface org.redisson.api.RTopic
Removes the listener by id for listening this topic
removeListener(Integer...) - Method in interface org.redisson.api.RTopicReactive
Removes the listener by id for listening this topic
removeListener(MessageListener<?>) - Method in interface org.redisson.api.RTopicReactive
Removes the listener by instance for listening this topic
removeListener(Integer...) - Method in interface org.redisson.api.RTopicRx
Removes the listener by id for listening this topic
removeListener(MessageListener<?>) - Method in interface org.redisson.api.RTopicRx
Removes the listener by instance for listening this topic
removeListener(RedisPubSubListener<?>) - Method in class org.redisson.client.RedisPubSubConnection
 
removeListener(int) - Method in class org.redisson.connection.ConnectionEventsHub
 
removeListener(ChannelName, EventListener) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
removeListener(ChannelName, int) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
removeListener(ChannelName, RedisPubSubListener<?>) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
removeListener(int) - Method in class org.redisson.RedissonBucket
 
removeListener(Runnable) - Method in class org.redisson.RedissonCountDownLatchEntry
 
removeListener(int) - Method in class org.redisson.RedissonList
 
removeListener(Runnable) - Method in class org.redisson.RedissonLockEntry
 
removeListener(int) - Method in class org.redisson.RedissonMapCache
 
removeListener(int) - Method in class org.redisson.RedissonObject
 
removeListener(int) - Method in class org.redisson.RedissonPatternTopic
 
removeListener(PatternMessageListener<?>) - Method in class org.redisson.RedissonPatternTopic
 
removeListener(MessageListener<?>) - Method in class org.redisson.RedissonTopic
 
removeListener(Integer...) - Method in class org.redisson.RedissonTopic
 
removeListenerAsync(int) - Method in interface org.redisson.api.RObjectAsync
Removes object event listener
removeListenerAsync(int) - Method in interface org.redisson.api.RPatternTopic
 
removeListenerAsync(Integer...) - Method in interface org.redisson.api.RTopicAsync
Removes the listener by id for listening this topic
removeListenerAsync(MessageListener<?>) - Method in interface org.redisson.api.RTopicAsync
Removes the listener by its instance
removeListenerAsync(int) - Method in class org.redisson.RedissonBucket
 
removeListenerAsync(int) - Method in class org.redisson.RedissonList
 
removeListenerAsync(int) - Method in class org.redisson.RedissonObject
 
removeListenerAsync(int) - Method in class org.redisson.RedissonPatternTopic
 
removeListenerAsync(MessageListener<?>) - Method in class org.redisson.RedissonTopic
 
removeListenerAsync(Integer...) - Method in class org.redisson.RedissonTopic
 
removeListeners() - Method in class org.redisson.pubsub.AsyncSemaphore
 
removeListenersAsync(int, CountableListener<Void>) - Method in class org.redisson.RedissonObject
 
removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
removeNotificationListener(NotificationListener) - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
RemoveOperation - Class in org.redisson.transaction.operation.set
 
RemoveOperation(RObject, Object, String, long) - Constructor for class org.redisson.transaction.operation.set.RemoveOperation
 
RemoveOperation(String, Codec, Object, String, long) - Constructor for class org.redisson.transaction.operation.set.RemoveOperation
 
removeOperationAsync(K) - Method in class org.redisson.RedissonLocalCachedMap
 
removeOperationAsync(Object, Object) - Method in class org.redisson.RedissonLocalCachedMap
 
removeOperationAsync(Object, Object) - Method in class org.redisson.RedissonMap
 
removeOperationAsync(K) - Method in class org.redisson.RedissonMap
 
removeOperationAsync(Object, Object) - Method in class org.redisson.RedissonMapCache
 
removeOperationAsync(K) - Method in class org.redisson.RedissonMapCache
 
removeOperationAsync(K) - Method in class org.redisson.transaction.BaseTransactionalMap
 
removeOperationAsync(Object, Object) - Method in class org.redisson.transaction.BaseTransactionalMap
 
removeOperationAsync(K) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
removeOperationAsync(Object, Object) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
removeOperationAsync(K) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
removeOperationAsync(Object, Object) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
removeRandom(int) - Method in interface org.redisson.api.RSet
Removes and returns random elements limited by amount
removeRandom() - Method in interface org.redisson.api.RSet
Removes and returns random element
removeRandom(int) - Method in interface org.redisson.api.RSetReactive
Removes and returns random elements limited by amount
removeRandom() - Method in interface org.redisson.api.RSetReactive
Removes and returns random element
removeRandom(int) - Method in interface org.redisson.api.RSetRx
Removes and returns random elements limited by amount
removeRandom() - Method in interface org.redisson.api.RSetRx
Removes and returns random element
removeRandom() - Method in class org.redisson.RedissonSet
 
removeRandom(int) - Method in class org.redisson.RedissonSet
 
removeRandom() - Method in class org.redisson.RedissonSetMultimapValues
 
removeRandom(int) - Method in class org.redisson.RedissonSetMultimapValues
 
removeRandomAsync(int) - Method in interface org.redisson.api.RSetAsync
Removes and returns random elements from set in async mode
removeRandomAsync() - Method in interface org.redisson.api.RSetAsync
Removes and returns random element from set in async mode
removeRandomAsync() - Method in class org.redisson.RedissonSet
 
removeRandomAsync(int) - Method in class org.redisson.RedissonSet
 
removeRandomAsync() - Method in class org.redisson.RedissonSetMultimapValues
 
removeRandomAsync(int) - Method in class org.redisson.RedissonSetMultimapValues
 
removeRandomAsync() - Method in class org.redisson.transaction.BaseTransactionalSet
 
removeRandomAsync(int) - Method in class org.redisson.transaction.BaseTransactionalSet
 
removeRandomAsync() - Method in class org.redisson.transaction.RedissonTransactionalSet
 
removeRandomAsync(int) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
removeRange(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Removes values range starting with fromElement and ending with toElement.
removeRange(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
Removes values range starting with fromElement and ending with toElement.
removeRange(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetRx
Removes values range starting with fromElement and ending with toElement.
removeRange(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
removeRangeAsync(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Removes values range starting with fromElement and ending with toElement.
removeRangeAsync(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
removeRangeByRank(int, int) - Method in interface org.redisson.api.RScoredSortedSet
Removes values by rank range.
removeRangeByRank(int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes values by rank range.
removeRangeByRank(int, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Removes values by rank range.
removeRangeByRank(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
removeRangeByRankAsync(int, int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes values by rank range.
removeRangeByRankAsync(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
removeRangeByScore(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSet
Removes values by score range.
removeRangeByScore(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes values by score range.
removeRangeByScore(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetRx
Removes values by score range.
removeRangeByScore(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
removeRangeByScoreAsync(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes values by score range.
removeRangeByScoreAsync(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
removeRangeHead(String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Removes head values range ending with toElement.
removeRangeHead(String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
Removes head values range ending with toElement.
removeRangeHead(String, boolean) - Method in interface org.redisson.api.RLexSortedSetRx
Removes head values range ending with toElement.
removeRangeHead(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
removeRangeHeadAsync(String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Removes head values range ending with toElement.
removeRangeHeadAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
removeRangeTail(String, boolean) - Method in interface org.redisson.api.RLexSortedSet
Removes tail values range starting with fromElement.
removeRangeTail(String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
Removes tail values range starting with fromElement.
removeRangeTail(String, boolean) - Method in interface org.redisson.api.RLexSortedSetRx
Removes tail values range starting with fromElement.
removeRangeTail(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
removeRangeTailAsync(String, boolean) - Method in interface org.redisson.api.RLexSortedSetAsync
Removes tail values range starting with fromElement.
removeRangeTailAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
 
removeSlaveAddress(RedisURI) - Method in class org.redisson.cluster.ClusterPartition
 
removeSlotRanges(Set<ClusterSlotRange>) - Method in class org.redisson.cluster.ClusterPartition
 
removeSlots(BitSet) - Method in class org.redisson.cluster.ClusterPartition
 
removeThreadId(long) - Method in class org.redisson.RedissonLock.ExpirationEntry
 
rename(String, String) - Method in interface org.redisson.api.RKeys
Rename current object key to newName
rename(String, String) - Method in interface org.redisson.api.RKeysReactive
Rename current object key to newName
rename(String, String) - Method in interface org.redisson.api.RKeysRx
Rename current object key to newName
rename(String) - Method in interface org.redisson.api.RObject
Rename current object key to newName
rename(String) - Method in interface org.redisson.api.RObjectReactive
Rename current object key to newName in mode
rename(String) - Method in interface org.redisson.api.RObjectRx
Rename current object key to newName in mode
RENAME - Static variable in interface org.redisson.client.protocol.RedisCommands
 
rename(String, String) - Method in class org.redisson.RedissonKeys
 
rename(String) - Method in class org.redisson.RedissonObject
 
renameAsync(String, String) - Method in interface org.redisson.api.RKeysAsync
Rename current object key to newName
renameAsync(String) - Method in interface org.redisson.api.RObjectAsync
Rename current object key to newName in async mode
renameAsync(String, String) - Method in class org.redisson.RedissonKeys
 
renameAsync(String) - Method in class org.redisson.RedissonListMultimapValues
 
renameAsync(String) - Method in class org.redisson.RedissonMultimap
 
renameAsync(String) - Method in class org.redisson.RedissonObject
 
renameAsync(String) - Method in class org.redisson.RedissonSetMultimapValues
 
renamenx(String, String) - Method in interface org.redisson.api.RKeys
Rename object with oldName to newName only if new key is not exists
renamenx(String, String) - Method in interface org.redisson.api.RKeysReactive
Rename object with oldName to newName only if new key is not exists
renamenx(String, String) - Method in interface org.redisson.api.RKeysRx
Rename object with oldName to newName only if new key is not exists
renamenx(String) - Method in interface org.redisson.api.RObject
Rename current object key to newName only if new key is not exists
renamenx(String) - Method in interface org.redisson.api.RObjectReactive
Rename current object key to newName in mode only if new key is not exists
renamenx(String) - Method in interface org.redisson.api.RObjectRx
Rename current object key to newName in mode only if new key is not exists
RENAMENX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
renamenx(String, String) - Method in class org.redisson.RedissonKeys
 
renamenx(String) - Method in class org.redisson.RedissonObject
 
renamenxAsync(String, String) - Method in interface org.redisson.api.RKeysAsync
Rename object with oldName to newName only if new key is not exists
renamenxAsync(String) - Method in interface org.redisson.api.RObjectAsync
Rename current object key to newName in async mode only if new key is not exists
renamenxAsync(String, String) - Method in class org.redisson.RedissonKeys
 
renamenxAsync(String) - Method in class org.redisson.RedissonListMultimapValues
 
renamenxAsync(String) - Method in class org.redisson.RedissonMultimap
 
renamenxAsync(String) - Method in class org.redisson.RedissonObject
 
renamenxAsync(String) - Method in class org.redisson.RedissonSetMultimapValues
 
renewExpirationAsync(long) - Method in class org.redisson.RedissonLock
 
renewExpirationAsync(long) - Method in class org.redisson.RedissonReadLock
 
renewRetryTime(String) - Method in class org.redisson.executor.TasksRunnerService
 
REntity - Annotation Type in org.redisson.api.annotation
Specifies that the class is a Live Object.
REntity.DEFAULT - Class in org.redisson.api.annotation
 
REntity.TransformationMode - Enum in org.redisson.api.annotation
 
replace(K, V, V) - Method in interface org.redisson.api.CacheReactive
This method atomically replaces an entry only if the key is currently mapped to a given value.
replace(K, V) - Method in interface org.redisson.api.CacheReactive
This method atomically replaces an entry only if the key is currently mapped to some value.
replace(K, V, V) - Method in interface org.redisson.api.CacheRx
This method atomically replaces an entry only if the key is currently mapped to a given value.
replace(K, V) - Method in interface org.redisson.api.CacheRx
This method atomically replaces an entry only if the key is currently mapped to some value.
replace(K, V) - Method in interface org.redisson.api.RMap
Replaces previous value with a new value mapped by specified key.
replace(K, V, V) - Method in interface org.redisson.api.RMap
Replaces previous oldValue with a newValue mapped by specified key.
replace(K, V) - Method in interface org.redisson.api.RMapReactive
Replaces previous value with a new value mapped by specified key.
replace(K, V, V) - Method in interface org.redisson.api.RMapReactive
Replaces previous oldValue with a newValue mapped by specified key.
replace(K, V) - Method in interface org.redisson.api.RMapRx
Replaces previous value with a new value mapped by specified key.
replace(K, V, V) - Method in interface org.redisson.api.RMapRx
Replaces previous oldValue with a newValue mapped by specified key.
replace(K, V, V) - Method in class org.redisson.cache.AbstractCacheMap
 
replace(K, V) - Method in class org.redisson.cache.AbstractCacheMap
 
replace(K, V, V) - Method in class org.redisson.jcache.JCache
 
replace(K, V) - Method in class org.redisson.jcache.JCache
 
replace(K, V, V) - Method in class org.redisson.RedissonMap
 
replace(K, V) - Method in class org.redisson.RedissonMap
 
replaceAsync(K, V, V) - Method in interface org.redisson.api.CacheAsync
This method atomically replaces an entry only if the key is currently mapped to a given value.
replaceAsync(K, V) - Method in interface org.redisson.api.CacheAsync
This method atomically replaces an entry only if the key is currently mapped to some value.
replaceAsync(K, V) - Method in interface org.redisson.api.RMapAsync
Replaces previous value with a new value mapped by specified key.
replaceAsync(K, V, V) - Method in interface org.redisson.api.RMapAsync
Replaces previous oldValue with a newValue mapped by specified key.
replaceAsync(K, V, V) - Method in class org.redisson.jcache.JCache
 
replaceAsync(K, V) - Method in class org.redisson.jcache.JCache
 
replaceAsync(K, V) - Method in class org.redisson.RedissonLocalCachedMap
 
replaceAsync(K, V, V) - Method in class org.redisson.RedissonLocalCachedMap
 
replaceAsync(K, V, V) - Method in class org.redisson.RedissonMap
 
replaceAsync(K, V) - Method in class org.redisson.RedissonMap
 
replaceOperationAsync(K, V) - Method in class org.redisson.RedissonLocalCachedMap
 
replaceOperationAsync(K, V, V) - Method in class org.redisson.RedissonLocalCachedMap
 
replaceOperationAsync(K, V, V) - Method in class org.redisson.RedissonMap
 
replaceOperationAsync(K, V) - Method in class org.redisson.RedissonMap
 
replaceOperationAsync(K, V, V) - Method in class org.redisson.RedissonMapCache
 
replaceOperationAsync(K, V) - Method in class org.redisson.RedissonMapCache
 
replaceOperationAsync(K, V, V) - Method in class org.redisson.transaction.BaseTransactionalMap
 
replaceOperationAsync(K, V) - Method in class org.redisson.transaction.BaseTransactionalMap
 
replaceOperationAsync(K, V, V) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
replaceOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
replaceOperationAsync(K, V, V) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
replaceOperationAsync(K, V) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
replaceValues(K, Iterable<? extends V>) - Method in interface org.redisson.api.RListMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.redisson.api.RListMultimapReactive
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.redisson.api.RListMultimapRx
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.redisson.api.RMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.redisson.api.RSetMultimap
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.redisson.api.RSetMultimapReactive
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in interface org.redisson.api.RSetMultimapRx
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValues(K, Iterable<? extends V>) - Method in class org.redisson.RedissonListMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class org.redisson.RedissonMultimap
 
replaceValues(K, Iterable<? extends V>) - Method in class org.redisson.RedissonSetMultimap
 
replaceValuesAsync(K, Iterable<? extends V>) - Method in interface org.redisson.api.RMultimapAsync
Stores a collection of values with the same key, replacing any existing values for that key.
replaceValuesAsync(K, Iterable<? extends V>) - Method in class org.redisson.RedissonListMultimap
 
replaceValuesAsync(K, Iterable<? extends V>) - Method in class org.redisson.RedissonSetMultimap
 
ReplicatedConnectionManager - Class in org.redisson.connection
ConnectionManager for AWS ElastiCache Replication Groups or Azure Redis Cache.
ReplicatedConnectionManager(ReplicatedServersConfig, Config, UUID) - Constructor for class org.redisson.connection.ReplicatedConnectionManager
 
ReplicatedServersConfig - Class in org.redisson.config
Configuration for an Azure Redis Cache or AWS ElastiCache servers.
ReplicatedServersConfig() - Constructor for class org.redisson.config.ReplicatedServersConfig
 
RequestId - Class in org.redisson.remote
 
RequestId(String) - Constructor for class org.redisson.remote.RequestId
 
RequestId(byte[]) - Constructor for class org.redisson.remote.RequestId
 
RequiredIdResolver - Class in org.redisson.liveobject.resolver
 
RequiredIdResolver() - Constructor for class org.redisson.liveobject.resolver.RequiredIdResolver
 
reset() - Method in interface org.redisson.api.RDoubleAdder
Resets value across all RDoubleAdder instances
reset() - Method in interface org.redisson.api.RLongAdder
Resets value across all RLongAdder instances
reset() - Method in class org.redisson.connection.ClientConnectionsEntry
 
reset() - Method in class org.redisson.RedissonBaseAdder
 
reset(long, TimeUnit) - Method in class org.redisson.RedissonBaseAdder
 
resetAsync() - Method in interface org.redisson.api.RDoubleAdder
Resets value across all RDoubleAdder instances
resetAsync(long, TimeUnit) - Method in interface org.redisson.api.RDoubleAdder
Resets value across all RDoubleAdder instances within defined timeout.
resetAsync() - Method in interface org.redisson.api.RLongAdder
Resets value across all RLongAdder instances
resetAsync(long, TimeUnit) - Method in interface org.redisson.api.RLongAdder
Resets value across all RLongAdder instances within defined timeout.
resetAsync() - Method in class org.redisson.RedissonBaseAdder
 
resetAsync(long, TimeUnit) - Method in class org.redisson.RedissonBaseAdder
 
resetFirstFail() - Method in class org.redisson.connection.ClientConnectionsEntry
 
resolve(Class<?>, RId, String, CommandAsyncExecutor) - Method in class org.redisson.liveobject.resolver.LongGenerator
 
resolve(Class<?>, RId, String, CommandAsyncExecutor) - Method in class org.redisson.liveobject.resolver.RequiredIdResolver
 
resolve(Class<?>, RId, String, CommandAsyncExecutor) - Method in interface org.redisson.liveobject.resolver.RIdResolver
RLiveObjectService instantiate the class and invokes this method to get a value used as the value for the field with RId annotation.
resolve(Class<?>, RId, String, CommandAsyncExecutor) - Method in class org.redisson.liveobject.resolver.UUIDGenerator
 
resolveAddr() - Method in class org.redisson.client.RedisClient
 
resolveClass(ObjectStreamClass) - Method in class org.redisson.codec.CustomObjectInputStream
 
resolveClassName(String) - Method in class org.redisson.liveobject.resolver.DefaultNamingScheme
 
resolveClassName(String) - Method in interface org.redisson.liveobject.resolver.NamingScheme
 
resolveId(String) - Method in class org.redisson.liveobject.resolver.DefaultNamingScheme
 
resolveId(String) - Method in interface org.redisson.liveobject.resolver.NamingScheme
 
resolveIdFieldName(String) - Method in class org.redisson.liveobject.resolver.DefaultNamingScheme
 
resolveIdFieldName(String) - Method in interface org.redisson.liveobject.resolver.NamingScheme
 
resolveProxyClass(String[]) - Method in class org.redisson.codec.CustomObjectInputStream
 
resolverGroup - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
ResponseEntry - Class in org.redisson.remote
 
ResponseEntry() - Constructor for class org.redisson.remote.ResponseEntry
 
ResponseEntry.Result - Class in org.redisson.remote
 
responseQueueName - Variable in class org.redisson.remote.BaseRemoteService
 
responses - Variable in class org.redisson.Redisson
 
responses - Variable in class org.redisson.RedissonReactive
 
responses - Variable in class org.redisson.RedissonRx
 
responseTimeout(long, TimeUnit) - Method in class org.redisson.api.BatchOptions
Defines timeout for Redis response.
responseTimeout(long, TimeUnit) - Method in class org.redisson.api.TransactionOptions
Defines timeout for Redis response.
restore(byte[]) - Method in interface org.redisson.api.RObject
Restores object using its state returned by RObject.dump() method.
restore(byte[], long, TimeUnit) - Method in interface org.redisson.api.RObject
Restores object using its state returned by RObject.dump() method and set time to live for it.
restore(byte[]) - Method in interface org.redisson.api.RObjectReactive
Restores object using its state returned by RObjectReactive.dump() method.
restore(byte[], long, TimeUnit) - Method in interface org.redisson.api.RObjectReactive
Restores object using its state returned by RObjectReactive.dump() method and set time to live for it.
restore(byte[]) - Method in interface org.redisson.api.RObjectRx
Restores object using its state returned by RObjectRx.dump() method.
restore(byte[], long, TimeUnit) - Method in interface org.redisson.api.RObjectRx
Restores object using its state returned by RObjectRx.dump() method and set time to live for it.
RESTORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
restore(byte[]) - Method in class org.redisson.RedissonObject
 
restore(byte[], long, TimeUnit) - Method in class org.redisson.RedissonObject
 
restoreAndReplace(byte[]) - Method in interface org.redisson.api.RObject
Restores and replaces object if it already exists.
restoreAndReplace(byte[], long, TimeUnit) - Method in interface org.redisson.api.RObject
Restores and replaces object if it already exists and set time to live for it.
restoreAndReplace(byte[]) - Method in interface org.redisson.api.RObjectReactive
Restores and replaces object if it already exists.
restoreAndReplace(byte[], long, TimeUnit) - Method in interface org.redisson.api.RObjectReactive
Restores and replaces object if it already exists and set time to live for it.
restoreAndReplace(byte[]) - Method in interface org.redisson.api.RObjectRx
Restores and replaces object if it already exists.
restoreAndReplace(byte[], long, TimeUnit) - Method in interface org.redisson.api.RObjectRx
Restores and replaces object if it already exists and set time to live for it.
restoreAndReplace(byte[], long, TimeUnit) - Method in class org.redisson.RedissonObject
 
restoreAndReplace(byte[]) - Method in class org.redisson.RedissonObject
 
restoreAndReplaceAsync(byte[]) - Method in interface org.redisson.api.RObjectAsync
Restores and replaces object if it already exists.
restoreAndReplaceAsync(byte[], long, TimeUnit) - Method in interface org.redisson.api.RObjectAsync
Restores and replaces object if it already exists and set time to live for it.
restoreAndReplaceAsync(byte[], long, TimeUnit) - Method in class org.redisson.RedissonObject
 
restoreAndReplaceAsync(byte[]) - Method in class org.redisson.RedissonObject
 
restoreAsync(byte[]) - Method in interface org.redisson.api.RObjectAsync
Restores object using its state returned by RObjectAsync.dumpAsync() method.
restoreAsync(byte[], long, TimeUnit) - Method in interface org.redisson.api.RObjectAsync
Restores object using its state returned by RObjectAsync.dumpAsync() method and set time to live for it.
restoreAsync(byte[]) - Method in class org.redisson.RedissonObject
 
restoreAsync(byte[], long, TimeUnit) - Method in class org.redisson.RedissonObject
 
result - Variable in class org.redisson.misc.CountableListener
 
Result(RPromise<? extends RRemoteServiceResponse>, ScheduledFuture<?>) - Constructor for class org.redisson.remote.ResponseEntry.Result
 
retainAll(Collection<?>) - Method in interface org.redisson.api.RCollectionReactive
Retains only the elements in this collection that are contained in the specified collection (optional operation).
retainAll(Collection<?>) - Method in interface org.redisson.api.RCollectionRx
Retains only the elements in this collection that are contained in the specified collection (optional operation).
retainAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSet
Retains only the elements in this sorted set that are contained in the specified collection.
retainAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetReactive
Retains only the elements in this sorted set that are contained in the specified collection.
retainAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetRx
Retains only the elements in this sorted set that are contained in the specified collection.
retainAll(Collection<?>) - Method in class org.redisson.RedissonDelayedQueue
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonList
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonListMultimapValues
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonPriorityQueue
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonScoredSortedSet
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonSet
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonSetCache
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonSetMultimapValues
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonSortedSet
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonTransferQueue
 
retainAllAsync(Collection<?>) - Method in interface org.redisson.api.RCollectionAsync
Retains only the elements in this collection that are contained in the specified collection.
retainAllAsync(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetAsync
Retains only the elements in this sorted set that are contained in the specified collection.
retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonDelayedQueue
 
retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonList
 
retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonListMultimapValues
 
retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonScoredSortedSet
 
retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonSet
 
retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonSetCache
 
retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonSetMultimapValues
 
retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonSubList
 
retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonTransferQueue
 
retainAllAsync(Collection<?>) - Method in class org.redisson.transaction.BaseTransactionalSet
 
retainAllAsync(Collection<?>) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
retainAllAsync(Collection<?>) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
retryAttempts(int) - Method in class org.redisson.api.BatchOptions
Defines attempts amount to send Redis commands batch if it hasn't been sent already.
retryAttempts(int) - Method in class org.redisson.api.TransactionOptions
Defines attempts amount to send transaction if it hasn't been sent already.
retryInterval(long, TimeUnit) - Method in class org.redisson.api.BatchOptions
Defines time interval for each attempt to send Redis commands batch if it hasn't been sent already.
retryInterval(long, TimeUnit) - Method in class org.redisson.api.TransactionOptions
Defines time interval for each attempt to send transaction if it hasn't been sent already.
returnConnection(RedisConnection) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
returnPubSubConnection(RedisPubSubConnection) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
returnPubSubConnection(PubSubConnectionEntry) - Method in class org.redisson.connection.MasterSlaveEntry
 
reverseEntrySet() - Method in class org.redisson.misc.BiHashMap
 
reverseGet(Object) - Method in class org.redisson.misc.BiHashMap
 
revRank(String) - Method in interface org.redisson.api.RLexSortedSet
Returns rank of value, with the scores ordered from high to low.
revRank(V) - Method in interface org.redisson.api.RScoredSortedSet
Returns rank of value, with the scores ordered from high to low.
revRank(V) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns rank of value, with the scores ordered from high to low.
revRank(V) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns rank of value, with the scores ordered from high to low.
revRank(V) - Method in class org.redisson.RedissonScoredSortedSet
 
revRankAsync(String) - Method in interface org.redisson.api.RLexSortedSetAsync
Returns rank of value, with the scores ordered from high to low.
revRankAsync(V) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns rank of value, with the scores ordered from high to low.
revRankAsync(V) - Method in class org.redisson.RedissonScoredSortedSet
 
RExecutorBatchFuture - Interface in org.redisson.api
Future object for submitted tasks in a batch
RExecutorFuture<V> - Interface in org.redisson.api
Future object for submitted task
RExecutorService - Interface in org.redisson.api
Distributed implementation of ExecutorService
RExecutorServiceAsync - Interface in org.redisson.api
Distributed async implementation of ExecutorService
RExpirable - Interface in org.redisson.api
Base interface for all Redisson objects which support expiration or TTL
RExpirableAsync - Interface in org.redisson.api
Base async interface for all Redisson objects which supports expiration (TTL)
RExpirableInterceptor - Class in org.redisson.liveobject.core
 
RExpirableInterceptor() - Constructor for class org.redisson.liveobject.core.RExpirableInterceptor
 
RExpirableReactive - Interface in org.redisson.api
Base interface for all Redisson objects which support expiration or TTL
RExpirableRx - Interface in org.redisson.api
Base interface for all Redisson objects which support expiration or TTL
RFieldAccessor - Annotation Type in org.redisson.api.annotation
Specifies that the method is a field accessor for Live Object.
RFuture<V> - Interface in org.redisson.api
Represents the result of an asynchronous computation
RGeo<V> - Interface in org.redisson.api
Geospatial items holder.
RGeoAsync<V> - Interface in org.redisson.api
Geospatial items holder.
RGeoReactive<V> - Interface in org.redisson.api
Geospatial items holder.
RGeoRx<V> - Interface in org.redisson.api
Geospatial items holder.
RHyperLogLog<V> - Interface in org.redisson.api
Probabilistic data structure that lets you maintain counts of millions of items with extreme space efficiency.
RHyperLogLogAsync<V> - Interface in org.redisson.api
Probabilistic data structure that lets you maintain counts of millions of items with extreme space efficiency.
RHyperLogLogReactive<V> - Interface in org.redisson.api
Probabilistic data structure that lets you maintain counts of millions of items with extreme space efficiency.
RHyperLogLogRx<V> - Interface in org.redisson.api
Probabilistic data structure that lets you maintain counts of millions of items with extreme space efficiency.
RId - Annotation Type in org.redisson.api.annotation
Specifies that the field is a Live Object's id field.
RIdResolver<V> - Interface in org.redisson.liveobject.resolver
 
RIndex - Annotation Type in org.redisson.api.annotation
Specifies that the field is used in search index.
RInject - Annotation Type in org.redisson.api.annotation
Specifies that the field value is filled up with RedissonClient instance.
RKeys - Interface in org.redisson.api
 
RKeysAsync - Interface in org.redisson.api
 
RKeysReactive - Interface in org.redisson.api
 
RKeysRx - Interface in org.redisson.api
 
RLexSortedSet - Interface in org.redisson.api
Sorted set contained values of String type
RLexSortedSetAsync - Interface in org.redisson.api
Async interface for sorted set contained values of String type.
RLexSortedSetReactive - Interface in org.redisson.api
Reactive interface for sorted set contained values of String type.
RLexSortedSetRx - Interface in org.redisson.api
RxJava2 interface for sorted set contained values of String type.
RList<V> - Interface in org.redisson.api
Distributed and concurrent implementation of List
RListAsync<V> - Interface in org.redisson.api
Async list functions
RListMultimap<K,V> - Interface in org.redisson.api
List based Multimap.
RListMultimapCache<K,V> - Interface in org.redisson.api
List based Multimap.
RListMultimapReactive<K,V> - Interface in org.redisson.api
Reactive interface for List based Multimap object
RListMultimapRx<K,V> - Interface in org.redisson.api
RxJava2 interface for List based Multimap object
RListReactive<V> - Interface in org.redisson.api
list functions
RListRx<V> - Interface in org.redisson.api
list functions
RLiveObject - Interface in org.redisson.api
 
RLiveObjectService - Interface in org.redisson.api
The pre-registration of each entity class is not necessary.
RLocalCachedMap<K,V> - Interface in org.redisson.api
Map object with local entry cache support.
RLock - Interface in org.redisson.api
Redis based implementation of Lock Implements re-entrant lock.
RLockAsync - Interface in org.redisson.api
Async interface for Lock object
RLockReactive - Interface in org.redisson.api
Reactive interface for Lock object
RLockRx - Interface in org.redisson.api
RxJava2 interface for Lock object
RLongAdder - Interface in org.redisson.api
Distributed implementation of LongAdder Internal state maintained on client side.
RMap<K,V> - Interface in org.redisson.api
Redis based implementation of ConcurrentMap and Map This map uses serialized state of key instead of hashCode or equals methods.
RMapAsync<K,V> - Interface in org.redisson.api
Async interface for Redis based implementation of ConcurrentMap and Map This map uses serialized state of key instead of hashCode or equals methods.
RMapCache<K,V> - Interface in org.redisson.api
Map-based cache with ability to set TTL for each entry via RMapCache.put(Object, Object, long, TimeUnit) or RMapCache.putIfAbsent(Object, Object, long, TimeUnit) And therefore has an complex lua-scripts inside.
RMapCacheAsync<K,V> - Interface in org.redisson.api
Map-based cache with ability to set TTL for each entry via RMapCache.put(Object, Object, long, TimeUnit) or RMapCache.putIfAbsent(Object, Object, long, TimeUnit) And therefore has an complex lua-scripts inside.
RMapCacheReactive<K,V> - Interface in org.redisson.api
RMapCacheRx<K,V> - Interface in org.redisson.api
Map-based cache with ability to set TTL for each entry via RMapCacheRx.put(Object, Object, long, TimeUnit) or RMapCacheRx.putIfAbsent(Object, Object, long, TimeUnit) method.
RMapInterceptor - Class in org.redisson.liveobject.core
 
RMapInterceptor() - Constructor for class org.redisson.liveobject.core.RMapInterceptor
 
RMapper<KIn,VIn,KOut,VOut> - Interface in org.redisson.api.mapreduce
Mapper task invoked during map phase of MapReduce process and launched across Redisson Nodes.
RMapReactive<K,V> - Interface in org.redisson.api
Reactive interface for Redis based implementation of ConcurrentMap and Map This map uses serialized state of key instead of hashCode or equals methods.
RMapReduce<KIn,VIn,KOut,VOut> - Interface in org.redisson.api.mapreduce
MapReduce allows to process large amount of data stored in Redis map using Mapper, Reducer and/or Collator tasks launched across Redisson Nodes.
RMapReduceExecutor<VIn,KOut,VOut> - Interface in org.redisson.api.mapreduce
Contains methods for MapReduce process execution.
RMapRx<K,V> - Interface in org.redisson.api
RxJava2 interface for Redis based implementation of ConcurrentMap and Map This map uses serialized state of key instead of hashCode or equals methods.
RMultimap<K,V> - Interface in org.redisson.api
Base Multimap interface.
RMultimapAsync<K,V> - Interface in org.redisson.api
Base asynchronous MultiMap interface.
RMultimapCache<K,V> - Interface in org.redisson.api
Base Multimap interface.
RMultimapCacheAsync<K,V> - Interface in org.redisson.api
Base asynchronous Multimap interface.
RMultimapReactive<K,V> - Interface in org.redisson.api
Base Reactive interface for Multimap object
RMultimapRx<K,V> - Interface in org.redisson.api
Base RxJava2 interface for Multimap object
RObject - Interface in org.redisson.api
Base interface for all Redisson objects
RObjectAsync - Interface in org.redisson.api
Base asynchronous interface for all Redisson objects
RObjectField - Annotation Type in org.redisson.api.annotation
By default namingScheme and/or codec parameters specified in REntity are applied for each Live Object field.
RObjectField.DEFAULT - Class in org.redisson.api.annotation
 
RObjectInterceptor - Class in org.redisson.liveobject.core
 
RObjectInterceptor() - Constructor for class org.redisson.liveobject.core.RObjectInterceptor
 
RObjectReactive - Interface in org.redisson.api
Base Reactive interface for all Redisson objects
RObjectRx - Interface in org.redisson.api
Base RxJava2 interface for all Redisson objects
rollback() - Method in interface org.redisson.api.RTransaction
Rollback all changes made on this transaction.
rollback() - Method in interface org.redisson.api.RTransactionReactive
Rollback all changes made on this transaction.
rollback() - Method in interface org.redisson.api.RTransactionRx
Rollback all changes made on this transaction.
rollback() - Method in class org.redisson.reactive.RedissonTransactionReactive
 
rollback() - Method in class org.redisson.rx.RedissonTransactionRx
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketCompareAndSetOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketGetAndDeleteOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketGetAndSetOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketSetOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketsTrySetOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketTrySetOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.DeleteOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.map.MapOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.AddCacheOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.AddOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.MoveOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.RemoveCacheOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.set.RemoveOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.TouchOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.TransactionalOperation
 
rollback(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.UnlinkOperation
 
rollback() - Method in class org.redisson.transaction.RedissonTransaction
 
rollback(List<TransactionalOperation>) - Method in class org.redisson.transaction.RedissonTransaction
 
rollbackAsync() - Method in interface org.redisson.api.RTransaction
Rollback all changes made on this transaction in async mode.
rollbackAsync() - Method in class org.redisson.transaction.RedissonTransaction
 
RoundRobinDnsAddressResolverGroupFactory - Class in org.redisson.connection
 
RoundRobinDnsAddressResolverGroupFactory() - Constructor for class org.redisson.connection.RoundRobinDnsAddressResolverGroupFactory
 
RoundRobinLoadBalancer - Class in org.redisson.connection.balancer
 
RoundRobinLoadBalancer() - Constructor for class org.redisson.connection.balancer.RoundRobinLoadBalancer
 
RPatternTopic - Interface in org.redisson.api
Pattern based observer for Publish Subscribe object.
RPatternTopicReactive - Interface in org.redisson.api
Reactive interface for Pattern based observer for Publish Subscribe object.
RPatternTopicRx - Interface in org.redisson.api
RxJava2 interface for Pattern based observer for Publish Subscribe object.
RPermitExpirableSemaphore - Interface in org.redisson.api
Semaphore object with lease time parameter support for each acquired permit.
RPermitExpirableSemaphoreAsync - Interface in org.redisson.api
Asynchronous interface for Semaphore object with lease time parameter support for each acquired permit.
RPermitExpirableSemaphoreReactive - Interface in org.redisson.api
Reactive interface for Semaphore object with lease time parameter support for each acquired permit.
RPermitExpirableSemaphoreRx - Interface in org.redisson.api
RxJava2 interface for Semaphore object with lease time parameter support for each acquired permit.
RPOP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
RPOPLPUSH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
RPriorityBlockingDeque<V> - Interface in org.redisson.api
RPriorityBlockingDeque backed by Redis
RPriorityBlockingQueue<V> - Interface in org.redisson.api
PriorityBlockingQueue backed by Redis
RPriorityDeque<V> - Interface in org.redisson.api
Redis based priority deque.
RPriorityQueue<V> - Interface in org.redisson.api
Redis based priority deque.
RPromise<T> - Interface in org.redisson.misc
 
RPUSH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
RPUSH_BOOLEAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
RPUSH_VOID - Static variable in interface org.redisson.client.protocol.RedisCommands
 
RPUSHX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
RQueue<V> - Interface in org.redisson.api
Queue backed by Redis
RQueueAsync<V> - Interface in org.redisson.api
Queue backed by Redis
RQueueReactive<V> - Interface in org.redisson.api
Reactive interface for Queue object
RQueueRx<V> - Interface in org.redisson.api
RxJava2 interface for Queue object
RRateLimiter - Interface in org.redisson.api
Redis based Rate Limiter object.
RRateLimiterAsync - Interface in org.redisson.api
Asynchronous interface for Redis based Rate Limiter object.
RRateLimiterReactive - Interface in org.redisson.api
Reactive interface for Redis based Rate Limiter object.
RRateLimiterRx - Interface in org.redisson.api
Reactive interface for Redis based Rate Limiter object.
RReadWriteLock - Interface in org.redisson.api
A ReadWriteLock maintains a pair of associated locks, one for read-only operations and one for writing.
RReadWriteLockReactive - Interface in org.redisson.api
A ReadWriteLock maintains a pair of associated locks, one for read-only operations and one for writing.
RReadWriteLockRx - Interface in org.redisson.api
A ReadWriteLock maintains a pair of associated locks, one for read-only operations and one for writing.
RReducer<K,V> - Interface in org.redisson.api.mapreduce
Reduces values mapped by key into single value.
RRemoteAsync - Annotation Type in org.redisson.api.annotation
Annotation used to mark interface as asynchronous client interface for remote service interface.
RRemoteReactive - Annotation Type in org.redisson.api.annotation
Annotation used to mark interface as Reactive client interface for remote service interface.
RRemoteRx - Annotation Type in org.redisson.api.annotation
Annotation used to mark interface as RxJava2 client interface for remote service interface.
RRemoteService - Interface in org.redisson.api
Allows to execute object methods remotely between Redisson instances (Server side and Client side instances in terms of remote invocation).
RRemoteServiceResponse - Interface in org.redisson.remote
 
RRingBuffer<V> - Interface in org.redisson.api
RingBuffer based queue evicts elements from the head if queue capacity became full.
RRingBufferAsync<V> - Interface in org.redisson.api
RingBuffer based queue evicts elements from the head if queue capacity became full.
RRingBufferReactive<V> - Interface in org.redisson.api
RingBuffer based queue evicts elements from the head if queue capacity became full.
RRingBufferRx<V> - Interface in org.redisson.api
RingBuffer based queue evicts elements from the head if queue capacity became full.
RScheduledExecutorService - Interface in org.redisson.api
Redis based implementation of ScheduledExecutorService
RScheduledExecutorServiceAsync - Interface in org.redisson.api
Redis based implementation of ScheduledExecutorService
RScheduledFuture<V> - Interface in org.redisson.api
 
RScoredSortedSet<V> - Interface in org.redisson.api
Set containing elements sorted by score.
RScoredSortedSet.Aggregate - Enum in org.redisson.api
 
RScoredSortedSetAsync<V> - Interface in org.redisson.api
 
RScoredSortedSetReactive<V> - Interface in org.redisson.api
Reactive interface for SortedSet object
RScoredSortedSetRx<V> - Interface in org.redisson.api
RxJava2 interface for scored sorted set data structure.
RScript - Interface in org.redisson.api
Interface for Redis Script feature
RScript.Mode - Enum in org.redisson.api
 
RScript.ReturnType - Enum in org.redisson.api
 
RScriptAsync - Interface in org.redisson.api
Async interface for Redis Script feature
RScriptReactive - Interface in org.redisson.api
Reactive interface for Redis Script feature
RScriptRx - Interface in org.redisson.api
RxJava2 interface for Redis Script feature
RSemaphore - Interface in org.redisson.api
Redis based implementation of Semaphore.
RSemaphoreAsync - Interface in org.redisson.api
Async interface of Redis based Semaphore.
RSemaphoreReactive - Interface in org.redisson.api
Reactive interface of Redis based Semaphore.
RSemaphoreRx - Interface in org.redisson.api
RxJava2 interface of Redis based Semaphore.
RSet<V> - Interface in org.redisson.api
Redis based implementation of Set
RSetAsync<V> - Interface in org.redisson.api
Async set functions
RSetCache<V> - Interface in org.redisson.api
Set-based cache with ability to set TTL for each object.
RSetCacheAsync<V> - Interface in org.redisson.api
Async set functions
RSetCacheReactive<V> - Interface in org.redisson.api
Reactive interface for RSetCache object
RSetCacheRx<V> - Interface in org.redisson.api
RxJava2 interface for RSetCache object
RSetMultimap<K,V> - Interface in org.redisson.api
Set based Multimap.
RSetMultimapCache<K,V> - Interface in org.redisson.api
 
RSetMultimapReactive<K,V> - Interface in org.redisson.api
Reactive interface for Set based Multimap
RSetMultimapRx<K,V> - Interface in org.redisson.api
RxJava2 interface for Set based Multimap
RSetReactive<V> - Interface in org.redisson.api
Reactive interface for Redis based implementation of Set
RSetRx<V> - Interface in org.redisson.api
RxJava2 interface for Redis based implementation of Set
RSortable<V> - Interface in org.redisson.api
 
RSortableAsync<V> - Interface in org.redisson.api
 
RSortableReactive<V> - Interface in org.redisson.api
 
RSortableRx<V> - Interface in org.redisson.api
 
RSortedSet<V> - Interface in org.redisson.api
 
RStream<K,V> - Interface in org.redisson.api
Interface for Redis Stream object.
RStreamAsync<K,V> - Interface in org.redisson.api
Async interface for Redis Stream object.
RStreamReactive<K,V> - Interface in org.redisson.api
Reactive interface for Redis Stream object.
RStreamRx<K,V> - Interface in org.redisson.api
Reactive interface for Redis Stream object.
RTopic - Interface in org.redisson.api
Distributed topic.
RTopicAsync - Interface in org.redisson.api
Distributed topic.
RTopicReactive - Interface in org.redisson.api
Reactive interface for Publish Subscribe object.
RTopicRx - Interface in org.redisson.api
RxJava2 interface for Publish Subscribe object.
RTransaction - Interface in org.redisson.api
Transaction object allows to execute transactions over Redisson objects.
RTransactionReactive - Interface in org.redisson.api
Reactive interface for transaction object allows to execute transactions over Redisson objects.
RTransactionRx - Interface in org.redisson.api
RxJava2 interface for transaction object allows to execute transactions over Redisson objects.
RTransferQueue<V> - Interface in org.redisson.api
Redis based implementation of TransferQueue
RTransferQueueAsync<V> - Interface in org.redisson.api
Async interface for Redis based implementation of TransferQueue
RTransferQueueReactive<V> - Interface in org.redisson.api
Reactive interface of Redis based implementation of TransferQueue
RTransferQueueRx<V> - Interface in org.redisson.api
RxJava2 interface of Redis based implementation of TransferQueue
RType - Enum in org.redisson.api
 
run() - Method in class org.redisson.mapreduce.CollectionMapperTask
 
run() - Method in class org.redisson.mapreduce.MapperTask
 
run() - Method in class org.redisson.mapreduce.ReducerTask
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in class org.redisson.misc.PromiseDelegator
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class org.redisson.misc.PromiseDelegator
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
runAfterEither(CompletionStage<?>, Runnable) - Method in class org.redisson.misc.PromiseDelegator
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class org.redisson.misc.PromiseDelegator
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
RxProxyBuilder - Class in org.redisson.rx
 
RxProxyBuilder() - Constructor for class org.redisson.rx.RxProxyBuilder
 
RxRemoteProxy - Class in org.redisson.remote
 
RxRemoteProxy(CommandAsyncExecutor, String, String, ConcurrentMap<String, ResponseEntry>, Codec, String, String, BaseRemoteService) - Constructor for class org.redisson.remote.RxRemoteProxy
 

S

SADD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SADD_BOOL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SADD_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SAVE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
save(RedissonSessionRepository.RedissonSession) - Method in class org.redisson.spring.session.ReactiveRedissonSessionRepository
 
save(RedissonSessionRepository.RedissonSession) - Method in class org.redisson.spring.session.RedissonSessionRepository
 
SCAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
scanIterator(RedisClient, long) - Method in class org.redisson.reactive.MapReactiveIterator
 
scanIterator(RedisClient, long) - Method in class org.redisson.reactive.SetReactiveIterator
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.RedissonMap
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.RedissonMapCache
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.RedissonSet
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.RedissonSetCache
 
scanIterator(RedisClient, long) - Method in class org.redisson.rx.SetRxIterator
 
ScanIterator - Interface in org.redisson
 
scanIterator(String, RedisClient, long, String, int) - Method in interface org.redisson.ScanIterator
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.transaction.BaseTransactionalMap
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.transaction.BaseTransactionalSet
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
scanIterator(String, RedisClient, long, String, int) - Method in class org.redisson.transaction.RedissonTransactionalSetCache
 
scanIteratorAsync(RedisClient, MasterSlaveEntry, long, String, int) - Method in class org.redisson.RedissonKeys
 
scanIteratorAsync(String, RedisClient, long, String, int) - Method in class org.redisson.RedissonMap
 
scanIteratorAsync(String, RedisClient, long, String, int) - Method in class org.redisson.RedissonMapCache
 
scanIteratorAsync(RedisClient, long, String, int) - Method in class org.redisson.RedissonScoredSortedSet
 
scanIteratorAsync(String, RedisClient, long, String, int) - Method in class org.redisson.RedissonSet
 
scanIteratorAsync(String, RedisClient, long, String, int) - Method in class org.redisson.RedissonSetCache
 
scanIteratorAsync(String, RedisClient, long, String, int) - Method in interface org.redisson.ScanIterator
 
scanIteratorSource(String, RedisClient, long, String, int) - Method in class org.redisson.transaction.BaseTransactionalSet
 
scanIteratorSource(String, RedisClient, long, String, int) - Method in class org.redisson.transaction.TransactionalSet
 
scanIteratorSource(String, RedisClient, long, String, int) - Method in class org.redisson.transaction.TransactionalSetCache
 
ScanResult<R> - Interface in org.redisson
 
SCARD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SCARD_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
schedule(Runnable, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorService
Synchronously schedules a Runnable task for execution asynchronously after the given delay.
schedule(Runnable, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorService
Synchronously schedules a Runnable task with defined timeToLive parameter for execution asynchronously after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorService
Synchronously schedules a value-returning task for execution asynchronously after the given delay.
schedule(Callable<V>, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorService
Synchronously schedules a value-returning task with defined timeToLive parameter for execution asynchronously after the given delay.
schedule(Runnable, CronSchedule) - Method in interface org.redisson.api.RScheduledExecutorService
Synchronously schedules a Runnable task for execution asynchronously cron schedule object.
schedule(String, long) - Method in class org.redisson.eviction.EvictionScheduler
 
schedule(String, String, String, String, String) - Method in class org.redisson.eviction.EvictionScheduler
 
schedule(ScheduledCronExpressionParameters) - Method in interface org.redisson.executor.RemoteExecutorService
 
schedule(ScheduledCronExpressionParameters) - Method in interface org.redisson.executor.RemoteExecutorServiceAsync
 
schedule(ScheduledCronExpressionParameters) - Method in class org.redisson.executor.TasksRunnerService
 
schedule(String, QueueTransferTask) - Method in class org.redisson.QueueTransferService
 
schedule(Runnable, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
schedule(Runnable, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
schedule(Callable<V>, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
schedule(Runnable, CronSchedule) - Method in class org.redisson.RedissonExecutorService
 
scheduleAsync(Runnable, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorServiceAsync
Schedules a Runnable task for execution asynchronously after the given delay.
scheduleAsync(Runnable, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorServiceAsync
Schedules a Runnable task with defined timeToLive parameter for execution asynchronously after the given delay.
scheduleAsync(Callable<V>, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorServiceAsync
Schedules a value-returning task for execution asynchronously after the given delay.
scheduleAsync(Callable<V>, long, TimeUnit, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorServiceAsync
Schedules a value-returning task with defined timeToLive parameter for execution asynchronously after the given delay.
scheduleAsync(Runnable, CronSchedule) - Method in interface org.redisson.api.RScheduledExecutorServiceAsync
Synchronously schedules a Runnable task for execution asynchronously cron schedule object.
scheduleAsync(Runnable, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
scheduleAsync(Callable<V>, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
scheduleAsync(Runnable, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
scheduleAsync(Callable<V>, long, TimeUnit, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
scheduleAsync(Runnable, CronSchedule) - Method in class org.redisson.RedissonExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorService
Synchronously schedules a Runnable task for execution asynchronously after the given initialDelay, and subsequently with the given period.
scheduleAtFixedRate(ScheduledAtFixedRateParameters) - Method in interface org.redisson.executor.RemoteExecutorService
 
scheduleAtFixedRate(ScheduledAtFixedRateParameters) - Method in interface org.redisson.executor.RemoteExecutorServiceAsync
 
scheduleAtFixedRate(ScheduledAtFixedRateParameters) - Method in class org.redisson.executor.TasksRunnerService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
scheduleAtFixedRateAsync(Runnable, long, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorServiceAsync
Schedules a Runnable task for execution asynchronously after the given initialDelay, and subsequently with the given period.
scheduleAtFixedRateAsync(Runnable, long, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
scheduleCallable(ScheduledParameters) - Method in interface org.redisson.executor.RemoteExecutorService
 
scheduleCallable(ScheduledParameters) - Method in interface org.redisson.executor.RemoteExecutorServiceAsync
 
scheduleCallable(ScheduledParameters) - Method in class org.redisson.executor.TasksRunnerService
 
scheduleCheck(String, RequestId, RPromise<T>) - Method in class org.redisson.remote.BaseRemoteService
 
scheduleCleanMultimap(String, String) - Method in class org.redisson.eviction.EvictionScheduler
 
ScheduledAtFixedRateParameters - Class in org.redisson.executor.params
 
ScheduledAtFixedRateParameters() - Constructor for class org.redisson.executor.params.ScheduledAtFixedRateParameters
 
ScheduledCronExpressionParameters - Class in org.redisson.executor.params
 
ScheduledCronExpressionParameters() - Constructor for class org.redisson.executor.params.ScheduledCronExpressionParameters
 
ScheduledParameters - Class in org.redisson.executor.params
 
ScheduledParameters() - Constructor for class org.redisson.executor.params.ScheduledParameters
 
ScheduledParameters(String, byte[], byte[], byte[], long) - Constructor for class org.redisson.executor.params.ScheduledParameters
 
ScheduledTasksService - Class in org.redisson.executor
 
ScheduledTasksService(Codec, String, CommandExecutor, String, ConcurrentMap<String, ResponseEntry>) - Constructor for class org.redisson.executor.ScheduledTasksService
 
ScheduledWithFixedDelayParameters - Class in org.redisson.executor.params
 
ScheduledWithFixedDelayParameters() - Constructor for class org.redisson.executor.params.ScheduledWithFixedDelayParameters
 
scheduleJCache(String, String, String) - Method in class org.redisson.eviction.EvictionScheduler
 
schedulerChannelName - Variable in class org.redisson.executor.TasksService
 
scheduleRetryTimeRenewal(String, long) - Method in class org.redisson.executor.TasksRunnerService
 
schedulerQueueName - Variable in class org.redisson.executor.TasksService
 
scheduleRunnable(ScheduledParameters) - Method in interface org.redisson.executor.RemoteExecutorService
 
scheduleRunnable(ScheduledParameters) - Method in interface org.redisson.executor.RemoteExecutorServiceAsync
 
scheduleRunnable(ScheduledParameters) - Method in class org.redisson.executor.TasksRunnerService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorService
Synchronously schedules a Runnable task for execution asynchronously after the given initialDelay, and subsequently with the given delay started from the task finishing moment.
scheduleWithFixedDelay(ScheduledWithFixedDelayParameters) - Method in interface org.redisson.executor.RemoteExecutorService
 
scheduleWithFixedDelay(ScheduledWithFixedDelayParameters) - Method in interface org.redisson.executor.RemoteExecutorServiceAsync
 
scheduleWithFixedDelay(ScheduledWithFixedDelayParameters) - Method in class org.redisson.executor.TasksRunnerService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
scheduleWithFixedDelayAsync(Runnable, long, long, TimeUnit) - Method in interface org.redisson.api.RScheduledExecutorServiceAsync
Schedules a Runnable task for execution asynchronously after the given initialDelay, and subsequently with the given delay started from the task finishing moment.
scheduleWithFixedDelayAsync(Runnable, long, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
ScoredEntry<V> - Class in org.redisson.client.protocol
 
ScoredEntry(Double, V) - Constructor for class org.redisson.client.protocol.ScoredEntry
 
ScoredSetEvictionTask - Class in org.redisson.eviction
 
ScoredSetEvictionTask(String, CommandAsyncExecutor, long) - Constructor for class org.redisson.eviction.ScoredSetEvictionTask
 
ScoredSortedSetPolledObjectDecoder - Class in org.redisson.client.protocol.decoder
 
ScoredSortedSetPolledObjectDecoder() - Constructor for class org.redisson.client.protocol.decoder.ScoredSortedSetPolledObjectDecoder
 
ScoredSortedSetReplayDecoder<T> - Class in org.redisson.client.protocol.decoder
 
ScoredSortedSetReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ScoredSortedSetReplayDecoder
 
ScoredSortedSetScanDecoder<T> - Class in org.redisson.client.protocol.decoder
 
ScoredSortedSetScanDecoder() - Constructor for class org.redisson.client.protocol.decoder.ScoredSortedSetScanDecoder
 
ScoredSortedSetScanReplayDecoder - Class in org.redisson.client.protocol.decoder
 
ScoredSortedSetScanReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ScoredSortedSetScanReplayDecoder
 
SCRIPT_EXISTS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SCRIPT_FLUSH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SCRIPT_KILL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SCRIPT_LOAD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
scriptExists(String...) - Method in interface org.redisson.api.RScript
Checks for presence Lua scripts in Redis script cache by SHA-1 digest.
scriptExists(String...) - Method in interface org.redisson.api.RScriptReactive
Checks for presence Lua scripts in Redis script cache by SHA-1 digest.
scriptExists(String...) - Method in interface org.redisson.api.RScriptRx
Checks for presence Lua scripts in Redis script cache by SHA-1 digest.
scriptExists(String...) - Method in class org.redisson.RedissonScript
 
scriptExists(String, String...) - Method in class org.redisson.RedissonScript
 
scriptExistsAsync(String...) - Method in interface org.redisson.api.RScriptAsync
Checks for presence Lua scripts in Redis script cache by SHA-1 digest.
scriptExistsAsync(String, String...) - Method in interface org.redisson.api.RScriptAsync
Checks for presence Lua scripts in Redis script cache by SHA-1 digest.
scriptExistsAsync(String...) - Method in class org.redisson.RedissonScript
 
scriptExistsAsync(String, String...) - Method in class org.redisson.RedissonScript
 
scriptFlush() - Method in interface org.redisson.api.RScript
Flushes Lua script cache.
scriptFlush() - Method in interface org.redisson.api.RScriptReactive
Flushes Lua script cache.
scriptFlush() - Method in interface org.redisson.api.RScriptRx
Flushes Lua script cache.
scriptFlush() - Method in class org.redisson.RedissonScript
 
scriptFlush(String) - Method in class org.redisson.RedissonScript
 
scriptFlushAsync() - Method in interface org.redisson.api.RScriptAsync
Flushes Lua script cache.
scriptFlushAsync() - Method in class org.redisson.RedissonScript
 
scriptFlushAsync(String) - Method in class org.redisson.RedissonScript
 
scriptKill() - Method in interface org.redisson.api.RScript
Kills currently executed Lua script
scriptKill() - Method in interface org.redisson.api.RScriptReactive
Kills currently executed Lua script
scriptKill() - Method in interface org.redisson.api.RScriptRx
Kills currently executed Lua script
scriptKill() - Method in class org.redisson.RedissonScript
 
scriptKill(String) - Method in class org.redisson.RedissonScript
 
scriptKillAsync() - Method in interface org.redisson.api.RScriptAsync
Kills currently executed Lua script
scriptKillAsync() - Method in class org.redisson.RedissonScript
 
scriptKillAsync(String) - Method in class org.redisson.RedissonScript
 
scriptLoad(String) - Method in interface org.redisson.api.RScript
Loads Lua script into Redis scripts cache and returns its SHA-1 digest
scriptLoad(String) - Method in interface org.redisson.api.RScriptReactive
Loads Lua script into Redis scripts cache and returns its SHA-1 digest
scriptLoad(String) - Method in interface org.redisson.api.RScriptRx
Loads Lua script into Redis scripts cache and returns its SHA-1 digest
scriptLoad(String) - Method in class org.redisson.RedissonScript
 
scriptLoad(String, String) - Method in class org.redisson.RedissonScript
 
scriptLoadAsync(String) - Method in interface org.redisson.api.RScriptAsync
Loads Lua script into Redis scripts cache and returns its SHA-1 digest
scriptLoadAsync(String, String) - Method in interface org.redisson.api.RScriptAsync
Loads Lua script into Redis scripts cache and returns its SHA-1 digest
scriptLoadAsync(String) - Method in class org.redisson.RedissonScript
 
scriptLoadAsync(String, String) - Method in class org.redisson.RedissonScript
 
SDIFF - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SDIFFSTORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SDIFFSTORE_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
searchForMethod(Class<?>, String, Class<?>[]) - Static method in class org.redisson.liveobject.misc.ClassUtils
Searches through all methods looking for one with the specified name that will take the specified paramaters even if the parameter types are more generic in the actual method implementation.
SECOND - Static variable in class org.redisson.executor.CronExpression
 
seconds - Variable in class org.redisson.executor.CronExpression
 
SELECT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
selectDecoder(CommandData<Object, Object>, List<Object>) - Method in class org.redisson.client.handler.CommandDecoder
 
selectDecoder(CommandData<Object, Object>, List<Object>) - Method in class org.redisson.client.handler.CommandPubSubDecoder
 
SemaphorePubSub - Class in org.redisson.pubsub
 
SemaphorePubSub(PublishSubscribeService) - Constructor for class org.redisson.pubsub.SemaphorePubSub
 
send(CommandData<T, R>) - Method in class org.redisson.client.RedisConnection
 
send(CommandsData) - Method in class org.redisson.client.RedisConnection
 
sendCommand(RPromise<Void>, RedisConnection) - Method in class org.redisson.command.RedisCommonBatchExecutor
 
sendCommand(RPromise<R>, RedisConnection) - Method in class org.redisson.command.RedisExecutor
 
sendCommand(RPromise<R>, RedisConnection) - Method in class org.redisson.command.RedisQueuedBatchExecutor
 
sendNext(Channel, QueueCommand) - Method in class org.redisson.client.handler.CommandDecoder
 
sendNext(Channel) - Method in class org.redisson.client.handler.CommandDecoder
 
sendNextCommand(Channel) - Method in class org.redisson.client.handler.CommandsQueue
 
sendNotification(Notification) - Method in class org.redisson.jcache.JCacheMBeanServerBuilder.JCacheMBeanServerDelegate
 
SENTINEL_FAILOVER - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SENTINEL_GET_MASTER_ADDR_BY_NAME - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SENTINEL_MASTER - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SENTINEL_MASTER_SLAVE - Static variable in class org.redisson.api.redisnode.RedisNodes
 
SENTINEL_MASTERS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SENTINEL_MONITOR - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SENTINEL_REMOVE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SENTINEL_SENTINELS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SENTINEL_SLAVES - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SentinelConnectionManager - Class in org.redisson.connection
 
SentinelConnectionManager(SentinelServersConfig, Config, UUID) - Constructor for class org.redisson.connection.SentinelConnectionManager
 
SentinelRedisNode - Class in org.redisson.redisnode
 
SentinelRedisNode(RedisClient, CommandAsyncService) - Constructor for class org.redisson.redisnode.SentinelRedisNode
 
SentinelServersConfig - Class in org.redisson.config
 
SentinelServersConfig() - Constructor for class org.redisson.config.SentinelServersConfig
 
SerializationCodec - Class in org.redisson.codec
 
SerializationCodec() - Constructor for class org.redisson.codec.SerializationCodec
 
SerializationCodec(ClassLoader) - Constructor for class org.redisson.codec.SerializationCodec
 
SerializationCodec(ClassLoader, SerializationCodec) - Constructor for class org.redisson.codec.SerializationCodec
 
sessionRepository(RedissonClient, ApplicationEventPublisher) - Method in class org.redisson.spring.session.config.RedissonHttpSessionConfiguration
 
sessionRepository(RedissonClient, ApplicationEventPublisher) - Method in class org.redisson.spring.session.config.RedissonWebSessionConfiguration
 
set(double) - Method in interface org.redisson.api.RAtomicDouble
Atomically sets the given value.
set(double) - Method in interface org.redisson.api.RAtomicDoubleReactive
Atomically sets the given value.
set(double) - Method in interface org.redisson.api.RAtomicDoubleRx
Atomically sets the given value.
set(long) - Method in interface org.redisson.api.RAtomicLong
Atomically sets the given value.
set(long) - Method in interface org.redisson.api.RAtomicLongReactive
Atomically sets the given value.
set(long) - Method in interface org.redisson.api.RAtomicLongRx
Atomically sets the given value.
set(long, long, boolean) - Method in interface org.redisson.api.RBitSet
Set all bits to value from fromIndex (inclusive) to toIndex (exclusive)
set(BitSet) - Method in interface org.redisson.api.RBitSet
Copy bits state of source BitSet object to this object
set(long, long) - Method in interface org.redisson.api.RBitSet
Set all bits to one from fromIndex (inclusive) to toIndex (exclusive)
set(long) - Method in interface org.redisson.api.RBitSet
Set bit to one at specified bitIndex
set(long, boolean) - Method in interface org.redisson.api.RBitSet
Set bit to value at specified bitIndex
set(long, long, boolean) - Method in interface org.redisson.api.RBitSetReactive
Set all bits to value from fromIndex (inclusive) to toIndex (exclusive)
set(BitSet) - Method in interface org.redisson.api.RBitSetReactive
Copy bits state of source BitSet object to this object
set(long, long) - Method in interface org.redisson.api.RBitSetReactive
Set all bits to one from fromIndex (inclusive) to toIndex (exclusive)
set(long) - Method in interface org.redisson.api.RBitSetReactive
Set bit to one at specified bitIndex
set(long, boolean) - Method in interface org.redisson.api.RBitSetReactive
Set bit to value at specified bitIndex
set(long, long, boolean) - Method in interface org.redisson.api.RBitSetRx
Set all bits to value from fromIndex (inclusive) to toIndex (exclusive)
set(BitSet) - Method in interface org.redisson.api.RBitSetRx
Copy bits state of source BitSet object to this object
set(long, long) - Method in interface org.redisson.api.RBitSetRx
Set all bits to one from fromIndex (inclusive) to toIndex (exclusive)
set(long) - Method in interface org.redisson.api.RBitSetRx
Set bit to one at specified bitIndex
set(long, boolean) - Method in interface org.redisson.api.RBitSetRx
Set bit to value at specified bitIndex
set(V) - Method in interface org.redisson.api.RBucket
Stores element into the holder.
set(V, long, TimeUnit) - Method in interface org.redisson.api.RBucket
Stores element into the holder with defined timeToLive interval.
set(V) - Method in interface org.redisson.api.RBucketReactive
Stores element into the holder.
set(V, long, TimeUnit) - Method in interface org.redisson.api.RBucketReactive
Stores element into the holder with defined timeToLive interval.
set(V) - Method in interface org.redisson.api.RBucketRx
Stores element into the holder.
set(V, long, TimeUnit) - Method in interface org.redisson.api.RBucketRx
Stores element into the holder with defined timeToLive interval.
set(Map<String, ?>) - Method in interface org.redisson.api.RBuckets
Saves objects mapped by Redis key.
set(Map<String, ?>) - Method in interface org.redisson.api.RBucketsReactive
Saves objects mapped by Redis key.
set(Map<String, ?>) - Method in interface org.redisson.api.RBucketsRx
Saves objects mapped by Redis key.
set(int, V) - Method in interface org.redisson.api.RListReactive
Set element at index and returns previous element.
set(int, V) - Method in interface org.redisson.api.RListRx
Set element at index and returns previous element.
SET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
set(V) - Method in class org.redisson.iterator.RedissonListIterator
 
set(double) - Method in class org.redisson.RedissonAtomicDouble
 
set(long) - Method in class org.redisson.RedissonAtomicLong
 
set(BitSet) - Method in class org.redisson.RedissonBitSet
 
set(long) - Method in class org.redisson.RedissonBitSet
 
set(long, long, boolean) - Method in class org.redisson.RedissonBitSet
 
set(long, long) - Method in class org.redisson.RedissonBitSet
 
set(long, boolean) - Method in class org.redisson.RedissonBitSet
 
set(V) - Method in class org.redisson.RedissonBucket
 
set(V, long, TimeUnit) - Method in class org.redisson.RedissonBucket
 
set(Map<String, ?>) - Method in class org.redisson.RedissonBuckets
 
set(int, V) - Method in class org.redisson.RedissonList
 
set(int, V) - Method in class org.redisson.RedissonListMultimapValues
 
set(int, V) - Method in class org.redisson.RedissonSubList
 
setAddFuture(RFuture<Boolean>) - Method in class org.redisson.executor.RemotePromise
 
setAddress(String, int) - Method in class org.redisson.client.RedisClientConfig
 
setAddress(String) - Method in class org.redisson.client.RedisClientConfig
 
setAddress(InetSocketAddress, RedisURI) - Method in class org.redisson.client.RedisClientConfig
 
setAddress(RedisURI) - Method in class org.redisson.client.RedisClientConfig
 
setAddress(String) - Method in class org.redisson.cluster.ClusterNodeInfo
 
setAddress(String) - Method in class org.redisson.config.SingleServerConfig
Set server address.
setAddressResolverGroupFactory(AddressResolverGroupFactory) - Method in class org.redisson.config.Config
Used to switch between DnsAddressResolverGroup implementations.
setAllowNullValues(boolean) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
Defines possibility of storing null values.
setAsync(double) - Method in interface org.redisson.api.RAtomicDoubleAsync
Atomically sets the given value.
setAsync(long) - Method in interface org.redisson.api.RAtomicLongAsync
Atomically sets the given value.
setAsync(long, long, boolean) - Method in interface org.redisson.api.RBitSetAsync
Set all bits to value from fromIndex (inclusive) to toIndex (exclusive)
setAsync(BitSet) - Method in interface org.redisson.api.RBitSetAsync
Copy bits state of source BitSet object to this object
setAsync(long, long) - Method in interface org.redisson.api.RBitSetAsync
Set all bits to one from fromIndex (inclusive) to toIndex (exclusive)
setAsync(long) - Method in interface org.redisson.api.RBitSetAsync
Set bit to one at specified bitIndex
setAsync(long, boolean) - Method in interface org.redisson.api.RBitSetAsync
Set bit to value at specified bitIndex
setAsync(V) - Method in interface org.redisson.api.RBucketAsync
Stores element into the holder.
setAsync(V, long, TimeUnit) - Method in interface org.redisson.api.RBucketAsync
Stores element into the holder with defined timeToLive interval.
setAsync(Map<String, ?>) - Method in interface org.redisson.api.RBucketsAsync
Saves objects mapped by Redis key.
setAsync(int, V) - Method in interface org.redisson.api.RListAsync
Set element at index and returns previous element.
setAsync(double) - Method in class org.redisson.RedissonAtomicDouble
 
setAsync(long) - Method in class org.redisson.RedissonAtomicLong
 
setAsync(long, boolean) - Method in class org.redisson.RedissonBitSet
 
setAsync(long, long, boolean) - Method in class org.redisson.RedissonBitSet
 
setAsync(BitSet) - Method in class org.redisson.RedissonBitSet
 
setAsync(long, long) - Method in class org.redisson.RedissonBitSet
 
setAsync(long) - Method in class org.redisson.RedissonBitSet
 
setAsync(V) - Method in class org.redisson.RedissonBucket
 
setAsync(V, long, TimeUnit) - Method in class org.redisson.RedissonBucket
 
setAsync(Map<String, ?>) - Method in class org.redisson.RedissonBuckets
 
setAsync(int, V) - Method in class org.redisson.RedissonList
 
setAsync(int, V) - Method in class org.redisson.RedissonListMultimapValues
 
setAsync(int, V) - Method in class org.redisson.RedissonSubList
 
setAsync(V) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
setAsync(V, long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
setAsync(Map<String, ?>) - Method in class org.redisson.transaction.RedissonTransactionalBuckets
 
setAttribute(Element, String, String) - Method in class org.redisson.spring.support.RedissonNamespaceParserSupport
 
setBatchIndex(int) - Method in class org.redisson.client.handler.State
 
setBeanFactory(BeanFactory) - Method in class org.redisson.config.RedissonNodeConfig
Defines Spring Bean Factory instance to execute tasks with Spring's '@Autowired', '@Value' or JSR-330's '@Inject' annotation.
setBeanFactory(BeanFactory) - Method in class org.redisson.executor.TasksRunnerService
 
SETBIT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SETBIT_VOID - Static variable in interface org.redisson.client.protocol.RedisCommands
 
setCacheNames(Collection<String>) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
Defines 'fixed' cache names.
setCalendarHour(Calendar, int) - Method in class org.redisson.executor.CronExpression
Advance the calendar to the particular hour paying particular attention to daylight saving problems.
setCheckSentinelsList(boolean) - Method in class org.redisson.config.SentinelServersConfig
Enables sentinels list check during Redisson startup.
setCheckSlotsCoverage(boolean) - Method in class org.redisson.config.ClusterServersConfig
Enables cluster slots check during Redisson startup.
setClassBody(byte[]) - Method in class org.redisson.executor.params.TaskParameters
 
setClassName(String) - Method in class org.redisson.executor.params.TaskParameters
 
setCleanUpKeysAmount(int) - Method in class org.redisson.config.Config
Defines expired keys amount deleted per single operation during clean up process of expired entries.
setClientName(String) - Method in class org.redisson.client.RedisClientConfig
 
setClientName(String) - Method in class org.redisson.config.BaseConfig
Setup connection name during connection init via CLIENT SETNAME command Default is null
setCodec(Codec) - Method in class org.redisson.config.Config
Redis key/value codec.
setCodec(Codec) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
Set Codec instance shared between all Cache instances
setCodecType(Class<? extends Codec>) - Method in class org.redisson.RedissonReference
 
setCollectorMapName(String) - Method in class org.redisson.mapreduce.BaseMapperTask
 
setCommandTimeout(int) - Method in class org.redisson.client.RedisClientConfig
 
setConfig(Map<String, ? extends CacheConfig>) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
Set cache config mapped by cache name
setConfigLocation(String) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
Set cache config location
setConnectedListener(Runnable) - Method in class org.redisson.client.RedisConnection
 
setConnectionFuture(RFuture<RedisConnection>) - Method in class org.redisson.command.CommandBatchService.ConnectionEntry
 
setConnectionMinimumIdleSize(int) - Method in class org.redisson.config.SingleServerConfig
Minimum idle Redis connection amount.
setConnectionPoolSize(int) - Method in class org.redisson.config.SingleServerConfig
Redis connection pool size Default is 64
setConnectTimeout(int) - Method in class org.redisson.client.RedisClientConfig
 
setConnectTimeout(int) - Method in class org.redisson.config.BaseConfig
Timeout during connecting to any Redis server.
setCounter(int) - Method in class org.redisson.misc.CountableListener
 
setCronExpression(String) - Method in class org.redisson.executor.params.ScheduledCronExpressionParameters
 
setDatabase(int) - Method in class org.redisson.client.RedisClientConfig
 
setDatabase(int) - Method in class org.redisson.config.MasterSlaveServersConfig
Database index used for Redis connection Default is 0
setDatabase(int) - Method in class org.redisson.config.ReplicatedServersConfig
Database index used for Redis connection.
setDatabase(int) - Method in class org.redisson.config.SentinelServersConfig
Database index used for Redis connection Default is 0
setDatabase(int) - Method in class org.redisson.config.SingleServerConfig
Database index used for Redis connection Default is 0
setDecodeInExecutor(boolean) - Method in class org.redisson.client.RedisClientConfig
Deprecated.
setDecodeInExecutor(boolean) - Method in class org.redisson.config.Config
Deprecated.
setDefaultMaxInactiveInterval(int) - Method in class org.redisson.spring.session.ReactiveRedissonSessionRepository
 
setDefaultMaxInactiveInterval(int) - Method in class org.redisson.spring.session.RedissonSessionRepository
 
setDelay(long) - Method in class org.redisson.executor.params.ScheduledWithFixedDelayParameters
 
setDisconnectedListener(Runnable) - Method in class org.redisson.client.RedisConnection
 
setDnsMonitoringInterval(long) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Interval in milliseconds to check the endpoint's DNS Applications must ensure the JVM DNS cache TTL is low enough to support this.
setDnsMonitoringInterval(long) - Method in class org.redisson.config.SingleServerConfig
Interval in milliseconds to check the endpoint's DNS Applications must ensure the JVM DNS cache TTL is low enough to support this.
setEventLoopGroup(EventLoopGroup) - Method in class org.redisson.config.Config
Use external EventLoopGroup.
setExecutor(ExecutorService) - Method in class org.redisson.client.RedisClientConfig
 
setExecutor(ExecutorService) - Method in class org.redisson.config.Config
Use external ExecutorService.
setExecutorId(String) - Method in class org.redisson.executor.params.ScheduledAtFixedRateParameters
 
setExecutorId(String) - Method in class org.redisson.executor.params.ScheduledCronExpressionParameters
 
setExecutorId(String) - Method in class org.redisson.executor.params.ScheduledWithFixedDelayParameters
 
setExecutorServiceWorkers(Map<String, Integer>) - Method in class org.redisson.config.RedissonNodeConfig
Executor service workers amount per service name
setFailedSlaveCheckInterval(int) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Redis Slave node failing to execute commands is excluded from the internal list of available nodes when the time interval from the moment of first Redis command execution failure on this server reaches slaveFailsInterval value.
setFailedSlaveReconnectionInterval(int) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Interval of Redis Slave reconnection attempt when it was excluded from internal list of available servers.
setField(Object, String, Object) - Static method in class org.redisson.liveobject.misc.ClassUtils
 
setFirstCommand(boolean) - Method in class org.redisson.command.CommandBatchService.ConnectionEntry
 
setFirstEntry(StreamInfo.Entry<K, V>) - Method in class org.redisson.api.StreamInfo
 
setFreezed(boolean) - Method in class org.redisson.connection.ClientConnectionsEntry
 
setFreezeReason(ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.ClientConnectionsEntry
 
setFuture(RFuture<String>) - Method in class org.redisson.RedissonRemoteService.Entry
 
setGroup(EventLoopGroup) - Method in class org.redisson.client.RedisClientConfig
 
setGroups(int) - Method in class org.redisson.api.StreamInfo
 
setHostsMap(Map<String, String>) - Method in class org.redisson.api.HostNatMapper
Defines hosts mapping.
setHostsPortMap(Map<String, String>) - Method in class org.redisson.api.HostPortNatMapper
Defines host and port mapping.
setIdleConnectionTimeout(int) - Method in class org.redisson.config.BaseConfig
If pooled connection not used for a timeout time and current connections amount bigger than minimum idle connections pool size, then it will closed and removed from pool.
setImportMetadata(AnnotationMetadata) - Method in class org.redisson.spring.session.config.RedissonHttpSessionConfiguration
 
setImportMetadata(AnnotationMetadata) - Method in class org.redisson.spring.session.config.RedissonWebSessionConfiguration
 
setIndex(int) - Method in class org.redisson.RedissonPriorityQueue.BinarySearchResult
 
setIndex(Integer) - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
 
setKeepAlive(boolean) - Method in class org.redisson.client.RedisClientConfig
 
setKeepAlive(boolean) - Method in class org.redisson.config.BaseConfig
Enables TCP keepAlive for connection Default is false
setKeepPubSubOrder(boolean) - Method in class org.redisson.client.RedisClientConfig
 
setKeepPubSubOrder(boolean) - Method in class org.redisson.config.Config
Defines whether to keep PubSub messages handling in arrival order or handle messages concurrently.
setKeyName(String) - Method in class org.redisson.RedissonReference
 
setKeyPrefix(String) - Method in class org.redisson.spring.session.config.RedissonHttpSessionConfiguration
 
setKeyPrefix(String) - Method in class org.redisson.spring.session.config.RedissonWebSessionConfiguration
 
setKeyPrefix(String) - Method in class org.redisson.spring.session.RedissonSessionRepository
 
setLambdaBody(byte[]) - Method in class org.redisson.executor.params.TaskParameters
 
setLastEntry(StreamInfo.Entry<K, V>) - Method in class org.redisson.api.StreamInfo
 
setLastGeneratedId(StreamMessageId) - Method in class org.redisson.api.StreamInfo
 
setLastUsageTime(long) - Method in class org.redisson.client.RedisConnection
 
setLength(int) - Method in class org.redisson.api.StreamInfo
 
setListeners(List<TaskListener>) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
setLiveObjectId(Object) - Method in interface org.redisson.api.RLiveObject
Change the value of the field that has the RId annotation.
setLoadBalancer(LoadBalancer) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Сonnection load balancer to multiple Redis slave servers.
setLockWatchdogTimeout(long) - Method in class org.redisson.config.Config
This parameter is only used if lock has been acquired without leaseTimeout parameter definition.
setManagementEnabled(boolean) - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
setMapReduceWorkers(int) - Method in class org.redisson.config.RedissonNodeConfig
MapReduce workers amount.
setMasterAddress(RedisURI) - Method in class org.redisson.cluster.ClusterPartition
 
setMasterAddress(String) - Method in class org.redisson.config.MasterSlaveServersConfig
Set Redis master server address.
setMasterConnectionMinimumIdleSize(int) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Redis 'master' node minimum idle connection amount for each slave node Default is 24
setMasterConnectionPoolSize(int) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Redis 'master' server connection pool size.
setMasterFail(boolean) - Method in class org.redisson.cluster.ClusterPartition
 
setMasterName(String) - Method in class org.redisson.config.SentinelServersConfig
Master server name used by Redis Sentinel servers and master change monitoring task.
setMaxCleanUpDelay(int) - Method in class org.redisson.config.Config
Defines maximum delay in seconds for clean up process of expired entries.
setMaxIdleTime(long) - Method in class org.redisson.spring.cache.CacheConfig
Set max idle time for key\value entry in milliseconds.
setMaxInactiveIntervalInSeconds(Integer) - Method in class org.redisson.spring.session.config.RedissonHttpSessionConfiguration
 
setMaxInactiveIntervalInSeconds(Integer) - Method in class org.redisson.spring.session.config.RedissonWebSessionConfiguration
 
setMaxSize(int) - Method in interface org.redisson.api.RMapCache
Sets max size of the map.
setMaxSize(int) - Method in interface org.redisson.api.RMapCacheReactive
Sets max size of the map.
setMaxSize(int) - Method in interface org.redisson.api.RMapCacheRx
Sets max size of the map.
setMaxSize(int) - Method in class org.redisson.RedissonMapCache
 
setMaxSize(int) - Method in class org.redisson.spring.cache.CacheConfig
Set max size of map.
setMaxSizeAsync(int) - Method in interface org.redisson.api.RMapCacheAsync
Sets max size of the map.
setMaxSizeAsync(int) - Method in class org.redisson.RedissonMapCache
 
setMaxSizeAsync(int) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
setMinCleanUpDelay(int) - Method in class org.redisson.config.Config
Defines minimum delay in seconds for clean up process of expired entries.
setNatMap(Map<String, String>) - Method in class org.redisson.config.ClusterServersConfig
Deprecated.
setNatMap(Map<String, String>) - Method in class org.redisson.config.SentinelServersConfig
Deprecated.
setNatMapper(NatMapper) - Method in class org.redisson.config.ClusterServersConfig
Defines NAT mapper which maps Redis URI object.
setNatMapper(NatMapper) - Method in class org.redisson.config.SentinelServersConfig
Defines NAT mapper which maps Redis URI object.
setNettyHook(NettyHook) - Method in class org.redisson.client.RedisClientConfig
 
setNettyHook(NettyHook) - Method in class org.redisson.config.Config
Netty hook applied to Netty Bootstrap and Channel objects.
setNettyThreads(int) - Method in class org.redisson.config.Config
Threads amount shared between all redis clients used by Redisson.
setNodeId(String) - Method in class org.redisson.cluster.ClusterNodeInfo
 
setNodeType(NodeType) - Method in class org.redisson.connection.ClientConnectionsEntry
 
SETNX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SetObjectListener - Interface in org.redisson.api.listener
Redisson Object Event listener for set event published by Redis.
SetOperation - Class in org.redisson.transaction.operation.set
 
SetOperation(String, Codec, String) - Constructor for class org.redisson.transaction.operation.set.SetOperation
 
setParent(ClusterPartition) - Method in class org.redisson.cluster.ClusterPartition
 
setPassword(String) - Method in class org.redisson.client.RedisClientConfig
 
setPassword(String) - Method in class org.redisson.config.BaseConfig
Password for Redis authentication.
setPeriod(long) - Method in class org.redisson.executor.params.ScheduledAtFixedRateParameters
 
setPingConnectionInterval(int) - Method in class org.redisson.client.RedisClientConfig
 
setPingConnectionInterval(int) - Method in class org.redisson.config.BaseConfig
Defines PING command sending interval per connection to Redis.
SETPXNX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
setQueueName(String) - Method in class org.redisson.RedissonQueueSemaphore
 
setRadixTreeKeys(int) - Method in class org.redisson.api.StreamInfo
 
setRadixTreeNodes(int) - Method in class org.redisson.api.StreamInfo
 
SETRANGE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SetReactiveIterator<V> - Class in org.redisson.reactive
 
SetReactiveIterator() - Constructor for class org.redisson.reactive.SetReactiveIterator
 
setReadMode(ReadMode) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Set node type used for read operation.
setReadOnly(boolean) - Method in class org.redisson.client.RedisClientConfig
 
setReadOnlyMode(boolean) - Method in class org.redisson.command.CommandBatchService.Entry
 
setRedisClient(RedisClient) - Method in class org.redisson.client.protocol.decoder.ListScanResult
 
setRedisClient(RedisClient) - Method in class org.redisson.client.protocol.decoder.MapScanResult
 
setRedisClient(RedisClient) - Method in interface org.redisson.ScanResult
 
setRedisson(RedissonClient) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
Set Redisson instance
setRedissonNodeInitializer(RedissonNodeInitializer) - Method in class org.redisson.config.RedissonNodeConfig
Redisson node initializer
setReferenceEnabled(boolean) - Method in class org.redisson.config.Config
Config option for enabling Redisson Reference feature Default value is true
setRequestId(String) - Method in class org.redisson.executor.params.TaskParameters
 
setRequestId(RequestId) - Method in class org.redisson.executor.ScheduledTasksService
 
setResolverGroup(AddressResolverGroup<InetSocketAddress>) - Method in class org.redisson.client.RedisClientConfig
 
setResourceHolder(ReactiveRedissonResourceHolder) - Method in class org.redisson.spring.transaction.ReactiveRedissonTransactionObject
 
setResourceLoader(ResourceLoader) - Method in class org.redisson.spring.cache.RedissonSpringCacheManager
 
setRetryAttempts(int) - Method in class org.redisson.config.BaseConfig
Error will be thrown if Redis command can't be sent to Redis server after retryAttempts.
setRetryInterval(int) - Method in class org.redisson.config.BaseConfig
Defines time interval for another one attempt send Redis command if it hasn't been sent already.
setRollbackOnly(boolean) - Method in class org.redisson.spring.transaction.RedissonTransactionObject
 
SetRxIterator<V> - Class in org.redisson.rx
 
SetRxIterator() - Constructor for class org.redisson.rx.SetRxIterator
 
setScanInterval(int) - Method in class org.redisson.config.ClusterServersConfig
Redis cluster scan interval in milliseconds Default is 5000
setScanInterval(int) - Method in class org.redisson.config.ReplicatedServersConfig
Replication group scan interval in milliseconds Default is 1000
setScanInterval(int) - Method in class org.redisson.config.SentinelServersConfig
Sentinel scan interval in milliseconds Default is 1000
setSchedulerChannelName(String) - Method in class org.redisson.executor.TasksRunnerService
 
setSchedulerChannelName(String) - Method in class org.redisson.executor.TasksService
 
setSchedulerQueueName(String) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
setSchedulerQueueName(String) - Method in class org.redisson.executor.TasksRunnerService
 
setSchedulerQueueName(String) - Method in class org.redisson.executor.TasksService
 
setSlaveAddresses(Set<String>) - Method in class org.redisson.config.MasterSlaveServersConfig
 
setSlaveConnectionMinimumIdleSize(int) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Minimum idle connection pool size for subscription (pub/sub) channels Default is 24
setSlaveConnectionPoolSize(int) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Redis 'slave' servers connection pool size for each slave node.
setSlaveOf(String) - Method in class org.redisson.cluster.ClusterNodeInfo
 
SetSlotCommand - Enum in org.redisson.api.redisnode
 
setSocketChannelClass(Class<? extends SocketChannel>) - Method in class org.redisson.client.RedisClientConfig
 
setSslEnableEndpointIdentification(boolean) - Method in class org.redisson.client.RedisClientConfig
 
setSslEnableEndpointIdentification(boolean) - Method in class org.redisson.config.BaseConfig
Enables SSL endpoint identification.
setSslHostname(String) - Method in class org.redisson.client.RedisClientConfig
 
setSslKeystore(URL) - Method in class org.redisson.client.RedisClientConfig
 
setSslKeystore(URL) - Method in class org.redisson.config.BaseConfig
Defines path to SSL keystore Default is null
setSslKeystorePassword(String) - Method in class org.redisson.client.RedisClientConfig
 
setSslKeystorePassword(String) - Method in class org.redisson.config.BaseConfig
Defines password for SSL keystore Default is null
setSslProvider(SslProvider) - Method in class org.redisson.client.RedisClientConfig
 
setSslProvider(SslProvider) - Method in class org.redisson.config.BaseConfig
Defines SSL provider used to handle SSL connections.
setSslTruststore(URL) - Method in class org.redisson.client.RedisClientConfig
 
setSslTruststore(URL) - Method in class org.redisson.config.BaseConfig
Defines path to SSL truststore Default is null
setSslTruststorePassword(String) - Method in class org.redisson.client.RedisClientConfig
 
setSslTruststorePassword(String) - Method in class org.redisson.config.BaseConfig
Defines password for SSL truststore Default is null
setStartTime(long) - Method in class org.redisson.executor.params.ScheduledParameters
 
setState(byte[]) - Method in class org.redisson.executor.params.TaskParameters
 
setStatisticsEnabled(boolean) - Method in class org.redisson.jcache.configuration.JCacheConfiguration
 
setStatusName(String) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
setStatusName(String) - Method in class org.redisson.executor.TasksRunnerService
 
setStatusName(String) - Method in class org.redisson.executor.TasksService
 
setSubscriptionConnectionMinimumIdleSize(int) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Redis 'slave' node minimum idle subscription (pub/sub) connection amount for each slave node.
setSubscriptionConnectionMinimumIdleSize(int) - Method in class org.redisson.config.SingleServerConfig
Minimum idle subscription connection amount.
setSubscriptionConnectionPoolSize(int) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Maximum connection pool size for subscription (pub/sub) channels Default is 50
setSubscriptionConnectionPoolSize(int) - Method in class org.redisson.config.SingleServerConfig
Redis subscription-connection pool size limit Default is 50
setSubscriptionMode(SubscriptionMode) - Method in class org.redisson.config.BaseMasterSlaveServersConfig
Set node type used for subscription operation.
setSubscriptionsPerConnection(int) - Method in class org.redisson.config.BaseConfig
Subscriptions per Redis connection limit Default is 5
setTasksCounterName(String) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
setTasksCounterName(String) - Method in class org.redisson.executor.TasksRunnerService
 
setTasksCounterName(String) - Method in class org.redisson.executor.TasksService
 
setTasksExpirationTimeName(String) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
setTasksExpirationTimeName(String) - Method in class org.redisson.executor.TasksRunnerService
 
setTasksExpirationTimeName(String) - Method in class org.redisson.executor.TasksService
 
setTasksName(String) - Method in class org.redisson.executor.TasksRunnerService
 
setTasksName(String) - Method in class org.redisson.executor.TasksService
 
setTasksRetryInterval(long) - Method in class org.redisson.executor.TasksService
 
setTasksRetryIntervalName(String) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
setTasksRetryIntervalName(String) - Method in class org.redisson.executor.TasksRunnerService
 
setTasksRetryIntervalName(String) - Method in class org.redisson.executor.TasksService
 
setTaskTimeout(long) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
setTcpNoDelay(boolean) - Method in class org.redisson.client.RedisClientConfig
 
setTcpNoDelay(boolean) - Method in class org.redisson.config.BaseConfig
Enables TCP noDelay for connection Default is false
setTerminationTopicName(String) - Method in class org.redisson.executor.RedissonExecutorRemoteService
 
setTerminationTopicName(String) - Method in class org.redisson.executor.TasksRunnerService
 
setTerminationTopicName(String) - Method in class org.redisson.executor.TasksService
 
setThreads(int) - Method in class org.redisson.config.Config
Threads amount shared across all listeners of RTopic object, invocation handlers of RRemoteService object and RExecutorService tasks.
setTimeout(int) - Method in class org.redisson.config.BaseConfig
Redis server response timeout.
setTimeout(long) - Method in class org.redisson.mapreduce.BaseMapperTask
 
setTimeout(Timeout) - Method in class org.redisson.RedissonLock.ExpirationEntry
 
setTimer(Timer) - Method in class org.redisson.client.RedisClientConfig
 
setTimeZone(TimeZone) - Method in class org.redisson.executor.CronExpression
Sets the time zone for which this CronExpression will be resolved.
setTimezone(String) - Method in class org.redisson.executor.params.ScheduledCronExpressionParameters
 
setTransaction(RTransactionReactive) - Method in class org.redisson.spring.transaction.ReactiveRedissonResourceHolder
 
setTransaction(RTransaction) - Method in class org.redisson.spring.transaction.RedissonTransactionHolder
 
setTransactionHolder(RedissonTransactionHolder) - Method in class org.redisson.spring.transaction.RedissonTransactionObject
 
setTransportMode(TransportMode) - Method in class org.redisson.config.Config
Transport mode Default is TransportMode.NIO
setTtl(long) - Method in class org.redisson.executor.params.TaskParameters
 
setTTL(long) - Method in class org.redisson.spring.cache.CacheConfig
Set time to live for key\value entry in milliseconds.
setType(ClusterPartition.Type) - Method in class org.redisson.cluster.ClusterPartition
 
setType(Class<?>) - Method in class org.redisson.RedissonReference
 
setUncancellable() - Method in class org.redisson.misc.PromiseDelegator
 
setUncancellable() - Method in class org.redisson.misc.RedissonPromise
 
setUncancellable() - Method in interface org.redisson.misc.RPromise
Make this future impossible to cancel.
setupMasterEntry(InetSocketAddress, RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
 
setupMasterEntry(RedisURI) - Method in class org.redisson.connection.MasterSlaveEntry
 
setUsername(String) - Method in class org.redisson.client.RedisClientConfig
 
setUsername(String) - Method in class org.redisson.config.BaseConfig
Username for Redis authentication.
setUseScriptCache(boolean) - Method in class org.redisson.config.Config
Defines whether to use Lua-script cache on Redis side.
setUseThreadClassLoader(boolean) - Method in class org.redisson.config.Config
Defines whether to supply Thread ContextClassLoader to Codec.
setValue(V) - Method in class org.redisson.jcache.JMutableEntry
 
setValue(Object) - Method in interface org.redisson.liveobject.core.LiveObjectInterceptor.Setter
 
setValue(V) - Method in class org.redisson.RedissonMapEntry
 
setValue(Object) - Method in class org.redisson.RedissonQueueSemaphore
 
setValues(Collection<?>) - Method in class org.redisson.RedissonQueueSemaphore
 
setWorkersAmount(int) - Method in class org.redisson.mapreduce.BaseMapperTask
 
shouldGenerateIdAsFallback() - Method in class org.redisson.spring.support.AbstractRedissonNamespaceDefinitionParser
 
shouldGenerateIdAsFallback() - Method in class org.redisson.spring.support.RedisDefinitionParser
 
shutdown() - Method in interface org.redisson.api.RedissonClient
Shutdown Redisson instance but NOT Redis server This equates to invoke shutdown(0, 2, TimeUnit.SECONDS);
shutdown(long, long, TimeUnit) - Method in interface org.redisson.api.RedissonClient
Shuts down Redisson instance but NOT Redis server Shutdown ensures that no tasks are submitted for 'the quiet period' (usually a couple seconds) before it shuts itself down.
shutdown() - Method in interface org.redisson.api.RedissonReactiveClient
Shuts down Redisson instance NOT Redis server
shutdown() - Method in interface org.redisson.api.RedissonRxClient
Shuts down Redisson instance NOT Redis server
SHUTDOWN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
shutdown() - Method in class org.redisson.client.RedisClient
 
shutdown() - Method in class org.redisson.cluster.ClusterConnectionManager
 
shutdown() - Method in interface org.redisson.connection.ConnectionManager
 
shutdown(long, long, TimeUnit) - Method in interface org.redisson.connection.ConnectionManager
 
shutdown() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
shutdown(long, long, TimeUnit) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
shutdown() - Method in class org.redisson.connection.ReplicatedConnectionManager
 
shutdown() - Method in class org.redisson.connection.SentinelConnectionManager
 
shutdown() - Method in class org.redisson.Redisson
 
shutdown(long, long, TimeUnit) - Method in class org.redisson.Redisson
 
shutdown() - Method in class org.redisson.RedissonExecutorService
 
shutdown() - Method in class org.redisson.RedissonNode
Shutdown Redisson node instance
shutdown() - Method in class org.redisson.RedissonReactive
 
shutdown() - Method in class org.redisson.RedissonRx
 
SHUTDOWN_STATE - Static variable in class org.redisson.RedissonExecutorService
 
shutdownAsync() - Method in class org.redisson.client.RedisClient
 
shutdownAsync() - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
shutdownAsync() - Method in class org.redisson.connection.MasterSlaveEntry
 
shutdownNow() - Method in class org.redisson.RedissonExecutorService
 
SINGLE - Static variable in class org.redisson.api.redisnode.RedisNodes
 
SingleConnectionManager - Class in org.redisson.connection
 
SingleConnectionManager(SingleServerConfig, Config, UUID) - Constructor for class org.redisson.connection.SingleConnectionManager
 
SingleEntry - Class in org.redisson.connection
 
SingleEntry(ConnectionManager, MasterSlaveServersConfig) - Constructor for class org.redisson.connection.SingleEntry
 
SingleServerConfig - Class in org.redisson.config
 
singleSlotRange - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
SINTER - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SINTERSTORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SINTERSTORE_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SISMEMBER - Static variable in interface org.redisson.client.protocol.RedisCommands
 
size() - Method in interface org.redisson.api.RBitSet
Returns number of set bits.
size() - Method in interface org.redisson.api.RBitSetReactive
Returns number of set bits.
size() - Method in interface org.redisson.api.RBitSetRx
Returns number of set bits.
size() - Method in interface org.redisson.api.RBucket
Returns size of object in bytes.
size() - Method in interface org.redisson.api.RBucketReactive
Returns size of object in bytes
size() - Method in interface org.redisson.api.RBucketRx
Returns size of object in bytes
size() - Method in interface org.redisson.api.RCollectionReactive
Returns number of elements in this collection.
size() - Method in interface org.redisson.api.RCollectionRx
Returns number of elements in this collection.
size() - Method in interface org.redisson.api.RMapCache
Returns the number of entries in cache.
size() - Method in interface org.redisson.api.RMapCacheReactive
Returns the number of entries in cache.
size() - Method in interface org.redisson.api.RMapCacheRx
Returns the number of entries in cache.
size() - Method in interface org.redisson.api.RMapReactive
Returns size of this map
size() - Method in interface org.redisson.api.RMapRx
Returns size of this map
size() - Method in interface org.redisson.api.RMultimap
Returns the number of key-value pairs in this multimap.
size() - Method in interface org.redisson.api.RMultimapReactive
Returns the number of key-value pairs in this multimap.
size() - Method in interface org.redisson.api.RMultimapRx
Returns the number of key-value pairs in this multimap.
size() - Method in interface org.redisson.api.RScoredSortedSet
Returns size of this set.
size() - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns size of this set.
size() - Method in interface org.redisson.api.RScoredSortedSetRx
Returns size of this set.
size() - Method in interface org.redisson.api.RSetCache
Returns the number of elements in cache.
size() - Method in interface org.redisson.api.RSetCacheReactive
Returns the number of elements in cache.
size() - Method in interface org.redisson.api.RSetCacheRx
Returns the number of elements in cache.
size() - Method in interface org.redisson.api.RStream
Returns number of entries in stream
size() - Method in interface org.redisson.api.RStreamReactive
Returns number of entries in stream
size() - Method in interface org.redisson.api.RStreamRx
Returns number of entries in stream
size() - Method in class org.redisson.cache.AbstractCacheMap
 
size() - Method in class org.redisson.cluster.ClusterSlotRange
 
size() - Method in class org.redisson.misc.BiHashMap
 
size() - Method in class org.redisson.RedissonBitSet
 
size() - Method in class org.redisson.RedissonBucket
 
size() - Method in class org.redisson.RedissonDelayedQueue
 
size() - Method in class org.redisson.RedissonList
 
size() - Method in class org.redisson.RedissonListMultimapValues
 
size() - Method in class org.redisson.RedissonMap
 
size() - Method in class org.redisson.RedissonMultimap
 
size() - Method in class org.redisson.RedissonScoredSortedSet
 
size() - Method in class org.redisson.RedissonSet
 
size() - Method in class org.redisson.RedissonSetCache
 
size() - Method in class org.redisson.RedissonSetMultimapValues
 
size() - Method in class org.redisson.RedissonSortedSet
 
size() - Method in class org.redisson.RedissonStream
 
size() - Method in class org.redisson.RedissonTransferQueue
 
size() - Method in class org.redisson.spring.cache.RedissonCacheMetrics
 
sizeAsync() - Method in interface org.redisson.api.RBitSetAsync
Returns number of set bits.
sizeAsync() - Method in interface org.redisson.api.RBucketAsync
Returns size of object in bytes
sizeAsync() - Method in interface org.redisson.api.RCollectionAsync
Returns number of elements in this collection.
sizeAsync() - Method in interface org.redisson.api.RMapAsync
Returns size of this map
sizeAsync() - Method in interface org.redisson.api.RMapCacheAsync
Returns the number of entries in cache.
sizeAsync() - Method in interface org.redisson.api.RMultimapAsync
Returns the number of key-value pairs in this multimap.
sizeAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns size of this set.
sizeAsync() - Method in interface org.redisson.api.RSetCacheAsync
Returns the number of elements in cache.
sizeAsync() - Method in interface org.redisson.api.RStreamAsync
Returns number of entries in stream
sizeAsync() - Method in class org.redisson.RedissonBitSet
 
sizeAsync() - Method in class org.redisson.RedissonBucket
 
sizeAsync() - Method in class org.redisson.RedissonDelayedQueue
 
sizeAsync() - Method in class org.redisson.RedissonList
 
sizeAsync() - Method in class org.redisson.RedissonListMultimap
 
sizeAsync() - Method in class org.redisson.RedissonListMultimapValues
 
sizeAsync() - Method in class org.redisson.RedissonLocalCachedMap
 
sizeAsync() - Method in class org.redisson.RedissonMap
 
sizeAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
sizeAsync() - Method in class org.redisson.RedissonSet
 
sizeAsync() - Method in class org.redisson.RedissonSetCache
 
sizeAsync() - Method in class org.redisson.RedissonSetMultimap
 
sizeAsync() - Method in class org.redisson.RedissonSetMultimapValues
 
sizeAsync() - Method in class org.redisson.RedissonStream
 
sizeAsync() - Method in class org.redisson.RedissonSubList
 
sizeAsync() - Method in class org.redisson.RedissonTransferQueue
 
sizeAsync() - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
sizeInMemory() - Method in interface org.redisson.api.RObject
Returns bytes amount used by object in Redis memory.
sizeInMemory() - Method in interface org.redisson.api.RObjectReactive
Returns bytes amount used by object in Redis memory.
sizeInMemory() - Method in interface org.redisson.api.RObjectRx
Returns bytes amount used by object in Redis memory.
sizeInMemory() - Method in class org.redisson.RedissonObject
 
sizeInMemoryAsync() - Method in interface org.redisson.api.RObjectAsync
Returns bytes amount used by object in Redis memory.
sizeInMemoryAsync() - Method in class org.redisson.RedissonBloomFilter
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonBoundedBlockingQueue
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonDelayedQueue
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonFairLock
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonListMultimapCache
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonListMultimapValues
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonLocalCachedMap
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonMapCache
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonMultimapCache
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonObject
 
sizeInMemoryAsync(List<Object>) - Method in class org.redisson.RedissonObject
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonSetMultimapCache
 
sizeInMemoryAsync() - Method in class org.redisson.RedissonSetMultimapValues
 
skip(long) - Method in class org.redisson.codec.MarshallingCodec.ByteInputWrapper
 
skipCommand(ByteBuf) - Method in class org.redisson.client.handler.CommandDecoder
 
skipDecode(ByteBuf) - Method in class org.redisson.client.handler.CommandDecoder
 
SKIPPED_CODECS - Static variable in class org.redisson.client.codec.BaseCodec
 
skipResult() - Method in class org.redisson.api.BatchOptions
Inform Redis not to send reply.
skipWhiteSpace(int, String) - Method in class org.redisson.executor.CronExpression
 
SlaveConnectionPool - Class in org.redisson.connection.pool
Connection pool for slave node
SlaveConnectionPool(MasterSlaveServersConfig, ConnectionManager, MasterSlaveEntry) - Constructor for class org.redisson.connection.pool.SlaveConnectionPool
 
slaveDown(ClientConnectionsEntry, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveEntry
 
slaveDown(InetSocketAddress, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveEntry
 
slaveDown(RedisURI, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveEntry
 
slaveUp(ClientConnectionsEntry, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveEntry
 
slaveUp(RedisURI, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveEntry
 
slaveUp(InetSocketAddress, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveEntry
 
SlotCallback<T,R> - Interface in org.redisson
 
slots() - Method in class org.redisson.cluster.ClusterPartition
 
SlotsDecoder - Class in org.redisson.client.protocol.decoder
 
SlotsDecoder() - Constructor for class org.redisson.client.protocol.decoder.SlotsDecoder
 
SMEMBERS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SmileJacksonCodec - Class in org.redisson.codec
Smile binary codec
SmileJacksonCodec() - Constructor for class org.redisson.codec.SmileJacksonCodec
 
SmileJacksonCodec(ClassLoader) - Constructor for class org.redisson.codec.SmileJacksonCodec
 
SmileJacksonCodec(ClassLoader, SmileJacksonCodec) - Constructor for class org.redisson.codec.SmileJacksonCodec
 
SMOVE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SnappyCodec - Class in org.redisson.codec
Snappy compression codec.
SnappyCodec() - Constructor for class org.redisson.codec.SnappyCodec
 
SnappyCodec(Codec) - Constructor for class org.redisson.codec.SnappyCodec
 
SnappyCodec(ClassLoader) - Constructor for class org.redisson.codec.SnappyCodec
 
SnappyCodec(ClassLoader, SnappyCodec) - Constructor for class org.redisson.codec.SnappyCodec
 
SnappyCodecV2 - Class in org.redisson.codec
Google's Snappy compression codec.
SnappyCodecV2() - Constructor for class org.redisson.codec.SnappyCodecV2
 
SnappyCodecV2(Codec) - Constructor for class org.redisson.codec.SnappyCodecV2
 
SnappyCodecV2(ClassLoader) - Constructor for class org.redisson.codec.SnappyCodecV2
 
SnappyCodecV2(ClassLoader, SnappyCodecV2) - Constructor for class org.redisson.codec.SnappyCodecV2
 
socketChannelClass - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
soft(long, long) - Static method in class org.redisson.cache.ReferenceCacheMap
 
SORT_LIST - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SORT_SET - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SORT_TO - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SortOrder - Enum in org.redisson.api
 
sortTo(String, SortOrder) - Method in interface org.redisson.api.RSortable
Sort data and store to destName list
sortTo(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortable
Sort data and store to destName list
sortTo(String, String, SortOrder) - Method in interface org.redisson.api.RSortable
Sort data and store to destName list
sortTo(String, String, SortOrder, int, int) - Method in interface org.redisson.api.RSortable
Sort data and store to destName list
sortTo(String, String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortable
Sort data and store to destName list
sortTo(String, String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortable
Sort data and store to destName list
sortTo(String, SortOrder) - Method in interface org.redisson.api.RSortableReactive
Sort data and store to destName list
sortTo(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableReactive
Sort data and store to destName list
sortTo(String, String, SortOrder) - Method in interface org.redisson.api.RSortableReactive
Sort data and store to destName list
sortTo(String, String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableReactive
Sort data and store to destName list
sortTo(String, String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortableReactive
Sort data and store to destName list
sortTo(String, String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortableReactive
Sort data and store to destName list
sortTo(String, SortOrder) - Method in interface org.redisson.api.RSortableRx
Sort data and store to destName list
sortTo(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableRx
Sort data and store to destName list
sortTo(String, String, SortOrder) - Method in interface org.redisson.api.RSortableRx
Sort data and store to destName list
sortTo(String, String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableRx
Sort data and store to destName list
sortTo(String, String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortableRx
Sort data and store to destName list
sortTo(String, String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortableRx
Sort data and store to destName list
sortTo(String, SortOrder) - Method in class org.redisson.RedissonList
 
sortTo(String, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
sortTo(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
sortTo(String, String, SortOrder) - Method in class org.redisson.RedissonList
 
sortTo(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonList
 
sortTo(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
sortTo(String, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
sortTo(String, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
sortTo(String, String, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
sortTo(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
sortTo(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
sortTo(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
sortTo(String, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
sortTo(String, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
sortTo(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
sortTo(String, String, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
sortTo(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
sortTo(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
sortTo(String, SortOrder) - Method in class org.redisson.RedissonSet
 
sortTo(String, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
sortTo(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
sortTo(String, String, SortOrder) - Method in class org.redisson.RedissonSet
 
sortTo(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonSet
 
sortTo(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
sortTo(String, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
sortTo(String, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
sortTo(String, String, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
sortTo(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
sortTo(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
sortTo(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
sortToAsync(String, SortOrder) - Method in interface org.redisson.api.RSortableAsync
Sort data and store to destName list
sortToAsync(String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableAsync
Sort data and store to destName list
sortToAsync(String, String, SortOrder) - Method in interface org.redisson.api.RSortableAsync
Sort data and store to destName list
sortToAsync(String, String, SortOrder, int, int) - Method in interface org.redisson.api.RSortableAsync
Sort data and store to destName list
sortToAsync(String, String, List<String>, SortOrder) - Method in interface org.redisson.api.RSortableAsync
Sort data and store to destName list
sortToAsync(String, String, List<String>, SortOrder, int, int) - Method in interface org.redisson.api.RSortableAsync
Sort data and store to destName list
sortToAsync(String, SortOrder) - Method in class org.redisson.RedissonList
 
sortToAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
sortToAsync(String, String, SortOrder) - Method in class org.redisson.RedissonList
 
sortToAsync(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
sortToAsync(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonList
 
sortToAsync(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonList
 
sortToAsync(String, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
sortToAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
sortToAsync(String, String, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
sortToAsync(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
sortToAsync(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonListMultimapValues
 
sortToAsync(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonListMultimapValues
 
sortToAsync(String, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
sortToAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
sortToAsync(String, String, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
sortToAsync(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
sortToAsync(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonScoredSortedSet
 
sortToAsync(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
sortToAsync(String, SortOrder) - Method in class org.redisson.RedissonSet
 
sortToAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
sortToAsync(String, String, SortOrder) - Method in class org.redisson.RedissonSet
 
sortToAsync(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
sortToAsync(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonSet
 
sortToAsync(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSet
 
sortToAsync(String, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
sortToAsync(String, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
sortToAsync(String, String, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
sortToAsync(String, String, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
sortToAsync(String, String, List<String>, SortOrder) - Method in class org.redisson.RedissonSetMultimapValues
 
sortToAsync(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.RedissonSetMultimapValues
 
sortToAsync(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.transaction.BaseTransactionalSet
 
sortToAsync(String, String, List<String>, SortOrder, int, int) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
SPOP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SPOP_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SRANDMEMBER - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SRANDMEMBER_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SREM_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SSCAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SslProvider - Enum in org.redisson.config
 
start() - Method in class org.redisson.connection.DNSMonitor
 
start() - Method in class org.redisson.MapWriteBehindTask
 
start() - Method in class org.redisson.QueueTransferTask
 
start() - Method in class org.redisson.RedissonNode
Start Redisson node instance
start(String, MapOptions<?, ?>) - Method in class org.redisson.WriteBehindService
 
startDNSMonitoring(RedisClient) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
startDNSMonitoring(RedisClient) - Method in class org.redisson.connection.SentinelConnectionManager
 
State - Class in org.redisson.client.handler
 
State() - Constructor for class org.redisson.client.handler.State
 
StateLevel - Class in org.redisson.client.handler
 
StateLevel(long, List<Object>) - Constructor for class org.redisson.client.handler.StateLevel
 
StatusListener - Interface in org.redisson.api.listener
Listener for Redis PubSub channel status changes
statusName - Variable in class org.redisson.executor.TasksService
 
StdCachedValue<K,V> - Class in org.redisson.cache
Created by jribble on 2/20/17.
StdCachedValue(K, V, long, long) - Constructor for class org.redisson.cache.StdCachedValue
 
stop() - Method in class org.redisson.connection.DNSMonitor
 
stop() - Method in class org.redisson.connection.IdleConnectionWatcher
 
stop() - Method in class org.redisson.MapWriteBehindTask
 
stop() - Method in class org.redisson.QueueTransferTask
 
stop(String) - Method in class org.redisson.WriteBehindService
 
stopThreads() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
store(RObject, String, RMap<String, Object>) - Method in class org.redisson.liveobject.core.RedissonObjectBuilder
 
storeExpressionVals(int, String, int) - Method in class org.redisson.executor.CronExpression
 
storeIndex(Field, Object, Object) - Method in class org.redisson.liveobject.core.AccessorInterceptor
 
storeMode(LocalCachedMapOptions.StoreMode) - Method in class org.redisson.api.LocalCachedMapOptions
Defines store mode of cache data.
stream() - Method in interface org.redisson.api.RScoredSortedSet
Returns stream of elements in this set.
stream(String) - Method in interface org.redisson.api.RScoredSortedSet
Returns stream of elements in this set.
stream(int) - Method in interface org.redisson.api.RScoredSortedSet
Returns stream of elements in this set.
stream(String, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns stream of elements in this set.
stream(int) - Method in interface org.redisson.api.RSet
Returns stream of elements fetches elements in a batch.
stream(String, int) - Method in interface org.redisson.api.RSet
Returns stream of elements fetches elements in a batch.
stream(String) - Method in interface org.redisson.api.RSet
Returns stream of elements.
stream(int) - Method in interface org.redisson.api.RSetCache
Returns stream of elements in this set.
stream(String, int) - Method in interface org.redisson.api.RSetCache
Returns stream of elements in this set.
stream(String) - Method in interface org.redisson.api.RSetCache
Returns stream of elements in this set matches pattern.
stream() - Method in class org.redisson.RedissonScoredSortedSet
 
stream(String) - Method in class org.redisson.RedissonScoredSortedSet
 
stream(int) - Method in class org.redisson.RedissonScoredSortedSet
 
stream(String, int) - Method in class org.redisson.RedissonScoredSortedSet
 
stream(int) - Method in class org.redisson.RedissonSet
 
stream(String, int) - Method in class org.redisson.RedissonSet
 
stream(String) - Method in class org.redisson.RedissonSet
 
stream(int) - Method in class org.redisson.RedissonSetCache
 
stream(String, int) - Method in class org.redisson.RedissonSetCache
 
stream(String) - Method in class org.redisson.RedissonSetCache
 
stream(int) - Method in class org.redisson.RedissonSetMultimapValues
 
stream(String, int) - Method in class org.redisson.RedissonSetMultimapValues
 
stream(String) - Method in class org.redisson.RedissonSetMultimapValues
 
StreamConsumer - Class in org.redisson.api
Object containing details about Stream Consumer
StreamConsumer(String, int, long) - Constructor for class org.redisson.api.StreamConsumer
 
StreamConsumerInfoDecoder - Class in org.redisson.client.protocol.decoder
 
StreamConsumerInfoDecoder() - Constructor for class org.redisson.client.protocol.decoder.StreamConsumerInfoDecoder
 
StreamGroup - Class in org.redisson.api
Object containing details about Stream Group
StreamGroup(String, int, int, StreamMessageId) - Constructor for class org.redisson.api.StreamGroup
 
StreamGroupInfoDecoder - Class in org.redisson.client.protocol.decoder
 
StreamGroupInfoDecoder() - Constructor for class org.redisson.client.protocol.decoder.StreamGroupInfoDecoder
 
StreamIdConvertor - Class in org.redisson.client.protocol.convertor
 
StreamIdConvertor() - Constructor for class org.redisson.client.protocol.convertor.StreamIdConvertor
 
StreamIdDecoder - Class in org.redisson.client.protocol.decoder
 
StreamIdDecoder() - Constructor for class org.redisson.client.protocol.decoder.StreamIdDecoder
 
StreamIdListDecoder - Class in org.redisson.client.protocol.decoder
 
StreamIdListDecoder() - Constructor for class org.redisson.client.protocol.decoder.StreamIdListDecoder
 
StreamInfo<K,V> - Class in org.redisson.api
Object containing details about Stream
StreamInfo() - Constructor for class org.redisson.api.StreamInfo
 
StreamInfo.Entry<K,V> - Class in org.redisson.api
 
StreamInfoDecoder - Class in org.redisson.client.protocol.decoder
 
StreamInfoDecoder() - Constructor for class org.redisson.client.protocol.decoder.StreamInfoDecoder
 
StreamMessageId - Class in org.redisson.api
Stream Message ID object
StreamMessageId(long) - Constructor for class org.redisson.api.StreamMessageId
 
StreamMessageId(long, long) - Constructor for class org.redisson.api.StreamMessageId
 
StreamObjectMapReplayDecoder - Class in org.redisson.client.protocol.decoder
 
StreamObjectMapReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.StreamObjectMapReplayDecoder
 
StreamObjectMapReplayDecoder(Decoder<Object>) - Constructor for class org.redisson.client.protocol.decoder.StreamObjectMapReplayDecoder
 
StreamResultDecoder - Class in org.redisson.client.protocol.decoder
 
StreamResultDecoder(boolean) - Constructor for class org.redisson.client.protocol.decoder.StreamResultDecoder
 
StringCodec - Class in org.redisson.client.codec
 
StringCodec() - Constructor for class org.redisson.client.codec.StringCodec
 
StringCodec(ClassLoader) - Constructor for class org.redisson.client.codec.StringCodec
 
StringCodec(String) - Constructor for class org.redisson.client.codec.StringCodec
 
StringCodec(Charset) - Constructor for class org.redisson.client.codec.StringCodec
 
StringDataDecoder - Class in org.redisson.client.protocol.decoder
 
StringDataDecoder() - Constructor for class org.redisson.client.protocol.decoder.StringDataDecoder
 
StringListReplayDecoder - Class in org.redisson.client.protocol.decoder
 
StringListReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.StringListReplayDecoder
 
StringMapDataDecoder - Class in org.redisson.client.protocol.decoder
 
StringMapDataDecoder() - Constructor for class org.redisson.client.protocol.decoder.StringMapDataDecoder
 
StringReplayDecoder - Class in org.redisson.client.protocol.decoder
 
StringReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.StringReplayDecoder
 
StringToListConvertor - Class in org.redisson.client.protocol.convertor
 
StringToListConvertor() - Constructor for class org.redisson.client.protocol.convertor.StringToListConvertor
 
STRLEN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
subList(int, int) - Method in interface org.redisson.api.RList
 
subList(int, int) - Method in class org.redisson.RedissonList
 
subList(int, int) - Method in class org.redisson.RedissonListMultimapValues
 
subList(int, int) - Method in class org.redisson.RedissonSubList
 
submit(Callable<T>) - Method in interface org.redisson.api.RExecutorService
Synchronously submits a value-returning task for execution asynchronously and returns a Future representing the pending results of the task.
submit(Callable<T>, long, TimeUnit) - Method in interface org.redisson.api.RExecutorService
Synchronously submits a value-returning task with defined timeToLive parameter for execution asynchronously.
submit(Callable<?>...) - Method in interface org.redisson.api.RExecutorService
Synchronously submits tasks batch for execution asynchronously.
submit(Runnable, T) - Method in interface org.redisson.api.RExecutorService
Synchronously submits a Runnable task for execution asynchronously and returns a RExecutorFuture representing that task.
submit(Runnable) - Method in interface org.redisson.api.RExecutorService
Synchronously submits a Runnable task for execution asynchronously.
submit(Runnable, long, TimeUnit) - Method in interface org.redisson.api.RExecutorService
Synchronously submits a task with defined timeToLive parameter for execution asynchronously.
submit(Runnable...) - Method in interface org.redisson.api.RExecutorService
Synchronously submits tasks batch for execution asynchronously.
submit(Callable<V>) - Method in class org.redisson.executor.RedissonCompletionService
 
submit(Runnable, V) - Method in class org.redisson.executor.RedissonCompletionService
 
submit(Runnable) - Method in class org.redisson.mapreduce.SubTasksExecutor
 
submit(Callable<T>) - Method in class org.redisson.RedissonExecutorService
 
submit(Callable<T>, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
submit(Callable<?>...) - Method in class org.redisson.RedissonExecutorService
 
submit(Runnable, T) - Method in class org.redisson.RedissonExecutorService
 
submit(Runnable...) - Method in class org.redisson.RedissonExecutorService
 
submit(Runnable) - Method in class org.redisson.RedissonExecutorService
 
submit(Runnable, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
submitAsync(Callable<T>) - Method in interface org.redisson.api.RExecutorServiceAsync
Submits task for execution asynchronously
submitAsync(Callable<T>, long, TimeUnit) - Method in interface org.redisson.api.RExecutorServiceAsync
Submits a value-returning task with defined timeToLive parameter for execution asynchronously.
submitAsync(Callable<?>...) - Method in interface org.redisson.api.RExecutorServiceAsync
Submits tasks batch for execution asynchronously.
submitAsync(Runnable) - Method in interface org.redisson.api.RExecutorServiceAsync
Submits task for execution asynchronously
submitAsync(Runnable, long, TimeUnit) - Method in interface org.redisson.api.RExecutorServiceAsync
Submits a task with defined timeToLive parameter for execution asynchronously.
submitAsync(Runnable...) - Method in interface org.redisson.api.RExecutorServiceAsync
Submits tasks batch for execution asynchronously.
submitAsync(Callable<T>, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
submitAsync(Callable<T>) - Method in class org.redisson.RedissonExecutorService
 
submitAsync(Callable<?>...) - Method in class org.redisson.RedissonExecutorService
 
submitAsync(Runnable...) - Method in class org.redisson.RedissonExecutorService
 
submitAsync(Runnable, long, TimeUnit) - Method in class org.redisson.RedissonExecutorService
 
submitAsync(Runnable) - Method in class org.redisson.RedissonExecutorService
 
SUBSCRIBE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
subscribe(Codec, ChannelName...) - Method in class org.redisson.client.RedisPubSubConnection
 
subscribe(Codec, ChannelName, RedisPubSubListener<?>...) - Method in class org.redisson.pubsub.PublishSubscribeService
 
subscribe(Codec, String, AsyncSemaphore, RedisPubSubListener<?>...) - Method in class org.redisson.pubsub.PublishSubscribeService
 
subscribe(Codec, ChannelName) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
subscribe(long) - Method in class org.redisson.RedissonFairLock
 
subscribe(long) - Method in class org.redisson.RedissonLock
 
SubscribeListener - Class in org.redisson.client
 
SubscribeListener(ChannelName, PubSubType) - Constructor for class org.redisson.client.SubscribeListener
 
subscribeOnElements(Consumer<V>) - Method in interface org.redisson.api.RBlockingQueue
Subscribes on elements appeared in this queue.
subscribeOnElements(Supplier<RFuture<V>>, Consumer<V>) - Method in class org.redisson.ElementsSubscribeService
 
subscribeOnElements(Consumer<V>) - Method in class org.redisson.RedissonBlockingDeque
 
subscribeOnElements(Consumer<V>) - Method in class org.redisson.RedissonBlockingQueue
 
subscribeOnElements(Consumer<V>) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
subscribeOnElements(Consumer<V>) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
subscribeOnElements(Consumer<V>) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
subscribeOnElements(Consumer<V>) - Method in class org.redisson.RedissonTransferQueue
 
subscribeOnFirstElements(Consumer<V>) - Method in interface org.redisson.api.RBlockingDeque
Subscribes on first elements appeared in this queue.
subscribeOnFirstElements(Consumer<V>) - Method in interface org.redisson.api.RScoredSortedSet
Subscribes on first elements appeared in this set.
subscribeOnFirstElements(Consumer<V>) - Method in class org.redisson.RedissonBlockingDeque
 
subscribeOnFirstElements(Consumer<V>) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
subscribeOnFirstElements(Consumer<V>) - Method in class org.redisson.RedissonScoredSortedSet
 
subscribeOnLastElements(Consumer<V>) - Method in interface org.redisson.api.RBlockingDeque
Subscribes on last elements appeared in this queue.
subscribeOnLastElements(Consumer<V>) - Method in interface org.redisson.api.RScoredSortedSet
Subscribes on last elements appeared in this set.
subscribeOnLastElements(Consumer<V>) - Method in class org.redisson.RedissonBlockingDeque
 
subscribeOnLastElements(Consumer<V>) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
subscribeOnLastElements(Consumer<V>) - Method in class org.redisson.RedissonScoredSortedSet
 
SubscriptionMode - Enum in org.redisson.config
 
subSequence(int, int) - Method in class org.redisson.client.ChannelName
 
subSet(String, String) - Method in class org.redisson.RedissonLexSortedSet
 
subSet(V, V) - Method in class org.redisson.RedissonSortedSet
 
SubTasksExecutor - Class in org.redisson.mapreduce
 
SubTasksExecutor(RExecutorService, int, long, long) - Constructor for class org.redisson.mapreduce.SubTasksExecutor
 
SubTasksExecutor.LatchListener - Class in org.redisson.mapreduce
 
suffixName(String, String) - Static method in class org.redisson.RedissonObject
 
sum() - Method in interface org.redisson.api.RDoubleAdder
Accumulates sum across all RDoubleAdder instances
sum() - Method in interface org.redisson.api.RLongAdder
Accumulates sum across all RLongAdder instances
sum() - Method in class org.redisson.RedissonDoubleAdder
 
sum() - Method in class org.redisson.RedissonLongAdder
 
sumAsync() - Method in interface org.redisson.api.RDoubleAdder
Accumulates sum across all RDoubleAdder instances
sumAsync(long, TimeUnit) - Method in interface org.redisson.api.RDoubleAdder
Accumulates sum across all RDoubleAdder instances within defined timeout.
sumAsync() - Method in interface org.redisson.api.RLongAdder
Accumulates sum across all RLongAdder instances
sumAsync(long, TimeUnit) - Method in interface org.redisson.api.RLongAdder
Accumulates sum across all RLongAdder instances within defined timeout.
sumAsync() - Method in class org.redisson.RedissonBaseAdder
 
sumAsync(long, TimeUnit) - Method in class org.redisson.RedissonBaseAdder
 
SUNION - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SUNIONSTORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
SUNIONSTORE_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
swapdb(int, int) - Method in interface org.redisson.api.RKeys
Swap two databases.
swapdb(int, int) - Method in interface org.redisson.api.RKeysReactive
Swap two databases.
swapdb(int, int) - Method in interface org.redisson.api.RKeysRx
Swap two databases.
SWAPDB - Static variable in interface org.redisson.client.protocol.RedisCommands
 
swapdb(int, int) - Method in class org.redisson.RedissonKeys
 
swapdbAsync(int, int) - Method in interface org.redisson.api.RKeysAsync
Swap two databases.
swapdbAsync(int, int) - Method in class org.redisson.RedissonKeys
 
sync() - Method in interface org.redisson.api.RFuture
Waits for this future until it is done, and rethrows the cause of the failure if this future failed.
sync(RedisCommand<T>, Object...) - Method in class org.redisson.client.RedisConnection
 
sync(Codec, RedisCommand<T>, Object...) - Method in class org.redisson.client.RedisConnection
 
sync() - Method in class org.redisson.command.BatchPromise
 
sync() - Method in class org.redisson.misc.PromiseDelegator
 
sync() - Method in class org.redisson.misc.RedissonPromise
 
sync() - Method in interface org.redisson.misc.RPromise
 
SyncRemoteProxy - Class in org.redisson.remote
 
SyncRemoteProxy(CommandAsyncExecutor, String, String, ConcurrentMap<String, ResponseEntry>, Codec, String, BaseRemoteService) - Constructor for class org.redisson.remote.SyncRemoteProxy
 
syncSlaves(int, long, TimeUnit) - Method in class org.redisson.api.BatchOptions
Synchronize write operations execution within defined timeout across specified amount of Redis slave nodes.
syncSlavesTimeout(long, TimeUnit) - Method in class org.redisson.api.TransactionOptions
Synchronization data timeout between Redis master participating in transaction and its slaves.
syncStrategy(LocalCachedMapOptions.SyncStrategy) - Method in class org.redisson.api.LocalCachedMapOptions
 
syncSubscription(RFuture<?>) - Method in interface org.redisson.command.CommandAsyncExecutor
 
syncSubscription(RFuture<?>) - Method in class org.redisson.command.CommandAsyncService
 
syncSubscriptionInterrupted(RFuture<?>) - Method in interface org.redisson.command.CommandAsyncExecutor
 
syncSubscriptionInterrupted(RFuture<?>) - Method in class org.redisson.command.CommandAsyncService
 
syncUninterruptibly() - Method in interface org.redisson.api.RFuture
Waits for this future until it is done, and rethrows the cause of the failure if this future failed.
syncUninterruptibly() - Method in class org.redisson.command.BatchPromise
 
syncUninterruptibly() - Method in class org.redisson.misc.PromiseDelegator
 
syncUninterruptibly() - Method in class org.redisson.misc.RedissonPromise
 
syncUninterruptibly() - Method in interface org.redisson.misc.RPromise
 

T

tailSet(String) - Method in class org.redisson.RedissonLexSortedSet
 
tailSet(V) - Method in class org.redisson.RedissonSortedSet
 
take() - Method in interface org.redisson.api.RBlockingQueueReactive
Retrieves and removes the head of this queue in async mode, waiting if necessary until an element becomes available.
take() - Method in interface org.redisson.api.RBlockingQueueRx
Retrieves and removes the head of this queue in async mode, waiting if necessary until an element becomes available.
take() - Method in class org.redisson.executor.RedissonCompletionService
 
take() - Method in class org.redisson.RedissonBlockingDeque
 
take() - Method in class org.redisson.RedissonBlockingQueue
 
take() - Method in class org.redisson.RedissonBoundedBlockingQueue
 
take() - Method in class org.redisson.RedissonPriorityBlockingDeque
 
take() - Method in class org.redisson.RedissonPriorityBlockingQueue
 
take() - Method in class org.redisson.RedissonTransferQueue
 
takeAsync() - Method in interface org.redisson.api.RBlockingQueueAsync
Retrieves and removes the head of this queue in async mode, waiting if necessary until an element becomes available.
takeAsync() - Method in class org.redisson.RedissonBlockingDeque
 
takeAsync() - Method in class org.redisson.RedissonBlockingQueue
 
takeAsync() - Method in class org.redisson.RedissonBoundedBlockingQueue
 
takeAsync() - Method in class org.redisson.RedissonPriorityBlockingDeque
 
takeAsync() - Method in class org.redisson.RedissonPriorityBlockingQueue
 
takeAsync(RPromise<V>, long, long, RedisCommand<T>, Object...) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
takeAsync() - Method in class org.redisson.RedissonTransferQueue
 
takeElements() - Method in interface org.redisson.api.RBlockingQueueReactive
Retrieves and removes continues stream of elements from the head of this queue.
takeElements() - Method in interface org.redisson.api.RBlockingQueueRx
Retrieves and removes continues stream of elements from the head of this queue.
takeElements(Callable<RFuture<V>>) - Static method in class org.redisson.reactive.ElementsStream
 
takeElements() - Method in class org.redisson.reactive.RedissonBlockingQueueReactive
 
takeElements() - Method in class org.redisson.reactive.RedissonTransferQueueReactive
 
takeElements(Supplier<RFuture<V>>) - Static method in class org.redisson.rx.ElementsStream
 
takeElements() - Method in class org.redisson.rx.RedissonBlockingQueueRx
 
takeElements() - Method in class org.redisson.rx.RedissonTransferQueueRx
 
takeFirst() - Method in interface org.redisson.api.RBlockingDequeReactive
Retrieves and removes value at the head of queue.
takeFirst() - Method in interface org.redisson.api.RBlockingDequeRx
Retrieves and removes value at the head of queue.
takeFirst() - Method in interface org.redisson.api.RScoredSortedSet
Removes and returns the head element waiting if necessary for an element to become available.
takeFirst() - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes and returns the head element waiting if necessary for an element to become available.
takeFirst() - Method in interface org.redisson.api.RScoredSortedSetRx
Removes and returns the head element waiting if necessary for an element to become available.
takeFirst() - Method in class org.redisson.RedissonBlockingDeque
 
takeFirst() - Method in class org.redisson.RedissonPriorityBlockingDeque
 
takeFirst() - Method in class org.redisson.RedissonScoredSortedSet
 
takeFirstAsync() - Method in interface org.redisson.api.RBlockingDequeAsync
Retrieves and removes value at the head of queue.
takeFirstAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes and returns the head element waiting if necessary for an element to become available.
takeFirstAsync() - Method in class org.redisson.RedissonBlockingDeque
 
takeFirstAsync() - Method in class org.redisson.RedissonPriorityBlockingDeque
 
takeFirstAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
takeFirstElements() - Method in interface org.redisson.api.RBlockingDequeReactive
Retrieves and removes continues stream of elements from the head of this queue.
takeFirstElements() - Method in interface org.redisson.api.RBlockingDequeRx
Retrieves and removes continues stream of elements from the head of this queue.
takeFirstElements() - Method in interface org.redisson.api.RScoredSortedSetReactive
Retrieves and removes continues stream of elements from the head of this queue.
takeFirstElements() - Method in interface org.redisson.api.RScoredSortedSetRx
Retrieves and removes continues stream of elements from the head.
takeFirstElements() - Method in class org.redisson.reactive.RedissonBlockingDequeReactive
 
takeFirstElements() - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
 
takeFirstElements() - Method in class org.redisson.rx.RedissonBlockingDequeRx
 
takeFirstElements() - Method in class org.redisson.rx.RedissonScoredSortedSetRx
 
takeLast() - Method in interface org.redisson.api.RBlockingDequeReactive
Retrieves and removes value at the tail of queue.
takeLast() - Method in interface org.redisson.api.RBlockingDequeRx
Retrieves and removes value at the tail of queue.
takeLast() - Method in interface org.redisson.api.RScoredSortedSet
Removes and returns the tail element waiting if necessary for an element to become available.
takeLast() - Method in interface org.redisson.api.RScoredSortedSetReactive
Removes and returns the tail element waiting if necessary for an element to become available.
takeLast() - Method in interface org.redisson.api.RScoredSortedSetRx
Removes and returns the tail element waiting if necessary for an element to become available.
takeLast() - Method in class org.redisson.RedissonBlockingDeque
 
takeLast() - Method in class org.redisson.RedissonPriorityBlockingDeque
 
takeLast() - Method in class org.redisson.RedissonScoredSortedSet
 
takeLastAndOfferFirstTo(String) - Method in interface org.redisson.api.RBlockingQueue
Retrieves and removes last available tail element of any queue and adds it at the head of queueName, waiting if necessary for an element to become available in any of defined queues including queue itself.
takeLastAndOfferFirstTo(String) - Method in interface org.redisson.api.RBlockingQueueReactive
Retrieves and removes last available tail element of any queue and adds it at the head of queueName, waiting if necessary for an element to become available in any of defined queues including queue itself.
takeLastAndOfferFirstTo(String) - Method in interface org.redisson.api.RBlockingQueueRx
Retrieves and removes last available tail element of any queue and adds it at the head of queueName, waiting if necessary for an element to become available in any of defined queues including queue itself.
takeLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonBlockingDeque
 
takeLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonBlockingQueue
 
takeLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
takeLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
takeLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
takeLastAndOfferFirstTo(String) - Method in class org.redisson.RedissonTransferQueue
 
takeLastAndOfferFirstToAsync(String) - Method in interface org.redisson.api.RBlockingQueueAsync
Retrieves and removes last available tail element of any queue and adds it at the head of queueName, waiting if necessary for an element to become available in any of defined queues including queue itself.
takeLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonBlockingDeque
 
takeLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonBlockingQueue
 
takeLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
takeLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
takeLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
takeLastAndOfferFirstToAsync(String) - Method in class org.redisson.RedissonTransferQueue
 
takeLastAsync() - Method in interface org.redisson.api.RBlockingDequeAsync
Retrieves and removes value at the tail of queue.
takeLastAsync() - Method in interface org.redisson.api.RScoredSortedSetAsync
Removes and returns the tail element waiting if necessary for an element to become available.
takeLastAsync() - Method in class org.redisson.RedissonBlockingDeque
 
takeLastAsync() - Method in class org.redisson.RedissonPriorityBlockingDeque
 
takeLastAsync() - Method in class org.redisson.RedissonScoredSortedSet
 
takeLastElements() - Method in interface org.redisson.api.RBlockingDequeReactive
Retrieves and removes continues stream of elements from the tail of this queue.
takeLastElements() - Method in interface org.redisson.api.RBlockingDequeRx
Retrieves and removes continues stream of elements from the tail of this queue.
takeLastElements() - Method in interface org.redisson.api.RScoredSortedSetReactive
Retrieves and removes continues stream of elements from the tail of this queue.
takeLastElements() - Method in interface org.redisson.api.RScoredSortedSetRx
Retrieves and removes continues stream of elements from the tail.
takeLastElements() - Method in class org.redisson.reactive.RedissonBlockingDequeReactive
 
takeLastElements() - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
 
takeLastElements() - Method in class org.redisson.rx.RedissonBlockingDequeRx
 
takeLastElements() - Method in class org.redisson.rx.RedissonScoredSortedSetRx
 
TaskFailureListener - Interface in org.redisson.api.executor
Task listener invoked when task was failed during execution
TaskFinishedListener - Interface in org.redisson.api.executor
Task listener invoked when task was finished
TaskListener - Interface in org.redisson.api.executor
Base task listener interface
TaskParameters - Class in org.redisson.executor.params
 
TaskParameters() - Constructor for class org.redisson.executor.params.TaskParameters
 
TaskParameters(String, byte[], byte[], byte[]) - Constructor for class org.redisson.executor.params.TaskParameters
 
taskRetryInterval(long, TimeUnit) - Method in class org.redisson.api.ExecutorOptions
Defines task retry interval at the end of which task is executed again.
TasksBatchService - Class in org.redisson.executor
 
TasksBatchService(Codec, String, CommandExecutor, String, ConcurrentMap<String, ResponseEntry>) - Constructor for class org.redisson.executor.TasksBatchService
 
tasksCounterName - Variable in class org.redisson.executor.TasksService
 
tasksExpirationTimeName - Variable in class org.redisson.executor.TasksService
 
tasksName - Variable in class org.redisson.executor.TasksService
 
tasksRetryInterval - Variable in class org.redisson.executor.TasksService
 
tasksRetryIntervalName - Variable in class org.redisson.executor.TasksService
 
TasksRunnerService - Class in org.redisson.executor
Executor service runs Callable and Runnable tasks.
TasksRunnerService(CommandExecutor, RedissonClient, Codec, String, ConcurrentMap<String, ResponseEntry>) - Constructor for class org.redisson.executor.TasksRunnerService
 
TasksService - Class in org.redisson.executor
 
TasksService(Codec, String, CommandAsyncExecutor, String, ConcurrentMap<String, ResponseEntry>) - Constructor for class org.redisson.executor.TasksService
 
TaskStartedListener - Interface in org.redisson.api.executor
Task listener invoked when task was started
TaskSuccessListener - Interface in org.redisson.api.executor
Task listener invoked when task was succeeded
taskTimeout(long, TimeUnit) - Method in class org.redisson.api.WorkerOptions
Defines task timeout since task execution start moment
TERMINATED_STATE - Static variable in class org.redisson.RedissonExecutorService
 
terminationTopicName - Variable in class org.redisson.executor.TasksService
 
thenAccept(Consumer<? super T>) - Method in class org.redisson.misc.PromiseDelegator
 
thenAcceptAsync(Consumer<? super T>) - Method in class org.redisson.misc.PromiseDelegator
 
thenAcceptAsync(Consumer<? super T>, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class org.redisson.misc.PromiseDelegator
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class org.redisson.misc.PromiseDelegator
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
thenApply(Function<? super T, ? extends U>) - Method in class org.redisson.misc.PromiseDelegator
 
thenApplyAsync(Function<? super T, ? extends U>) - Method in class org.redisson.misc.PromiseDelegator
 
thenApplyAsync(Function<? super T, ? extends U>, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class org.redisson.misc.PromiseDelegator
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class org.redisson.misc.PromiseDelegator
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
thenCompose(Function<? super T, ? extends CompletionStage<U>>) - Method in class org.redisson.misc.PromiseDelegator
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>) - Method in class org.redisson.misc.PromiseDelegator
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
thenRun(Runnable) - Method in class org.redisson.misc.PromiseDelegator
 
thenRunAsync(Runnable) - Method in class org.redisson.misc.PromiseDelegator
 
thenRunAsync(Runnable, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
ThrowableMixIn() - Constructor for class org.redisson.codec.JsonJacksonCodec.ThrowableMixIn
 
time() - Method in interface org.redisson.api.Node
Deprecated.
Returns current Redis server time in seconds
time() - Method in interface org.redisson.api.redisnode.RedisNode
Returns current Redis server time in seconds
TIME - Static variable in interface org.redisson.client.protocol.RedisCommands
 
Time - Class in org.redisson.client.protocol
 
Time(int, int) - Constructor for class org.redisson.client.protocol.Time
 
time() - Method in class org.redisson.connection.RedisClientEntry
 
time() - Method in class org.redisson.redisnode.RedisNode
 
time() - Method in class org.redisson.redisnode.SentinelRedisNode
 
TIME_LONG - Static variable in interface org.redisson.client.protocol.RedisCommands
 
timeAsync() - Method in interface org.redisson.api.NodeAsync
Deprecated.
 
timeAsync() - Method in interface org.redisson.api.redisnode.RedisNodeAsync
Returns current Redis server time in seconds
timeAsync() - Method in class org.redisson.connection.RedisClientEntry
 
timeAsync() - Method in class org.redisson.redisnode.RedisNode
 
timeAsync() - Method in class org.redisson.redisnode.SentinelRedisNode
 
TimeLongObjectDecoder - Class in org.redisson.client.protocol.decoder
 
TimeLongObjectDecoder() - Constructor for class org.redisson.client.protocol.decoder.TimeLongObjectDecoder
 
TimeObjectDecoder - Class in org.redisson.client.protocol.convertor
 
TimeObjectDecoder() - Constructor for class org.redisson.client.protocol.convertor.TimeObjectDecoder
 
timeout(long, TimeUnit) - Method in interface org.redisson.api.mapreduce.RCollectionMapReduce
Defines timeout for MapReduce process
timeout(long, TimeUnit) - Method in interface org.redisson.api.mapreduce.RMapReduce
Defines timeout for MapReduce process.
timeout(long, TimeUnit) - Method in class org.redisson.api.TransactionOptions
If transaction hasn't been committed within timeout it will rollback automatically.
timeout - Variable in class org.redisson.mapreduce.BaseMapperTask
 
timeout(long, TimeUnit) - Method in class org.redisson.mapreduce.RedissonCollectionMapReduce
 
timeout(long, TimeUnit) - Method in class org.redisson.mapreduce.RedissonMapReduce
 
TimeoutTask(long, Timeout) - Constructor for class org.redisson.QueueTransferTask.TimeoutTask
 
timeToLive(long) - Method in class org.redisson.api.LocalCachedMapOptions
Defines time to live in milliseconds of each map entry in local cache.
timeToLive(long, TimeUnit) - Method in class org.redisson.api.LocalCachedMapOptions
Defines time to live of each map entry in local cache.
toArray() - Method in interface org.redisson.api.RScoredSortedSet
Returns this sorted set in array of Object type.
toArray(T[]) - Method in interface org.redisson.api.RScoredSortedSet
Returns this sorted set in array of defined type.
toArray() - Method in class org.redisson.RedissonDelayedQueue
 
toArray(T[]) - Method in class org.redisson.RedissonDelayedQueue
 
toArray() - Method in class org.redisson.RedissonList
 
toArray(T[]) - Method in class org.redisson.RedissonList
 
toArray() - Method in class org.redisson.RedissonListMultimapValues
 
toArray(T[]) - Method in class org.redisson.RedissonListMultimapValues
 
toArray() - Method in class org.redisson.RedissonScoredSortedSet
 
toArray(T[]) - Method in class org.redisson.RedissonScoredSortedSet
 
toArray() - Method in class org.redisson.RedissonSet
 
toArray(T[]) - Method in class org.redisson.RedissonSet
 
toArray() - Method in class org.redisson.RedissonSetCache
 
toArray(T[]) - Method in class org.redisson.RedissonSetCache
 
toArray() - Method in class org.redisson.RedissonSetMultimapValues
 
toArray(T[]) - Method in class org.redisson.RedissonSetMultimapValues
 
toArray() - Method in class org.redisson.RedissonSortedSet
 
toArray(T[]) - Method in class org.redisson.RedissonSortedSet
 
toArray() - Method in class org.redisson.RedissonTransferQueue
 
toArray(T[]) - Method in class org.redisson.RedissonTransferQueue
 
toByteArray() - Method in interface org.redisson.api.RBitSet
 
toByteArray() - Method in interface org.redisson.api.RBitSetReactive
 
toByteArray() - Method in interface org.redisson.api.RBitSetRx
 
toByteArray() - Method in class org.redisson.RedissonBitSet
 
toByteArrayAsync() - Method in interface org.redisson.api.RBitSetAsync
 
toByteArrayAsync() - Method in class org.redisson.RedissonBitSet
 
toCacheKey(Object) - Method in class org.redisson.cache.LocalCacheView
 
toCacheKey(Object) - Method in class org.redisson.RedissonLocalCachedMap
 
toCompletableFuture() - Method in class org.redisson.misc.PromiseDelegator
 
toInt(boolean) - Method in class org.redisson.RedissonBitSet
 
toJSON() - Method in class org.redisson.config.Config
Deprecated.
toJSON(Config) - Method in class org.redisson.config.ConfigSupport
 
toJSON(Map<String, ? extends CacheConfig>) - Static method in class org.redisson.spring.cache.CacheConfig
Convert current configuration to JSON format
toJSON(Map<String, ? extends CacheConfig>) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
toMillis(long) - Method in enum org.redisson.api.RateIntervalUnit
 
TOPIC_SUFFIX - Static variable in class org.redisson.cache.LocalCacheListener
 
TOPIC_SUFFIX - Static variable in class org.redisson.RedissonLocalCachedMap
 
toReference(Object) - Method in class org.redisson.liveobject.core.RedissonObjectBuilder
 
toSeconds(long, TimeUnit) - Method in class org.redisson.RedissonObject
 
toStoreValue(Object) - Method in class org.redisson.spring.cache.RedissonCache
 
toStream(Iterator<T>) - Method in class org.redisson.RedissonKeys
 
toStream(Iterator<T>) - Method in class org.redisson.RedissonObject
 
toString() - Method in class org.redisson.api.BatchOptions
 
toString() - Method in class org.redisson.api.GeoPosition
 
toString() - Method in class org.redisson.api.RemoteInvocationOptions
 
toString() - Method in class org.redisson.api.StreamMessageId
 
toString() - Method in class org.redisson.cache.CacheKey
 
toString() - Method in class org.redisson.cache.CacheValue
 
toString() - Method in class org.redisson.cache.LFUCacheMap.MapKey
 
toString() - Method in class org.redisson.cache.StdCachedValue
 
toString() - Method in class org.redisson.client.ChannelName
 
toString() - Method in class org.redisson.client.codec.BaseCodec
 
toString() - Method in class org.redisson.client.handler.State
 
toString() - Method in class org.redisson.client.handler.StateLevel
 
toString() - Method in class org.redisson.client.protocol.CommandData
 
toString() - Method in class org.redisson.client.protocol.CommandsData
 
toString() - Method in class org.redisson.client.protocol.pubsub.PubSubMessage
 
toString() - Method in class org.redisson.client.protocol.pubsub.PubSubPatternMessage
 
toString() - Method in class org.redisson.client.protocol.pubsub.PubSubStatusMessage
 
toString() - Method in class org.redisson.client.protocol.QueueCommandHolder
 
toString() - Method in class org.redisson.client.protocol.RedisCommand
 
toString() - Method in class org.redisson.client.RedisClient
 
toString() - Method in class org.redisson.client.RedisConnection
 
toString() - Method in class org.redisson.cluster.ClusterNodeInfo
 
toString() - Method in class org.redisson.cluster.ClusterPartition
 
toString() - Method in class org.redisson.cluster.ClusterSlotRange
 
toString() - Method in class org.redisson.connection.ClientConnectionsEntry
 
toString() - Method in class org.redisson.connection.MasterSlaveEntry
 
toString() - Method in class org.redisson.connection.NodeSource
 
toString() - Method in class org.redisson.connection.RedisClientEntry
 
toString() - Method in class org.redisson.executor.CronExpression
Returns the string representation of the CronExpression
toString() - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
toString(RedisCommand<?>, Object...) - Static method in class org.redisson.misc.LogHelper
 
toString(Object) - Static method in class org.redisson.misc.LogHelper
 
toString() - Method in class org.redisson.misc.ReclosableLatch
 
toString() - Method in class org.redisson.misc.RedissonPromise
 
toString() - Method in class org.redisson.misc.RedisURI
 
toString() - Method in class org.redisson.pubsub.AsyncSemaphore
 
toString() - Method in class org.redisson.pubsub.PublishSubscribeService
 
toString() - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
toString() - Method in class org.redisson.redisnode.RedisNode
 
toString() - Method in class org.redisson.redisnode.SentinelRedisNode
 
toString() - Method in class org.redisson.RedissonAtomicDouble
 
toString() - Method in class org.redisson.RedissonAtomicLong
 
toString() - Method in class org.redisson.RedissonBitSet
 
toString() - Method in class org.redisson.RedissonList
 
toString() - Method in class org.redisson.RedissonListMultimapValues
 
toString() - Method in class org.redisson.RedissonPriorityQueue
 
toString() - Method in class org.redisson.RedissonSet
 
toString() - Method in class org.redisson.RedissonSortedSet
 
toString() - Method in class org.redisson.RedissonSubList
 
toString() - Method in class org.redisson.remote.RemoteServiceAck
 
toString() - Method in class org.redisson.remote.RemoteServiceRequest
 
toString() - Method in class org.redisson.remote.RemoteServiceResponse
 
toString() - Method in class org.redisson.remote.RequestId
 
touch(String...) - Method in interface org.redisson.api.RKeys
Update the last access time of an object.
touch(String...) - Method in interface org.redisson.api.RKeysReactive
Update the last access time of an object.
touch(String...) - Method in interface org.redisson.api.RKeysRx
Update the last access time of an object.
touch() - Method in interface org.redisson.api.RObject
Update the last access time of an object.
touch() - Method in interface org.redisson.api.RObjectReactive
Update the last access time of an object.
touch() - Method in interface org.redisson.api.RObjectRx
Update the last access time of an object.
TOUCH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
touch(String...) - Method in class org.redisson.RedissonKeys
 
touch() - Method in class org.redisson.RedissonObject
 
TOUCH_LONG - Static variable in interface org.redisson.client.protocol.RedisCommands
 
touchAsync(String...) - Method in interface org.redisson.api.RKeysAsync
Update the last access time of an object.
touchAsync() - Method in interface org.redisson.api.RObjectAsync
Update the last access time of an object in async mode.
touchAsync(String...) - Method in class org.redisson.RedissonKeys
 
touchAsync() - Method in class org.redisson.RedissonObject
 
touchAsync(CommandAsyncExecutor) - Method in class org.redisson.transaction.BaseTransactionalMap
 
touchAsync(CommandAsyncExecutor) - Method in class org.redisson.transaction.BaseTransactionalSet
 
touchAsync() - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
touchAsync() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
touchAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
TouchOperation - Class in org.redisson.transaction.operation
 
TouchOperation(String) - Constructor for class org.redisson.transaction.operation.TouchOperation
 
TouchOperation(String, String) - Constructor for class org.redisson.transaction.operation.TouchOperation
 
toYAML() - Method in class org.redisson.config.Config
Convert current configuration to YAML format
toYAML(Config) - Method in class org.redisson.config.ConfigSupport
 
toYAML(Map<String, ? extends CacheConfig>) - Static method in class org.redisson.spring.cache.CacheConfig
Convert current configuration to YAML format
toYAML(Map<String, ? extends CacheConfig>) - Method in class org.redisson.spring.cache.CacheConfigSupport
 
TransactionalOperation - Class in org.redisson.transaction.operation
 
TransactionalOperation() - Constructor for class org.redisson.transaction.operation.TransactionalOperation
 
TransactionalOperation(String, Codec) - Constructor for class org.redisson.transaction.operation.TransactionalOperation
 
TransactionalSet<V> - Class in org.redisson.transaction
 
TransactionalSet(CommandAsyncExecutor, long, List<TransactionalOperation>, RSet<V>, String) - Constructor for class org.redisson.transaction.TransactionalSet
 
TransactionalSetCache<V> - Class in org.redisson.transaction
 
TransactionalSetCache(CommandAsyncExecutor, long, List<TransactionalOperation>, RSetCache<V>, String) - Constructor for class org.redisson.transaction.TransactionalSetCache
 
TransactionException - Exception in org.redisson.transaction
This exception used to report an error during Transaction execution.
TransactionException(String) - Constructor for exception org.redisson.transaction.TransactionException
 
TransactionException(String, Throwable) - Constructor for exception org.redisson.transaction.TransactionException
 
TransactionOptions - Class in org.redisson.api
Configuration for Transaction.
TransactionTimeoutException - Exception in org.redisson.transaction
This exception used to report an error during Transaction execution.
TransactionTimeoutException(String) - Constructor for exception org.redisson.transaction.TransactionTimeoutException
 
transfer(V) - Method in interface org.redisson.api.RTransferQueueReactive
Transfers the element to waiting consumer which invoked RBlockingQueueReactive.take() or RBlockingQueueReactive.poll(long, java.util.concurrent.TimeUnit) method at the moment of transfer.
transfer(V) - Method in interface org.redisson.api.RTransferQueueRx
Transfers the element to waiting consumer which invoked RBlockingQueueRx.take() or RBlockingQueueRx.poll(long, java.util.concurrent.TimeUnit) method at the moment of transfer.
transfer(V) - Method in class org.redisson.RedissonTransferQueue
 
transferAsync(V) - Method in interface org.redisson.api.RTransferQueueAsync
Transfers the element to waiting consumer which invoked RBlockingQueueAsync.takeAsync() or RBlockingQueueAsync.pollAsync(long, java.util.concurrent.TimeUnit) method at the moment of transfer.
transferAsync(V) - Method in class org.redisson.RedissonTransferQueue
 
TransferListener<T> - Class in org.redisson.misc
 
TransferListener(RPromise<T>) - Constructor for class org.redisson.misc.TransferListener
 
TransferQueueServiceImpl() - Constructor for class org.redisson.RedissonTransferQueue.TransferQueueServiceImpl
 
TransportMode - Enum in org.redisson.config
 
trim(int, int) - Method in interface org.redisson.api.RList
Trim list and remains elements only in specified range fromIndex, inclusive, and toIndex, inclusive.
trim(int, int) - Method in interface org.redisson.api.RListReactive
Trim list and remains elements only in specified range fromIndex, inclusive, and toIndex, inclusive.
trim(int, int) - Method in interface org.redisson.api.RListRx
Trim list and remains elements only in specified range fromIndex, inclusive, and toIndex, inclusive.
trim(int) - Method in interface org.redisson.api.RStream
Trims stream to specified size
trim(int) - Method in interface org.redisson.api.RStreamReactive
Trims stream to specified size
trim(int) - Method in interface org.redisson.api.RStreamRx
Trims stream to specified size
trim(int, int) - Method in class org.redisson.RedissonList
 
trim(int, int) - Method in class org.redisson.RedissonListMultimapValues
 
trim(int) - Method in class org.redisson.RedissonStream
 
trim(int, int) - Method in class org.redisson.RedissonSubList
 
trimAsync(int, int) - Method in interface org.redisson.api.RListAsync
Trim list and remains elements only in specified range fromIndex, inclusive, and toIndex, inclusive.
trimAsync(int) - Method in interface org.redisson.api.RStreamAsync
Trims stream to specified size
trimAsync(int, int) - Method in class org.redisson.RedissonList
 
trimAsync(int, int) - Method in class org.redisson.RedissonListMultimapValues
 
trimAsync(int) - Method in class org.redisson.RedissonStream
 
trimAsync(int, int) - Method in class org.redisson.RedissonSubList
 
trimNonStrict(int) - Method in interface org.redisson.api.RStream
Trims stream to few tens of entries more than specified length to trim.
trimNonStrict(int) - Method in interface org.redisson.api.RStreamReactive
Trims stream to few tens of entries more than specified length to trim.
trimNonStrict(int) - Method in interface org.redisson.api.RStreamRx
Trims stream to few tens of entries more than specified length to trim.
trimNonStrict(int) - Method in class org.redisson.RedissonStream
 
trimNonStrictAsync(int) - Method in interface org.redisson.api.RStreamAsync
Trims stream to few tens of entries more than specified length to trim.
trimNonStrictAsync(int) - Method in class org.redisson.RedissonStream
 
TrueReplayConvertor - Class in org.redisson.client.protocol.convertor
 
TrueReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.TrueReplayConvertor
 
tryAcquire() - Method in interface org.redisson.api.RPermitExpirableSemaphore
Tries to acquire currently available permit and return its id.
tryAcquire(long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphore
Tries to acquire currently available permit and return its id.
tryAcquire(long, long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphore
Tries to acquire currently available permit with defined leaseTime and return its id.
tryAcquire() - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Tries to acquire currently available permit and return its id.
tryAcquire(long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Tries to acquire currently available permit and return its id.
tryAcquire(long, long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Tries to acquire currently available permit with defined leaseTime and return its id.
tryAcquire() - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Acquires a permit only if one is available at the time of invocation.
tryAcquire(long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Acquires a permit from this semaphore, if one becomes available within the given waiting time and the current thread has not been interrupted.
tryAcquire(long, long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Acquires a permit with defined lease time from this semaphore, if one becomes available within the given waiting time and the current thread has not been interrupted.
tryAcquire() - Method in interface org.redisson.api.RRateLimiter
Acquires a permit only if one is available at the time of invocation.
tryAcquire(long) - Method in interface org.redisson.api.RRateLimiter
Acquires the given number of permits only if all are available at the time of invocation.
tryAcquire(long, TimeUnit) - Method in interface org.redisson.api.RRateLimiter
Acquires a permit from this RateLimiter, if one becomes available within the given waiting time.
tryAcquire(long, long, TimeUnit) - Method in interface org.redisson.api.RRateLimiter
Acquires the given number of permits only if all are available within the given waiting time.
tryAcquire() - Method in interface org.redisson.api.RRateLimiterReactive
Acquires a permit only if one is available at the time of invocation.
tryAcquire(long) - Method in interface org.redisson.api.RRateLimiterReactive
Acquires the given number of permits only if all are available at the time of invocation.
tryAcquire(long, TimeUnit) - Method in interface org.redisson.api.RRateLimiterReactive
Acquires a permit from this RateLimiter, if one becomes available within the given waiting time.
tryAcquire(long, long, TimeUnit) - Method in interface org.redisson.api.RRateLimiterReactive
Acquires the given number of permits only if all are available within the given waiting time.
tryAcquire() - Method in interface org.redisson.api.RRateLimiterRx
Acquires a permit only if one is available at the time of invocation.
tryAcquire(long) - Method in interface org.redisson.api.RRateLimiterRx
Acquires the given number of permits only if all are available at the time of invocation.
tryAcquire(long, TimeUnit) - Method in interface org.redisson.api.RRateLimiterRx
Acquires a permit from this RateLimiter, if one becomes available within the given waiting time.
tryAcquire(long, long, TimeUnit) - Method in interface org.redisson.api.RRateLimiterRx
Acquires the given number of permits only if all are available within the given waiting time.
tryAcquire() - Method in interface org.redisson.api.RSemaphore
Tries to acquire currently available permit.
tryAcquire(int) - Method in interface org.redisson.api.RSemaphore
Tries to acquire defined amount of currently available permits.
tryAcquire(long, TimeUnit) - Method in interface org.redisson.api.RSemaphore
Tries to acquire currently available permit.
tryAcquire(int, long, TimeUnit) - Method in interface org.redisson.api.RSemaphore
Tries to acquire defined amount of currently available permits.
tryAcquire() - Method in interface org.redisson.api.RSemaphoreReactive
Acquires a permit.
tryAcquire(int) - Method in interface org.redisson.api.RSemaphoreReactive
Tries to acquire defined amount of currently available permits.
tryAcquire(long, TimeUnit) - Method in interface org.redisson.api.RSemaphoreReactive
Tries to acquire currently available permit.
tryAcquire(int, long, TimeUnit) - Method in interface org.redisson.api.RSemaphoreReactive
Tries to acquire defined amount of currently available permits.
tryAcquire() - Method in interface org.redisson.api.RSemaphoreRx
Acquires a permit.
tryAcquire(int) - Method in interface org.redisson.api.RSemaphoreRx
Tries to acquire defined amount of currently available permits.
tryAcquire(long, TimeUnit) - Method in interface org.redisson.api.RSemaphoreRx
Tries to acquire currently available permit.
tryAcquire(int, long, TimeUnit) - Method in interface org.redisson.api.RSemaphoreRx
Tries to acquire defined amount of currently available permits.
tryAcquire(long) - Method in class org.redisson.pubsub.AsyncSemaphore
 
tryAcquire() - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
tryAcquire(long, TimeUnit, int) - Method in class org.redisson.RedissonBaseAdder
 
tryAcquire() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
tryAcquire(long, long, TimeUnit) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
tryAcquire(long, TimeUnit) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
tryAcquire() - Method in class org.redisson.RedissonRateLimiter
 
tryAcquire(long) - Method in class org.redisson.RedissonRateLimiter
 
tryAcquire(long, TimeUnit) - Method in class org.redisson.RedissonRateLimiter
 
tryAcquire(long, long, TimeUnit) - Method in class org.redisson.RedissonRateLimiter
 
tryAcquire() - Method in class org.redisson.RedissonSemaphore
 
tryAcquire(int) - Method in class org.redisson.RedissonSemaphore
 
tryAcquire(int, long, TimeUnit) - Method in class org.redisson.RedissonSemaphore
 
tryAcquire(long, TimeUnit) - Method in class org.redisson.RedissonSemaphore
 
tryAcquireAsync() - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Tries to acquire currently available permit and return its id.
tryAcquireAsync(long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Tries to acquire currently available permit and return its id.
tryAcquireAsync(long, long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Tries to acquire currently available permit with defined leaseTime and return its id.
tryAcquireAsync() - Method in interface org.redisson.api.RRateLimiterAsync
Acquires a permit only if one is available at the time of invocation.
tryAcquireAsync(long) - Method in interface org.redisson.api.RRateLimiterAsync
Acquires the given number of permits only if all are available at the time of invocation.
tryAcquireAsync(long, TimeUnit) - Method in interface org.redisson.api.RRateLimiterAsync
Acquires a permit from this RateLimiter, if one becomes available within the given waiting time.
tryAcquireAsync(long, long, TimeUnit) - Method in interface org.redisson.api.RRateLimiterAsync
Acquires the given number of permits only if all are available within the given waiting time.
tryAcquireAsync() - Method in interface org.redisson.api.RSemaphoreAsync
Acquires a permit.
tryAcquireAsync(int) - Method in interface org.redisson.api.RSemaphoreAsync
Tries to acquire defined amount of currently available permits.
tryAcquireAsync(long, TimeUnit) - Method in interface org.redisson.api.RSemaphoreAsync
Tries to acquire currently available permit.
tryAcquireAsync(int, long, TimeUnit) - Method in interface org.redisson.api.RSemaphoreAsync
Tries to acquire defined amount of currently available permits.
tryAcquireAsync() - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
tryAcquireAsync(int, long) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
tryAcquireAsync(long, TimeUnit) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
tryAcquireAsync(long, long, TimeUnit) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
tryAcquireAsync(int) - Method in class org.redisson.RedissonQueueSemaphore
 
tryAcquireAsync() - Method in class org.redisson.RedissonRateLimiter
 
tryAcquireAsync(long) - Method in class org.redisson.RedissonRateLimiter
 
tryAcquireAsync(long, TimeUnit) - Method in class org.redisson.RedissonRateLimiter
 
tryAcquireAsync(long, long, TimeUnit) - Method in class org.redisson.RedissonRateLimiter
 
tryAcquireAsync() - Method in class org.redisson.RedissonSemaphore
 
tryAcquireAsync(int) - Method in class org.redisson.RedissonSemaphore
 
tryAcquireAsync(long, TimeUnit) - Method in class org.redisson.RedissonSemaphore
 
tryAcquireAsync(int, long, TimeUnit) - Method in class org.redisson.RedissonSemaphore
 
tryAcquireShared(int) - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
tryAcquireShared(int) - Method in class org.redisson.misc.ReclosableLatch
 
tryAdd(double, V) - Method in interface org.redisson.api.RScoredSortedSet
Adds element to this set only if has not been added before.
tryAdd(double, V) - Method in interface org.redisson.api.RScoredSortedSetReactive
Adds element to this set only if has not been added before.
tryAdd(double, V) - Method in interface org.redisson.api.RScoredSortedSetRx
Adds element to this set only if has not been added before.
tryAdd(double, V) - Method in class org.redisson.RedissonScoredSortedSet
 
tryAddAsync(double, V) - Method in interface org.redisson.api.RScoredSortedSetAsync
Adds element to this set only if has not been added before.
tryAddAsync(double, V) - Method in class org.redisson.RedissonScoredSortedSet
 
tryAgain() - Method in class org.redisson.iterator.BaseIterator
 
tryAgain() - Method in class org.redisson.reactive.MapReactiveIterator
 
tryAgain() - Method in class org.redisson.reactive.SetReactiveIterator
 
tryAgain() - Method in class org.redisson.rx.RedissonMapRxIterator
 
tryAgain() - Method in class org.redisson.rx.SetRxIterator
 
tryExecute(Class<T>, T, long, TimeUnit) - Method in interface org.redisson.api.RRemoteService
Tries to execute one awaiting remote request.
tryExecute(Class<T>, T, ExecutorService, long, TimeUnit) - Method in interface org.redisson.api.RRemoteService
Tries to execute one awaiting remote request.
tryExecute(Class<T>, T, long, TimeUnit) - Method in class org.redisson.RedissonRemoteService
 
tryExecute(Class<T>, T, ExecutorService, long, TimeUnit) - Method in class org.redisson.RedissonRemoteService
 
tryExecuteAsync(Class<T>, T) - Method in interface org.redisson.api.RRemoteService
Tries to execute one awaiting remote request.
tryExecuteAsync(Class<T>, T, long, TimeUnit) - Method in interface org.redisson.api.RRemoteService
Tries to execute one awaiting remote request.
tryExecuteAsync(Class<T>, T, ExecutorService, long, TimeUnit) - Method in interface org.redisson.api.RRemoteService
Tries to execute one awaiting remote request.
tryExecuteAsync(Class<T>, T, long, TimeUnit) - Method in class org.redisson.RedissonRemoteService
 
tryExecuteAsync(Class<T>, T, ExecutorService, long, TimeUnit) - Method in class org.redisson.RedissonRemoteService
 
tryExecuteAsync(Class<T>, T) - Method in class org.redisson.RedissonRemoteService
 
tryFailure(Throwable) - Method in class org.redisson.client.protocol.BatchCommandData
 
tryFailure(Throwable) - Method in class org.redisson.client.protocol.CommandData
 
tryFailure(Throwable) - Method in class org.redisson.client.protocol.CommandsData
 
tryFailure(Throwable) - Method in interface org.redisson.client.protocol.QueueCommand
 
tryFailure(Throwable) - Method in class org.redisson.misc.PromiseDelegator
 
tryFailure(Throwable) - Method in class org.redisson.misc.RedissonPromise
 
tryFailure(Throwable) - Method in interface org.redisson.misc.RPromise
Marks this future as a failure and notifies all listeners.
tryHandleReference(RedissonObjectBuilder, Object) - Static method in class org.redisson.command.RedisExecutor
 
tryInit(long, double) - Method in interface org.redisson.api.RBloomFilter
Initializes Bloom filter params (size and hashIterations) calculated from expectedInsertions and falseProbability Stores config to Redis server.
tryInit(long, double) - Method in class org.redisson.RedissonBloomFilter
 
tryLock(long, long, TimeUnit) - Method in interface org.redisson.api.RLock
Tries to acquire the lock with defined leaseTime.
tryLock() - Method in interface org.redisson.api.RLockReactive
Tries to acquire the lock.
tryLock(long) - Method in interface org.redisson.api.RLockReactive
Tries to acquire the lock by thread with specified threadId.
tryLock(long, TimeUnit) - Method in interface org.redisson.api.RLockReactive
Tries to acquire the lock.
tryLock(long, long, TimeUnit) - Method in interface org.redisson.api.RLockReactive
Tries to acquire the lock with defined leaseTime.
tryLock(long, long, TimeUnit, long) - Method in interface org.redisson.api.RLockReactive
Tries to acquire the lock by thread with specified threadId and leaseTime.
tryLock() - Method in interface org.redisson.api.RLockRx
Tries to acquire the lock.
tryLock(long) - Method in interface org.redisson.api.RLockRx
Tries to acquire the lock by thread with specified threadId.
tryLock(long, TimeUnit) - Method in interface org.redisson.api.RLockRx
Tries to acquire the lock.
tryLock(long, long, TimeUnit) - Method in interface org.redisson.api.RLockRx
Tries to acquire the lock with defined leaseTime.
tryLock(long, long, TimeUnit, long) - Method in interface org.redisson.api.RLockRx
Tries to acquire the lock by thread with specified threadId and leaseTime.
tryLock() - Method in class org.redisson.RedissonLock
 
tryLock(long, long, TimeUnit) - Method in class org.redisson.RedissonLock
 
tryLock(long, TimeUnit) - Method in class org.redisson.RedissonLock
 
tryLock() - Method in class org.redisson.RedissonMultiLock
 
tryLock(long, TimeUnit) - Method in class org.redisson.RedissonMultiLock
 
tryLock(long, long, TimeUnit) - Method in class org.redisson.RedissonMultiLock
 
tryLockAsync() - Method in interface org.redisson.api.RLockAsync
Tries to acquire the lock.
tryLockAsync(long) - Method in interface org.redisson.api.RLockAsync
Tries to acquire the lock by thread with specified threadId.
tryLockAsync(long, TimeUnit) - Method in interface org.redisson.api.RLockAsync
Tries to acquire the lock.
tryLockAsync(long, long, TimeUnit) - Method in interface org.redisson.api.RLockAsync
Tries to acquire the lock with defined leaseTime.
tryLockAsync(long, long, TimeUnit, long) - Method in interface org.redisson.api.RLockAsync
Tries to acquire the lock by thread with specified threadId and leaseTime.
tryLockAsync() - Method in class org.redisson.RedissonLock
 
tryLockAsync(long) - Method in class org.redisson.RedissonLock
 
tryLockAsync(long, TimeUnit) - Method in class org.redisson.RedissonLock
 
tryLockAsync(long, long, TimeUnit) - Method in class org.redisson.RedissonLock
 
tryLockAsync(long, long, TimeUnit, long) - Method in class org.redisson.RedissonLock
 
tryLockAsync(long, long, TimeUnit, long, RPromise<Void>) - Method in class org.redisson.RedissonMultiLock
 
tryLockAsync(long, long, TimeUnit, long) - Method in class org.redisson.RedissonMultiLock
 
tryLockAsync(long, long, TimeUnit) - Method in class org.redisson.RedissonMultiLock
 
tryLockAsync() - Method in class org.redisson.RedissonMultiLock
 
tryLockAsync(long) - Method in class org.redisson.RedissonMultiLock
 
tryLockAsync(long, TimeUnit) - Method in class org.redisson.RedissonMultiLock
 
tryPollAckAgainAsync(RemoteInvocationOptions, String, RequestId) - Method in class org.redisson.remote.BaseRemoteProxy
 
tryRelease(String) - Method in interface org.redisson.api.RPermitExpirableSemaphore
Tries to release permit by its id.
tryRelease(String) - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Tries to release permit by its id.
tryRelease(String) - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Releases a permit by its id, returning it to the semaphore.
tryRelease(String) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
tryReleaseAsync(String) - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Tries to release permit by its id.
tryReleaseAsync(String) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
tryReleaseShared(int) - Method in class org.redisson.misc.InfinitySemaphoreLatch
 
tryReleaseShared(int) - Method in class org.redisson.misc.ReclosableLatch
 
trySend() - Method in class org.redisson.client.protocol.QueueCommandHolder
 
trySet(V) - Method in interface org.redisson.api.RBucket
Tries to set element atomically into empty holder.
trySet(V, long, TimeUnit) - Method in interface org.redisson.api.RBucket
Tries to set element atomically into empty holder with defined timeToLive interval.
trySet(V) - Method in interface org.redisson.api.RBucketReactive
Tries to set element atomically into empty holder.
trySet(V, long, TimeUnit) - Method in interface org.redisson.api.RBucketReactive
Tries to set element atomically into empty holder with defined timeToLive interval.
trySet(V) - Method in interface org.redisson.api.RBucketRx
Tries to set element atomically into empty holder.
trySet(V, long, TimeUnit) - Method in interface org.redisson.api.RBucketRx
Tries to set element atomically into empty holder with defined timeToLive interval.
trySet(Map<String, ?>) - Method in interface org.redisson.api.RBuckets
Try to save objects mapped by Redis key.
trySet(Map<String, ?>) - Method in interface org.redisson.api.RBucketsReactive
Try to save objects mapped by Redis key.
trySet(Map<String, ?>) - Method in interface org.redisson.api.RBucketsRx
Try to save objects mapped by Redis key.
trySet(V, long, TimeUnit) - Method in class org.redisson.RedissonBucket
 
trySet(V) - Method in class org.redisson.RedissonBucket
 
trySet(Map<String, ?>) - Method in class org.redisson.RedissonBuckets
 
trySetAsync(V) - Method in interface org.redisson.api.RBucketAsync
Tries to set element atomically into empty holder.
trySetAsync(V, long, TimeUnit) - Method in interface org.redisson.api.RBucketAsync
Tries to set element atomically into empty holder with defined timeToLive interval.
trySetAsync(Map<String, ?>) - Method in interface org.redisson.api.RBucketsAsync
Try to save objects mapped by Redis key.
trySetAsync(V) - Method in class org.redisson.RedissonBucket
 
trySetAsync(V, long, TimeUnit) - Method in class org.redisson.RedissonBucket
 
trySetAsync(Map<String, ?>) - Method in class org.redisson.RedissonBuckets
 
trySetAsync(V) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
trySetAsync(V, long, TimeUnit) - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
trySetAsync(Map<String, ?>) - Method in class org.redisson.transaction.RedissonTransactionalBuckets
 
trySetCapacity(int) - Method in interface org.redisson.api.RBoundedBlockingQueue
Sets queue capacity only if it is not set before.
trySetCapacity(int) - Method in interface org.redisson.api.RRingBuffer
Sets queue capacity only if it is not set before.
trySetCapacity(int) - Method in interface org.redisson.api.RRingBufferReactive
Sets queue capacity only if it is not set before.
trySetCapacity(int) - Method in interface org.redisson.api.RRingBufferRx
Sets queue capacity only if it is not set before.
trySetCapacity(int) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
trySetCapacity(int) - Method in class org.redisson.RedissonRingBuffer
 
trySetCapacityAsync(int) - Method in interface org.redisson.api.RBoundedBlockingQueueAsync
Sets queue capacity only if it is not set before.
trySetCapacityAsync(int) - Method in interface org.redisson.api.RRingBufferAsync
Sets queue capacity only if it is not set before.
trySetCapacityAsync(int) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
trySetCapacityAsync(int) - Method in class org.redisson.RedissonRingBuffer
 
trySetComparator(Comparator<? super V>) - Method in interface org.redisson.api.RPriorityQueue
Sets new comparator only if current set is empty
trySetComparator(Comparator<? super V>) - Method in interface org.redisson.api.RSortedSet
Sets new comparator only if current set is empty
trySetComparator(Comparator<? super String>) - Method in class org.redisson.RedissonLexSortedSet
 
trySetComparator(Comparator<? super V>) - Method in class org.redisson.RedissonPriorityQueue
 
trySetComparator(Comparator<? super V>) - Method in class org.redisson.RedissonSortedSet
 
trySetCount(long) - Method in interface org.redisson.api.RCountDownLatch
Sets new count value only if previous count already has reached zero or is not set at all.
trySetCount(long) - Method in interface org.redisson.api.RCountDownLatchReactive
Sets new count value only if previous count already has reached zero or is not set at all.
trySetCount(long) - Method in interface org.redisson.api.RCountDownLatchRx
Sets new count value only if previous count already has reached zero or is not set at all.
trySetCount(long) - Method in class org.redisson.RedissonCountDownLatch
 
trySetCountAsync(long) - Method in interface org.redisson.api.RCountDownLatchAsync
Sets new count value only if previous count already has reached zero or is not set at all.
trySetCountAsync(long) - Method in class org.redisson.RedissonCountDownLatch
 
trySetMaxSize(int) - Method in interface org.redisson.api.RMapCache
Tries to set max size of the map.
trySetMaxSize(int) - Method in interface org.redisson.api.RMapCacheReactive
Tries to set max size of the map.
trySetMaxSize(int) - Method in interface org.redisson.api.RMapCacheRx
Tries to set max size of the map.
trySetMaxSize(int) - Method in class org.redisson.RedissonMapCache
 
trySetMaxSizeAsync(int) - Method in interface org.redisson.api.RMapCacheAsync
Tries to set max size of the map.
trySetMaxSizeAsync(int) - Method in class org.redisson.RedissonMapCache
 
trySetMaxSizeAsync(int) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
trySetPermits(int) - Method in interface org.redisson.api.RPermitExpirableSemaphore
Tries to set number of permits.
trySetPermits(int) - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Tries to set number of permits.
trySetPermits(int) - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Sets number of permits.
trySetPermits(int) - Method in interface org.redisson.api.RSemaphore
Tries to set number of permits.
trySetPermits(int) - Method in interface org.redisson.api.RSemaphoreReactive
Tries to set number of permits.
trySetPermits(int) - Method in interface org.redisson.api.RSemaphoreRx
Tries to set number of permits.
trySetPermits(int) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
trySetPermits(int) - Method in class org.redisson.RedissonSemaphore
 
trySetPermitsAsync(int) - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Tries to set number of permits.
trySetPermitsAsync(int) - Method in interface org.redisson.api.RSemaphoreAsync
Tries to set number of permits.
trySetPermitsAsync(int) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
trySetPermitsAsync(int) - Method in class org.redisson.RedissonSemaphore
 
trySetRate(RateType, long, long, RateIntervalUnit) - Method in interface org.redisson.api.RRateLimiter
Initializes RateLimiter's state and stores config to Redis server.
trySetRate(RateType, long, long, RateIntervalUnit) - Method in interface org.redisson.api.RRateLimiterReactive
Initializes RateLimiter's state and stores config to Redis server.
trySetRate(RateType, long, long, RateIntervalUnit) - Method in interface org.redisson.api.RRateLimiterRx
Initializes RateLimiter's state and stores config to Redis server.
trySetRate(RateType, long, long, RateIntervalUnit) - Method in class org.redisson.RedissonRateLimiter
 
trySetRateAsync(RateType, long, long, RateIntervalUnit) - Method in interface org.redisson.api.RRateLimiterAsync
Initializes RateLimiter's state and stores config to Redis server.
trySetRateAsync(RateType, long, long, RateIntervalUnit) - Method in class org.redisson.RedissonRateLimiter
 
trySetupFistFail() - Method in class org.redisson.connection.ClientConnectionsEntry
 
trySuccess(T) - Method in class org.redisson.misc.PromiseDelegator
 
trySuccess(T) - Method in class org.redisson.misc.RedissonPromise
 
trySuccess(T) - Method in interface org.redisson.misc.RPromise
Marks this future as a success and notifies all listeners.
tryTransfer(V) - Method in interface org.redisson.api.RTransferQueueReactive
Tries to transfer the element to waiting consumer which invoked RBlockingQueueReactive.take() or RBlockingQueueReactive.poll(long, java.util.concurrent.TimeUnit) method at the moment of transfer.
tryTransfer(V, long, TimeUnit) - Method in interface org.redisson.api.RTransferQueueReactive
Transfers the element to waiting consumer which invoked RBlockingQueueReactive.take() or RBlockingQueueReactive.poll(long, java.util.concurrent.TimeUnit) method at the moment of transfer.
tryTransfer(V) - Method in interface org.redisson.api.RTransferQueueRx
Tries to transfer the element to waiting consumer which invoked RBlockingQueueRx.take() or RBlockingQueueRx.poll(long, java.util.concurrent.TimeUnit) method at the moment of transfer.
tryTransfer(V, long, TimeUnit) - Method in interface org.redisson.api.RTransferQueueRx
Transfers the element to waiting consumer which invoked RBlockingQueueRx.take() or RBlockingQueueRx.poll(long, java.util.concurrent.TimeUnit) method at the moment of transfer.
tryTransfer(V) - Method in class org.redisson.RedissonTransferQueue
 
tryTransfer(V, long, TimeUnit) - Method in class org.redisson.RedissonTransferQueue
 
tryTransferAsync(V) - Method in interface org.redisson.api.RTransferQueueAsync
Tries to transfer the element to waiting consumer which invoked RBlockingQueueAsync.takeAsync() or RBlockingQueueAsync.pollAsync(long, java.util.concurrent.TimeUnit) method at the moment of transfer.
tryTransferAsync(V, long, TimeUnit) - Method in interface org.redisson.api.RTransferQueueAsync
Transfers the element to waiting consumer which invoked RBlockingQueueAsync.takeAsync() or RBlockingQueueAsync.pollAsync(long, java.util.concurrent.TimeUnit) method at the moment of transfer.
tryTransferAsync(V) - Method in class org.redisson.RedissonTransferQueue
 
tryTransferAsync(V, long, TimeUnit) - Method in class org.redisson.RedissonTransferQueue
 
TYPE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
TypeConvertor - Class in org.redisson.client.protocol.convertor
 
TypeConvertor() - Constructor for class org.redisson.client.protocol.convertor.TypeConvertor
 
TypedJsonJacksonCodec - Class in org.redisson.codec
Json Jackson Type codec.
TypedJsonJacksonCodec(Class<?>) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(Class<?>, ObjectMapper) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(Class<?>, Class<?>) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(Class<?>, Class<?>, ObjectMapper) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(Class<?>, Class<?>, Class<?>) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(Class<?>, Class<?>, Class<?>, ObjectMapper) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(TypeReference<?>) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(TypeReference<?>, ObjectMapper) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(TypeReference<?>, TypeReference<?>) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(TypeReference<?>, TypeReference<?>, ObjectMapper) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(TypeReference<?>, TypeReference<?>, TypeReference<?>) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(TypeReference<?>, TypeReference<?>, TypeReference<?>, ObjectMapper) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 
TypedJsonJacksonCodec(ClassLoader, TypedJsonJacksonCodec) - Constructor for class org.redisson.codec.TypedJsonJacksonCodec
 

U

unfreeze(RedisURI, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
unfreeze(InetSocketAddress, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
unfreeze(ClientConnectionsEntry, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.balancer.LoadBalancerManager
 
union(String...) - Method in interface org.redisson.api.RScoredSortedSet
Union provided ScoredSortedSets and store result to current ScoredSortedSet
union(RScoredSortedSet.Aggregate, String...) - Method in interface org.redisson.api.RScoredSortedSet
Union provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSet
union(Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSet
Union provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSet
union(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSet
Union provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSet
union(String...) - Method in interface org.redisson.api.RScoredSortedSetReactive
Union provided ScoredSortedSets and store result to current ScoredSortedSet
union(RScoredSortedSet.Aggregate, String...) - Method in interface org.redisson.api.RScoredSortedSetReactive
Union provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSet
union(Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetReactive
Union provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSet
union(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetReactive
Union provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSet
union(String...) - Method in interface org.redisson.api.RScoredSortedSetRx
Union provided ScoredSortedSets and store result to current ScoredSortedSet
union(RScoredSortedSet.Aggregate, String...) - Method in interface org.redisson.api.RScoredSortedSetRx
Union provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSet
union(Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetRx
Union provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSet
union(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetRx
Union provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSet
union(String...) - Method in interface org.redisson.api.RSet
Union sets specified by name and write to current set.
union(String...) - Method in interface org.redisson.api.RSetReactive
Union sets specified by name and write to current set.
union(String...) - Method in interface org.redisson.api.RSetRx
Union sets specified by name and write to current set.
union(String...) - Method in class org.redisson.RedissonScoredSortedSet
 
union(RScoredSortedSet.Aggregate, String...) - Method in class org.redisson.RedissonScoredSortedSet
 
union(Map<String, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
union(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
union(String...) - Method in class org.redisson.RedissonSet
 
union(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
unionAsync(String...) - Method in interface org.redisson.api.RScoredSortedSetAsync
Union provided ScoredSortedSets and store result to current ScoredSortedSet
unionAsync(RScoredSortedSet.Aggregate, String...) - Method in interface org.redisson.api.RScoredSortedSetAsync
Union provided ScoredSortedSets with defined aggregation method and store result to current ScoredSortedSet
unionAsync(Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetAsync
Union provided ScoredSortedSets mapped to weight multiplier and store result to current ScoredSortedSet
unionAsync(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in interface org.redisson.api.RScoredSortedSetAsync
Union provided ScoredSortedSets mapped to weight multiplier with defined aggregation method and store result to current ScoredSortedSet
unionAsync(String...) - Method in interface org.redisson.api.RSetAsync
Union sets specified by name and write to current set.
unionAsync(String...) - Method in class org.redisson.RedissonScoredSortedSet
 
unionAsync(RScoredSortedSet.Aggregate, String...) - Method in class org.redisson.RedissonScoredSortedSet
 
unionAsync(Map<String, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
unionAsync(RScoredSortedSet.Aggregate, Map<String, Double>) - Method in class org.redisson.RedissonScoredSortedSet
 
unionAsync(String...) - Method in class org.redisson.RedissonSet
 
unionAsync(String...) - Method in class org.redisson.RedissonSetMultimapValues
 
unionAsync(String...) - Method in class org.redisson.transaction.BaseTransactionalSet
 
unionAsync(String...) - Method in class org.redisson.transaction.RedissonTransactionalSet
 
unlink(String...) - Method in interface org.redisson.api.RKeys
Delete multiple objects by name.
unlink(String...) - Method in interface org.redisson.api.RKeysReactive
Delete multiple objects by name.
unlink(String...) - Method in interface org.redisson.api.RKeysRx
Delete multiple objects by name.
unlink() - Method in interface org.redisson.api.RObject
Delete the objects.
unlink() - Method in interface org.redisson.api.RObjectReactive
Delete the objects.
unlink() - Method in interface org.redisson.api.RObjectRx
Delete the objects.
UNLINK - Static variable in interface org.redisson.client.protocol.RedisCommands
 
unlink(String...) - Method in class org.redisson.RedissonKeys
 
unlink() - Method in class org.redisson.RedissonObject
 
UNLINK_BOOL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
unlinkAsync(String...) - Method in interface org.redisson.api.RKeysAsync
Delete multiple objects by name.
unlinkAsync() - Method in interface org.redisson.api.RObjectAsync
Delete the objects.
unlinkAsync(String...) - Method in class org.redisson.RedissonKeys
 
unlinkAsync() - Method in class org.redisson.RedissonObject
 
unlinkAsync(CommandAsyncExecutor) - Method in class org.redisson.transaction.BaseTransactionalMap
 
unlinkAsync(CommandAsyncExecutor) - Method in class org.redisson.transaction.BaseTransactionalSet
 
unlinkAsync() - Method in class org.redisson.transaction.RedissonTransactionalBucket
 
unlinkAsync() - Method in class org.redisson.transaction.RedissonTransactionalMap
 
unlinkAsync() - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
UnlinkOperation - Class in org.redisson.transaction.operation
 
UnlinkOperation(String) - Constructor for class org.redisson.transaction.operation.UnlinkOperation
 
UnlinkOperation(String, String) - Constructor for class org.redisson.transaction.operation.UnlinkOperation
 
unlock() - Method in interface org.redisson.api.RLockReactive
Unlocks the lock
unlock(long) - Method in interface org.redisson.api.RLockReactive
Unlocks the lock.
unlock() - Method in interface org.redisson.api.RLockRx
Unlocks the lock
unlock(long) - Method in interface org.redisson.api.RLockRx
Unlocks the lock.
unlock() - Method in class org.redisson.RedissonLock
 
unlock() - Method in class org.redisson.RedissonMultiLock
 
unlock() - Method in class org.redisson.RedissonRedLock
 
unlock(CommandAsyncExecutor) - Method in class org.redisson.transaction.operation.bucket.BucketsTrySetOperation
 
UNLOCK_MESSAGE - Static variable in class org.redisson.pubsub.LockPubSub
 
unlockAsync() - Method in interface org.redisson.api.RLockAsync
Unlocks the lock
unlockAsync(long) - Method in interface org.redisson.api.RLockAsync
Unlocks the lock.
unlockAsync() - Method in class org.redisson.RedissonLock
 
unlockAsync(long) - Method in class org.redisson.RedissonLock
 
unlockAsync(long) - Method in class org.redisson.RedissonMultiLock
 
unlockAsync() - Method in class org.redisson.RedissonMultiLock
 
unlockInner(Collection<RLock>) - Method in class org.redisson.RedissonMultiLock
 
unlockInnerAsync(long) - Method in class org.redisson.RedissonFairLock
 
unlockInnerAsync(long) - Method in class org.redisson.RedissonLock
 
unlockInnerAsync(Collection<RLock>, long) - Method in class org.redisson.RedissonMultiLock
 
unlockInnerAsync(long) - Method in class org.redisson.RedissonReadLock
 
unlockInnerAsync(long) - Method in class org.redisson.RedissonWriteLock
 
unregisterClass(Class<?>) - Method in interface org.redisson.api.RLiveObjectService
Unregister the class with the service.
unregisterClass(Class<?>) - Method in class org.redisson.RedissonLiveObjectService
 
unsubscribe(int) - Method in interface org.redisson.api.RBlockingQueue
Un-subscribes defined listener.
unsubscribe(int) - Method in interface org.redisson.api.RScoredSortedSet
Un-subscribes defined listener.
UNSUBSCRIBE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
unsubscribe(ChannelName...) - Method in class org.redisson.client.RedisPubSubConnection
 
unsubscribe(int) - Method in class org.redisson.ElementsSubscribeService
 
unsubscribe(ChannelName, AsyncSemaphore) - Method in class org.redisson.pubsub.PublishSubscribeService
 
unsubscribe(ChannelName, PubSubType) - Method in class org.redisson.pubsub.PublishSubscribeService
 
unsubscribe(ChannelName, RedisPubSubListener<?>) - Method in class org.redisson.pubsub.PubSubConnectionEntry
 
unsubscribe(int) - Method in class org.redisson.RedissonBlockingDeque
 
unsubscribe(int) - Method in class org.redisson.RedissonBlockingQueue
 
unsubscribe(int) - Method in class org.redisson.RedissonBoundedBlockingQueue
 
unsubscribe(RFuture<RedissonLockEntry>, long) - Method in class org.redisson.RedissonFairLock
 
unsubscribe(RFuture<RedissonLockEntry>, long) - Method in class org.redisson.RedissonLock
 
unsubscribe(int) - Method in class org.redisson.RedissonPriorityBlockingDeque
 
unsubscribe(int) - Method in class org.redisson.RedissonPriorityBlockingQueue
 
unsubscribe(int) - Method in class org.redisson.RedissonScoredSortedSet
 
unsubscribe(int) - Method in class org.redisson.RedissonTransferQueue
 
UNWATCH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
unwrap(Class<T>) - Method in class org.redisson.jcache.JCache
 
unwrap(Class<T>) - Method in class org.redisson.jcache.JCacheEntry
 
unwrap(Class<T>) - Method in class org.redisson.jcache.JCacheEntryEvent
 
unwrap(Class<T>) - Method in class org.redisson.jcache.JCacheManager
 
unwrap(Class<T>) - Method in class org.redisson.jcache.JMutableEntry
 
update(long, long, long, long) - Method in class org.redisson.misc.HighwayHash
Updates the hash with 32 bytes of data given as 4 longs.
updateCache(ByteBuf, ByteBuf) - Method in class org.redisson.cache.LocalCacheListener
 
updateChannel(Channel) - Method in class org.redisson.client.RedisConnection
 
updateGroupMessageId(String, StreamMessageId) - Method in interface org.redisson.api.RStream
Updates next message id delivered to consumers.
updateGroupMessageId(String, StreamMessageId) - Method in interface org.redisson.api.RStreamReactive
Updates next message id delivered to consumers.
updateGroupMessageId(String, StreamMessageId) - Method in interface org.redisson.api.RStreamRx
Updates next message id delivered to consumers.
updateGroupMessageId(String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
updateGroupMessageIdAsync(String, StreamMessageId) - Method in interface org.redisson.api.RStreamAsync
Updates next message id delivered to consumers.
updateGroupMessageIdAsync(String, StreamMessageId) - Method in class org.redisson.RedissonStream
 
updateLeaseTime(String, long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphore
Overrides and updates lease time for defined permit id.
updateLeaseTime(String, long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreReactive
Overrides and updates lease time for defined permit id.
updateLeaseTime(String, long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreRx
Overrides and updates lease time for defined permit id.
updateLeaseTime(String, long, TimeUnit) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
updateLeaseTimeAsync(String, long, TimeUnit) - Method in interface org.redisson.api.RPermitExpirableSemaphoreAsync
Overrides and updates lease time for defined permit id.
updateLeaseTimeAsync(String, long, TimeUnit) - Method in class org.redisson.RedissonPermitExpirableSemaphore
 
updatePacket(byte[], int) - Method in class org.redisson.misc.HighwayHash
Updates the hash with 32 bytes of data.
updateRemainder(byte[], int, int) - Method in class org.redisson.misc.HighwayHash
Updates the hash with the last 1 to 31 bytes of the data.
useClusterServers() - Method in class org.redisson.config.Config
Init cluster servers configuration
useCustomServers(ConnectionManager) - Method in class org.redisson.config.Config
This is an extension point to supply custom connection manager.
useMasterSlaveServers() - Method in class org.redisson.config.Config
Init master/slave servers configuration.
useReplicatedServers() - Method in class org.redisson.config.Config
Init Replicated servers configuration.
useSentinelServers() - Method in class org.redisson.config.Config
Init sentinel servers configuration.
useSingleServer() - Method in class org.redisson.config.Config
Init single server configuration.
UUIDGenerator - Class in org.redisson.liveobject.resolver
 
UUIDGenerator() - Constructor for class org.redisson.liveobject.resolver.UUIDGenerator
 

V

validateExpression(String) - Static method in class org.redisson.executor.CronExpression
 
value - Variable in class org.redisson.iterator.BaseIterator
 
value() - Method in class org.redisson.jcache.JMutableEntry
 
value - Variable in class org.redisson.misc.CountableListener
 
valueIterator() - Method in interface org.redisson.api.RMapReactive
Returns iterator over values collection of this map.
valueIterator(int) - Method in interface org.redisson.api.RMapReactive
Returns iterator over values collection of this map.
valueIterator(String) - Method in interface org.redisson.api.RMapReactive
Returns iterator over values collection of this map.
valueIterator(String, int) - Method in interface org.redisson.api.RMapReactive
Returns iterator over values collection of this map.
valueIterator() - Method in interface org.redisson.api.RMapRx
Returns iterator over values collection of this map.
valueIterator(int) - Method in interface org.redisson.api.RMapRx
Returns iterator over values collection of this map.
valueIterator(String) - Method in interface org.redisson.api.RMapRx
Returns iterator over values collection of this map.
valueIterator(String, int) - Method in interface org.redisson.api.RMapRx
Returns iterator over values collection of this map.
valueIterator() - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
valueIterator(String) - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
valueIterator(int) - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
valueIterator(String, int) - Method in class org.redisson.reactive.RedissonMapCacheReactive
 
valueIterator() - Method in class org.redisson.reactive.RedissonMapReactive
 
valueIterator(String) - Method in class org.redisson.reactive.RedissonMapReactive
 
valueIterator(int) - Method in class org.redisson.reactive.RedissonMapReactive
 
valueIterator(String, int) - Method in class org.redisson.reactive.RedissonMapReactive
 
valueIterator(String, int) - Method in class org.redisson.RedissonMap
 
valueIterator() - Method in class org.redisson.rx.RedissonMapCacheRx
 
valueIterator(String) - Method in class org.redisson.rx.RedissonMapCacheRx
 
valueIterator(int) - Method in class org.redisson.rx.RedissonMapCacheRx
 
valueIterator(String, int) - Method in class org.redisson.rx.RedissonMapCacheRx
 
valueIterator() - Method in class org.redisson.rx.RedissonMapRx
 
valueIterator(String) - Method in class org.redisson.rx.RedissonMapRx
 
valueIterator(int) - Method in class org.redisson.rx.RedissonMapRx
 
valueIterator(String, int) - Method in class org.redisson.rx.RedissonMapRx
 
valueOf(String) - Static method in enum org.redisson.api.annotation.REntity.TransformationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.BatchOptions.ExecutionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.GeoOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.GeoUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.LocalCachedMapOptions.CacheProvider
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.LocalCachedMapOptions.EvictionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.LocalCachedMapOptions.ReconnectionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.LocalCachedMapOptions.StoreMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.LocalCachedMapOptions.SyncStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.map.event.EntryEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.MapOptions.WriteMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.Node.InfoSection
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.RateIntervalUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.RateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.RCascadeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.redisnode.RedisNode.InfoSection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.redisnode.SetSlotCommand
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.RScoredSortedSet.Aggregate
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.RScript.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.RScript.ReturnType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.RType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.api.SortOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.cache.ReferenceCachedValue.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.client.handler.RedisChannelInitializer.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.client.protocol.pubsub.PubSubType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.client.protocol.RedisCommand.ValueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.cluster.ClusterNodeInfo.Flag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.cluster.ClusterPartition.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.codec.BaseEventCodec.OSType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.codec.MarshallingCodec.Protocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.config.ReadMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.config.SslProvider
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.config.SubscriptionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.config.TransportMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.connection.ClientConnectionsEntry.FreezeReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.connection.ConnectionEventsHub.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.connection.NodeSource.Redirect
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.redisson.jcache.JMutableEntry.Action
Returns the enum constant of this type with the specified name.
valueRange(int, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns values by rank range.
valueRange(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSet
Returns all values between startScore and endScore.
valueRange(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns all values between startScore and endScore.
valueRange(int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns values by rank range.
valueRange(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns all values between startScore and endScore.
valueRange(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns all values between startScore and endScore.
valueRange(int, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns values by rank range.
valueRange(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns all values between startScore and endScore.
valueRange(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns all values between startScore and endScore.
valueRange(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRange(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRange(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRangeAsync(int, int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns values by rank range.
valueRangeAsync(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns all values between startScore and endScore.
valueRangeAsync(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns all values between startScore and endScore.
valueRangeAsync(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRangeAsync(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRangeAsync(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRangeReversed(int, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns values by rank range in reverse order.
valueRangeReversed(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSet
Returns all values between startScore and endScore in reversed order.
valueRangeReversed(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSet
Returns all values between startScore and endScore in reversed order.
valueRangeReversed(int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns values by rank range in reverse order.
valueRangeReversed(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns all values between startScore and endScore in reversed order.
valueRangeReversed(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
Returns all values between startScore and endScore in reversed order.
valueRangeReversed(int, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns values by rank range in reverse order.
valueRangeReversed(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns all values between startScore and endScore in reversed order.
valueRangeReversed(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetRx
Returns all values between startScore and endScore in reversed order.
valueRangeReversed(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRangeReversed(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRangeReversed(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRangeReversedAsync(int, int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns values by rank range in reverse order.
valueRangeReversedAsync(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns all values between startScore and endScore in reversed order.
valueRangeReversedAsync(double, boolean, double, boolean, int, int) - Method in interface org.redisson.api.RScoredSortedSetAsync
Returns all values between startScore and endScore in reversed order.
valueRangeReversedAsync(int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRangeReversedAsync(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
 
valueRangeReversedAsync(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
 
values() - Static method in enum org.redisson.api.annotation.REntity.TransformationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.BatchOptions.ExecutionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.GeoOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.GeoUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.LocalCachedMapOptions.CacheProvider
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.LocalCachedMapOptions.EvictionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.LocalCachedMapOptions.ReconnectionStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.LocalCachedMapOptions.StoreMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.LocalCachedMapOptions.SyncStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.map.event.EntryEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.MapOptions.WriteMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.Node.InfoSection
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.NodeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.RateIntervalUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.RateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.RCascadeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.redisnode.RedisNode.InfoSection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.redisnode.SetSlotCommand
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.redisson.api.RMap
Returns values collection of this map.
values(String) - Method in interface org.redisson.api.RMap
Returns values collection of this map.
values(String, int) - Method in interface org.redisson.api.RMap
Returns values collection of this map.
values(int) - Method in interface org.redisson.api.RMap
Returns values collection of this map.
values() - Method in interface org.redisson.api.RMultimap
Returns a view collection containing the value from each key-value pair contained in this multimap, without collapsing duplicates (so values().size() == size()).
values() - Static method in enum org.redisson.api.RScoredSortedSet.Aggregate
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.RScript.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.RScript.ReturnType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.RType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.api.SortOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.redisson.cache.AbstractCacheMap
 
values() - Static method in enum org.redisson.cache.ReferenceCachedValue.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.client.handler.RedisChannelInitializer.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.client.protocol.pubsub.PubSubType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.client.protocol.RedisCommand.ValueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.cluster.ClusterNodeInfo.Flag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.cluster.ClusterPartition.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.codec.BaseEventCodec.OSType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.codec.MarshallingCodec.Protocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.config.ReadMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.config.SslProvider
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.config.SubscriptionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.config.TransportMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.connection.ClientConnectionsEntry.FreezeReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.connection.ConnectionEventsHub.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.connection.NodeSource.Redirect
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.redisson.jcache.JMutableEntry.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.redisson.misc.BiHashMap
 
values() - Method in class org.redisson.RedissonMap
 
values(String, int) - Method in class org.redisson.RedissonMap
 
values(String) - Method in class org.redisson.RedissonMap
 
values(int) - Method in class org.redisson.RedissonMap
 
values() - Method in class org.redisson.RedissonMultimap
 
valueSet() - Method in class org.redisson.misc.BiHashMap
 
valueSize(K) - Method in interface org.redisson.api.RMap
Returns size of value mapped by specified key in bytes
valueSize(K) - Method in interface org.redisson.api.RMapReactive
Returns size of value mapped by key in bytes
valueSize(K) - Method in interface org.redisson.api.RMapRx
Returns size of value mapped by key in bytes
valueSize(K) - Method in class org.redisson.RedissonMap
 
valueSizeAsync(K) - Method in interface org.redisson.api.RMapAsync
Returns size of value mapped by key in bytes
valueSizeAsync(K) - Method in class org.redisson.RedissonMap
 
valueSizeAsync(K) - Method in class org.redisson.transaction.BaseTransactionalMap
 
valueSizeAsync(K) - Method in class org.redisson.transaction.RedissonTransactionalMap
 
valueSizeAsync(K) - Method in class org.redisson.transaction.RedissonTransactionalMapCache
 
Version - Class in org.redisson
 
Version() - Constructor for class org.redisson.Version
 
VoidReplayConvertor - Class in org.redisson.client.protocol.convertor
 
VoidReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.VoidReplayConvertor
 

W

WAIT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
waitSync(double, RFuture<List<Object>>) - Method in class org.redisson.jcache.JCache
 
warmUp() - Static method in class org.redisson.RedissonReference
 
WATCH - Static variable in interface org.redisson.client.protocol.RedisCommands
 
weak(long, long) - Static method in class org.redisson.cache.ReferenceCacheMap
 
weeklyOnDayAndHourAndMinute(int, int, Integer...) - Static method in class org.redisson.api.CronSchedule
Creates cron expression which schedule task execution every given days of the week at the given time.
WeightedRoundRobinBalancer - Class in org.redisson.connection.balancer
Weighted Round Robin balancer.
WeightedRoundRobinBalancer(Map<String, Integer>, int) - Constructor for class org.redisson.connection.balancer.WeightedRoundRobinBalancer
Creates weighted round robin balancer.
whenComplete(BiConsumer<? super T, ? super Throwable>) - Method in class org.redisson.misc.PromiseDelegator
 
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>) - Method in class org.redisson.misc.PromiseDelegator
 
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>, Executor) - Method in class org.redisson.misc.PromiseDelegator
 
WorkerOptions - Class in org.redisson.api
Configuration for RExecutorService workers.
workers(int) - Method in class org.redisson.api.WorkerOptions
Defines workers amount used to execute tasks.
workersAmount - Variable in class org.redisson.mapreduce.BaseMapperTask
 
wrapLockedAsync(RedisCommand<T>, Object...) - Method in class org.redisson.RedissonPriorityQueue
 
wrapLockedAsync(Supplier<RFuture<R>>) - Method in class org.redisson.RedissonPriorityQueue
 
write(Map<K, V>) - Method in interface org.redisson.api.map.MapWriter
 
write(ByteBuffer) - Method in interface org.redisson.api.RBinaryStreamReactive
Writes a sequence of bytes from defined buffer.
write(ByteBuffer) - Method in interface org.redisson.api.RBinaryStreamRx
Writes a sequence of bytes from defined buffer.
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.redisson.client.handler.CommandBatchEncoder
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.redisson.client.handler.CommandEncoder
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.redisson.client.handler.CommandsQueue
 
write(int) - Method in class org.redisson.codec.MarshallingCodec.ByteOutputWrapper
 
write(byte[]) - Method in class org.redisson.codec.MarshallingCodec.ByteOutputWrapper
 
write(byte[], int, int) - Method in class org.redisson.codec.MarshallingCodec.ByteOutputWrapper
 
write(ByteBuffer) - Method in class org.redisson.reactive.RedissonBinaryStreamReactive
 
write(ByteBuffer, A, CompletionHandler<Integer, ? super A>) - Method in class org.redisson.RedissonBinaryStream.RedissonAsynchronousByteChannel
 
write(ByteBuffer) - Method in class org.redisson.RedissonBinaryStream.RedissonAsynchronousByteChannel
 
write(ByteBuffer) - Method in class org.redisson.rx.RedissonBinaryStreamRx
 
writeAllAsync(RedisCommand<T>, SlotCallback<T, R>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
writeAllAsync(Codec, RedisCommand<T>, SlotCallback<T, R>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
writeAllAsync(RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
writeAllAsync(RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
writeAllAsync(RedisCommand<T>, SlotCallback<T, R>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
writeAllAsync(Codec, RedisCommand<T>, SlotCallback<T, R>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
writeAsync(RedisClient, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
writeAsync(MasterSlaveEntry, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
writeAsync(byte[], Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
writeAsync(String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
writeAsync(String, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
writeAsync(RedisClient, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
writeAsync(MasterSlaveEntry, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
writeAsync(String, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
writeAsync(String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
writeAsync(byte[], Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
 
writeBatchedAsync(Codec, RedisCommand<T>, SlotCallback<T, R>, String...) - Method in interface org.redisson.command.CommandAsyncExecutor
 
writeBatchedAsync(Codec, RedisCommand<T>, SlotCallback<T, R>, String...) - Method in class org.redisson.command.CommandAsyncService
 
writeBehindBatchSize(int) - Method in class org.redisson.api.LocalCachedMapOptions
 
writeBehindBatchSize(int) - Method in class org.redisson.api.MapOptions
Sets write behind tasks batch size.
writeBehindDelay(int) - Method in class org.redisson.api.LocalCachedMapOptions
 
writeBehindDelay(int) - Method in class org.redisson.api.MapOptions
Sets write behind tasks execution delay.
writeBehindService - Variable in class org.redisson.Redisson
 
writeBehindService - Variable in class org.redisson.RedissonReactive
 
writeBehindService - Variable in class org.redisson.RedissonRx
 
WriteBehindService - Class in org.redisson
 
WriteBehindService(CommandAsyncExecutor) - Constructor for class org.redisson.WriteBehindService
 
writeLock() - Method in interface org.redisson.api.RReadWriteLock
Returns the lock used for writing.
writeLock() - Method in interface org.redisson.api.RReadWriteLockReactive
Returns the lock used for writing.
writeLock() - Method in interface org.redisson.api.RReadWriteLockRx
Returns the lock used for writing.
writeLock() - Method in class org.redisson.reactive.RedissonReadWriteLockReactive
 
writeLock() - Method in class org.redisson.RedissonReadWriteLock
 
writeLock() - Method in class org.redisson.rx.RedissonReadWriteLockRx
 
writeMode(MapOptions.WriteMode) - Method in class org.redisson.api.LocalCachedMapOptions
 
writeMode(MapOptions.WriteMode) - Method in class org.redisson.api.MapOptions
Sets write mode.
writer(MapWriter<K, V>) - Method in class org.redisson.api.LocalCachedMapOptions
 
writer(MapWriter<K, V>) - Method in class org.redisson.api.MapOptions
Sets MapWriter object.
WriteRedisConnectionException - Exception in org.redisson.client
 
WriteRedisConnectionException(String) - Constructor for exception org.redisson.client.WriteRedisConnectionException
 
WriteRedisConnectionException(String, Throwable) - Constructor for exception org.redisson.client.WriteRedisConnectionException
 
writeValue(OutputStream, Object) - Method in class org.redisson.codec.AvroJacksonCodec.AvroExtendedMapper
 
writeValueAsBytes(Object) - Method in class org.redisson.codec.AvroJacksonCodec.AvroExtendedMapper
 

X

XACK - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XADD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XADD_VOID - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XCLAIM - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XCLAIM_IDS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XDEL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XGROUP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XGROUP_LONG - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XINFO_CONSUMERS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XINFO_GROUPS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XLEN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
xor(String...) - Method in interface org.redisson.api.RBitSet
Executes XOR operation over this object and specified bitsets.
xor(String...) - Method in interface org.redisson.api.RBitSetReactive
Executes XOR operation over this object and specified bitsets.
xor(String...) - Method in interface org.redisson.api.RBitSetRx
Executes XOR operation over this object and specified bitsets.
xor(String...) - Method in class org.redisson.RedissonBitSet
 
xorAsync(String...) - Method in interface org.redisson.api.RBitSetAsync
Executes XOR operation over this object and specified bitsets.
xorAsync(String...) - Method in class org.redisson.RedissonBitSet
 
XPENDING - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XPENDING_ENTRIES - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XRANGE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XREAD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XREAD_BLOCKING - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XREAD_BLOCKING_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XREAD_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XREADGROUP - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XREADGROUP_BLOCKING - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XREADGROUP_BLOCKING_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XREADGROUP_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XREVRANGE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
XTRIM - Static variable in interface org.redisson.client.protocol.RedisCommands
 

Y

YEAR - Static variable in class org.redisson.executor.CronExpression
 
years - Variable in class org.redisson.executor.CronExpression
 
yield(Kryo) - Method in class org.redisson.codec.KryoCodec
 

Z

ZADD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZADD_BOOL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZADD_BOOL_RAW - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZADD_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZADD_NX_BOOL - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZADD_RAW - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZCARD - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZCARD_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZCOUNT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZERO_COUNT_MESSAGE - Static variable in class org.redisson.pubsub.CountDownLatchPubSub
 
ZINCRBY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZINTERSTORE_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZLEXCOUNT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZPOPMAX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZPOPMIN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANGE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANGE_ENTRY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANGE_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANGE_SINGLE_SCORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANGEBYLEX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANGEBYSCORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANGEBYSCORE_ENTRY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANGEBYSCORE_LIST - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANK - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZRANK_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREM - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREM_LONG - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREMRANGEBYLEX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREMRANGEBYRANK - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREMRANGEBYSCORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREVRANGE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREVRANGE_ENTRY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREVRANGEBYLEX - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREVRANGEBYSCORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREVRANGEBYSCORE_ENTRY - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREVRANK - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZREVRANK_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZSCAN - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZSCORE - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZSCORE_CONTAINS - Static variable in interface org.redisson.client.protocol.RedisCommands
 
ZUNIONSTORE_INT - Static variable in interface org.redisson.client.protocol.RedisCommands
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

Copyright © 2014–2020 Redisson. All rights reserved.