- get() - Method in interface org.redisson.api.RAtomicLongReactive
-
- get(long) - Method in interface org.redisson.api.RBitSetReactive
-
- get() - Method in interface org.redisson.api.RBucketReactive
-
- get(long) - Method in interface org.redisson.api.RListReactive
-
- get(K) - Method in interface org.redisson.api.RMapReactive
-
- GET - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- get() - Method in interface org.redisson.codec.KryoCodec.KryoPool
-
- get() - Method in class org.redisson.codec.KryoCodec.KryoPoolImpl
-
- get(Future<V>) - Method in interface org.redisson.command.CommandAsyncExecutor
-
- get(Future<V>) - Method in class org.redisson.command.CommandAsyncService
-
- get(Future<V>) - Method in interface org.redisson.command.CommandSyncExecutor
-
- get() - Method in interface org.redisson.core.RAtomicDouble
-
Gets the current value.
- get() - Method in interface org.redisson.core.RAtomicLong
-
Gets the current value.
- get(long) - Method in interface org.redisson.core.RBitSet
-
- get() - Method in interface org.redisson.core.RBucket
-
- get() - Method in class org.redisson.misc.ConnectionPool
-
- get(ClientConnectionsEntry) - Method in class org.redisson.misc.ConnectionPool
-
- get() - Method in class org.redisson.reactive.RedissonAtomicLongReactive
-
- get(long) - Method in class org.redisson.reactive.RedissonBitSetReactive
-
- get() - Method in class org.redisson.reactive.RedissonBucketReactive
-
- get(long) - Method in class org.redisson.reactive.RedissonListReactive
-
- get(K) - Method in class org.redisson.reactive.RedissonMapCacheReactive
-
- get(K) - Method in class org.redisson.reactive.RedissonMapReactive
-
- 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(int) - Method in class org.redisson.RedissonList
-
- get(Object) - Method in class org.redisson.RedissonMap
-
- 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
-
- getAcquireFuture() - Method in class org.redisson.client.RedisConnection
-
- getAddr() - Method in class org.redisson.client.RedisClient
-
- getAddr() - Method in class org.redisson.connection.NodeSource
-
- getAddr() - Method in class org.redisson.connection.RedisClientEntry
-
- getAddr() - Method in interface org.redisson.core.Node
-
Get Redis node address
- getAddress() - Method in class org.redisson.cluster.ClusterNodeInfo
-
- getAddress() - Method in class org.redisson.SingleServerConfig
-
- getAll(Set<K>) - Method in interface org.redisson.api.RMapReactive
-
- getAll(Set<K>) - Method in interface org.redisson.core.RMap
-
Gets a map slice contains the mappings with defined keys
by one operation.
- getAll(Set<K>) - Method in class org.redisson.reactive.RedissonMapCacheReactive
-
- getAll(Set<K>) - Method in class org.redisson.reactive.RedissonMapReactive
-
- getAll(Set<K>) - Method in class org.redisson.RedissonMap
-
- getAllAddresses() - Method in class org.redisson.cluster.ClusterPartition
-
- getAllAsync(Set<K>) - Method in interface org.redisson.core.RMapAsync
-
- getAllAsync(Set<K>) - Method in class org.redisson.RedissonMap
-
- getAllAsync(Set<K>) - Method in class org.redisson.RedissonMapCache
-
- getAllSubscribeConnections() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- getAndAdd(long) - Method in interface org.redisson.api.RAtomicLongReactive
-
- getAndAdd(double) - Method in interface org.redisson.core.RAtomicDouble
-
Atomically adds the given value to the current value.
- getAndAdd(long) - Method in interface org.redisson.core.RAtomicLong
-
Atomically adds the given value to the current value.
- getAndAdd(long) - Method in class org.redisson.reactive.RedissonAtomicLongReactive
-
- getAndAdd(double) - Method in class org.redisson.RedissonAtomicDouble
-
- getAndAdd(long) - Method in class org.redisson.RedissonAtomicLong
-
- getAndAddAsync(double) - Method in interface org.redisson.core.RAtomicDoubleAsync
-
- getAndAddAsync(long) - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAndAddAsync(double) - Method in class org.redisson.RedissonAtomicDouble
-
- getAndAddAsync(long) - Method in class org.redisson.RedissonAtomicLong
-
- getAndDecrement() - Method in interface org.redisson.api.RAtomicLongReactive
-
- getAndDecrement() - Method in interface org.redisson.core.RAtomicDouble
-
Atomically decrements by one the current value.
- getAndDecrement() - Method in interface org.redisson.core.RAtomicLong
-
Atomically decrements by one the current value.
- getAndDecrement() - Method in class org.redisson.reactive.RedissonAtomicLongReactive
-
- getAndDecrement() - Method in class org.redisson.RedissonAtomicDouble
-
- getAndDecrement() - Method in class org.redisson.RedissonAtomicLong
-
- getAndDecrementAsync() - Method in interface org.redisson.core.RAtomicDoubleAsync
-
- getAndDecrementAsync() - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAndDecrementAsync() - Method in class org.redisson.RedissonAtomicDouble
-
- getAndDecrementAsync() - Method in class org.redisson.RedissonAtomicLong
-
- getAndIncrement() - Method in interface org.redisson.api.RAtomicLongReactive
-
- getAndIncrement() - Method in interface org.redisson.core.RAtomicDouble
-
Atomically increments the current value by one.
- getAndIncrement() - Method in interface org.redisson.core.RAtomicLong
-
Atomically increments the current value by one.
- getAndIncrement() - Method in class org.redisson.reactive.RedissonAtomicLongReactive
-
- getAndIncrement() - Method in class org.redisson.RedissonAtomicDouble
-
- getAndIncrement() - Method in class org.redisson.RedissonAtomicLong
-
- getAndIncrementAsync() - Method in interface org.redisson.core.RAtomicDoubleAsync
-
- getAndIncrementAsync() - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAndIncrementAsync() - Method in class org.redisson.RedissonAtomicDouble
-
- getAndIncrementAsync() - Method in class org.redisson.RedissonAtomicLong
-
- getAndSet(long) - Method in interface org.redisson.api.RAtomicLongReactive
-
- getAndSet(double) - Method in interface org.redisson.core.RAtomicDouble
-
Atomically sets the given value and returns the old value.
- getAndSet(long) - Method in interface org.redisson.core.RAtomicLong
-
Atomically sets the given value and returns the old value.
- getAndSet(V) - Method in interface org.redisson.core.RBucket
-
- getAndSet(long) - Method in class org.redisson.reactive.RedissonAtomicLongReactive
-
- getAndSet(double) - Method in class org.redisson.RedissonAtomicDouble
-
- getAndSet(long) - Method in class org.redisson.RedissonAtomicLong
-
- getAndSet(V) - Method in class org.redisson.RedissonBucket
-
- getAndSetAsync(double) - Method in interface org.redisson.core.RAtomicDoubleAsync
-
- getAndSetAsync(long) - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAndSetAsync(V) - Method in interface org.redisson.core.RBucketAsync
-
- getAndSetAsync(double) - Method in class org.redisson.RedissonAtomicDouble
-
- getAndSetAsync(long) - Method in class org.redisson.RedissonAtomicLong
-
- getAndSetAsync(V) - Method in class org.redisson.RedissonBucket
-
- getAsync() - Method in interface org.redisson.core.RAtomicDoubleAsync
-
- getAsync() - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAsync(long) - Method in interface org.redisson.core.RBitSetAsync
-
- getAsync() - Method in interface org.redisson.core.RBucketAsync
-
- getAsync(int) - Method in interface org.redisson.core.RListAsync
-
- getAsync(K) - Method in interface org.redisson.core.RMapAsync
-
- 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(int) - Method in class org.redisson.RedissonList
-
- getAsync(K) - Method in class org.redisson.RedissonMap
-
- getAsync(K) - Method in class org.redisson.RedissonMapCache
-
- getAtomicDouble(String) - Method in interface org.redisson.core.RBatch
-
Returns atomicDouble instance by name.
- getAtomicDouble(String) - Method in class org.redisson.Redisson
-
- getAtomicDouble(String) - Method in class org.redisson.RedissonBatch
-
- getAtomicDouble(String) - Method in interface org.redisson.RedissonClient
-
Returns atomicDouble 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.core.RBatch
-
Returns atomicLong instance by name.
- getAtomicLong(String) - Method in class org.redisson.Redisson
-
- getAtomicLong(String) - Method in class org.redisson.RedissonBatch
-
- getAtomicLong(String) - Method in interface org.redisson.RedissonClient
-
Returns atomicLong instance by name.
- getAtomicLong(String) - Method in class org.redisson.RedissonReactive
-
- getAtomicLongReactive(String) - Method in interface org.redisson.api.RBatchReactive
-
Returns "atomic long" instance by name.
- getAtomicLongReactive(String) - Method in class org.redisson.reactive.RedissonBatchReactive
-
- getAttempt() - Method in class org.redisson.command.AsyncDetails
-
- getAttemptPromise() - Method in class org.redisson.command.AsyncDetails
-
- getAvailableClients() - Method in interface org.redisson.connection.balancer.LoadBalancerManager
-
- getAvailableClients() - Method in class org.redisson.connection.balancer.LoadBalancerManagerImpl
-
- GETBIT - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- getBitSet(String) - Method in interface org.redisson.api.RBatchReactive
-
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.core.RBatch
-
- 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 interface org.redisson.RedissonClient
-
Returns bitSet instance by name.
- getBitSet(String) - Method in class org.redisson.RedissonReactive
-
- getBlockingDeque(String) - Method in interface org.redisson.core.RBatch
-
Returns blocking deque instance by name.
- getBlockingDeque(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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 interface org.redisson.RedissonClient
-
Returns blocking deque instance by name.
- getBlockingDeque(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns blocking deque instance by name
using provided codec for deque objects.
- 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.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.core.RBatch
-
Returns blocking queue instance by name.
- getBlockingQueue(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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 interface org.redisson.RedissonClient
-
Returns blocking queue instance by name.
- getBlockingQueue(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns blocking queue instance by name
using provided codec for queue objects.
- getBlockingQueue(String) - Method in class org.redisson.RedissonReactive
-
- getBlockingQueue(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getBloomFilter(String) - Method in class org.redisson.Redisson
-
- getBloomFilter(String, Codec) - Method in class org.redisson.Redisson
-
- getBloomFilter(String) - Method in interface org.redisson.RedissonClient
-
- getBloomFilter(String, Codec) - Method in interface org.redisson.RedissonClient
-
- getBootstrap() - Method in class org.redisson.client.RedisClient
-
- 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.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.core.RBatch
-
Returns object holder by name
- getBucket(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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.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 interface org.redisson.RedissonClient
-
Returns object holder instance by name.
- getBucket(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns object holder instance by name
using provided codec for object.
- getBucket(String) - Method in class org.redisson.RedissonReactive
-
- getBucket(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getBuckets(String) - Method in class org.redisson.Redisson
-
- getBuckets(String) - Method in interface org.redisson.RedissonClient
-
Deprecated.
- getBuf() - Method in class org.redisson.client.protocol.decoder.ScanObjectEntry
-
- getCache(String) - Method in class org.redisson.spring.cache.RedissonCacheManager
-
- getCacheNames() - Method in class org.redisson.spring.cache.RedissonCacheManager
-
- 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.
- getChannelNames() - Method in interface org.redisson.api.RTopicReactive
-
- getChannelNames() - Method in interface org.redisson.core.RTopic
-
Get topic channel names
- getChannelNames() - Method in class org.redisson.reactive.RedissonTopicReactive
-
- getChannelNames() - Method in class org.redisson.RedissonTopic
-
- getChannelPromise() - Method in class org.redisson.client.protocol.QueueCommandHolder
-
- getChannels() - Method in class org.redisson.client.RedisPubSubConnection
-
- getClient() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- getClient() - Method in class org.redisson.connection.MasterSlaveEntry
-
- getClient() - Method in class org.redisson.connection.RedisClientEntry
-
- getClients() - Method in interface org.redisson.connection.ConnectionManager
-
- getClients() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getClusterNodesGroup() - Method in interface org.redisson.api.RedissonReactiveClient
-
Get Redis cluster nodes group for server operations
- getClusterNodesGroup() - Method in class org.redisson.Redisson
-
- getClusterNodesGroup() - Method in interface org.redisson.RedissonClient
-
Get Redis cluster nodes group for server operations
- getClusterNodesGroup() - Method in class org.redisson.RedissonReactive
-
- getCodec() - Method in class org.redisson.client.protocol.CommandData
-
- getCodec() - Method in class org.redisson.command.AsyncDetails
-
- getCodec() - Method in class org.redisson.Config
-
- getCodec() - Method in interface org.redisson.connection.ConnectionManager
-
- getCodec() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getCommand() - Method in class org.redisson.client.protocol.CommandData
-
- getCommand() - Method in class org.redisson.client.protocol.QueueCommandHolder
-
- getCommand() - Method in class org.redisson.command.AsyncDetails
-
- getCommand() - Method in class org.redisson.command.CommandBatchService.CommandEntry
-
- getCommand() - Method in enum org.redisson.core.RScript.ReturnType
-
- getCommands() - Method in class org.redisson.client.protocol.CommandsData
-
- getCommands() - Method in class org.redisson.command.CommandBatchService.Entry
-
- getConfig() - Method in interface org.redisson.api.RedissonReactiveClient
-
Allows to get configuration provided
during Redisson instance creation.
- getConfig() - Method in interface org.redisson.connection.ConnectionManager
-
- getConfig() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getConfig() - Method in class org.redisson.Redisson
-
- getConfig() - Method in interface org.redisson.RedissonClient
-
Allows to get configuration provided
during Redisson instance creation.
- getConfig() - Method in class org.redisson.RedissonReactive
-
- getConnection(InetSocketAddress) - Method in interface org.redisson.connection.balancer.LoadBalancerManager
-
- getConnection(InetSocketAddress) - Method in class org.redisson.connection.balancer.LoadBalancerManagerImpl
-
- getConnection() - Method in class org.redisson.connection.PubSubConnectionEntry
-
- getConnectionEventsHub() - Method in interface org.redisson.connection.ConnectionManager
-
- getConnectionEventsHub() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getConnectionFuture() - Method in class org.redisson.command.AsyncDetails
-
- getConnectionListener() - Method in class org.redisson.Config
-
Deprecated.
- getConnectionManager() - Method in interface org.redisson.command.CommandAsyncExecutor
-
- getConnectionManager() - Method in class org.redisson.command.CommandAsyncService
-
- getConnectionManager() - Method in interface org.redisson.command.CommandReactiveExecutor
-
- getConnectionManager() - Method in interface org.redisson.command.CommandSyncExecutor
-
- getConnectionMinimumIdleSize() - Method in class org.redisson.SingleServerConfig
-
- getConnectionPoolSize() - Method in class org.redisson.SingleServerConfig
-
- getConnectionWatcher() - Method in interface org.redisson.connection.ConnectionManager
-
- getConnectionWatcher() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getConnectListener() - Method in interface org.redisson.connection.ConnectionManager
-
- getConnectListener() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getConvertor() - Method in class org.redisson.client.protocol.RedisCommand
-
- getCount() - Method in interface org.redisson.core.RCountDownLatch
-
Returns the current count.
- getCount() - Method in class org.redisson.RedissonCountDownLatch
-
- getCountDownLatch(String) - Method in class org.redisson.Redisson
-
- getCountDownLatch(String) - Method in interface org.redisson.RedissonClient
-
Returns countDownLatch instance by name.
- getDecoders() - Method in class org.redisson.client.protocol.decoder.NestedMultiDecoder.DecoderState
-
- getDecoderState() - Method in class org.redisson.client.handler.State
-
- 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.core.RBatch
-
Returns deque instance by name.
- getDeque(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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 interface org.redisson.RedissonClient
-
Returns deque instance by name.
- getDeque(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns deque instance by name
using provided codec for deque objects.
- getDeque(String) - Method in class org.redisson.RedissonReactive
-
- getDeque(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getDequeReactive(String) - Method in interface org.redisson.api.RBatchReactive
-
Returns deque instance by name.
- getDequeReactive(String, Codec) - Method in interface org.redisson.api.RBatchReactive
-
- getDequeReactive(String) - Method in class org.redisson.reactive.RedissonBatchReactive
-
- getDequeReactive(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
-
- getDnsMonitoringInterval() - Method in class org.redisson.SingleServerConfig
-
- getElement() - Method in class org.redisson.client.protocol.decoder.ListIteratorResult
-
- getEndSlot() - Method in class org.redisson.cluster.ClusterSlotRange
-
- getEntries() - Method in interface org.redisson.connection.ConnectionManager
-
- getEntries() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getEntry(List<ClientConnectionsEntry>) - Method in interface org.redisson.connection.balancer.LoadBalancer
-
- 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(InetSocketAddress) - Method in interface org.redisson.connection.ConnectionManager
-
- getEntry(InetSocketAddress) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getEntry(ClusterSlotRange) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getEntry(int) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getEntry() - Method in class org.redisson.misc.ConnectionPool
-
- getEntry() - Method in class org.redisson.misc.MasterConnectionPool
-
- getException() - Method in class org.redisson.command.AsyncDetails
-
- getExpectedInsertions() - Method in interface org.redisson.core.RBloomFilter
-
- getExpectedInsertions() - Method in class org.redisson.RedissonBloomFilter
-
- getFailedAttempts() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- getFalseProbability() - Method in interface org.redisson.core.RBloomFilter
-
- getFalseProbability() - Method in class org.redisson.RedissonBloomFilter
-
- getFirst() - Method in class org.redisson.RedissonQueue
-
- getFlipDecoders() - Method in class org.redisson.client.protocol.decoder.NestedMultiDecoder.DecoderState
-
- getFreeAmount() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- getFreezeReason() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- getFreezeReason() - Method in class org.redisson.connection.MasterSlaveEntry
-
- getFrom(Channel) - Static method in class org.redisson.client.RedisConnection
-
- getGroup() - Method in interface org.redisson.connection.ConnectionManager
-
- getGroup() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getHashIterations() - Method in interface org.redisson.core.RBloomFilter
-
- getHashIterations() - Method in class org.redisson.RedissonBloomFilter
-
- getHoldCount() - Method in interface org.redisson.core.RLock
-
Number of holds on this lock by the current thread
- getHoldCount() - Method in class org.redisson.RedissonLock
-
- getHoldCount() - Method in class org.redisson.RedissonReadLock
-
- getHoldCount() - Method in class org.redisson.RedissonWriteLock
-
- getHyperLogLog(String) - Method in interface org.redisson.api.RBatchReactive
-
Returns HyperLogLog object
- getHyperLogLog(String, Codec) - Method in interface org.redisson.api.RBatchReactive
-
- 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.core.RBatch
-
Returns HyperLogLog object
- getHyperLogLog(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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 interface org.redisson.RedissonClient
-
Returns HyperLogLog instance by name.
- getHyperLogLog(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns HyperLogLog instance by name
using provided codec for hll objects.
- getHyperLogLog(String) - Method in class org.redisson.RedissonReactive
-
- getHyperLogLog(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getIndex() - Method in class org.redisson.client.handler.State
-
- getIndex() - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
-
- getInParamIndex() - Method in class org.redisson.client.protocol.RedisCommand
-
- getInParamType() - Method in class org.redisson.client.protocol.RedisCommand
-
- getKey() - Method in class org.redisson.client.protocol.decoder.KeyValueMessage
-
- getKey() - Method in class org.redisson.RedissonMapEntry
-
- getKeys() - Method in interface org.redisson.api.RBatchReactive
-
Returns keys operations.
- getKeys() - Method in interface org.redisson.api.RedissonReactiveClient
-
Returns keys operations.
- getKeys() - Method in interface org.redisson.api.RKeysReactive
-
Load keys in incrementally iterate mode.
- getKeys() - Method in interface org.redisson.core.RBatch
-
Returns keys operations.
- getKeys() - Method in interface org.redisson.core.RKeys
-
Get all keys using iterator.
- getKeys() - Method in class org.redisson.reactive.RedissonBatchReactive
-
- getKeys() - Method in class org.redisson.reactive.RedissonKeysReactive
-
- getKeys() - Method in class org.redisson.Redisson
-
- getKeys() - Method in class org.redisson.RedissonBatch
-
- getKeys() - Method in interface org.redisson.RedissonClient
-
Returns interface with methods for Redis keys.
- getKeys() - Method in class org.redisson.RedissonKeys
-
- getKeys() - Method in class org.redisson.RedissonReactive
-
- getKeysByPattern(String) - Method in interface org.redisson.api.RKeysReactive
-
Find keys by pattern and load it in incrementally iterate mode.
- getKeysByPattern(String) - Method in interface org.redisson.core.RKeys
-
Get all keys by pattern using iterator.
- getKeysByPattern(String) - Method in class org.redisson.reactive.RedissonKeysReactive
-
- getKeysByPattern(String) - Method in class org.redisson.RedissonKeys
-
- getLast() - Method in interface org.redisson.api.RDequeReactive
-
- getLast() - Method in class org.redisson.reactive.RedissonDequeReactive
-
- getLast() - Method in class org.redisson.RedissonDeque
-
- getLastAsync() - Method in interface org.redisson.core.RDequeAsync
-
- getLastAsync() - Method in class org.redisson.RedissonDeque
-
- getLastUsageTime() - Method in class org.redisson.client.RedisConnection
-
- getLatch() - Method in class org.redisson.RedissonCountDownLatchEntry
-
- getLatch() - Method in class org.redisson.RedissonLockEntry
-
- 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.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.core.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 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 interface org.redisson.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 class org.redisson.RedissonReactive
-
- 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.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.core.RBatch
-
Returns list instance by name.
- getList(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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 interface org.redisson.RedissonClient
-
Returns list instance by name.
- getList(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns list instance by name
using provided codec for list objects.
- getList(String) - Method in class org.redisson.RedissonReactive
-
- getList(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getListeners(String) - Method in class org.redisson.connection.PubSubConnectionEntry
-
- getLoadBalancer() - Method in class org.redisson.BaseMasterSlaveServersConfig
-
- getLock(String) - Method in class org.redisson.Redisson
-
- getLock(String) - Method in interface org.redisson.RedissonClient
-
Returns lock instance by name.
- getMainPromise() - Method in class org.redisson.command.AsyncDetails
-
- 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.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() - Method in class org.redisson.client.protocol.decoder.MapScanResult
-
- getMap(String) - Method in interface org.redisson.core.RBatch
-
Returns map instance by name.
- getMap(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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.Redisson
-
- getMap(String, Codec) - 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 interface org.redisson.RedissonClient
-
Returns map instance by name.
- getMap(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns map instance by name
using provided codec for both map keys and values.
- getMap(String) - Method in class org.redisson.RedissonReactive
-
- getMap(String, Codec) - Method in class org.redisson.RedissonReactive
-
- 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.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, Codec) - Method in interface org.redisson.core.RBatch
-
Returns map-based cache instance by name
using provided codec
for both cache keys and values.
- getMapCache(String) - Method in interface org.redisson.core.RBatch
-
Returns map-based cache instance by name
.
- getMapCache(String, Codec) - Method in class org.redisson.reactive.RedissonBatchReactive
-
- getMapCache(String) - Method in class org.redisson.reactive.RedissonBatchReactive
-
- getMapCache(String) - Method in class org.redisson.Redisson
-
- getMapCache(String, Codec) - 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 interface org.redisson.RedissonClient
-
Returns map-based cache instance by name
using provided codec
for both cache keys and values.
- getMapCache(String) - Method in interface org.redisson.RedissonClient
-
Returns map-based cache instance by name.
- getMapCache(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getMapCache(String) - Method in class org.redisson.RedissonReactive
-
- getMapKeyDecoder() - Method in class org.redisson.client.codec.BitSetCodec
-
- getMapKeyDecoder() - Method in class org.redisson.client.codec.ByteArrayCodec
-
- 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.client.codec.ScanCodec
-
- getMapKeyDecoder() - Method in class org.redisson.client.codec.StringCodec
-
- getMapKeyDecoder() - Method in class org.redisson.codec.FstCodec
-
- getMapKeyDecoder() - Method in class org.redisson.codec.JsonJacksonCodec
-
- getMapKeyDecoder() - Method in class org.redisson.codec.KryoCodec
-
- getMapKeyDecoder() - Method in class org.redisson.codec.LZ4Codec
-
- getMapKeyDecoder() - Method in class org.redisson.codec.SerializationCodec
-
- getMapKeyDecoder() - Method in class org.redisson.codec.SnappyCodec
-
- getMapKeyEncoder() - Method in class org.redisson.client.codec.BitSetCodec
-
- getMapKeyEncoder() - Method in class org.redisson.client.codec.ByteArrayCodec
-
- 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.client.codec.ScanCodec
-
- getMapKeyEncoder() - Method in class org.redisson.client.codec.StringCodec
-
- getMapKeyEncoder() - Method in class org.redisson.codec.FstCodec
-
- getMapKeyEncoder() - Method in class org.redisson.codec.JsonJacksonCodec
-
- getMapKeyEncoder() - Method in class org.redisson.codec.KryoCodec
-
- getMapKeyEncoder() - Method in class org.redisson.codec.LZ4Codec
-
- getMapKeyEncoder() - Method in class org.redisson.codec.SerializationCodec
-
- getMapKeyEncoder() - Method in class org.redisson.codec.SnappyCodec
-
- getMapValueDecoder() - Method in class org.redisson.client.codec.BitSetCodec
-
- getMapValueDecoder() - Method in class org.redisson.client.codec.ByteArrayCodec
-
- 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.client.codec.ScanCodec
-
- getMapValueDecoder() - Method in class org.redisson.client.codec.StringCodec
-
- getMapValueDecoder() - Method in class org.redisson.codec.FstCodec
-
- getMapValueDecoder() - Method in class org.redisson.codec.JsonJacksonCodec
-
- getMapValueDecoder() - Method in class org.redisson.codec.KryoCodec
-
- getMapValueDecoder() - Method in class org.redisson.codec.LZ4Codec
-
- getMapValueDecoder() - Method in class org.redisson.codec.SerializationCodec
-
- getMapValueDecoder() - Method in class org.redisson.codec.SnappyCodec
-
- getMapValueEncoder() - Method in class org.redisson.client.codec.BitSetCodec
-
- getMapValueEncoder() - Method in class org.redisson.client.codec.ByteArrayCodec
-
- 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.client.codec.ScanCodec
-
- getMapValueEncoder() - Method in class org.redisson.client.codec.StringCodec
-
- getMapValueEncoder() - Method in class org.redisson.codec.FstCodec
-
- getMapValueEncoder() - Method in class org.redisson.codec.JsonJacksonCodec
-
- getMapValueEncoder() - Method in class org.redisson.codec.KryoCodec
-
- getMapValueEncoder() - Method in class org.redisson.codec.LZ4Codec
-
- getMapValueEncoder() - Method in class org.redisson.codec.SerializationCodec
-
- getMapValueEncoder() - Method in class org.redisson.codec.SnappyCodec
-
- getMasterAddr() - Method in class org.redisson.cluster.ClusterPartition
-
- getMasterAddress() - Method in class org.redisson.cluster.ClusterPartition
-
- getMasterAddress() - Method in class org.redisson.MasterSlaveServersConfig
-
- getMasterConnectionMinimumIdleSize() - Method in class org.redisson.BaseMasterSlaveServersConfig
-
- getMasterConnectionPoolSize() - Method in class org.redisson.BaseMasterSlaveServersConfig
-
- getMasterName() - Method in class org.redisson.SentinelServersConfig
-
- getMessageDecoder() - Method in class org.redisson.client.protocol.CommandData
-
- getMinimumIdleSize(ClientConnectionsEntry) - Method in class org.redisson.misc.ConnectionPool
-
- getMinimumIdleSize(ClientConnectionsEntry) - Method in class org.redisson.misc.MasterConnectionPool
-
- getMinimumIdleSize(ClientConnectionsEntry) - Method in class org.redisson.misc.PubSubConnectionPoll
-
- getName() - Method in interface org.redisson.api.RObjectReactive
-
- getName() - Method in class org.redisson.client.protocol.RedisCommand
-
- getName() - Method in interface org.redisson.core.RObject
-
Returns name of object
- 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.spring.cache.RedissonCache
-
- getNativeCache() - Method in class org.redisson.spring.cache.RedissonCache
-
- getNodeAddresses() - Method in class org.redisson.ClusterServersConfig
-
- getNodeAddresses() - Method in class org.redisson.ElasticacheServersConfig
-
- getNodeId() - Method in class org.redisson.cluster.ClusterNodeInfo
-
- getNodeId() - Method in class org.redisson.cluster.ClusterPartition
-
- getNodes() - Method in interface org.redisson.core.NodesGroup
-
All Redis nodes used by Redisson.
- getNodes() - Method in class org.redisson.RedisNodes
-
- getNodesGroup() - Method in interface org.redisson.api.RedissonReactiveClient
-
Get Redis nodes group for server operations
- getNodesGroup() - Method in class org.redisson.Redisson
-
- getNodesGroup() - Method in interface org.redisson.RedissonClient
-
Get Redis nodes group for server operations
- getNodesGroup() - Method in class org.redisson.RedissonReactive
-
- getNodeType() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- getNow() - Method in class org.redisson.connection.FastFailedFuture
-
- getNow() - Method in class org.redisson.connection.FastSuccessFuture
-
- getObj() - Method in class org.redisson.client.protocol.decoder.ScanObjectEntry
-
- getOutParamType() - Method in class org.redisson.client.protocol.RedisCommand
-
- getParams() - Method in class org.redisson.client.protocol.CommandData
-
- getParams() - Method in class org.redisson.command.AsyncDetails
-
- 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.RPatternTopicReactive
-
Get topic channel patterns
- getPatternNames() - Method in interface org.redisson.core.RPatternTopic
-
Get topic channel patterns
- getPatternNames() - Method in class org.redisson.reactive.RedissonPatternTopicReactive
-
- getPatternNames() - Method in class org.redisson.RedissonPatternTopic
-
- 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 class org.redisson.Redisson
-
- getPatternTopic(String, Codec) - Method in class org.redisson.Redisson
-
- getPatternTopic(String) - Method in interface org.redisson.RedissonClient
-
Returns topic instance satisfies by pattern name.
- getPatternTopic(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns topic instance satisfies by pattern name
using provided codec for messages.
- getPatternTopic(String) - Method in class org.redisson.RedissonReactive
-
- getPatternTopic(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getPos() - Method in class org.redisson.client.protocol.decoder.ListScanResult
-
- getPos() - Method in class org.redisson.client.protocol.decoder.MapScanResult
-
- getPromise() - Method in class org.redisson.client.protocol.CommandData
-
- getPromise() - Method in class org.redisson.client.protocol.CommandsData
-
- getPromise() - Method in interface org.redisson.PubSubEntry
-
- getPromise() - Method in class org.redisson.RedissonCountDownLatchEntry
-
- getPromise() - Method in class org.redisson.RedissonLockEntry
-
- getPubSubEntry(String) - Method in interface org.redisson.connection.ConnectionManager
-
- getPubSubEntry(String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- 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.RBatchReactive
-
Returns queue instance by name.
- getQueue(String, Codec) - Method in interface org.redisson.api.RBatchReactive
-
- 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.core.RBatch
-
Returns queue instance by name.
- getQueue(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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 interface org.redisson.RedissonClient
-
Returns queue instance by name.
- getQueue(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns queue instance by name
using provided codec for queue objects.
- getQueue(String) - Method in class org.redisson.RedissonReactive
-
- getQueue(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getReadWriteLock(String) - Method in class org.redisson.Redisson
-
- getReadWriteLock(String) - Method in interface org.redisson.RedissonClient
-
Returns readWriteLock instance by name.
- getReconnectListener() - Method in class org.redisson.client.RedisConnection
-
- 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 interface org.redisson.RedisClientResult
-
- getReplayDecoder() - Method in class org.redisson.client.protocol.RedisCommand
-
- getReplayMultiDecoder() - Method in class org.redisson.client.protocol.RedisCommand
-
- getRespParts() - Method in class org.redisson.client.handler.State
-
- getScanInterval() - Method in class org.redisson.ClusterServersConfig
-
- getScanInterval() - Method in class org.redisson.ElasticacheServersConfig
-
- getScore(V) - Method in interface org.redisson.api.RScoredSortedSetReactive
-
- getScore() - Method in class org.redisson.client.protocol.ScoredEntry
-
- getScore(V) - Method in interface org.redisson.core.RScoredSortedSet
-
- getScore(V) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
-
- getScore(V) - Method in class org.redisson.RedissonScoredSortedSet
-
- getScoreAsync(V) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- getScoreAsync(V) - Method in class org.redisson.RedissonScoredSortedSet
-
- 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.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.core.RBatch
-
Returns Redis Sorted Set instance by name
- getScoredSortedSet(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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 interface org.redisson.RedissonClient
-
Returns Redis Sorted Set instance by name.
- getScoredSortedSet(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns Redis Sorted Set instance by name
using provided codec for sorted set objects.
- getScoredSortedSet(String) - Method in class org.redisson.RedissonReactive
-
- getScoredSortedSet(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getScript() - Method in interface org.redisson.api.RBatchReactive
-
Returns script operations object
- getScript() - Method in interface org.redisson.api.RedissonReactiveClient
-
Returns script operations object
- getScript() - Method in interface org.redisson.core.RBatch
-
Returns script operations object
- getScript() - Method in class org.redisson.reactive.RedissonBatchReactive
-
- getScript() - Method in class org.redisson.Redisson
-
- getScript() - Method in class org.redisson.RedissonBatch
-
- getScript() - Method in interface org.redisson.RedissonClient
-
Returns script operations object
- getScript() - Method in class org.redisson.RedissonReactive
-
- getSemaphore(String) - Method in class org.redisson.Redisson
-
- getSemaphore(String) - Method in interface org.redisson.RedissonClient
-
Returns semaphore instance by name
- getSentinelAddresses() - Method in class org.redisson.SentinelServersConfig
-
- 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.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 - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- getSet(String) - Method in interface org.redisson.core.RBatch
-
Returns set instance by name.
- getSet(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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.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 interface org.redisson.RedissonClient
-
Returns set instance by name.
- getSet(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns set instance by name
using provided codec for set objects.
- getSet(String) - Method in class org.redisson.RedissonReactive
-
- getSet(String, Codec) - Method in class org.redisson.RedissonReactive
-
- 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.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.core.RBatch
-
Returns set-based cache instance by name
.
- getSetCache(String, Codec) - Method in interface org.redisson.core.RBatch
-
Returns set-based cache instance by name
using provided codec
for values.
- 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.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 interface org.redisson.RedissonClient
-
Returns set-based cache instance by name
.
- getSetCache(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns set-based cache instance by name
.
- getSetCache(String) - Method in class org.redisson.RedissonReactive
-
- getSetCache(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getShutdownLatch() - Method in interface org.redisson.connection.ConnectionManager
-
- getShutdownLatch() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getSize() - Method in class org.redisson.client.handler.State
-
- getSize() - Method in class org.redisson.client.protocol.decoder.ListIteratorResult
-
- getSize() - Method in interface org.redisson.core.RBloomFilter
-
- getSize() - Method in class org.redisson.RedissonBloomFilter
-
- getSlaveAddresses() - Method in class org.redisson.cluster.ClusterPartition
-
- getSlaveAddresses() - Method in class org.redisson.MasterSlaveServersConfig
-
- getSlaveConnectionMinimumIdleSize() - Method in class org.redisson.BaseMasterSlaveServersConfig
-
- getSlaveConnectionPoolSize() - Method in class org.redisson.BaseMasterSlaveServersConfig
-
- getSlaveOf() - Method in class org.redisson.cluster.ClusterNodeInfo
-
- getSlaveSubscriptionConnectionMinimumIdleSize() - Method in class org.redisson.BaseMasterSlaveServersConfig
-
- getSlaveSubscriptionConnectionPoolSize() - Method in class org.redisson.BaseMasterSlaveServersConfig
-
- getSlot(String) - Method in interface org.redisson.api.RKeysReactive
-
Get hash slot identifier for key.
- getSlot() - Method in class org.redisson.connection.NodeSource
-
- getSlot(String) - Method in interface org.redisson.core.RKeys
-
Get hash slot identifier for key.
- getSlot(String) - Method in class org.redisson.reactive.RedissonKeysReactive
-
- getSlot(String) - Method in class org.redisson.RedissonKeys
-
- getSlotAsync(String) - Method in interface org.redisson.core.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
-
- getSlotRanges() - Method in class org.redisson.connection.MasterSlaveEntry
-
- getSortedSet(String) - Method in class org.redisson.Redisson
-
- getSortedSet(String, Codec) - Method in class org.redisson.Redisson
-
- getSortedSet(String) - Method in interface org.redisson.RedissonClient
-
Returns sorted set instance by name.
- getSortedSet(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns sorted set instance by name
using provided codec for sorted set objects.
- getSource() - Method in class org.redisson.command.AsyncDetails
-
- getStartSlot() - Method in class org.redisson.cluster.ClusterSlotRange
-
- getSubName() - Method in class org.redisson.client.protocol.RedisCommand
-
- getSubscriptionConnectionMinimumIdleSize() - Method in class org.redisson.SingleServerConfig
-
- getSubscriptionConnectionPoolSize() - Method in class org.redisson.SingleServerConfig
-
- getThreads() - Method in class org.redisson.Config
-
- getTimeout() - Method in class org.redisson.command.AsyncDetails
-
- 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.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.core.RBatch
-
Returns topic instance by name.
- getTopic(String, Codec) - Method in interface org.redisson.core.RBatch
-
- 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 interface org.redisson.RedissonClient
-
Returns topic instance by name.
- getTopic(String, Codec) - Method in interface org.redisson.RedissonClient
-
Returns topic instance by name
using provided codec for messages.
- getTopic(String) - Method in class org.redisson.RedissonReactive
-
- getTopic(String, Codec) - Method in class org.redisson.RedissonReactive
-
- getType() - Method in class org.redisson.client.protocol.pubsub.PubSubStatusMessage
-
- 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() - Method in class org.redisson.RedissonMapEntry
-
- getValue() - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
-
- 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.ScanCodec
-
- getValueDecoder() - Method in class org.redisson.client.codec.StringCodec
-
- getValueDecoder() - Method in class org.redisson.codec.FstCodec
-
- getValueDecoder() - Method in class org.redisson.codec.JsonJacksonCodec
-
- getValueDecoder() - Method in class org.redisson.codec.KryoCodec
-
- getValueDecoder() - Method in class org.redisson.codec.LZ4Codec
-
- getValueDecoder() - Method in class org.redisson.codec.SerializationCodec
-
- getValueDecoder() - Method in class org.redisson.codec.SnappyCodec
-
- 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.ScanCodec
-
- getValueEncoder() - Method in class org.redisson.client.codec.ScoredCodec
-
- getValueEncoder() - Method in class org.redisson.client.codec.StringCodec
-
- getValueEncoder() - Method in class org.redisson.codec.FstCodec
-
- getValueEncoder() - Method in class org.redisson.codec.JsonJacksonCodec
-
- getValueEncoder() - Method in class org.redisson.codec.KryoCodec
-
- getValueEncoder() - Method in class org.redisson.codec.LZ4Codec
-
- getValueEncoder() - Method in class org.redisson.codec.SerializationCodec
-
- getValueEncoder() - Method in class org.redisson.codec.SnappyCodec
-
- getValues() - Method in class org.redisson.client.protocol.decoder.ListScanResult
-
- getWriteFuture() - Method in class org.redisson.command.AsyncDetails
-
- group - Variable in class org.redisson.connection.MasterSlaveConnectionManager
-
- RANDOM_KEY - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- randomKey() - Method in interface org.redisson.api.RKeysReactive
-
Get random key
Uses RANDOM_KEY
Redis command.
- randomKey() - Method in interface org.redisson.core.RKeys
-
Get random key
- randomKey() - Method in class org.redisson.reactive.RedissonKeysReactive
-
- randomKey() - Method in class org.redisson.RedissonKeys
-
- randomKeyAsync() - Method in interface org.redisson.core.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
-
- rank(String) - Method in interface org.redisson.api.RLexSortedSetReactive
-
- rank(V) - Method in interface org.redisson.api.RScoredSortedSetReactive
-
- rank(String) - Method in interface org.redisson.core.RLexSortedSet
-
- rank(V) - Method in interface org.redisson.core.RScoredSortedSet
-
- rank(V) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
-
- rank(V) - Method in class org.redisson.RedissonScoredSortedSet
-
- rankAsync(String) - Method in interface org.redisson.core.RLexSortedSetAsync
-
- rankAsync(V) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- rankAsync(V) - Method in class org.redisson.RedissonScoredSortedSet
-
- RAtomicDouble - Interface in org.redisson.core
-
Distributed alternative to the AtomicDouble
- RAtomicDoubleAsync - Interface in org.redisson.core
-
- RAtomicLong - Interface in org.redisson.core
-
- RAtomicLongAsync - Interface in org.redisson.core
-
- RAtomicLongReactive - Interface in org.redisson.api
-
- RBatch - Interface in org.redisson.core
-
Interface for using pipeline feature.
- RBatchReactive - Interface in org.redisson.api
-
Interface for using pipeline feature.
- RBitSet - Interface in org.redisson.core
-
- RBitSetAsync - Interface in org.redisson.core
-
- RBitSetReactive - Interface in org.redisson.api
-
- RBlockingDeque<V> - Interface in org.redisson.core
-
- RBlockingDequeAsync<V> - Interface in org.redisson.core
-
- RBlockingQueue<V> - Interface in org.redisson.core
-
- RBlockingQueueAsync<V> - Interface in org.redisson.core
-
- RBlockingQueueReactive<V> - Interface in org.redisson.api
-
- RBloomFilter<T> - Interface in org.redisson.core
-
Bloom filter based on 64-bit hash derived from 128-bit hash (xxHash + FarmHash).
- RBucket<V> - Interface in org.redisson.core
-
Any object holder
- RBucketAsync<V> - Interface in org.redisson.core
-
Async object functions
- RBucketReactive<V> - Interface in org.redisson.api
-
object functions
- RCollectionAsync<V> - Interface in org.redisson.core
-
- RCollectionReactive<V> - Interface in org.redisson.api
-
- RCountDownLatch - Interface in org.redisson.core
-
- RDeque<V> - Interface in org.redisson.core
-
- RDequeAsync<V> - Interface in org.redisson.core
-
- RDequeReactive<V> - Interface in org.redisson.api
-
- read(String, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandSyncExecutor
-
- read(String, Codec, SyncOperation<R>) - Method in interface org.redisson.command.CommandSyncExecutor
-
- read(String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandSyncExecutor
-
- read(InetSocketAddress, String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandSyncExecutor
-
- read(InetSocketAddress, String, 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(InetSocketAddress, String, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandSyncService
-
- read(InetSocketAddress, String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandSyncService
-
- read(String, Codec, SyncOperation<R>) - Method in class org.redisson.command.CommandSyncService
-
- readAllAsync(RedisCommand<T>, SlotCallback<T, R>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
-
- readAllAsync(RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
-
- readAllAsync(RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
-
- readAllAsync(RedisCommand<T>, SlotCallback<T, R>, Object...) - Method in class org.redisson.command.CommandAsyncService
-
- readAllReactive(RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandReactiveExecutor
-
- readAllReactive(RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandReactiveService
-
- readAsync(InetSocketAddress, String, 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(InetSocketAddress, String, 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(String, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
-
- readBytes(ByteBuf) - Method in class org.redisson.client.handler.CommandDecoder
-
- readLock() - Method in interface org.redisson.core.RReadWriteLock
-
Returns the lock used for reading.
- readLock() - Method in class org.redisson.RedissonReadWriteLock
-
- readLong(ByteBuf) - Static method in class org.redisson.client.handler.CommandDecoder
-
- READONLY - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- readRandomAsync(RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandAsyncExecutor
-
- readRandomAsync(RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandAsyncService
-
- readRandomReactive(RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandReactiveExecutor
-
- readRandomReactive(RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandReactiveService
-
- readReactive(InetSocketAddress, String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandReactiveExecutor
-
- readReactive(String, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandReactiveExecutor
-
- readReactive(String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.command.CommandReactiveExecutor
-
- readReactive(InetSocketAddress, String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandReactiveService
-
- readReactive(String, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandReactiveService
-
- readReactive(String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.command.CommandReactiveService
-
- ReclosableLatch - Class in org.redisson.misc
-
- ReclosableLatch() - Constructor for class org.redisson.misc.ReclosableLatch
-
- ReclosableLatch(boolean) - Constructor for class org.redisson.misc.ReclosableLatch
-
- ReconnectListener - Interface in org.redisson.client
-
- RedisAskException - Exception in org.redisson.client
-
- RedisAskException(int, String) - Constructor for exception org.redisson.client.RedisAskException
-
- RedisClient - Class in org.redisson.client
-
- RedisClient(String, int) - Constructor for class org.redisson.client.RedisClient
-
- RedisClient(EventLoopGroup, Class<? extends SocketChannel>, String, int, int) - Constructor for class org.redisson.client.RedisClient
-
- RedisClientEntry - Class in org.redisson.connection
-
- RedisClientEntry(RedisClient, ConnectionManager) - Constructor for class org.redisson.connection.RedisClientEntry
-
- RedisClientResult - Interface in org.redisson
-
- 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(String) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, int, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, RedisCommand.ValueType, RedisCommand.ValueType) - 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, String, int) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, int) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Convertor<R>, int, RedisCommand.ValueType, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, int, RedisCommand.ValueType, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, int, List<RedisCommand.ValueType>, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Decoder<R>, int, List<RedisCommand.ValueType>, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Decoder<R>, int, List<RedisCommand.ValueType>) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Convertor<R>, int, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Convertor<R>, int, List<RedisCommand.ValueType>) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Convertor<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Convertor<R>, int) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Decoder<R>) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Decoder<R>, int, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, Decoder<R>, int) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, String, MultiDecoder<R>, RedisCommand.ValueType) - 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>, int, RedisCommand.ValueType, 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(String, MultiDecoder<R>, Convertor<R>, int) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, MultiDecoder<R>, int, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, MultiDecoder<R>, int) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, String, MultiDecoder<R>, int) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand(String, String, MultiDecoder<R>, Decoder<R>, int) - Constructor for class org.redisson.client.protocol.RedisCommand
-
- RedisCommand.ValueType - Enum in org.redisson.client.protocol
-
- RedisCommands - Interface in org.redisson.client.protocol
-
- RedisConnection - Class in org.redisson.client
-
- RedisConnection(RedisClient, Channel) - 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
-
- 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
-
- RedisLoadingException - Exception in org.redisson.client
-
- RedisLoadingException(String) - Constructor for exception org.redisson.client.RedisLoadingException
-
- RedisMovedException - Exception in org.redisson.client
-
- RedisMovedException(int, String) - Constructor for exception org.redisson.client.RedisMovedException
-
- RedisNodeNotFoundException - Exception in org.redisson.client
-
- RedisNodeNotFoundException(String) - Constructor for exception org.redisson.client.RedisNodeNotFoundException
-
- RedisNodes<N extends Node> - Class in org.redisson
-
- RedisNodes(ConnectionManager) - Constructor for class org.redisson.RedisNodes
-
- RedisPubSubConnection - Class in org.redisson.client
-
- RedisPubSubConnection(RedisClient, Channel) - Constructor for class org.redisson.client.RedisPubSubConnection
-
- RedisPubSubListener<V> - Interface in org.redisson.client
-
- Redisson - Class in org.redisson
-
Main infrastructure class allows to get access
to all Redisson objects on top of Redis server.
- RedissonAtomicDouble - Class in org.redisson
-
- RedissonAtomicDouble(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonAtomicDouble
-
- RedissonAtomicLong - Class in org.redisson
-
- RedissonAtomicLong(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonAtomicLong
-
- RedissonAtomicLongReactive - Class in org.redisson.reactive
-
- RedissonAtomicLongReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonAtomicLongReactive
-
- RedissonBatch - Class in org.redisson
-
- RedissonBatch(EvictionScheduler, ConnectionManager) - Constructor for class org.redisson.RedissonBatch
-
- RedissonBatchReactive - Class in org.redisson.reactive
-
- RedissonBatchReactive(EvictionScheduler, ConnectionManager) - Constructor for class org.redisson.reactive.RedissonBatchReactive
-
- RedissonBitSet - Class in org.redisson
-
- RedissonBitSet(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonBitSet
-
- RedissonBitSetReactive - Class in org.redisson.reactive
-
- RedissonBitSetReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonBitSetReactive
-
- RedissonBlockingDeque<V> - Class in org.redisson
-
- RedissonBlockingDeque(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonBlockingDeque
-
- RedissonBlockingDeque(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonBlockingDeque
-
- RedissonBlockingQueue<V> - Class in org.redisson
-
- RedissonBlockingQueue(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonBlockingQueue
-
- RedissonBlockingQueue(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonBlockingQueue
-
- RedissonBlockingQueueReactive<V> - Class in org.redisson.reactive
-
- RedissonBlockingQueueReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonBlockingQueueReactive
-
- RedissonBlockingQueueReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonBlockingQueueReactive
-
- RedissonBloomFilter<T> - Class in org.redisson
-
Bloom filter based on 64-bit hash derived from 128-bit hash (xxHash 64-bit + FarmHash 64-bit).
- RedissonBloomFilter(CommandExecutor, String) - Constructor for class org.redisson.RedissonBloomFilter
-
- RedissonBloomFilter(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonBloomFilter
-
- 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
-
- RedissonBucketReactive<V> - Class in org.redisson.reactive
-
- RedissonBucketReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonBucketReactive
-
- RedissonBucketReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonBucketReactive
-
- RedissonCache - Class in org.redisson.spring.cache
-
- RedissonCache(RMap<Object, Object>) - Constructor for class org.redisson.spring.cache.RedissonCache
-
- RedissonCacheManager - Class in org.redisson.spring.cache
-
- RedissonCacheManager() - Constructor for class org.redisson.spring.cache.RedissonCacheManager
-
- RedissonCacheManager(RedissonClient) - Constructor for class org.redisson.spring.cache.RedissonCacheManager
-
- RedissonClient - Interface in org.redisson
-
Main Redisson interface for access
to all redisson objects with sync/async interface.
- RedissonCountDownLatch - Class in org.redisson
-
- RedissonCountDownLatch(CommandAsyncExecutor, String, UUID) - Constructor for class org.redisson.RedissonCountDownLatch
-
- RedissonCountDownLatchEntry - Class in org.redisson
-
- RedissonCountDownLatchEntry(Promise<RedissonCountDownLatchEntry>) - Constructor for class org.redisson.RedissonCountDownLatchEntry
-
- RedissonDeque<V> - Class in org.redisson
-
Distributed and concurrent implementation of
Queue
- RedissonDeque(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonDeque
-
- RedissonDeque(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonDeque
-
- RedissonDequeReactive<V> - Class in org.redisson.reactive
-
Distributed and concurrent implementation of
Queue
- RedissonDequeReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonDequeReactive
-
- RedissonDequeReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonDequeReactive
-
- 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
-
- RedissonHyperLogLogReactive<V> - Class in org.redisson.reactive
-
- RedissonHyperLogLogReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonHyperLogLogReactive
-
- RedissonHyperLogLogReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonHyperLogLogReactive
-
- RedissonKeys - Class in org.redisson
-
- RedissonKeys(CommandAsyncExecutor) - Constructor for class org.redisson.RedissonKeys
-
- RedissonKeysReactive - Class in org.redisson.reactive
-
- RedissonKeysReactive(CommandReactiveService) - Constructor for class org.redisson.reactive.RedissonKeysReactive
-
- RedissonLexSortedSet - Class in org.redisson
-
- RedissonLexSortedSet(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonLexSortedSet
-
- RedissonLexSortedSetReactive - Class in org.redisson.reactive
-
- RedissonLexSortedSetReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonLexSortedSetReactive
-
- RedissonList<V> - Class in org.redisson
-
Distributed and concurrent implementation of
List
- RedissonList(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonList
-
- RedissonList(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonList
-
- RedissonListReactive<V> - Class in org.redisson.reactive
-
Distributed and concurrent implementation of
List
- RedissonListReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonListReactive
-
- RedissonListReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonListReactive
-
- RedissonLock - Class in org.redisson
-
Distributed implementation of
Lock
Implements reentrant lock.
- RedissonLock(CommandExecutor, String, UUID) - Constructor for class org.redisson.RedissonLock
-
- RedissonLockEntry - Class in org.redisson
-
- RedissonLockEntry(Promise<RedissonLockEntry>) - Constructor for class org.redisson.RedissonLockEntry
-
- RedissonMap<K,V> - Class in org.redisson
-
- RedissonMap(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonMap
-
- RedissonMap(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonMap
-
- RedissonMapCache<K,V> - Class in org.redisson
-
- RedissonMapCache(EvictionScheduler, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonMapCache
-
- RedissonMapCache(Codec, EvictionScheduler, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonMapCache
-
- RedissonMapCacheReactive<K,V> - Class in org.redisson.reactive
-
- RedissonMapCacheReactive(EvictionScheduler, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonMapCacheReactive
-
- RedissonMapCacheReactive(Codec, EvictionScheduler, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonMapCacheReactive
-
- RedissonMapEntry<K,V> - Class in org.redisson
-
- RedissonMapEntry(K, V) - Constructor for class org.redisson.RedissonMapEntry
-
- RedissonMapIterator<K,V,M> - Class in org.redisson
-
- RedissonMapIterator(RedissonMap<K, V>) - Constructor for class org.redisson.RedissonMapIterator
-
- RedissonMapReactive<K,V> - Class in org.redisson.reactive
-
- RedissonMapReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonMapReactive
-
- RedissonMapReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonMapReactive
-
- RedissonMapReactiveIterator<K,V,M> - Class in org.redisson.reactive
-
- RedissonMapReactiveIterator(RedissonMapReactive<K, V>) - Constructor for class org.redisson.reactive.RedissonMapReactiveIterator
-
- RedissonPatternTopic<M> - Class in org.redisson
-
Distributed topic implementation.
- RedissonPatternTopic(CommandExecutor, String) - Constructor for class org.redisson.RedissonPatternTopic
-
- RedissonPatternTopic(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonPatternTopic
-
- RedissonPatternTopicReactive<M> - Class in org.redisson.reactive
-
Distributed topic implementation.
- RedissonPatternTopicReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonPatternTopicReactive
-
- RedissonPatternTopicReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonPatternTopicReactive
-
- RedissonQueue<V> - Class in org.redisson
-
Distributed and concurrent implementation of
Queue
- RedissonQueue(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonQueue
-
- RedissonQueue(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonQueue
-
- RedissonQueueReactive<V> - Class in org.redisson.reactive
-
Distributed and concurrent implementation of
Queue
- RedissonQueueReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonQueueReactive
-
- RedissonQueueReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonQueueReactive
-
- RedissonReactive - Class in org.redisson
-
Main infrastructure class allows to get access
to all Redisson objects on top of Redis server.
- RedissonReactiveClient - Interface in org.redisson.api
-
Main Redisson interface for access
to all redisson objects with reactive interface.
- RedissonReadLock - Class in org.redisson
-
Lock will be removed automatically if client disconnects.
- RedissonReadLock(CommandExecutor, String, UUID) - 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.
- RedissonScoredSortedSet<V> - Class in org.redisson
-
- RedissonScoredSortedSet(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonScoredSortedSet
-
- RedissonScoredSortedSet(Codec, CommandAsyncExecutor, String) - 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
-
- RedissonScript - Class in org.redisson
-
- RedissonScript(CommandAsyncExecutor) - Constructor for class org.redisson.RedissonScript
-
- RedissonScriptReactive - Class in org.redisson.reactive
-
- RedissonScriptReactive(CommandReactiveExecutor) - Constructor for class org.redisson.reactive.RedissonScriptReactive
-
- RedissonSemaphore - Class in org.redisson
-
Distributed and concurrent implementation of
Semaphore
.
- RedissonSemaphore(CommandExecutor, String, UUID) - Constructor for class org.redisson.RedissonSemaphore
-
- RedissonSet<V> - Class in org.redisson
-
Distributed and concurrent implementation of
Set
- RedissonSet(CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonSet
-
- RedissonSet(Codec, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonSet
-
- RedissonSetCache<V> - Class in org.redisson
-
Set-based cache with ability to set TTL for each entry via
#put(Object, Object, long, TimeUnit)
method.
- RedissonSetCache(EvictionScheduler, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonSetCache
-
- RedissonSetCache(Codec, EvictionScheduler, CommandAsyncExecutor, String) - Constructor for class org.redisson.RedissonSetCache
-
- RedissonSetCacheReactive<V> - Class in org.redisson.reactive
-
Set-based cache with ability to set TTL for each entry via
#put(Object, Object, long, TimeUnit)
method.
- RedissonSetCacheReactive(EvictionScheduler, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonSetCacheReactive
-
- RedissonSetCacheReactive(Codec, EvictionScheduler, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonSetCacheReactive
-
- RedissonSetReactive<V> - Class in org.redisson.reactive
-
Distributed and concurrent implementation of
Set
- RedissonSetReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonSetReactive
-
- RedissonSetReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonSetReactive
-
- RedissonSortedSet<V> - Class in org.redisson
-
- RedissonSortedSet(CommandExecutor, String) - Constructor for class org.redisson.RedissonSortedSet
-
- RedissonSortedSet(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonSortedSet
-
- RedissonSortedSet.BinarySearchResult<V> - Class in org.redisson
-
- RedissonSortedSet.BinarySearchResult(V) - Constructor for class org.redisson.RedissonSortedSet.BinarySearchResult
-
- RedissonSortedSet.BinarySearchResult() - Constructor for class org.redisson.RedissonSortedSet.BinarySearchResult
-
- RedissonTopic<M> - 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<M> - Class in org.redisson.reactive
-
Distributed topic implementation.
- RedissonTopicReactive(CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonTopicReactive
-
- RedissonTopicReactive(Codec, CommandReactiveExecutor, String) - Constructor for class org.redisson.reactive.RedissonTopicReactive
-
- RedissonWriteLock - Class in org.redisson
-
Lock will be removed automatically if client disconnects.
- RedissonWriteLock(CommandExecutor, String, UUID) - Constructor for class org.redisson.RedissonWriteLock
-
- RedisStrictCommand<T> - Class in org.redisson.client.protocol
-
- RedisStrictCommand(String, int, RedisCommand.ValueType) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
-
- RedisStrictCommand(String, int) - Constructor for class org.redisson.client.protocol.RedisStrictCommand
-
- 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, Convertor<T>, int) - 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
-
- release(AsyncDetails) - Static method in class org.redisson.command.AsyncDetails
-
- release() - Method in class org.redisson.connection.PubSubConnectionEntry
-
- release() - Method in interface org.redisson.core.RSemaphore
-
Releases a permit, returning it to the semaphore.
- release(int) - Method in interface org.redisson.core.RSemaphore
-
Releases the given number of permits, returning them to the semaphore.
- release() - Method in class org.redisson.misc.InfinitySemaphoreLatch
-
- release() - Method in interface org.redisson.PubSubEntry
-
- release() - Method in class org.redisson.RedissonCountDownLatchEntry
-
- release() - Method in class org.redisson.RedissonLockEntry
-
- release() - Method in class org.redisson.RedissonSemaphore
-
- release(int) - Method in class org.redisson.RedissonSemaphore
-
- releaseConnection(NodeSource, Future<RedisConnection>, boolean, Promise<R>, AsyncDetails<V, R>) - Method in class org.redisson.command.CommandAsyncService
-
- releaseConnection() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- releaseConnection(RedisConnection) - Method in class org.redisson.connection.ClientConnectionsEntry
-
- releaseConnection(ClientConnectionsEntry) - Method in class org.redisson.misc.ConnectionPool
-
- releaseConnection(ClientConnectionsEntry, T) - Method in class org.redisson.misc.ConnectionPool
-
- releaseConnection(ClientConnectionsEntry) - Method in class org.redisson.misc.PubSubConnectionPoll
-
- releaseConnection(ClientConnectionsEntry, RedisPubSubConnection) - Method in class org.redisson.misc.PubSubConnectionPoll
-
- 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
-
- releaseSubscribeConnection(int, PubSubConnectionEntry) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- 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 class org.redisson.RedissonBlockingDeque
-
- remainingCapacity() - Method in class org.redisson.RedissonBlockingQueue
-
- remainTimeToLive() - Method in interface org.redisson.api.RExpirableReactive
-
Get remaining time to live of object in milliseconds.
- remainTimeToLive() - Method in interface org.redisson.core.RExpirable
-
Remaining time to live of Redisson object that has a timeout
- remainTimeToLiveAsync() - Method in interface org.redisson.core.RExpirableAsync
-
Get remaining time to live of object in seconds.
- remove(Object) - Method in interface org.redisson.api.RCollectionReactive
-
- remove(int) - Method in interface org.redisson.api.RListReactive
-
- remove(K) - Method in interface org.redisson.api.RMapReactive
-
- remove(Object, Object) - Method in interface org.redisson.api.RMapReactive
-
- remove(V) - Method in interface org.redisson.api.RScoredSortedSetReactive
-
- remove(Object) - Method in interface org.redisson.core.RScoredSortedSet
-
- remove() - Method in class org.redisson.misc.CompositeIterable
-
- remove(ClientConnectionsEntry) - Method in class org.redisson.misc.MasterConnectionPool
-
- remove(Object) - Method in class org.redisson.reactive.RedissonListReactive
-
- remove(Object, int) - Method in class org.redisson.reactive.RedissonListReactive
-
- remove(int) - Method in class org.redisson.reactive.RedissonListReactive
-
- remove(Object, Object) - Method in class org.redisson.reactive.RedissonMapCacheReactive
-
- remove(K) - Method in class org.redisson.reactive.RedissonMapCacheReactive
-
- remove(Object, Object) - Method in class org.redisson.reactive.RedissonMapReactive
-
- remove(K) - Method in class org.redisson.reactive.RedissonMapReactive
-
- remove(Object) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
-
- remove(Object) - Method in class org.redisson.reactive.RedissonSetCacheReactive
-
- remove(Object) - Method in class org.redisson.reactive.RedissonSetReactive
-
- 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.RedissonMap
-
- remove(Object, Object) - Method in class org.redisson.RedissonMap
-
- remove() - Method in class org.redisson.RedissonMapIterator
-
- 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.RedissonSortedSet
-
- removeAll(Collection<?>) - Method in interface org.redisson.api.RCollectionReactive
-
- removeAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetReactive
-
- removeAll(Collection<?>) - Method in interface org.redisson.core.RScoredSortedSet
-
- removeAll(Collection<?>) - Method in class org.redisson.reactive.RedissonListReactive
-
- removeAll(Collection<?>) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
-
- removeAll(Collection<?>) - Method in class org.redisson.reactive.RedissonSetCacheReactive
-
- removeAll(Collection<?>) - Method in class org.redisson.reactive.RedissonSetReactive
-
- removeAll(Collection<?>) - Method in class org.redisson.RedissonList
-
- 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(Collection<?>) - Method in class org.redisson.RedissonSortedSet
-
- removeAllAsync(Collection<?>) - Method in interface org.redisson.core.RCollectionAsync
-
- removeAllAsync(Collection<?>) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonList
-
- removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonScoredSortedSet
-
- removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonSet
-
- removeAllAsync(Collection<?>) - Method in class org.redisson.RedissonSetCache
-
- removeAsync(Object) - Method in interface org.redisson.core.RCollectionAsync
-
- removeAsync(K) - Method in interface org.redisson.core.RMapAsync
-
- removeAsync(Object, Object) - Method in interface org.redisson.core.RMapAsync
-
- removeAsync(V) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- removeAsync(V) - Method in interface org.redisson.core.RSortedSet
-
- removeAsync(Object) - Method in class org.redisson.RedissonList
-
- removeAsync(Object, int) - Method in class org.redisson.RedissonList
-
- removeAsync(Object, Object) - Method in class org.redisson.RedissonMap
-
- removeAsync(K) - Method in class org.redisson.RedissonMap
-
- removeAsync(Object, Object) - Method in class org.redisson.RedissonMapCache
-
- removeAsync(K) - Method in class org.redisson.RedissonMapCache
-
- 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(V) - Method in class org.redisson.RedissonSortedSet
-
- removeConnectionListener(int) - Method in interface org.redisson.core.NodesGroup
-
Removes connect listener by id
- removeConnectionListener(int) - Method in class org.redisson.RedisNodes
-
- removeFirst() - Method in interface org.redisson.api.RDequeReactive
-
- removeFirst() - Method in class org.redisson.reactive.RedissonDequeReactive
-
- removeFirst() - Method in class org.redisson.RedissonQueue
-
- removeFirstAsync() - Method in interface org.redisson.core.RDequeAsync
-
- removeFirstAsync() - Method in class org.redisson.RedissonDeque
-
- removeFirstOccurrence(Object) - Method in interface org.redisson.api.RDequeReactive
-
- removeFirstOccurrence(Object) - Method in class org.redisson.reactive.RedissonDequeReactive
-
- removeFirstOccurrence(Object) - Method in class org.redisson.RedissonDeque
-
- removeFirstOccurrenceAsync(Object) - Method in interface org.redisson.core.RDequeAsync
-
- removeFirstOccurrenceAsync(Object) - Method in class org.redisson.RedissonDeque
-
- removeLast() - Method in interface org.redisson.api.RDequeReactive
-
- removeLast() - Method in class org.redisson.reactive.RedissonDequeReactive
-
- removeLast() - Method in class org.redisson.RedissonDeque
-
- removeLastAsync() - Method in interface org.redisson.core.RDequeAsync
-
- removeLastAsync() - Method in class org.redisson.RedissonDeque
-
- removeLastOccurrence(Object) - Method in interface org.redisson.api.RDequeReactive
-
- removeLastOccurrence(Object) - Method in class org.redisson.reactive.RedissonDequeReactive
-
- removeLastOccurrence(Object) - Method in class org.redisson.RedissonDeque
-
- removeLastOccurrenceAsync(Object) - Method in interface org.redisson.core.RDequeAsync
-
- removeLastOccurrenceAsync(Object) - Method in class org.redisson.RedissonDeque
-
- 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.RTopicReactive
-
- removeListener(RedisPubSubListener<?>) - Method in class org.redisson.client.RedisPubSubConnection
-
- removeListener(int) - Method in class org.redisson.connection.ConnectionEventsHub
-
- removeListener(String, int) - Method in class org.redisson.connection.PubSubConnectionEntry
-
- removeListener(int) - Method in interface org.redisson.core.RPatternTopic
-
Removes the listener by id
for listening this topic
- removeListener(int) - Method in interface org.redisson.core.RTopic
-
Removes the listener by id
for listening this topic
- removeListener(int) - Method in class org.redisson.reactive.RedissonPatternTopicReactive
-
- removeListener(int) - Method in class org.redisson.reactive.RedissonTopicReactive
-
- removeListener(int) - Method in class org.redisson.RedissonPatternTopic
-
- removeListener(int) - Method in class org.redisson.RedissonTopic
-
- removeMaster(ClusterSlotRange) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- removeRandom() - Method in interface org.redisson.api.RSetReactive
-
Removes and returns random element from set
in async mode
- removeRandom() - Method in interface org.redisson.core.RSet
-
Removes and returns random element from set
- removeRandom() - Method in class org.redisson.reactive.RedissonSetReactive
-
- removeRandom() - Method in class org.redisson.RedissonSet
-
- removeRandomAsync() - Method in interface org.redisson.core.RSetAsync
-
Removes and returns random element from set
in async mode
- removeRandomAsync() - Method in class org.redisson.RedissonSet
-
- removeRangeByLex(String, boolean, String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
-
- removeRangeByLex(String, boolean, String, boolean) - Method in interface org.redisson.core.RLexSortedSet
-
- removeRangeByLex(String, boolean, String, boolean) - Method in class org.redisson.reactive.RedissonLexSortedSetReactive
-
- removeRangeByLex(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
-
- removeRangeByLexAsync(String, boolean, String, boolean) - Method in interface org.redisson.core.RLexSortedSetAsync
-
- removeRangeByLexAsync(String, boolean, String, boolean) - Method in class org.redisson.RedissonLexSortedSet
-
- removeRangeByRank(int, int) - Method in interface org.redisson.api.RScoredSortedSetReactive
-
- removeRangeByRank(int, int) - Method in interface org.redisson.core.RScoredSortedSet
-
- removeRangeByRank(int, int) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
-
- removeRangeByRank(int, int) - Method in class org.redisson.RedissonScoredSortedSet
-
- removeRangeByRankAsync(int, int) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- removeRangeByRankAsync(int, int) - Method in class org.redisson.RedissonScoredSortedSet
-
- removeRangeByScore(double, boolean, double, boolean) - Method in interface org.redisson.api.RScoredSortedSetReactive
-
- removeRangeByScore(double, boolean, double, boolean) - Method in interface org.redisson.core.RScoredSortedSet
-
- removeRangeByScore(double, boolean, double, boolean) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
-
- removeRangeByScore(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
-
- removeRangeByScoreAsync(double, boolean, double, boolean) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- removeRangeByScoreAsync(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
-
- removeRangeHeadByLex(String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
-
- removeRangeHeadByLex(String, boolean) - Method in interface org.redisson.core.RLexSortedSet
-
- removeRangeHeadByLex(String, boolean) - Method in class org.redisson.reactive.RedissonLexSortedSetReactive
-
- removeRangeHeadByLex(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
-
- removeRangeHeadByLexAsync(String, boolean) - Method in interface org.redisson.core.RLexSortedSetAsync
-
- removeRangeHeadByLexAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
-
- removeRangeTailByLex(String, boolean) - Method in interface org.redisson.api.RLexSortedSetReactive
-
- removeRangeTailByLex(String, boolean) - Method in interface org.redisson.core.RLexSortedSet
-
- removeRangeTailByLex(String, boolean) - Method in class org.redisson.reactive.RedissonLexSortedSetReactive
-
- removeRangeTailByLex(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
-
- removeRangeTailByLexAsync(String, boolean) - Method in interface org.redisson.core.RLexSortedSetAsync
-
- removeRangeTailByLexAsync(String, boolean) - Method in class org.redisson.RedissonLexSortedSet
-
- removeSlaveAddress(URI) - Method in class org.redisson.cluster.ClusterPartition
-
- removeSlotRange(ClusterSlotRange) - Method in class org.redisson.connection.MasterSlaveEntry
-
- removeSlotRanges(Set<ClusterSlotRange>) - Method in class org.redisson.cluster.ClusterPartition
-
- rename(String) - Method in interface org.redisson.api.RObjectReactive
-
Rename current object key to newName
in mode
- RENAME - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- rename(String) - Method in interface org.redisson.core.RObject
-
Rename current object key to newName
- renameAsync(String) - Method in interface org.redisson.core.RObjectAsync
-
Rename current object key to newName
in async mode
- 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 - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- renamenx(String) - Method in interface org.redisson.core.RObject
-
Rename current object key to newName
only if new key is not exists
- renamenxAsync(String) - Method in interface org.redisson.core.RObjectAsync
-
Rename current object key to newName
in async mode only if new key is not exists
- replace(K, V) - Method in interface org.redisson.api.RMapReactive
-
- replace(K, V, V) - Method in interface org.redisson.api.RMapReactive
-
- replace(K, V, V) - Method in class org.redisson.reactive.RedissonMapReactive
-
- replace(K, V) - Method in class org.redisson.reactive.RedissonMapReactive
-
- replace(K, V, V) - Method in class org.redisson.RedissonMap
-
- replace(K, V) - Method in class org.redisson.RedissonMap
-
- replaceAsync(K, V) - Method in interface org.redisson.core.RMapAsync
-
- replaceAsync(K, V, V) - Method in interface org.redisson.core.RMapAsync
-
- replaceAsync(K, V, V) - Method in class org.redisson.RedissonMap
-
- replaceAsync(K, V) - Method in class org.redisson.RedissonMap
-
- resetFailedAttempts() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- retainAll(Collection<?>) - Method in interface org.redisson.api.RCollectionReactive
-
- retainAll(Collection<?>) - Method in interface org.redisson.api.RScoredSortedSetReactive
-
- retainAll(Collection<?>) - Method in interface org.redisson.core.RScoredSortedSet
-
- retainAll(Collection<?>) - Method in class org.redisson.reactive.RedissonListReactive
-
- retainAll(Collection<?>) - Method in class org.redisson.reactive.RedissonScoredSortedSetReactive
-
- retainAll(Collection<?>) - Method in class org.redisson.reactive.RedissonSetCacheReactive
-
- retainAll(Collection<?>) - Method in class org.redisson.reactive.RedissonSetReactive
-
- retainAll(Collection<?>) - Method in class org.redisson.RedissonList
-
- 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.RedissonSortedSet
-
- retainAllAsync(Collection<?>) - Method in interface org.redisson.core.RCollectionAsync
-
- retainAllAsync(Collection<?>) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonList
-
- retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonScoredSortedSet
-
- retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonSet
-
- retainAllAsync(Collection<?>) - Method in class org.redisson.RedissonSetCache
-
- returnConnection(RedisConnection) - Method in interface org.redisson.connection.balancer.LoadBalancerManager
-
- returnConnection(RedisConnection) - Method in class org.redisson.connection.balancer.LoadBalancerManagerImpl
-
- returnConnection(ClientConnectionsEntry, T) - Method in class org.redisson.misc.ConnectionPool
-
- returnSubscribeConnection(RedisPubSubConnection) - Method in interface org.redisson.connection.balancer.LoadBalancerManager
-
- returnSubscribeConnection(RedisPubSubConnection) - Method in class org.redisson.connection.balancer.LoadBalancerManagerImpl
-
- returnSubscribeConnection(PubSubConnectionEntry) - Method in class org.redisson.connection.MasterSlaveEntry
-
- returnSubscribeConnection(PubSubConnectionEntry) - Method in class org.redisson.connection.SingleEntry
-
- RExpirable - Interface in org.redisson.core
-
Base interface for all Redisson objects
which support expiration or TTL
- RExpirableAsync - Interface in org.redisson.core
-
Base async interface for all Redisson objects
which supports expiration (TTL)
- RExpirableReactive - Interface in org.redisson.api
-
Base interface for all Redisson objects
which support expiration or TTL
- RHyperLogLog<V> - Interface in org.redisson.core
-
- RHyperLogLogAsync<V> - Interface in org.redisson.core
-
- RHyperLogLogReactive<V> - Interface in org.redisson.api
-
- RKeys - Interface in org.redisson.core
-
- RKeysAsync - Interface in org.redisson.core
-
- RKeysReactive - Interface in org.redisson.api
-
- RLexSortedSet - Interface in org.redisson.core
-
- RLexSortedSetAsync - Interface in org.redisson.core
-
- RLexSortedSetReactive - Interface in org.redisson.api
-
- RList<V> - Interface in org.redisson.core
-
Distributed and concurrent implementation of
List
- RListAsync<V> - Interface in org.redisson.core
-
Async list functions
- RListReactive<V> - Interface in org.redisson.api
-
list functions
- RLock - Interface in org.redisson.core
-
Distributed implementation of
Lock
Implements reentrant lock.
- RMap<K,V> - Interface in org.redisson.core
-
Distributed and concurrent implementation of
ConcurrentMap
and
Map
This map doesn't allow to store
null
as key or value.
- RMapAsync<K,V> - Interface in org.redisson.core
-
Async map functions
- RMapCache<K,V> - Interface in org.redisson.core
-
- RMapCacheAsync<K,V> - Interface in org.redisson.core
-
Async interface for map-based cache with ability to set TTL for each entry via
#put(Object, Object, long, TimeUnit)
or #putIfAbsent(Object, Object, long, TimeUnit)
And therefore has an complex lua-scripts inside.
- RMapCacheReactive<K,V> - Interface in org.redisson.api
-
- RMapReactive<K,V> - Interface in org.redisson.api
-
map functions
- RObject - Interface in org.redisson.core
-
Base interface for all Redisson objects
- RObjectAsync - Interface in org.redisson.core
-
Base interface for all Redisson objects
- RObjectReactive - Interface in org.redisson.api
-
Base interface for all Redisson objects
- RoundRobinLoadBalancer - Class in org.redisson.connection.balancer
-
- RoundRobinLoadBalancer() - Constructor for class org.redisson.connection.balancer.RoundRobinLoadBalancer
-
- RPatternTopic<M> - Interface in org.redisson.core
-
Distributed topic.
- RPatternTopicReactive<M> - Interface in org.redisson.api
-
Distributed topic.
- RPOP - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- RPOPLPUSH - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- RPUSH - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- RPUSH_BOOLEAN - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- RQueue<V> - Interface in org.redisson.core
-
- RQueueAsync<V> - Interface in org.redisson.core
-
- RQueueReactive<V> - Interface in org.redisson.api
-
- RReadWriteLock - Interface in org.redisson.core
-
A
ReadWriteLock
maintains a pair of associated
locks
, one for read-only operations and one for writing.
- RScoredSortedSet<V> - Interface in org.redisson.core
-
- RScoredSortedSetAsync<V> - Interface in org.redisson.core
-
- RScoredSortedSetReactive<V> - Interface in org.redisson.api
-
- RScript - Interface in org.redisson.core
-
- RScript.Mode - Enum in org.redisson.core
-
- RScript.ReturnType - Enum in org.redisson.core
-
- RScriptAsync - Interface in org.redisson.core
-
- RScriptReactive - Interface in org.redisson.api
-
- RSemaphore - Interface in org.redisson.core
-
Distributed and concurrent implementation of
Semaphore
.
- RSet<V> - Interface in org.redisson.core
-
Distributed and concurrent implementation of
Set
- RSetAsync<V> - Interface in org.redisson.core
-
Async set functions
- RSetCache<V> - Interface in org.redisson.core
-
Set-based cache with ability to set TTL for each entry via
#put(Object, Object, long, TimeUnit)
method.
- RSetCacheAsync<V> - Interface in org.redisson.core
-
Async set functions
- RSetCacheReactive<V> - Interface in org.redisson.api
-
Async set functions
- RSetReactive<V> - Interface in org.redisson.api
-
Async set functions
- RSortedSet<V> - Interface in org.redisson.core
-
- RTopic<M> - Interface in org.redisson.core
-
Distributed topic.
- RTopicAsync<M> - Interface in org.redisson.core
-
Distributed topic.
- RTopicReactive<M> - Interface in org.redisson.api
-
Distributed topic.
- run() - Method in class org.redisson.EvictionScheduler.RedissonCacheTask
-
- runCleanTask(String, String, long) - Method in class org.redisson.EvictionScheduler
-