- fastPut(K, V) - Method in interface org.redisson.core.RMap
-
Associates the specified value
with the specified key
.
- fastPut(K, V) - Method in class org.redisson.RedissonMap
-
- fastPutAsync(K, V) - Method in interface org.redisson.core.RMapAsync
-
Associates the specified value
with the specified key
in async manner.
- fastPutAsync(K, V) - Method in class org.redisson.RedissonMap
-
- fastRemove(K...) - Method in interface org.redisson.core.RMap
-
Removes keys
from map by one operation
Works faster than RMap.remove
but not returning
the value associated with key
- fastRemove(K...) - Method in class org.redisson.RedissonMap
-
- fastRemoveAsync(K...) - Method in interface org.redisson.core.RMapAsync
-
Removes keys
from map by one operation in async manner
Works faster than RMap.removeAsync
but not returning
the value associated with key
- fastRemoveAsync(K...) - Method in class org.redisson.RedissonMap
-
- fastSet(int, V) - Method in interface org.redisson.core.RList
-
- fastSet(int, V) - Method in class org.redisson.RedissonList
-
- fastSetAsync(int, V) - Method in interface org.redisson.core.RListAsync
-
- fastSetAsync(int, V) - Method in class org.redisson.RedissonList
-
- filterEntries(Predicate<Map.Entry<K, V>>) - Method in interface org.redisson.core.RMap
-
Returns a map slice containing the mappings in whose Map.Entry<K, V> entries
satisfy a predicate.
- filterEntries(Predicate<Map.Entry<K, V>>) - Method in class org.redisson.RedissonMap
-
- filterKeys(Predicate<K>) - Method in interface org.redisson.core.RMap
-
Returns a map slice containing the mappings in whose keys
satisfy a predicate.
- filterKeys(Predicate<K>) - Method in class org.redisson.RedissonMap
-
- filterValues(Predicate<V>) - Method in interface org.redisson.core.RMap
-
Returns a map slice containing the mappings in whose values
satisfy a predicate.
- filterValues(Predicate<V>) - Method in class org.redisson.RedissonMap
-
- findKeysByPattern(String) - Method in interface org.redisson.core.RKeys
-
Find keys by key search pattern
Supported glob-style patterns:
h?
- findKeysByPattern(String) - Method in class org.redisson.Redisson
-
Find keys by key search pattern
Supported glob-style patterns:
h?
- findKeysByPattern(String) - Method in interface org.redisson.RedissonClient
-
Deprecated.
- findKeysByPattern(String) - Method in class org.redisson.RedissonKeys
-
Find keys by key search pattern
Supported glob-style patterns:
h?
- findKeysByPatternAsync(String) - Method in interface org.redisson.core.RKeysAsync
-
Find keys by key search pattern in async mode
Supported glob-style patterns:
h?
- findKeysByPatternAsync(String) - Method in class org.redisson.Redisson
-
Find keys by key search pattern in async mode
Supported glob-style patterns:
h?
- findKeysByPatternAsync(String) - Method in interface org.redisson.RedissonClient
-
Deprecated.
- findKeysByPatternAsync(String) - Method in class org.redisson.RedissonKeys
-
Find keys by key search pattern in async mode
Supported glob-style patterns:
h?
- first() - Method in interface org.redisson.core.RScoredSortedSet
-
- first() - Method in class org.redisson.RedissonScoredSortedSet
-
- first() - Method in class org.redisson.RedissonSortedSet
-
- firstAsync() - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- firstAsync() - Method in class org.redisson.RedissonScoredSortedSet
-
- FLUSHALL - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- flushall() - Method in class org.redisson.Redisson
-
Delete all the keys of all the existing databases
- flushall() - Method in interface org.redisson.RedissonClient
-
Delete all the keys of all the existing databases
- FLUSHDB - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- flushdb() - Method in class org.redisson.Redisson
-
Delete all the keys of the currently selected database
- flushdb() - Method in interface org.redisson.RedissonClient
-
Delete all the keys of the currently selected database
- forceReconnect() - Method in class org.redisson.client.RedisConnection
-
- forceUnlock() - Method in interface org.redisson.core.RLock
-
Unlocks lock independently of state
- forceUnlock() - Method in class org.redisson.RedissonLock
-
- freeze(String, int, ClientConnectionsEntry.FreezeReason) - Method in interface org.redisson.connection.balancer.LoadBalancerManager
-
- freeze(String, int, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.balancer.LoadBalancerManagerImpl
-
- freeze() - Method in class org.redisson.connection.MasterSlaveEntry
-
- freezeMaster(ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.ClientConnectionsEntry
-
- FstCodec - Class in org.redisson.codec
-
Efficient and speedy serialization codec fully
compatible with JDK codec.
- FstCodec() - Constructor for class org.redisson.codec.FstCodec
-
- FstCodec(FSTConfiguration) - Constructor for class org.redisson.codec.FstCodec
-
- FutureConnectionListener<T extends RedisConnection> - Class in org.redisson.connection
-
- FutureConnectionListener(Promise<T>, T) - Constructor for class org.redisson.connection.FutureConnectionListener
-
- 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.CommandExecutor
-
- get(Future<V>) - Method in class org.redisson.CommandExecutorService
-
- get() - Method in interface org.redisson.core.RAtomicLong
-
Gets the current value.
- get(int) - 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.RedissonAtomicLong
-
- get(int) - 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
-
- 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.core.RMap
-
Gets a map slice contains the mappings with defined keys
by one operation.
- getAll(Set<K>) - Method in class org.redisson.RedissonMap
-
- getAllAddresses() - Method in class org.redisson.cluster.ClusterPartition
-
- getAllSubscribeConnections() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- 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.RedissonAtomicLong
-
- getAndAddAsync(long) - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAndAddAsync(long) - Method in class org.redisson.RedissonAtomicLong
-
- getAndDecrement() - Method in interface org.redisson.core.RAtomicLong
-
Atomically decrements by one the current value.
- getAndDecrement() - Method in class org.redisson.RedissonAtomicLong
-
- getAndDecrementAsync() - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAndDecrementAsync() - Method in class org.redisson.RedissonAtomicLong
-
- getAndIncrement() - Method in interface org.redisson.core.RAtomicLong
-
Atomically increments the current value by one.
- getAndIncrement() - Method in class org.redisson.RedissonAtomicLong
-
- getAndIncrementAsync() - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAndIncrementAsync() - Method in class org.redisson.RedissonAtomicLong
-
- getAndSet(long) - Method in interface org.redisson.core.RAtomicLong
-
Atomically sets the given value and returns the old value.
- getAndSet(long) - Method in class org.redisson.RedissonAtomicLong
-
- getAndSetAsync(long) - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAndSetAsync(long) - Method in class org.redisson.RedissonAtomicLong
-
- getAsync() - Method in interface org.redisson.core.RAtomicLongAsync
-
- getAsync(int) - 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.RedissonAtomicLong
-
- getAsync(int) - 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
-
- getAtomicLong(String) - Method in class org.redisson.Redisson
-
Returns distributed "atomic long" instance by name.
- getAtomicLong(String) - Method in interface org.redisson.RedissonClient
-
Returns "atomic long" instance by name.
- getAtomicLongAsync(String) - Method in interface org.redisson.core.RBatch
-
Returns "atomic long" instance by name.
- getAtomicLongAsync(String) - Method in class org.redisson.RedissonBatch
-
- 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.core.RBatch
-
- getBitSet(String) - Method in class org.redisson.Redisson
-
- getBitSet(String) - Method in class org.redisson.RedissonBatch
-
- getBitSet(String) - Method in interface org.redisson.RedissonClient
-
- 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.Redisson
-
Returns distributed blocking queue instance by name.
- 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
-
- getBootstrap() - Method in class org.redisson.client.RedisClient
-
- 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.Redisson
-
Returns object holder by name
- 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 by name
- getBucket(String, Codec) - Method in interface org.redisson.RedissonClient
-
- getBuckets(String) - Method in class org.redisson.Redisson
-
Returns a list of object holder by a key pattern
Supported glob-style patterns:
h?
- getBuckets(String) - Method in interface org.redisson.RedissonClient
-
Returns a list of object holder by a key pattern
- 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.core.RTopic
-
Get topic channel names
- getChannelNames() - Method in class org.redisson.RedissonTopic
-
- getChannelPromise() - Method in class org.redisson.client.protocol.QueueCommandHolder
-
- getChannels() - Method in class org.redisson.client.RedisPubSubConnection
-
- 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 class org.redisson.Redisson
-
Get Redis cluster nodes group for server operations
- getClusterNodesGroup() - Method in interface org.redisson.RedissonClient
-
Get Redis cluster nodes group for server operations
- getCodec() - Method in class org.redisson.client.protocol.CommandData
-
- 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.CommandBatchExecutorService.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.CommandBatchExecutorService.Entry
-
- getConfig() - Method in interface org.redisson.connection.ConnectionManager
-
- getConfig() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- getConfig() - Method in class org.redisson.Redisson
-
Allows to get configuration provided
during Redisson instance creation.
- getConfig() - Method in interface org.redisson.RedissonClient
-
Allows to get configuration provided
during Redisson instance creation.
- 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
-
- getConnectionManager() - Method in interface org.redisson.CommandExecutor
-
- getConnectionManager() - Method in class org.redisson.CommandExecutorService
-
- 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
-
- 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
-
Returns distributed "count down latch" instance by name.
- getCountDownLatch(String) - Method in interface org.redisson.RedissonClient
-
Returns "count down latch" 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 class org.redisson.Redisson
-
Returns distributed deque instance by name.
- getDeque(String, Codec) - Method in class org.redisson.Redisson
-
- getDeque(String) - Method in interface org.redisson.RedissonClient
-
Returns deque instance by name.
- getDeque(String, Codec) - Method in interface org.redisson.RedissonClient
-
- getDequeAsync(String) - Method in interface org.redisson.core.RBatch
-
Returns deque instance by name.
- getDequeAsync(String, Codec) - Method in interface org.redisson.core.RBatch
-
- getDequeAsync(String) - Method in class org.redisson.RedissonBatch
-
- getDequeAsync(String, Codec) - Method in class org.redisson.RedissonBatch
-
- getDnsMonitoringInterval() - Method in class org.redisson.SingleServerConfig
-
- 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(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
-
- getFailAttempts() - Method in class org.redisson.client.RedisConnection
-
- getFailedAttempts() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- 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
-
- 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
-
- 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
-
- 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.Redisson
-
Returns HyperLogLog object
- 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 object
- getHyperLogLog(String, Codec) - Method in interface org.redisson.RedissonClient
-
- 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.core.RBatch
-
Returns keys operations.
- getKeys() - Method in interface org.redisson.core.RKeys
-
Get all keys using iterator.
- getKeys() - Method in class org.redisson.Redisson
-
Returns keys operations.
- getKeys() - Method in class org.redisson.RedissonBatch
-
- getKeys() - Method in interface org.redisson.RedissonClient
-
Returns keys operations.
- getKeys() - Method in class org.redisson.RedissonKeys
-
- getKeysByPattern(String) - Method in interface org.redisson.core.RKeys
-
Get all keys by pattern using iterator.
- getKeysByPattern(String) - Method in class org.redisson.RedissonKeys
-
- 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.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.Redisson
-
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.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
- 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.Redisson
-
Returns distributed list instance by name.
- 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
-
- getListeners(String) - Method in class org.redisson.connection.PubSubConnectionEntry
-
- getLoadBalancer() - Method in class org.redisson.BaseMasterSlaveServersConfig
-
- getLock(String) - Method in class org.redisson.Redisson
-
Returns distributed lock instance by name.
- getLock(String) - Method in interface org.redisson.RedissonClient
-
Returns lock instance by name.
- 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.Redisson
-
Returns distributed map instance by name.
- 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
-
- 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.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.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.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.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.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.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.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 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
-
- 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 class org.redisson.Redisson
-
Get Redis nodes group for server operations
- getNodesGroup() - Method in interface org.redisson.RedissonClient
-
Get Redis nodes group for server operations
- getNodeType() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- getOutParamType() - Method in class org.redisson.client.protocol.RedisCommand
-
- getParams() - Method in class org.redisson.client.protocol.CommandData
-
- getPattern() - Method in class org.redisson.client.protocol.pubsub.PubSubPatternMessage
-
- getPatternChannels() - Method in class org.redisson.client.RedisPubSubConnection
-
- getPatternNames() - Method in interface org.redisson.core.RPatternTopic
-
Get topic channel patterns
- getPatternNames() - Method in class org.redisson.RedissonPatternTopic
-
- getPatternTopic(String) - Method in class org.redisson.Redisson
-
Returns topic instance satisfies by pattern name.
- 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
-
- 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 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.core.RBatch
-
Returns queue instance by name.
- getQueue(String, Codec) - Method in interface org.redisson.core.RBatch
-
- getQueue(String) - Method in class org.redisson.Redisson
-
Returns distributed queue instance by name.
- 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
-
- 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() - Method in class org.redisson.client.protocol.ScoredEntry
-
- getScore(V) - Method in interface org.redisson.core.RScoredSortedSet
-
- 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.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.Redisson
-
Returns Redis Sorted Set instance by name
- 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
-
- getScript() - Method in interface org.redisson.core.RBatch
-
Returns script operations object
- getScript() - Method in class org.redisson.Redisson
-
Returns script with eval-operations support
- getScript() - Method in class org.redisson.RedissonBatch
-
- getScript() - Method in interface org.redisson.RedissonClient
-
Returns script operations object
- getSended() - Method in class org.redisson.client.protocol.QueueCommandHolder
-
- getSentinelAddresses() - Method in class org.redisson.SentinelServersConfig
-
- 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.Redisson
-
Returns distributed set instance by name.
- 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
-
- 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
-
- 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() - 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.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
-
Returns distributed sorted set instance by name.
- 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
-
- 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
-
- 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.Redisson
-
Returns topic instance by name.
- 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
-
- 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.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.LongCodec
-
- 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.ByteArrayCodec
-
- getValueEncoder() - Method in interface org.redisson.client.codec.Codec
-
Returns object encoder used for any objects stored Redis structure except HMAP
- getValueEncoder() - Method in class org.redisson.client.codec.StringCodec
-
- getValueEncoder() - Method in class org.redisson.codec.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
-
- 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.core.RKeys
-
Get random key
- 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.core.RLexSortedSet
-
- rank(V) - Method in interface org.redisson.core.RScoredSortedSet
-
- 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
-
- RAtomicLong - Interface in org.redisson.core
-
- RAtomicLongAsync - Interface in org.redisson.core
-
- RBatch - Interface in org.redisson.core
-
Interface for using pipeline feature.
- RBitSet - Interface in org.redisson.core
-
- RBitSetAsync - Interface in org.redisson.core
-
- RBlockingQueue<V> - Interface in org.redisson.core
-
- RBlockingQueueAsync<V> - Interface in org.redisson.core
-
- RBucket<V> - Interface in org.redisson.core
-
Any object holder
- RBucketAsync<V> - Interface in org.redisson.core
-
Async object functions
- RCollectionAsync<V> - Interface in org.redisson.core
-
- RCountDownLatch - Interface in org.redisson.core
-
- RDeque<V> - Interface in org.redisson.core
-
- RDequeAsync<V> - Interface in org.redisson.core
-
- read(String, Codec, SyncOperation<R>) - Method in class org.redisson.CommandBatchExecutorService
-
- read(String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.CommandBatchExecutorService
-
- read(String, RedisCommand<T>, Object...) - Method in class org.redisson.CommandBatchExecutorService
-
- read(InetSocketAddress, String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.CommandExecutor
-
- read(InetSocketAddress, String, RedisCommand<T>, Object...) - Method in interface org.redisson.CommandExecutor
-
- read(String, Codec, SyncOperation<R>) - Method in interface org.redisson.CommandExecutor
-
- read(String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.CommandExecutor
-
- read(String, RedisCommand<T>, Object...) - Method in interface org.redisson.CommandExecutor
-
- read(String, RedisCommand<T>, Object...) - Method in class org.redisson.CommandExecutorService
-
- read(String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.CommandExecutorService
-
- read(InetSocketAddress, String, RedisCommand<T>, Object...) - Method in class org.redisson.CommandExecutorService
-
- read(InetSocketAddress, String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.CommandExecutorService
-
- read(String, Codec, SyncOperation<R>) - Method in class org.redisson.CommandExecutorService
-
- readAllAsync(RedisCommand<T>, Object...) - Method in interface org.redisson.CommandExecutor
-
- readAllAsync(RedisCommand<T>, Object...) - Method in class org.redisson.CommandExecutorService
-
- readAsync(String, Codec, RedisCommand<T>, Object...) - Method in interface org.redisson.CommandExecutor
-
- readAsync(String, RedisCommand<T>, Object...) - Method in interface org.redisson.CommandExecutor
-
- readAsync(InetSocketAddress, String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.CommandExecutorService
-
- readAsync(String, Codec, RedisCommand<T>, Object...) - Method in class org.redisson.CommandExecutorService
-
- readAsync(String, RedisCommand<T>, Object...) - Method in class org.redisson.CommandExecutorService
-
- readBytes(ByteBuf) - Method in class org.redisson.client.handler.CommandDecoder
-
- 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.CommandExecutor
-
- readRandomAsync(RedisCommand<T>, Object...) - Method in class org.redisson.CommandExecutorService
-
- 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) - 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, 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>, 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.
- RedissonAtomicLong - Class in org.redisson
-
- RedissonAtomicLong(CommandExecutor, String) - Constructor for class org.redisson.RedissonAtomicLong
-
- RedissonBatch - Class in org.redisson
-
- RedissonBatch(ConnectionManager) - Constructor for class org.redisson.RedissonBatch
-
- RedissonBitSet - Class in org.redisson
-
- RedissonBitSet(CommandExecutor, String) - Constructor for class org.redisson.RedissonBitSet
-
- RedissonBlockingQueue<V> - Class in org.redisson
-
Offers blocking queue facilities through an intermediary
LinkedBlockingQueue
where items are added as soon as
blpop
returns.
- RedissonBlockingQueue(CommandExecutor, String) - Constructor for class org.redisson.RedissonBlockingQueue
-
- RedissonBlockingQueue(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonBlockingQueue
-
- RedissonBucket<V> - Class in org.redisson
-
- RedissonBucket(CommandExecutor, String) - Constructor for class org.redisson.RedissonBucket
-
- RedissonBucket(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonBucket
-
- RedissonClient - Interface in org.redisson
-
- RedissonCountDownLatch - Class in org.redisson
-
- RedissonCountDownLatch(CommandExecutor, 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(CommandExecutor, String) - Constructor for class org.redisson.RedissonDeque
-
- RedissonDeque(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonDeque
-
- RedissonHyperLogLog<V> - Class in org.redisson
-
- RedissonHyperLogLog(CommandExecutor, String) - Constructor for class org.redisson.RedissonHyperLogLog
-
- RedissonHyperLogLog(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonHyperLogLog
-
- RedissonKeys - Class in org.redisson
-
- RedissonKeys(CommandExecutor) - Constructor for class org.redisson.RedissonKeys
-
- RedissonLexSortedSet - Class in org.redisson
-
- RedissonLexSortedSet(CommandExecutor, String) - Constructor for class org.redisson.RedissonLexSortedSet
-
- RedissonList<V> - Class in org.redisson
-
Distributed and concurrent implementation of
List
- RedissonList(CommandExecutor, String) - Constructor for class org.redisson.RedissonList
-
- RedissonList(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonList
-
- 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(RedissonLockEntry) - Constructor for class org.redisson.RedissonLockEntry
-
- RedissonLockEntry(Promise<RedissonLockEntry>) - Constructor for class org.redisson.RedissonLockEntry
-
- RedissonMap<K,V> - Class in org.redisson
-
- RedissonMap(CommandExecutor, String) - Constructor for class org.redisson.RedissonMap
-
- RedissonMap(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonMap
-
- 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
-
- 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
-
- RedissonQueue<V> - Class in org.redisson
-
Distributed and concurrent implementation of
Queue
- RedissonQueue(CommandExecutor, String) - Constructor for class org.redisson.RedissonQueue
-
- RedissonQueue(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonQueue
-
- RedissonScoredSortedSet<V> - Class in org.redisson
-
- RedissonScoredSortedSet(CommandExecutor, String) - Constructor for class org.redisson.RedissonScoredSortedSet
-
- RedissonScoredSortedSet(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonScoredSortedSet
-
- RedissonScript - Class in org.redisson
-
- RedissonScript(CommandExecutor) - Constructor for class org.redisson.RedissonScript
-
- RedissonSet<V> - Class in org.redisson
-
Distributed and concurrent implementation of
Set
- RedissonSet(CommandExecutor, String) - Constructor for class org.redisson.RedissonSet
-
- RedissonSet(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonSet
-
- 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(CommandExecutor, String) - Constructor for class org.redisson.RedissonTopic
-
- RedissonTopic(Codec, CommandExecutor, String) - Constructor for class org.redisson.RedissonTopic
-
- RedisStrictCommand<T> - Class in org.redisson.client.protocol
-
- RedisStrictCommand(String, int, RedisCommand.ValueType) - 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() - Method in class org.redisson.connection.PubSubConnectionEntry
-
- release() - Method in class org.redisson.misc.InfinitySemaphoreLatch
-
- release() - Method in class org.redisson.RedissonCountDownLatchEntry
-
- release() - Method in class org.redisson.RedissonLockEntry
-
- 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.RedissonBlockingQueue
-
- 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.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.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.RedissonSortedSet
-
- removeAll(Collection<?>) - Method in interface org.redisson.core.RScoredSortedSet
-
- 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.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
-
- 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) - Method in class org.redisson.RedissonScoredSortedSet
-
- removeAsync(Object) - Method in class org.redisson.RedissonSet
-
- removeAsync(V) - Method in class org.redisson.RedissonSortedSet
-
- 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 class org.redisson.RedissonDeque
-
- removeFirstOccurrenceAsync(Object) - Method in interface org.redisson.core.RDequeAsync
-
- removeFirstOccurrenceAsync(Object) - Method in class org.redisson.RedissonDeque
-
- 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 class org.redisson.RedissonDeque
-
- removeLastOccurrenceAsync(Object) - Method in interface org.redisson.core.RDequeAsync
-
- removeLastOccurrenceAsync(Object) - Method in class org.redisson.RedissonDeque
-
- removeListener(RedisPubSubListener<?>) - Method in class org.redisson.client.RedisPubSubConnection
-
- 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 interface org.redisson.core.RTopicAsync
-
Removes the listener by id
for listening this topic
- 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.core.RSet
-
Removes and returns random element from set
- 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.core.RLexSortedSet
-
- 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.core.RScoredSortedSet
-
- 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.core.RScoredSortedSet
-
- removeRangeByScore(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
-
- removeRangeByScoreAsync(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
-
- removeRangeHeadByLex(String, boolean) - Method in interface org.redisson.core.RLexSortedSet
-
- 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.core.RLexSortedSet
-
- 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 - 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 - 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, 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
-
- REPLAY - Static variable in class org.redisson.client.handler.CommandsQueue
-
- resetFailAttempt() - Method in class org.redisson.client.RedisConnection
-
- resetFailedAttempts() - Method in class org.redisson.connection.ClientConnectionsEntry
-
- retainAll(Collection<?>) - Method in interface org.redisson.core.RScoredSortedSet
-
- 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.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
-
- 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 support expiration or TTL
- RHyperLogLog<V> - Interface in org.redisson.core
-
- RHyperLogLogAsync<V> - Interface in org.redisson.core
-
- RKeys - Interface in org.redisson.core
-
- RKeysAsync - Interface in org.redisson.core
-
- RLexSortedSet - Interface in org.redisson.core
-
- RLexSortedSetAsync - Interface in org.redisson.core
-
- RList<V> - Interface in org.redisson.core
-
Distributed and concurrent implementation of
List
- RListAsync<V> - Interface in org.redisson.core
-
Async list functions
- RLock - Interface in org.redisson.core
-
Distributed implementation of
Lock
Implements reentrant lock.
- RMap<K,V> - Interface in org.redisson.core
-
- RMapAsync<K,V> - Interface in org.redisson.core
-
Async 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
- 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.
- 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
-
- RScoredSortedSet<V> - Interface in org.redisson.core
-
- RScoredSortedSetAsync<V> - Interface in org.redisson.core
-
- 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
-
- RSet<V> - Interface in org.redisson.core
-
Distributed and concurrent implementation of
Set
- RSetAsync<V> - Interface in org.redisson.core
-
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.
- SADD - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SADD_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SCAN - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SCARD - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- ScoredEntry<V> - Class in org.redisson.client.protocol
-
- ScoredEntry(Double, V) - Constructor for class org.redisson.client.protocol.ScoredEntry
-
- ScoredSortedSetReplayDecoder<T> - Class in org.redisson.client.protocol.decoder
-
- ScoredSortedSetReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ScoredSortedSetReplayDecoder
-
- ScoredSortedSetScanReplayDecoder - Class in org.redisson.client.protocol.decoder
-
- ScoredSortedSetScanReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.ScoredSortedSetScanReplayDecoder
-
- SCRIPT_EXISTS - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SCRIPT_FLUSH - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SCRIPT_KILL - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SCRIPT_LOAD - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- scriptExists(String...) - Method in interface org.redisson.core.RScript
-
- scriptExists(String...) - Method in class org.redisson.RedissonScript
-
- scriptExists(String, String...) - Method in class org.redisson.RedissonScript
-
- scriptExistsAsync(String...) - Method in interface org.redisson.core.RScriptAsync
-
- scriptExistsAsync(String...) - Method in class org.redisson.RedissonScript
-
- scriptExistsAsync(String, String...) - Method in class org.redisson.RedissonScript
-
- scriptFlush() - Method in interface org.redisson.core.RScript
-
- scriptFlush() - Method in class org.redisson.RedissonScript
-
- scriptFlush(String) - Method in class org.redisson.RedissonScript
-
- scriptFlushAsync() - Method in interface org.redisson.core.RScriptAsync
-
- scriptFlushAsync() - Method in class org.redisson.RedissonScript
-
- scriptFlushAsync(String) - Method in class org.redisson.RedissonScript
-
- scriptKill() - Method in interface org.redisson.core.RScript
-
- scriptKill() - Method in class org.redisson.RedissonScript
-
- scriptKill(String) - Method in class org.redisson.RedissonScript
-
- scriptKillAsync() - Method in interface org.redisson.core.RScriptAsync
-
- scriptKillAsync() - Method in class org.redisson.RedissonScript
-
- scriptKillAsync(String) - Method in class org.redisson.RedissonScript
-
- scriptLoad(String) - Method in interface org.redisson.core.RScript
-
- scriptLoad(String) - Method in class org.redisson.RedissonScript
-
- scriptLoad(String, String) - Method in class org.redisson.RedissonScript
-
- scriptLoadAsync(String) - Method in interface org.redisson.core.RScriptAsync
-
- scriptLoadAsync(String) - Method in class org.redisson.RedissonScript
-
- scriptLoadAsync(String, String) - Method in class org.redisson.RedissonScript
-
- SELECT - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- send(CommandData<T, R>) - Method in class org.redisson.client.RedisConnection
-
- send(CommandsData) - Method in class org.redisson.client.RedisConnection
-
- sendNextCommand(ChannelHandlerContext) - Method in class org.redisson.client.handler.CommandsQueue
-
- SENTINEL_GET_MASTER_ADDR_BY_NAME - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SENTINEL_SLAVES - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SentinelConnectionManager - Class in org.redisson.connection
-
- SentinelConnectionManager(SentinelServersConfig, Config) - Constructor for class org.redisson.connection.SentinelConnectionManager
-
- SentinelServersConfig - Class in org.redisson
-
- SentinelServersConfig() - Constructor for class org.redisson.SentinelServersConfig
-
- SerializationCodec - Class in org.redisson.codec
-
- SerializationCodec() - Constructor for class org.redisson.codec.SerializationCodec
-
- SET - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- set(long) - Method in interface org.redisson.core.RAtomicLong
-
Atomically sets the given value.
- set(int, int, boolean) - Method in interface org.redisson.core.RBitSet
-
- set(BitSet) - Method in interface org.redisson.core.RBitSet
-
- set(int, int) - Method in interface org.redisson.core.RBitSet
-
- set(int) - Method in interface org.redisson.core.RBitSet
-
- set(int, boolean) - Method in interface org.redisson.core.RBitSet
-
- set(V) - Method in interface org.redisson.core.RBucket
-
- set(V, long, TimeUnit) - Method in interface org.redisson.core.RBucket
-
- set(long) - Method in class org.redisson.RedissonAtomicLong
-
- set(BitSet) - Method in class org.redisson.RedissonBitSet
-
- set(int) - Method in class org.redisson.RedissonBitSet
-
- set(int, int, boolean) - Method in class org.redisson.RedissonBitSet
-
- set(int, int) - Method in class org.redisson.RedissonBitSet
-
- set(int, boolean) - Method in class org.redisson.RedissonBitSet
-
- set(V) - Method in class org.redisson.RedissonBucket
-
- set(V, long, TimeUnit) - Method in class org.redisson.RedissonBucket
-
- set(int, V) - Method in class org.redisson.RedissonList
-
- setAddress(String) - Method in class org.redisson.cluster.ClusterNodeInfo
-
- setAddress(String) - Method in class org.redisson.SingleServerConfig
-
Set server address.
- setAsync(long) - Method in interface org.redisson.core.RAtomicLongAsync
-
- setAsync(int, int, boolean) - Method in interface org.redisson.core.RBitSetAsync
-
- setAsync(BitSet) - Method in interface org.redisson.core.RBitSetAsync
-
- setAsync(int, int) - Method in interface org.redisson.core.RBitSetAsync
-
- setAsync(int) - Method in interface org.redisson.core.RBitSetAsync
-
- setAsync(int, boolean) - Method in interface org.redisson.core.RBitSetAsync
-
- setAsync(V) - Method in interface org.redisson.core.RBucketAsync
-
- setAsync(V, long, TimeUnit) - Method in interface org.redisson.core.RBucketAsync
-
- setAsync(int, V) - Method in interface org.redisson.core.RListAsync
-
- setAsync(long) - Method in class org.redisson.RedissonAtomicLong
-
- setAsync(int, boolean) - Method in class org.redisson.RedissonBitSet
-
- setAsync(int, int, boolean) - Method in class org.redisson.RedissonBitSet
-
- setAsync(BitSet) - Method in class org.redisson.RedissonBitSet
-
- setAsync(int, int) - Method in class org.redisson.RedissonBitSet
-
- setAsync(int) - Method in class org.redisson.RedissonBitSet
-
- setAsync(V) - Method in class org.redisson.RedissonBucket
-
- setAsync(V, long, TimeUnit) - Method in class org.redisson.RedissonBucket
-
- setAsync(int, V) - Method in class org.redisson.RedissonList
-
- SETBIT - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- setClosed(boolean) - Method in class org.redisson.client.RedisConnection
-
- setCodec(Codec) - Method in class org.redisson.Config
-
Redis key/value codec.
- setConnectionMinimumIdleSize(int) - Method in class org.redisson.SingleServerConfig
-
Minimum idle Redis connection amount.
- setConnectionPoolSize(int) - Method in class org.redisson.SingleServerConfig
-
Redis connection pool size
Default is 100
- setDecoderState(Object) - Method in class org.redisson.client.handler.State
-
- setDnsMonitoring(boolean) - Method in class org.redisson.SingleServerConfig
-
Monitoring of the endpoint address for DNS changes.
- setDnsMonitoringInterval(long) - Method in class org.redisson.SingleServerConfig
-
- SETEX - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- setFreezed(boolean) - Method in class org.redisson.connection.ClientConnectionsEntry
-
- setFreezeReason(ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.ClientConnectionsEntry
-
- setIndex(int) - Method in class org.redisson.client.handler.State
-
- setIndex(int) - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
-
- setLastUsageTime(long) - Method in class org.redisson.client.RedisConnection
-
- setLoadBalancer(LoadBalancer) - Method in class org.redisson.BaseMasterSlaveServersConfig
-
Сonnection load balancer to multiple Redis slave servers.
- setMasterAddress(String) - Method in class org.redisson.cluster.ClusterPartition
-
- setMasterAddress(URI) - Method in class org.redisson.cluster.ClusterPartition
-
- setMasterAddress(String) - Method in class org.redisson.MasterSlaveServersConfig
-
Set Redis master server address.
- setMasterAddress(URI) - Method in class org.redisson.MasterSlaveServersConfig
-
- setMasterConnectionMinimumIdleSize(int) - Method in class org.redisson.BaseMasterSlaveServersConfig
-
Redis 'master' node minimum idle connection amount for each slave node
Default is 5
- setMasterConnectionPoolSize(int) - Method in class org.redisson.BaseMasterSlaveServersConfig
-
Redis 'master' server connection pool size.
- setMasterFail(boolean) - Method in class org.redisson.cluster.ClusterPartition
-
- setMasterName(String) - Method in class org.redisson.SentinelServersConfig
-
- setNodeId(String) - Method in class org.redisson.cluster.ClusterNodeInfo
-
- SETNX - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- setReadFromSlaves(boolean) - Method in class org.redisson.ClusterServersConfig
-
Use cluster slave nodes for read-operations
- setReadOnlyMode(boolean) - Method in class org.redisson.CommandBatchExecutorService.Entry
-
- setReconnectListener(ReconnectListener) - Method in class org.redisson.client.RedisConnection
-
- setRedisClient(InetSocketAddress) - Method in class org.redisson.client.protocol.decoder.ListScanResult
-
- setRedisClient(InetSocketAddress) - Method in class org.redisson.client.protocol.decoder.MapScanResult
-
- setRedisClient(InetSocketAddress) - Method in interface org.redisson.RedisClientResult
-
- setRespParts(List<Object>) - Method in class org.redisson.client.handler.State
-
- setScanInterval(int) - Method in class org.redisson.ClusterServersConfig
-
Redis cluster scan interval in milliseconds
- setScanInterval(int) - Method in class org.redisson.ElasticacheServersConfig
-
Elasticache node scan interval in milliseconds
- setSizeOnce(long) - Method in class org.redisson.client.handler.State
-
- setSlaveAddresses(Set<URI>) - Method in class org.redisson.MasterSlaveServersConfig
-
- setSlaveConnectionMinimumIdleSize(int) - Method in class org.redisson.BaseMasterSlaveServersConfig
-
Redis 'slave' node minimum idle connection amount for each slave node
Default is 5
- setSlaveConnectionPoolSize(int) - Method in class org.redisson.BaseMasterSlaveServersConfig
-
Redis 'slave' servers connection pool size for each slave node.
- setSlaveOf(String) - Method in class org.redisson.cluster.ClusterNodeInfo
-
- setSlaveSubscriptionConnectionMinimumIdleSize(int) - Method in class org.redisson.BaseMasterSlaveServersConfig
-
Redis 'slave' node minimum idle subscription (pub/sub) connection amount for each slave node
Default is 1
- setSlaveSubscriptionConnectionPoolSize(int) - Method in class org.redisson.BaseMasterSlaveServersConfig
-
Redis 'slave' node maximum subscription (pub/sub) connection pool size for each slave node
Default is 25
- setSubscriptionConnectionMinimumIdleSize(int) - Method in class org.redisson.SingleServerConfig
-
Minimum idle subscription connection amount.
- setSubscriptionConnectionPoolSize(int) - Method in class org.redisson.SingleServerConfig
-
Redis subscription-connection pool size limit
Default is 25
- setThreads(int) - Method in class org.redisson.Config
-
- setupMasterEntry(String, int) - Method in class org.redisson.connection.MasterSlaveEntry
-
- setupMasterEntry(String, int) - Method in class org.redisson.connection.SingleEntry
-
- setUseLinuxNativeEpoll(boolean) - Method in class org.redisson.Config
-
Activates an unix socket if servers binded to loopback interface.
- setValue(V) - Method in class org.redisson.RedissonMapEntry
-
- shutdown() - Method in class org.redisson.client.RedisClient
-
- shutdown() - Method in class org.redisson.cluster.ClusterConnectionManager
-
- shutdown() - Method in interface org.redisson.connection.balancer.LoadBalancerManager
-
- shutdown() - Method in class org.redisson.connection.balancer.LoadBalancerManagerImpl
-
- shutdown() - Method in interface org.redisson.connection.ConnectionManager
-
- shutdown() - Method in class org.redisson.connection.ElasticacheConnectionManager
-
- shutdown() - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- shutdown() - Method in class org.redisson.connection.MasterSlaveEntry
-
- shutdown() - Method in class org.redisson.connection.SentinelConnectionManager
-
- shutdown() - Method in class org.redisson.connection.SingleConnectionManager
-
- shutdown() - Method in class org.redisson.Redisson
-
Shuts down Redisson instance NOT Redis server
- shutdown() - Method in interface org.redisson.RedissonClient
-
Shuts down Redisson instance NOT Redis server
- shutdownAsync() - Method in class org.redisson.client.RedisClient
-
- shutdownAsync() - Method in interface org.redisson.connection.balancer.LoadBalancerManager
-
- shutdownAsync() - Method in class org.redisson.connection.balancer.LoadBalancerManagerImpl
-
- shutdownAsync(RedisClient) - Method in interface org.redisson.connection.ConnectionManager
-
- shutdownAsync(RedisClient) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- shutdownMasterAsync() - Method in class org.redisson.connection.MasterSlaveEntry
-
- SingleConnectionManager - Class in org.redisson.connection
-
- SingleConnectionManager(SingleServerConfig, Config) - Constructor for class org.redisson.connection.SingleConnectionManager
-
- SingleConvertor<R> - Class in org.redisson.client.protocol.convertor
-
- SingleConvertor() - Constructor for class org.redisson.client.protocol.convertor.SingleConvertor
-
- SingleEntry - Class in org.redisson.connection
-
- SingleEntry(Set<ClusterSlotRange>, ConnectionManager, MasterSlaveServersConfig, ConnectionListener) - Constructor for class org.redisson.connection.SingleEntry
-
- SingleServerConfig - Class in org.redisson
-
- singleSlotRange - Variable in class org.redisson.connection.MasterSlaveConnectionManager
-
- SISMEMBER - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- size() - Method in interface org.redisson.core.RBitSet
-
- size() - Method in interface org.redisson.core.RScoredSortedSet
-
- size() - Method in class org.redisson.RedissonBitSet
-
- size() - Method in class org.redisson.RedissonList
-
- size() - Method in class org.redisson.RedissonMap
-
- size() - Method in class org.redisson.RedissonScoredSortedSet
-
- size() - Method in class org.redisson.RedissonSet
-
- size() - Method in class org.redisson.RedissonSortedSet
-
- sizeAsync() - Method in interface org.redisson.core.RBitSetAsync
-
- sizeAsync() - Method in interface org.redisson.core.RCollectionAsync
-
- sizeAsync() - Method in interface org.redisson.core.RMapAsync
-
- sizeAsync() - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- sizeAsync() - Method in class org.redisson.RedissonBitSet
-
- sizeAsync() - Method in class org.redisson.RedissonList
-
- sizeAsync() - Method in class org.redisson.RedissonMap
-
- sizeAsync() - Method in class org.redisson.RedissonScoredSortedSet
-
- sizeAsync() - Method in class org.redisson.RedissonSet
-
- slaveDown(MasterSlaveEntry, String, int, ClientConnectionsEntry.FreezeReason) - Method in interface org.redisson.connection.ConnectionManager
-
- slaveDown(MasterSlaveEntry, String, int, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- slaveDown(ClusterSlotRange, String, int, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- slaveDown(String, int, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveEntry
-
- slaveUp(String, int, ClientConnectionsEntry.FreezeReason) - Method in class org.redisson.connection.MasterSlaveEntry
-
- SlotCallback<T,R> - Interface in org.redisson
-
- SMEMBERS - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SnappyCodec - Class in org.redisson.codec
-
Snappy compression codec.
- SnappyCodec() - Constructor for class org.redisson.codec.SnappyCodec
-
- SnappyCodec(Codec) - Constructor for class org.redisson.codec.SnappyCodec
-
- socketChannelClass - Variable in class org.redisson.connection.MasterSlaveConnectionManager
-
- SPOP_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SREM - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SREM_SINGLE - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- SSCAN - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- State - Class in org.redisson.client.handler
-
- State() - Constructor for class org.redisson.client.handler.State
-
- StatusListener - Interface in org.redisson.core
-
Listener for Redis PubSub channel status changes
- StringCodec - Class in org.redisson.client.codec
-
- StringCodec() - Constructor for class org.redisson.client.codec.StringCodec
-
- StringDataDecoder - Class in org.redisson.client.protocol.decoder
-
- StringDataDecoder() - Constructor for class org.redisson.client.protocol.decoder.StringDataDecoder
-
- StringListReplayDecoder - Class in org.redisson.client.protocol.decoder
-
- StringListReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.StringListReplayDecoder
-
- StringMapDataDecoder - Class in org.redisson.client.protocol.decoder
-
- StringMapDataDecoder() - Constructor for class org.redisson.client.protocol.decoder.StringMapDataDecoder
-
- StringObjectDecoder - Class in org.redisson.client.protocol.decoder
-
- StringObjectDecoder() - Constructor for class org.redisson.client.protocol.decoder.StringObjectDecoder
-
- StringParamsEncoder - Class in org.redisson.client.protocol
-
- StringParamsEncoder() - Constructor for class org.redisson.client.protocol.StringParamsEncoder
-
- StringReplayDecoder - Class in org.redisson.client.protocol.decoder
-
- StringReplayDecoder() - Constructor for class org.redisson.client.protocol.decoder.StringReplayDecoder
-
- STRLEN - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- subList(int, int) - Method in class org.redisson.RedissonList
-
- SUBSCRIBE - Static variable in interface org.redisson.client.protocol.RedisCommands
-
- subscribe(Codec, String...) - Method in class org.redisson.client.RedisPubSubConnection
-
- subscribe(String, Codec) - Method in interface org.redisson.connection.ConnectionManager
-
- subscribe(RedisPubSubListener<V>, String) - Method in interface org.redisson.connection.ConnectionManager
-
- subscribe(String, Codec) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- subscribe(RedisPubSubListener, String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
-
- subscribe(Codec, String) - Method in class org.redisson.connection.PubSubConnectionEntry
-
- subscribe(Codec, RedisPubSubListener, String) - Method in class org.redisson.connection.PubSubConnectionEntry
-
- subSet(V, V) - Method in class org.redisson.RedissonSortedSet
-
- sync(RedisStrictCommand<T>, Object...) - Method in class org.redisson.client.RedisConnection
-
- sync(Codec, RedisCommand<T>, Object...) - Method in class org.redisson.client.RedisConnection
-
- SyncOperation<R> - Interface in org.redisson
-
- valueIterator() - Method in interface org.redisson.core.RMap
-
Map value-iterator with small memory footprint
- valueIterator() - Method in class org.redisson.RedissonMap
-
- valueOf(String) - Static method in enum org.redisson.client.protocol.pubsub.PubSubType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.redisson.client.protocol.RedisCommand.ValueType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.redisson.cluster.ClusterNodeInfo.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.redisson.connection.ClientConnectionsEntry.FreezeReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.redisson.connection.ClientConnectionsEntry.NodeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.redisson.connection.NodeSource.Redirect
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.redisson.connection.PubSubConnectionEntry.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.redisson.core.RScript.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.redisson.core.RScript.ReturnType
-
Returns the enum constant of this type with the specified name.
- valueRange(int, int) - Method in interface org.redisson.core.RLexSortedSet
-
- valueRange(int, int) - Method in interface org.redisson.core.RScoredSortedSet
-
- valueRange(double, boolean, double, boolean) - Method in interface org.redisson.core.RScoredSortedSet
-
- valueRange(double, boolean, double, boolean, int, int) - Method in interface org.redisson.core.RScoredSortedSet
-
- valueRange(int, int) - Method in class org.redisson.RedissonScoredSortedSet
-
- valueRange(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
-
- valueRange(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
-
- valueRangeAsync(int, int) - Method in interface org.redisson.core.RLexSortedSetAsync
-
- valueRangeAsync(int, int) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- valueRangeAsync(double, boolean, double, boolean) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- valueRangeAsync(double, boolean, double, boolean, int, int) - Method in interface org.redisson.core.RScoredSortedSetAsync
-
- valueRangeAsync(int, int) - Method in class org.redisson.RedissonScoredSortedSet
-
- valueRangeAsync(double, boolean, double, boolean) - Method in class org.redisson.RedissonScoredSortedSet
-
- valueRangeAsync(double, boolean, double, boolean, int, int) - Method in class org.redisson.RedissonScoredSortedSet
-
- values() - Static method in enum org.redisson.client.protocol.pubsub.PubSubType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.redisson.client.protocol.RedisCommand.ValueType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.redisson.cluster.ClusterNodeInfo.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.redisson.connection.ClientConnectionsEntry.FreezeReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.redisson.connection.ClientConnectionsEntry.NodeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.redisson.connection.NodeSource.Redirect
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.redisson.connection.PubSubConnectionEntry.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.redisson.core.RScript.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.redisson.core.RScript.ReturnType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.redisson.RedissonMap
-
- valuesAsync() - Method in interface org.redisson.core.RMapAsync
-
- valuesAsync() - Method in class org.redisson.RedissonMap
-
- VoidReplayConvertor - Class in org.redisson.client.protocol.convertor
-
- VoidReplayConvertor() - Constructor for class org.redisson.client.protocol.convertor.VoidReplayConvertor
-