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

A

add(Command<K, V, ?>) - Method in class com.lambdaworks.redis.output.MultiOutput
 
add(Map<K, V>) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
add(String) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
add(long) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
add(double) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
add(byte[]) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
add(CommandKeyword) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
add(CommandType) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
add(ConnectionEntry) - Method in interface org.redisson.connection.LoadBalancer
 
add(V) - Method in interface org.redisson.core.RHyperLogLog
 
add(V) - Method in class org.redisson.RedissonHyperLogLog
 
add(V) - Method in class org.redisson.RedissonList
 
add(int, V) - Method in class org.redisson.RedissonList
 
add(V) - Method in class org.redisson.RedissonSet
 
add(V) - Method in class org.redisson.RedissonSortedSet
 
addAll(Collection<V>) - Method in interface org.redisson.core.RHyperLogLog
 
addAll(Collection<V>) - Method in class org.redisson.RedissonHyperLogLog
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonList
 
addAll(int, Collection<? extends V>) - Method in class org.redisson.RedissonList
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonSet
 
addAll(Collection<? extends V>) - Method in class org.redisson.RedissonSortedSet
 
addAllAsync(Collection<V>) - Method in interface org.redisson.core.RHyperLogLog
 
addAllAsync(Collection<V>) - Method in class org.redisson.RedissonHyperLogLog
 
addAndGet(long) - Method in interface org.redisson.core.RAtomicLong
Atomically adds the given value to the current value.
addAndGet(long) - Method in class org.redisson.RedissonAtomicLong
 
addAsync(V) - Method in interface org.redisson.core.RHyperLogLog
 
addAsync(V) - Method in interface org.redisson.core.RSet
 
addAsync(V) - Method in interface org.redisson.core.RSortedSet
 
addAsync(V) - Method in class org.redisson.RedissonHyperLogLog
 
addAsync(V) - Method in class org.redisson.RedissonSet
 
addAsync(V) - Method in class org.redisson.RedissonSortedSet
 
addFirst(V) - Method in class org.redisson.RedissonDeque
 
addKey(K) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
addKeys(K...) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
addLast(V) - Method in class org.redisson.RedissonDeque
 
addListener(RedisPubSubListener<V>) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubConnection
Add a new listener.
addListener(String, RedisPubSubListener) - Method in class org.redisson.connection.PubSubConnectionEntry
 
addListener(MessageListener<M>) - Method in interface org.redisson.core.RTopic
Subscribes to this topic.
addListener(MessageListener<M>) - Method in class org.redisson.RedissonTopic
 
addMapKey(K) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
addMapKeys(K...) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
addMapValue(V) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
addMapValues(V...) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
addSentinelAddress(String...) - Method in class org.redisson.SentinelServersConfig
 
addSlave(String, int) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
addSlaveAddress(String...) - Method in class org.redisson.MasterSlaveServersConfig
Add Redis slave server address.
addValue(V) - Method in class com.lambdaworks.redis.output.ScanResult
 
addValue(V) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
addValues(V...) - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
alpha() - Method in class com.lambdaworks.redis.SortArgs
 
alpha() - Static method in class com.lambdaworks.redis.SortArgs.Builder
 
append(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
append(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
aquire() - Method in class org.redisson.RedissonCountDownLatchEntry
 
aquire() - Method in class org.redisson.RedissonLockEntry
 
args - Variable in class com.lambdaworks.redis.protocol.Command
 
asc() - Method in class com.lambdaworks.redis.SortArgs
 
asc() - Static method in class com.lambdaworks.redis.SortArgs.Builder
 
ASCII - Static variable in class com.lambdaworks.redis.protocol.Charsets
 
auth(String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
auth(String) - Method in class com.lambdaworks.redis.RedisConnection
 
await(Future<T>, long, TimeUnit) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
await() - Method in interface org.redisson.core.RCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted.
await(long, TimeUnit) - Method in interface org.redisson.core.RCountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
await() - Method in class org.redisson.misc.ReclosableLatch
 
await(long, TimeUnit) - Method in class org.redisson.misc.ReclosableLatch
 
await() - Method in class org.redisson.RedissonCountDownLatch
 
await(long, TimeUnit) - Method in class org.redisson.RedissonCountDownLatch
 
awaitAll(Future<?>...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
Wait until commands are complete or the connection timeout is reached.
awaitAll(long, TimeUnit, Future<?>...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
Wait until futures are complete or the supplied timeout is reached.
awaitUninterruptibly() - Method in class org.redisson.misc.ReclosableLatch
 

B

balancer - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
Base16 - Class in com.lambdaworks.codec
High-performance base16 (AKA hex) codec.
Base16() - Constructor for class com.lambdaworks.codec.Base16
 
bgrewriteaof() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
bgrewriteaof() - Method in class com.lambdaworks.redis.RedisConnection
 
bgsave() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
bgsave() - Method in class com.lambdaworks.redis.RedisConnection
 
binarySearch(V, RedisConnection<Object, V>) - Method in class org.redisson.RedissonSortedSet
 
bitcount(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
bitcount(K, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
bitcount(K) - Method in class com.lambdaworks.redis.RedisConnection
 
bitcount(K, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
bitopAnd(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
bitopAnd(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
bitopNot(K, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
bitopNot(K, K) - Method in class com.lambdaworks.redis.RedisConnection
 
bitopOr(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
bitopOr(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
bitopXor(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
bitopXor(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
blpop(long, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
blpop(long, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
BooleanListOutput<K,V> - Class in com.lambdaworks.redis.output
List of boolean output.
BooleanListOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.BooleanListOutput
 
BooleanOutput<K,V> - Class in com.lambdaworks.redis.output
Boolean output.
BooleanOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.BooleanOutput
 
brpop(long, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
brpop(long, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
brpoplpush(long, K, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
brpoplpush(long, K, K) - Method in class com.lambdaworks.redis.RedisConnection
 
buffer(String) - Static method in class com.lambdaworks.redis.protocol.Charsets
 
buffer() - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
buffer - Variable in class com.lambdaworks.redis.protocol.CommandHandler
 
by(String) - Static method in class com.lambdaworks.redis.SortArgs.Builder
 
by(String) - Method in class com.lambdaworks.redis.SortArgs
 
ByteArrayOutput<K,V> - Class in com.lambdaworks.redis.output
Byte array output.
ByteArrayOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.ByteArrayOutput
 
bytes - Variable in enum com.lambdaworks.redis.protocol.CommandKeyword
 
bytes - Variable in enum com.lambdaworks.redis.protocol.CommandType
 

C

c - Variable in class com.lambdaworks.redis.RedisConnection
 
calcIncrement(double) - Static method in class org.redisson.RedissonSortedSet
 
calcNewScore(int, RedisConnection<Object, V>) - Method in class org.redisson.RedissonSortedSet
score for first entry = 0 score for entry added before = head - calcIncrement(head) score for entry added after = tail + calcIncrement(head) score for entry inserted between head and tail = head + (tail - head) / 2
cancel() - Method in class com.lambdaworks.redis.output.MultiOutput
 
changeMaster(String, int) - Method in class org.redisson.connection.MasterSlaveConnectionManager
Freeze slave with host:port from slaves list.
channel() - Method in class com.lambdaworks.redis.pubsub.PubSubOutput
 
channel - Variable in class com.lambdaworks.redis.RedisAsyncConnection
 
channelActive(ChannelHandlerContext) - Method in class com.lambdaworks.redis.protocol.ConnectionWatchdog
 
channelActive(ChannelHandlerContext) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubConnection
 
channelActive(ChannelHandlerContext) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
channelInactive(ChannelHandlerContext) - Method in class com.lambdaworks.redis.protocol.ConnectionWatchdog
 
channelInactive(ChannelHandlerContext) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
channelRead(ChannelHandlerContext, Object) - Method in class com.lambdaworks.redis.protocol.CommandHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubConnection
 
channelRegistered(ChannelHandlerContext) - Method in class com.lambdaworks.redis.protocol.CommandHandler
 
channelUnregistered(ChannelHandlerContext) - Method in class com.lambdaworks.redis.protocol.CommandHandler
 
Charsets - Class in com.lambdaworks.redis.protocol
Charset-related utilities.
Charsets() - Constructor for class com.lambdaworks.redis.protocol.Charsets
 
clear() - Method in class org.redisson.misc.ReferenceMap
 
clear() - Method in class org.redisson.RedissonList
 
clear() - Method in class org.redisson.RedissonMap
 
clear() - Method in class org.redisson.RedissonSet
 
clear() - Method in class org.redisson.RedissonSortedSet
 
clearExpire() - Method in interface org.redisson.core.RExpirable
Remove the existing timeout of Redisson object
clientGetname() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
clientGetname() - Method in class com.lambdaworks.redis.RedisConnection
 
clientKill(String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
clientKill(String) - Method in class com.lambdaworks.redis.RedisConnection
 
clientList() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
clientList() - Method in class com.lambdaworks.redis.RedisConnection
 
clientSetname(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
clientSetname(K) - Method in class com.lambdaworks.redis.RedisConnection
 
close() - Method in class com.lambdaworks.redis.RedisAsyncConnection
Close the connection.
close() - Method in class com.lambdaworks.redis.RedisConnection
Close the connection.
close() - Method in class org.redisson.connection.PubSubConnectionEntry
 
close() - Method in class org.redisson.misc.ReclosableLatch
 
close() - Method in class org.redisson.RedissonCountDownLatch
 
close() - Method in class org.redisson.RedissonLock
 
codec - Variable in class com.lambdaworks.redis.protocol.CommandOutput
 
codec - Variable in class com.lambdaworks.redis.RedisAsyncConnection
 
codec - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
com.lambdaworks.codec - package com.lambdaworks.codec
 
com.lambdaworks.redis - package com.lambdaworks.redis
 
com.lambdaworks.redis.codec - package com.lambdaworks.redis.codec
 
com.lambdaworks.redis.output - package com.lambdaworks.redis.output
 
com.lambdaworks.redis.protocol - package com.lambdaworks.redis.protocol
 
com.lambdaworks.redis.pubsub - package com.lambdaworks.redis.pubsub
 
Command<K,V,T> - Class in com.lambdaworks.redis.protocol
A redis command and its result.
Command(CommandType, CommandOutput<K, V, T>, CommandArgs<K, V>, boolean, Promise<T>) - Constructor for class com.lambdaworks.redis.protocol.Command
Create a new command with the supplied type and args.
CommandArgs<K,V> - Class in com.lambdaworks.redis.protocol
Redis command argument encoder.
CommandArgs(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.protocol.CommandArgs
 
CommandHandler<K,V> - Class in com.lambdaworks.redis.protocol
A netty ChannelHandler responsible for writing redis commands and reading responses from the server.
CommandHandler(BlockingQueue<Command<K, V, ?>>) - Constructor for class com.lambdaworks.redis.protocol.CommandHandler
Initialize a new instance that handles commands from the supplied queue.
CommandKeyword - Enum in com.lambdaworks.redis.protocol
Keyword modifiers for redis commands.
CommandOutput<K,V,T> - Class in com.lambdaworks.redis.protocol
Abstract representation of the output of a redis command.
CommandOutput(RedisCodec<K, V>, T) - Constructor for class com.lambdaworks.redis.protocol.CommandOutput
Initialize a new instance that encodes and decodes keys and values using the supplied codec.
CommandType - Enum in com.lambdaworks.redis.protocol
Redis commands.
comparator() - Method in class org.redisson.RedissonSortedSet
 
compareAndSet(long, long) - Method in interface org.redisson.core.RAtomicLong
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(long, long) - Method in class org.redisson.RedissonAtomicLong
 
complete(int) - Method in class com.lambdaworks.redis.output.MultiOutput
 
complete(int) - Method in class com.lambdaworks.redis.output.NestedMultiOutput
 
complete() - Method in class com.lambdaworks.redis.protocol.Command
Mark this command complete and notify all waiting threads.
complete(int) - Method in class com.lambdaworks.redis.protocol.CommandOutput
Mark the command output complete.
completeAmount - Variable in class com.lambdaworks.redis.protocol.Command
 
Config - Class in org.redisson
Redisson configuration
Config() - Constructor for class org.redisson.Config
 
config - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
configGet(String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
configGet(String) - Method in class com.lambdaworks.redis.RedisConnection
 
configResetstat() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
configResetstat() - Method in class com.lambdaworks.redis.RedisConnection
 
configSet(String, String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
configSet(String, String) - Method in class com.lambdaworks.redis.RedisConnection
 
connect() - Method in class com.lambdaworks.redis.RedisClient
Open a new synchronous connection to the redis server that treats keys and values as UTF-8 strings.
connect(RedisCodec<K, V>) - Method in class com.lambdaworks.redis.RedisClient
Open a new synchronous connection to the redis server.
connectAsync() - Method in class com.lambdaworks.redis.RedisClient
Open a new asynchronous connection to the redis server that treats keys and values as UTF-8 strings.
connectAsync(RedisCodec<K, V>) - Method in class com.lambdaworks.redis.RedisClient
Open a new asynchronous connection to the redis server.
ConnectionEntry - Class in org.redisson.connection
 
ConnectionEntry(RedisClient, int, int) - Constructor for class org.redisson.connection.ConnectionEntry
 
ConnectionManager - Interface in org.redisson.connection
 
connectionReadOp() - Method in interface org.redisson.connection.ConnectionManager
 
connectionReadOp() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
connectionReadOp() - Method in class org.redisson.connection.SingleConnectionManager
 
ConnectionWatchdog - Class in com.lambdaworks.redis.protocol
A netty ChannelHandler responsible for monitoring the channel and reconnecting when the connection is lost.
ConnectionWatchdog(Bootstrap, ChannelGroup) - Constructor for class com.lambdaworks.redis.protocol.ConnectionWatchdog
Create a new watchdog that adds to new connections to the supplied ChannelGroup and establishes a new Channel when disconnected, while reconnect is true.
connectionWriteOp() - Method in interface org.redisson.connection.ConnectionManager
 
connectionWriteOp() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
connectPubSub() - Method in class com.lambdaworks.redis.RedisClient
Open a new pub/sub connection to the redis server that treats keys and values as UTF-8 strings.
connectPubSub(RedisCodec<K, V>) - Method in class com.lambdaworks.redis.RedisClient
Open a new pub/sub connection to the redis server.
contains(Object) - Method in class org.redisson.RedissonList
 
contains(Object) - Method in class org.redisson.RedissonSet
 
contains(Object) - Method in class org.redisson.RedissonSortedSet
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonList
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonSet
 
containsAll(Collection<?>) - Method in class org.redisson.RedissonSortedSet
 
containsKey(Object) - Method in class org.redisson.misc.ReferenceMap
 
containsKey(Object) - Method in class org.redisson.RedissonMap
 
containsValue(Object) - Method in class org.redisson.misc.ReferenceMap
 
containsValue(Object) - Method in class org.redisson.RedissonMap
 
count() - Method in class com.lambdaworks.redis.protocol.CommandArgs
 
count() - Method in class com.lambdaworks.redis.pubsub.PubSubOutput
 
count() - Method in interface org.redisson.core.RHyperLogLog
 
count() - Method in class org.redisson.RedissonHyperLogLog
 
countAsync() - Method in interface org.redisson.core.RHyperLogLog
 
countAsync() - Method in class org.redisson.RedissonHyperLogLog
 
countDown() - Method in interface org.redisson.core.RCountDownLatch
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
countDown() - Method in class org.redisson.RedissonCountDownLatch
 
countWith(String...) - Method in interface org.redisson.core.RHyperLogLog
 
countWith(String...) - Method in class org.redisson.RedissonHyperLogLog
 
countWithAsync(String...) - Method in interface org.redisson.core.RHyperLogLog
 
countWithAsync(String...) - Method in class org.redisson.RedissonHyperLogLog
 
create() - Static method in class org.redisson.Redisson
Creates an Redisson instance
create(Config) - Static method in class org.redisson.Redisson
Creates an Redisson instance with configuration
createInstance() - Method in class org.redisson.codec.KryoCodec.KryoPoolImpl
Sub classes can customize the Kryo instance by overriding this method
createReleaseReadListener(RedisConnection) - Method in interface org.redisson.connection.ConnectionManager
 
createReleaseReadListener(RedisConnection) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
createReleaseWriteListener(RedisConnection) - Method in interface org.redisson.connection.ConnectionManager
 
createReleaseWriteListener(RedisConnection) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 

D

DateOutput<K,V> - Class in com.lambdaworks.redis.output
Date output with no milliseconds.
DateOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.DateOutput
 
dbsize() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
dbsize() - Method in class com.lambdaworks.redis.RedisConnection
 
debugObject(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
debugObject(K) - Method in class com.lambdaworks.redis.RedisConnection
 
decCounter() - Method in class org.redisson.RedissonLock.LockValue
 
decode(char[]) - Static method in class com.lambdaworks.codec.Base16
Decode base16 chars to bytes.
decode(ChannelHandlerContext, ByteBuf) - Method in class com.lambdaworks.redis.protocol.CommandHandler
 
decode(ByteBuf, CommandOutput<K, V, ?>) - Method in class com.lambdaworks.redis.protocol.RedisStateMachine
Attempt to decode a redis response and return a flag indicating whether a complete response was read.
decode(ChannelHandlerContext, ByteBuf) - Method in class com.lambdaworks.redis.pubsub.PubSubCommandHandler
 
decodeAscii(ByteBuffer) - Method in class com.lambdaworks.redis.protocol.CommandOutput
 
decodeKey(ByteBuffer) - Method in class com.lambdaworks.redis.codec.RedisCodec
Decode the key output by redis.
decodeKey(ByteBuffer) - Method in class com.lambdaworks.redis.codec.Utf8StringCodec
 
decodeKey(ByteBuffer) - Method in class org.redisson.codec.JsonJacksonCodec
 
decodeKey(ByteBuffer) - Method in class org.redisson.codec.KryoCodec
 
decodeKey(ByteBuffer) - Method in class org.redisson.codec.RedisCodecWrapper
 
decodeKey(ByteBuffer) - Method in interface org.redisson.codec.RedissonCodec
 
decodeKey(ByteBuffer) - Method in class org.redisson.codec.SerializationCodec
 
decodeKey(ByteBuffer) - Method in class org.redisson.codec.StringCodec
 
decodeMapKey(ByteBuffer) - Method in class com.lambdaworks.redis.codec.RedisCodec
 
decodeMapKey(ByteBuffer) - Method in class com.lambdaworks.redis.codec.Utf8StringCodec
 
decodeMapKey(ByteBuffer) - Method in class org.redisson.codec.JsonJacksonCodec
 
decodeMapKey(ByteBuffer) - Method in class org.redisson.codec.KryoCodec
 
decodeMapKey(ByteBuffer) - Method in class org.redisson.codec.RedisCodecWrapper
 
decodeMapKey(ByteBuffer) - Method in interface org.redisson.codec.RedissonCodec
 
decodeMapKey(ByteBuffer) - Method in class org.redisson.codec.SerializationCodec
 
decodeMapKey(ByteBuffer) - Method in class org.redisson.codec.StringCodec
 
decodeMapValue(ByteBuffer) - Method in class com.lambdaworks.redis.codec.RedisCodec
 
decodeMapValue(ByteBuffer) - Method in class com.lambdaworks.redis.codec.Utf8StringCodec
 
decodeMapValue(ByteBuffer) - Method in class org.redisson.codec.JsonJacksonCodec
 
decodeMapValue(ByteBuffer) - Method in class org.redisson.codec.KryoCodec
 
decodeMapValue(ByteBuffer) - Method in class org.redisson.codec.RedisCodecWrapper
 
decodeMapValue(ByteBuffer) - Method in interface org.redisson.codec.RedissonCodec
 
decodeMapValue(ByteBuffer) - Method in class org.redisson.codec.SerializationCodec
 
decodeMapValue(ByteBuffer) - Method in class org.redisson.codec.StringCodec
 
decodeValue(ByteBuffer) - Method in class com.lambdaworks.redis.codec.RedisCodec
Decode the value output by redis.
decodeValue(ByteBuffer) - Method in class com.lambdaworks.redis.codec.Utf8StringCodec
 
decodeValue(ByteBuffer) - Method in class org.redisson.codec.JsonJacksonCodec
 
decodeValue(ByteBuffer) - Method in class org.redisson.codec.KryoCodec
 
decodeValue(ByteBuffer) - Method in class org.redisson.codec.RedisCodecWrapper
 
decodeValue(ByteBuffer) - Method in interface org.redisson.codec.RedissonCodec
 
decodeValue(ByteBuffer) - Method in class org.redisson.codec.SerializationCodec
 
decodeValue(ByteBuffer) - Method in class org.redisson.codec.StringCodec
 
decr(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
decr(K) - Method in class com.lambdaworks.redis.RedisConnection
 
decrby(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
decrby(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
decrementAndGet() - Method in interface org.redisson.core.RAtomicLong
Atomically decrements the current value by one.
decrementAndGet() - Method in class org.redisson.RedissonAtomicLong
 
del(K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
del(K...) - Method in class com.lambdaworks.redis.RedisConnection
 
delegate - Variable in class org.redisson.misc.ReferenceMap
 
delete() - Method in interface org.redisson.core.RObject
Deletes the object
delete() - Method in class org.redisson.RedissonCountDownLatch
 
delete() - Method in class org.redisson.RedissonLock
 
delete() - Method in class org.redisson.RedissonTopic
 
desc() - Static method in class com.lambdaworks.redis.SortArgs.Builder
 
desc() - Method in class com.lambdaworks.redis.SortArgs
 
descendingIterator() - Method in class org.redisson.RedissonDeque
 
digest(V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
digest(V) - Method in class com.lambdaworks.redis.RedisConnection
Generate SHA-1 digest for the supplied script.
discard() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
discard() - Method in class com.lambdaworks.redis.RedisConnection
 
dispatch(CommandType, CommandOutput<K, V, T>) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
dispatch(CommandType, CommandOutput<K, V, T>, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
dispatch(CommandType, CommandOutput<K, V, T>, K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
dispatch(CommandType, CommandOutput<K, V, T>, K, V[]) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
dispatch(CommandType, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
DoubleOutput<K,V> - Class in com.lambdaworks.redis.output
Double output, may be null.
DoubleOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.DoubleOutput
 
dump(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
dump(K) - Method in class com.lambdaworks.redis.RedisConnection
 

E

echo(V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
echo(V) - Method in class com.lambdaworks.redis.RedisConnection
 
element() - Method in class org.redisson.RedissonQueue
 
encode(byte[], boolean) - Static method in class com.lambdaworks.codec.Base16
Encode bytes to base16 chars.
encodeKey(K) - Method in class com.lambdaworks.redis.codec.RedisCodec
Encode the key for output to redis.
encodeKey(String) - Method in class com.lambdaworks.redis.codec.Utf8StringCodec
 
encodeKey(Object) - Method in class org.redisson.codec.JsonJacksonCodec
 
encodeKey(Object) - Method in class org.redisson.codec.KryoCodec
 
encodeKey(Object) - Method in class org.redisson.codec.RedisCodecWrapper
 
encodeKey(Object) - Method in interface org.redisson.codec.RedissonCodec
 
encodeKey(Object) - Method in class org.redisson.codec.SerializationCodec
 
encodeKey(Object) - Method in class org.redisson.codec.StringCodec
 
encodeMapKey(K) - Method in class com.lambdaworks.redis.codec.RedisCodec
 
encodeMapKey(String) - Method in class com.lambdaworks.redis.codec.Utf8StringCodec
 
encodeMapKey(Object) - Method in class org.redisson.codec.JsonJacksonCodec
 
encodeMapKey(Object) - Method in class org.redisson.codec.KryoCodec
 
encodeMapKey(Object) - Method in class org.redisson.codec.RedisCodecWrapper
 
encodeMapKey(Object) - Method in interface org.redisson.codec.RedissonCodec
 
encodeMapKey(Object) - Method in class org.redisson.codec.SerializationCodec
 
encodeMapKey(Object) - Method in class org.redisson.codec.StringCodec
 
encodeMapValue(V) - Method in class com.lambdaworks.redis.codec.RedisCodec
 
encodeMapValue(String) - Method in class com.lambdaworks.redis.codec.Utf8StringCodec
 
encodeMapValue(Object) - Method in class org.redisson.codec.JsonJacksonCodec
 
encodeMapValue(Object) - Method in class org.redisson.codec.KryoCodec
 
encodeMapValue(Object) - Method in class org.redisson.codec.RedisCodecWrapper
 
encodeMapValue(Object) - Method in interface org.redisson.codec.RedissonCodec
 
encodeMapValue(Object) - Method in class org.redisson.codec.SerializationCodec
 
encodeMapValue(Object) - Method in class org.redisson.codec.StringCodec
 
encodeValue(V) - Method in class com.lambdaworks.redis.codec.RedisCodec
Encode the value for output to redis.
encodeValue(String) - Method in class com.lambdaworks.redis.codec.Utf8StringCodec
 
encodeValue(Object) - Method in class org.redisson.codec.JsonJacksonCodec
 
encodeValue(Object) - Method in class org.redisson.codec.KryoCodec
 
encodeValue(Object) - Method in class org.redisson.codec.RedisCodecWrapper
 
encodeValue(Object) - Method in interface org.redisson.codec.RedissonCodec
 
encodeValue(Object) - Method in class org.redisson.codec.SerializationCodec
 
encodeValue(Object) - Method in class org.redisson.codec.StringCodec
 
entrySet() - Method in class org.redisson.misc.ReferenceMap
 
entrySet() - Method in class org.redisson.RedissonMap
 
equals(Object) - Method in class com.lambdaworks.redis.KeyValue
 
equals(Object) - Method in class com.lambdaworks.redis.ScoredValue
 
equals(Object) - Method in class org.redisson.RedisPubSubTopicListenerWrapper
 
equals(Object) - Method in class org.redisson.RedissonCountDownLatchEntry
 
equals(Object) - Method in class org.redisson.RedissonLock.LockValue
 
equals(Object) - Method in class org.redisson.RedissonLockEntry
 
error - Variable in class com.lambdaworks.redis.protocol.CommandOutput
 
eval(V, ScriptOutputType, K[], V...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
eval(V, ScriptOutputType, K...) - Method in class com.lambdaworks.redis.RedisConnection
Eval the supplied script, which must result in the requested type.
eval(V, ScriptOutputType, K[], V...) - Method in class com.lambdaworks.redis.RedisConnection
 
evalsha(String, ScriptOutputType, K[], V...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
evalsha(String, ScriptOutputType, K...) - Method in class com.lambdaworks.redis.RedisConnection
Eval a pre-loaded script identified by its SHA-1 digest, which must result in the requested type.
evalsha(String, ScriptOutputType, K[], V...) - Method in class com.lambdaworks.redis.RedisConnection
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.lambdaworks.redis.protocol.ConnectionWatchdog
 
exec() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
exec() - Method in class com.lambdaworks.redis.RedisConnection
 
execute(ReferenceMap, Object, Object) - Method in interface org.redisson.misc.ReferenceMap.Strategy
 
exists(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
exists(K) - Method in class com.lambdaworks.redis.RedisConnection
 
expire(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
expire(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
expire(long, TimeUnit) - Method in interface org.redisson.core.RExpirable
 
expireat(K, Date) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
expireat(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
expireat(K, Date) - Method in class com.lambdaworks.redis.RedisConnection
 
expireat(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
expireAt(long) - Method in interface org.redisson.core.RExpirable
 
expireAt(Date) - Method in interface org.redisson.core.RExpirable
 

F

first() - Method in class org.redisson.RedissonSortedSet
 
flushall() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
flushall() - Method in class com.lambdaworks.redis.RedisConnection
 
flushdb() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
flushdb() - Method in class com.lambdaworks.redis.RedisConnection
 
flushdb() - Method in class org.redisson.Redisson
 
forceUnlock() - Method in interface org.redisson.core.RLock
Unlocks lock independently of state
forceUnlock() - Method in class org.redisson.RedissonLock
 
freeze(String, int) - Method in interface org.redisson.connection.LoadBalancer
 

G

get() - Method in class com.lambdaworks.redis.protocol.CommandOutput
Get the command output.
get(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
get(K) - Method in class com.lambdaworks.redis.RedisConnection
 
get(String) - Static method in class com.lambdaworks.redis.SortArgs.Builder
 
get(String) - Method in class com.lambdaworks.redis.SortArgs
 
get() - Method in interface org.redisson.codec.KryoCodec.KryoPool
 
get() - Method in class org.redisson.codec.KryoCodec.KryoPoolImpl
 
get() - Method in interface org.redisson.core.RAtomicLong
Gets the current value.
get() - Method in interface org.redisson.core.RBucket
 
get(Object) - Method in class org.redisson.misc.ReferenceMap
 
get() - Method in class org.redisson.RedissonAtomicLong
 
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 com.lambdaworks.redis.RedisClient
 
getAddress() - Method in class org.redisson.SingleServerConfig
 
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
 
getAndDecrement() - Method in interface org.redisson.core.RAtomicLong
Atomically decrements by one the current value.
getAndDecrement() - 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
 
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
 
getAsync() - Method in class com.lambdaworks.redis.RedisConnection
 
getAsync() - Method in interface org.redisson.core.RBucket
 
getAsync(K) - Method in interface org.redisson.core.RMap
 
getAsync() - Method in class org.redisson.RedissonBucket
 
getAsync(K) - Method in class org.redisson.RedissonMap
 
getAtomicLong(String) - Method in class org.redisson.Redisson
Returns distributed "atomic long" instance by name.
getbit(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
getbit(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
getBucket(String) - Method in class org.redisson.Redisson
 
getClient() - Method in class org.redisson.connection.ConnectionEntry
 
getCodec() - Method in class org.redisson.Config
 
getConfig() - Method in class org.redisson.Redisson
Allows to get configuration provided during Redisson instance creation.
getConnection() - Method in class org.redisson.connection.PubSubConnectionEntry
 
getConnectionPoolSize() - Method in class org.redisson.SingleServerConfig
 
getConnections() - Method in class org.redisson.connection.ConnectionEntry
 
getConnectionsSemaphore() - Method in class org.redisson.connection.ConnectionEntry
 
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.
getCounter() - Method in class org.redisson.RedissonLock.LockValue
 
getDeque(String) - Method in class org.redisson.Redisson
Returns distributed deque instance by name.
getEntry(String) - Method in interface org.redisson.connection.ConnectionManager
 
getEntry(String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
getError() - Method in class com.lambdaworks.redis.protocol.CommandOutput
Get the error that occurred.
getFirst() - Method in class org.redisson.RedissonQueue
 
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 class org.redisson.Redisson
 
getIndex() - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
 
getLast() - Method in class org.redisson.RedissonDeque
 
getLatch() - Method in class org.redisson.RedissonCountDownLatchEntry
 
getLatch() - Method in class org.redisson.RedissonLockEntry
 
getLeftScore() - Method in class org.redisson.RedissonSortedSet.NewScore
 
getList(String) - Method in class org.redisson.Redisson
Returns distributed list instance by name.
getListeners(String) - Method in class org.redisson.connection.PubSubConnectionEntry
 
getLoadBalancer() - Method in class org.redisson.MasterSlaveServersConfig
 
getLock(String) - Method in class org.redisson.Redisson
Returns distributed lock instance by name.
getMap(String) - Method in class org.redisson.Redisson
Returns distributed map instance by name.
getMasterAddrByKey(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
getMasterAddress() - Method in class org.redisson.MasterSlaveServersConfig
 
getMasterConnectionPoolSize() - Method in class org.redisson.MasterSlaveServersConfig
 
getMasterName() - Method in class org.redisson.SentinelServersConfig
 
getName() - Method in interface org.redisson.core.RObject
Returns name of object
getName() - Method in class org.redisson.RedisPubSubTopicListenerWrapper
 
getOutput() - Method in class com.lambdaworks.redis.protocol.Command
Get the object that holds this command's output.
getPos() - Method in class com.lambdaworks.redis.output.ScanResult
 
getProimse() - Method in class com.lambdaworks.redis.protocol.Command
 
getPromise() - Method in class org.redisson.RedissonCountDownLatchEntry
 
getPromise() - Method in class org.redisson.RedissonLockEntry
 
getQueue(String) - Method in class org.redisson.Redisson
Returns distributed queue instance by name.
getrange(K, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
getrange(K, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
getRedisClient() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
getRedisClient() - Method in class com.lambdaworks.redis.RedisConnection
 
getRightScore() - Method in class org.redisson.RedissonSortedSet.NewScore
 
getScore() - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
 
getScore() - Method in class org.redisson.RedissonSortedSet.NewScore
 
getSentinelAddresses() - Method in class org.redisson.SentinelServersConfig
 
getset(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
getset(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
getSet(String) - Method in class org.redisson.Redisson
Returns distributed set instance by name.
getSlaveAddresses() - Method in class org.redisson.MasterSlaveServersConfig
 
getSlaveConnectionPoolSize() - Method in class org.redisson.MasterSlaveServersConfig
 
getSlaveSubscriptionConnectionPoolSize() - Method in class org.redisson.MasterSlaveServersConfig
 
getSortedSet(String) - Method in class org.redisson.Redisson
Returns distributed sorted set instance by name.
getSubscribeConnections() - Method in class org.redisson.connection.ConnectionEntry
 
getSubscribeConnectionsSemaphore() - Method in class org.redisson.connection.ConnectionEntry
 
getSubscriptionConnectionPoolSize() - Method in class org.redisson.SingleServerConfig
 
getThreads() - Method in class org.redisson.Config
 
getTopic(String) - Method in class org.redisson.Redisson
Returns distributed topic instance by name.
getValue() - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
 
getValues() - Method in class com.lambdaworks.redis.output.ScanResult
 
group - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 

H

hasError() - Method in class com.lambdaworks.redis.protocol.CommandOutput
Check if the command resulted in an error.
hashCode() - Method in class com.lambdaworks.redis.KeyValue
 
hashCode() - Method in class com.lambdaworks.redis.ScoredValue
 
hashCode() - Method in class org.redisson.RedisPubSubTopicListenerWrapper
 
hashCode() - Method in class org.redisson.RedissonCountDownLatchEntry
 
hashCode() - Method in class org.redisson.RedissonLock.LockValue
 
hashCode() - Method in class org.redisson.RedissonLockEntry
 
hdel(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hdel(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
headSet(V) - Method in class org.redisson.RedissonSortedSet
 
hexists(K, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hexists(K, K) - Method in class com.lambdaworks.redis.RedisConnection
 
hget(K, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hget(K, K) - Method in class com.lambdaworks.redis.RedisConnection
 
hgetall(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hgetall(K) - Method in class com.lambdaworks.redis.RedisConnection
 
hincrby(K, K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hincrby(K, K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
hincrbyfloat(K, K, double) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hincrbyfloat(K, K, double) - Method in class com.lambdaworks.redis.RedisConnection
 
hkeys(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hkeys(K) - Method in class com.lambdaworks.redis.RedisConnection
 
hlen(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hlen(K) - Method in class com.lambdaworks.redis.RedisConnection
 
hmget(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hmget(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
hmset(K, Map<K, V>) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hmset(K, Map<K, V>) - Method in class com.lambdaworks.redis.RedisConnection
 
hset(K, K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hset(K, K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
hsetnx(K, K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hsetnx(K, K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
hvals(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
hvals(K) - Method in class com.lambdaworks.redis.RedisConnection
 

I

incCounter() - Method in class org.redisson.RedissonLock.LockValue
 
incr(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
incr(K) - Method in class com.lambdaworks.redis.RedisConnection
 
incrby(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
incrby(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
incrbyfloat(K, double) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
incrbyfloat(K, double) - Method in class com.lambdaworks.redis.RedisConnection
 
incrementAndGet() - Method in interface org.redisson.core.RAtomicLong
Atomically increments the current value by one.
incrementAndGet() - Method in class org.redisson.RedissonAtomicLong
 
indexOf(Object) - Method in class org.redisson.RedissonList
 
info() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
info(String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
info() - Method in class com.lambdaworks.redis.RedisConnection
 
info(String) - Method in class com.lambdaworks.redis.RedisConnection
 
init(RedisCodec, String) - Method in interface org.redisson.connection.LoadBalancer
 
init(MasterSlaveServersConfig, Config) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
init(MasterSlaveServersConfig) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
init(Config) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
IntegerOutput<K,V> - Class in com.lambdaworks.redis.output
64-bit integer output, may be null.
IntegerOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.IntegerOutput
 
isActive() - Method in class org.redisson.connection.PubSubConnectionEntry
 
isBreak(RedisAsyncConnection<Object, V>, Promise<V>, Future<F>) - Method in class org.redisson.OperationListener
 
isEmpty() - Method in class org.redisson.misc.ReferenceMap
 
isEmpty() - Method in class org.redisson.RedissonList
 
isEmpty() - Method in class org.redisson.RedissonMap
 
isEmpty() - Method in class org.redisson.RedissonSet
 
isEmpty() - Method in class org.redisson.RedissonSortedSet
 
isFree() - Method in class org.redisson.RedissonCountDownLatchEntry
 
isFree() - Method in class org.redisson.RedissonLockEntry
 
isFreezed() - Method in class org.redisson.connection.ConnectionEntry
 
isHeldByCurrentThread() - Method in interface org.redisson.core.RLock
Checks if this lock is held by the current thread
isHeldByCurrentThread() - Method in class org.redisson.RedissonLock
 
isLocked() - Method in interface org.redisson.core.RLock
Checks if this lock locked by any thread in Redisson cluster
isLocked() - Method in class org.redisson.RedissonLock
 
isMultiMode() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
isOpened() - Method in class org.redisson.misc.ReclosableLatch
 
iterator() - Method in class org.redisson.RedissonList
 
iterator() - Method in class org.redisson.RedissonSet
 
iterator() - Method in class org.redisson.RedissonSortedSet
 
iterator(double, double) - Method in class org.redisson.RedissonSortedSet
 

J

JsonJacksonCodec - Class in org.redisson.codec
 
JsonJacksonCodec() - Constructor for class org.redisson.codec.JsonJacksonCodec
 

K

key - Variable in class com.lambdaworks.redis.KeyValue
 
KeyListOutput<K,V> - Class in com.lambdaworks.redis.output
List of keys output.
KeyListOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.KeyListOutput
 
KeyOutput<K,V> - Class in com.lambdaworks.redis.output
Key output.
KeyOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.KeyOutput
 
keyReferenceType - Variable in class org.redisson.misc.ReferenceMap
 
keys(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
keys(K) - Method in class com.lambdaworks.redis.RedisConnection
 
keySet() - Method in class org.redisson.RedissonMap
 
KeyValue<K,V> - Class in com.lambdaworks.redis
A key-value pair.
KeyValue(K, V) - Constructor for class com.lambdaworks.redis.KeyValue
 
KeyValueOutput<K,V> - Class in com.lambdaworks.redis.output
Key-value pair output.
KeyValueOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.KeyValueOutput
 
KryoCodec - Class in org.redisson.codec
 
KryoCodec() - Constructor for class org.redisson.codec.KryoCodec
 
KryoCodec(KryoCodec.KryoPool) - Constructor for class org.redisson.codec.KryoCodec
 
KryoCodec.KryoPool - Interface in org.redisson.codec
 
KryoCodec.KryoPoolImpl - Class in org.redisson.codec
 
KryoCodec.KryoPoolImpl() - Constructor for class org.redisson.codec.KryoCodec.KryoPoolImpl
 
KryoCodec.RedissonKryoCodecException - Exception in org.redisson.codec
 
KryoCodec.RedissonKryoCodecException(Throwable) - Constructor for exception org.redisson.codec.KryoCodec.RedissonKryoCodecException
 

L

last() - Method in class org.redisson.RedissonSortedSet
 
lastIndexOf(Object) - Method in class org.redisson.RedissonList
 
lastsave() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
lastsave() - Method in class com.lambdaworks.redis.RedisConnection
 
limit(long, long) - Static method in class com.lambdaworks.redis.SortArgs.Builder
 
limit(long, long) - Method in class com.lambdaworks.redis.SortArgs
 
lindex(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
lindex(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
linsert(K, boolean, V, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
linsert(K, boolean, V, V) - Method in class com.lambdaworks.redis.RedisConnection
 
listIterator() - Method in class org.redisson.RedissonList
 
listIterator(int) - Method in class org.redisson.RedissonList
 
ListMapOutput<K,V> - Class in com.lambdaworks.redis.output
 
ListMapOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.ListMapOutput
 
llen(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
llen(K) - Method in class com.lambdaworks.redis.RedisConnection
 
LoadBalancer - Interface in org.redisson.connection
 
lock() - Method in class org.redisson.RedissonLock
 
lockInterruptibly() - Method in class org.redisson.RedissonLock
 
lpop(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
lpop(K) - Method in class com.lambdaworks.redis.RedisConnection
 
lpush(K, V...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
lpush(K, V...) - Method in class com.lambdaworks.redis.RedisConnection
 
lpushx(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
lpushx(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
lrange(K, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
lrange(K, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
lrem(K, long, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
lrem(K, long, V) - Method in class com.lambdaworks.redis.RedisConnection
 
lset(K, long, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
lset(K, long, V) - Method in class com.lambdaworks.redis.RedisConnection
 
ltrim(K, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
ltrim(K, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 

M

MapKeyListOutput<K,V> - Class in com.lambdaworks.redis.output
List of keys output.
MapKeyListOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.MapKeyListOutput
 
MapOutput<K,V> - Class in com.lambdaworks.redis.output
Map of keys and values output.
MapOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.MapOutput
 
MapValueListOutput<K,V> - Class in com.lambdaworks.redis.output
List of values output.
MapValueListOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.MapValueListOutput
 
MapValueOutput<K,V> - Class in com.lambdaworks.redis.output
Value output.
MapValueOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.MapValueOutput
 
masterClient - Variable in class org.redisson.connection.MasterSlaveConnectionManager
 
MasterSlaveConnectionManager - Class in org.redisson.connection
 
MasterSlaveConnectionManager(MasterSlaveServersConfig, Config) - Constructor for class org.redisson.connection.MasterSlaveConnectionManager
 
MasterSlaveServersConfig - Class in org.redisson
 
MasterSlaveServersConfig() - Constructor for class org.redisson.MasterSlaveServersConfig
 
max() - Static method in class com.lambdaworks.redis.ZStoreArgs.Builder
 
max() - Method in class com.lambdaworks.redis.ZStoreArgs
 
mergeWith(String...) - Method in interface org.redisson.core.RHyperLogLog
 
mergeWith(String...) - Method in class org.redisson.RedissonHyperLogLog
 
mergeWithAsync(String...) - Method in interface org.redisson.core.RHyperLogLog
 
mergeWithAsync(String...) - Method in class org.redisson.RedissonHyperLogLog
 
message(String, V) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubAdapter
 
message(String, String, V) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubAdapter
 
message(String, V) - Method in interface com.lambdaworks.redis.pubsub.RedisPubSubListener
Message received from a channel subscription.
message(String, String, V) - Method in interface com.lambdaworks.redis.pubsub.RedisPubSubListener
Message received from a pattern subscription.
message(String, V) - Method in class org.redisson.RedisPubSubTopicListenerWrapper
 
MessageListener<M> - Interface in org.redisson.core
Listener for Redis messages published via RTopic Redisson object
mget(K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
mget(K...) - Method in class com.lambdaworks.redis.RedisConnection
 
migrate(String, int, K, int, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
migrate(String, int, K, int, long) - Method in class com.lambdaworks.redis.RedisConnection
 
min() - Static method in class com.lambdaworks.redis.ZStoreArgs.Builder
 
min() - Method in class com.lambdaworks.redis.ZStoreArgs
 
move(K, int) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
move(K, int) - Method in class com.lambdaworks.redis.RedisConnection
 
mset(Map<K, V>) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
mset(Map<K, V>) - Method in class com.lambdaworks.redis.RedisConnection
 
msetnx(Map<K, V>) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
msetnx(Map<K, V>) - Method in class com.lambdaworks.redis.RedisConnection
 
multi - Variable in class com.lambdaworks.redis.RedisAsyncConnection
 
multi() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
multi() - Method in class com.lambdaworks.redis.RedisConnection
 
MultiOutput<K,V> - Class in com.lambdaworks.redis.output
Output of all commands within a MULTI block.
MultiOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.MultiOutput
 

N

NestedMultiOutput<K,V> - Class in com.lambdaworks.redis.output
List of command outputs, possibly deeply nested.
NestedMultiOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.NestedMultiOutput
 
newCondition() - Method in class org.redisson.RedissonLock
 
newScriptOutput(RedisCodec<K, V>, ScriptOutputType) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
nextConnection() - Method in interface org.redisson.connection.LoadBalancer
 
nextPubSubConnection() - Method in interface org.redisson.connection.LoadBalancer
 

O

objectEncoding(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
objectEncoding(K) - Method in class com.lambdaworks.redis.RedisConnection
 
objectIdletime(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
objectIdletime(K) - Method in class com.lambdaworks.redis.RedisConnection
 
objectRefcount(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
objectRefcount(K) - Method in class com.lambdaworks.redis.RedisConnection
 
offer(V) - Method in class org.redisson.RedissonQueue
 
offerFirst(V) - Method in class org.redisson.RedissonDeque
 
offerLast(V) - Method in class org.redisson.RedissonDeque
 
onMessage(M) - Method in interface org.redisson.core.MessageListener
Invokes on every message in topic
onOperationComplete(Future<F>) - Method in class org.redisson.OperationListener
 
onRemove(V) - Method in interface org.redisson.misc.ReferenceMap.RemoveValueListener
 
onSlaveAdded(Set<String>, URI, String) - Method in class org.redisson.connection.SentinelConnectionManager
 
onSlaveUp(Set<String>, URI, String) - Method in class org.redisson.connection.SentinelConnectionManager
 
open() - Method in class org.redisson.misc.ReclosableLatch
 
operationComplete(Future<F>) - Method in class org.redisson.OperationListener
 
OperationListener<V,F> - Class in org.redisson
 
OperationListener(Promise<V>, RedisAsyncConnection<Object, V>) - Constructor for class org.redisson.OperationListener
 
org.redisson - package org.redisson
 
org.redisson.codec - package org.redisson.codec
 
org.redisson.connection - package org.redisson.connection
 
org.redisson.core - package org.redisson.core
 
org.redisson.misc - package org.redisson.misc
 
output - Variable in class com.lambdaworks.redis.protocol.Command
 
output - Variable in class com.lambdaworks.redis.protocol.CommandOutput
 

P

pattern() - Method in class com.lambdaworks.redis.pubsub.PubSubOutput
 
peek() - Method in class org.redisson.RedissonQueue
 
peekFirst() - Method in class org.redisson.RedissonDeque
 
peekLast() - Method in class org.redisson.RedissonDeque
 
persist(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
persist(K) - Method in class com.lambdaworks.redis.RedisConnection
 
pexpire(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
pexpire(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
pexpireat(K, Date) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
pexpireat(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
pexpireat(K, Date) - Method in class com.lambdaworks.redis.RedisConnection
 
pexpireat(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
pfadd(K, V...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
pfadd(K, V...) - Method in class com.lambdaworks.redis.RedisConnection
 
pfcount(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
pfcount(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
pfmerge(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
pfmerge(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
ping() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
ping() - Method in class com.lambdaworks.redis.RedisConnection
 
poll() - Method in class org.redisson.RedissonQueue
 
pollFirst() - Method in class org.redisson.RedissonDeque
 
pollLast() - Method in class org.redisson.RedissonDeque
 
pop() - Method in class org.redisson.RedissonDeque
 
psubscribe(String...) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubConnection
 
psubscribed(String, long) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubAdapter
 
psubscribed(String, long) - Method in interface com.lambdaworks.redis.pubsub.RedisPubSubListener
Subscribed to a pattern.
pttl(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
pttl(K) - Method in class com.lambdaworks.redis.RedisConnection
 
publish(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
publish(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
publish(M) - Method in interface org.redisson.core.RTopic
Publish the message to all subscribers of this topic
publish(M) - Method in class org.redisson.RedissonTopic
 
publishAsync(M) - Method in interface org.redisson.core.RTopic
Publish the message to all subscribers of this topic asynchronously
publishAsync(M) - Method in class org.redisson.RedissonTopic
 
PubSubCommandHandler<K,V> - Class in com.lambdaworks.redis.pubsub
A netty ChannelHandler responsible for writing redis pub/sub commands and reading the response stream from the server.
PubSubCommandHandler(BlockingQueue<Command<K, V, ?>>, RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.pubsub.PubSubCommandHandler
Initialize a new instance.
PubSubConnectionEntry - Class in org.redisson.connection
 
PubSubConnectionEntry(RedisPubSubConnection, int) - Constructor for class org.redisson.connection.PubSubConnectionEntry
 
PubSubConnectionEntry.Status - Enum in org.redisson.connection
 
PubSubOutput<K,V> - Class in com.lambdaworks.redis.pubsub
One element of the redis pub/sub stream.
PubSubOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.pubsub.PubSubOutput
 
punsubscribe(String...) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubConnection
 
punsubscribed(String, long) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubAdapter
 
punsubscribed(String, long) - Method in interface com.lambdaworks.redis.pubsub.RedisPubSubListener
Unsubscribed from a pattern.
push(V) - Method in class org.redisson.RedissonDeque
 
put(K, V) - Method in class org.redisson.misc.ReferenceMap
 
put(K, V) - Method in class org.redisson.RedissonMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.redisson.misc.ReferenceMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.redisson.RedissonMap
 
putAsync(K, V) - Method in interface org.redisson.core.RMap
 
putAsync(K, V) - Method in class org.redisson.RedissonMap
 
putIfAbsent(K, V) - Method in class org.redisson.misc.ReferenceMap
 
putIfAbsent(K, V) - Method in class org.redisson.RedissonMap
 

Q

queue - Variable in class com.lambdaworks.redis.protocol.CommandHandler
 
queue - Variable in class com.lambdaworks.redis.RedisAsyncConnection
 
quit() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
quit() - Method in class com.lambdaworks.redis.RedisConnection
 

R

randomkey() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
randomkey() - Method in class com.lambdaworks.redis.RedisConnection
 
RandomLoadBalancer - Class in org.redisson.connection
 
RandomLoadBalancer() - Constructor for class org.redisson.connection.RandomLoadBalancer
 
RAtomicLong - Interface in org.redisson.core
Distributed alternative to the AtomicLong
RBucket<V> - Interface in org.redisson.core
 
RCountDownLatch - Interface in org.redisson.core
Distributed alternative to the CountDownLatch It has a advantage over CountDownLatch -- count can be reset via RCountDownLatch.trySetCount(long).
RDeque<V> - Interface in org.redisson.core
Deque backed by Redis
ReclosableLatch - Class in org.redisson.misc
A thread gate, that uses an AbstractQueuedSynchronizer.
ReclosableLatch() - Constructor for class org.redisson.misc.ReclosableLatch
 
ReclosableLatch(boolean) - Constructor for class org.redisson.misc.ReclosableLatch
 
RedisAsyncConnection<K,V> - Class in com.lambdaworks.redis
An asynchronous thread-safe connection to a redis server.
RedisAsyncConnection(RedisClient, BlockingQueue<Command<K, V, ?>>, RedisCodec<K, V>, long, TimeUnit, EventLoopGroup) - Constructor for class com.lambdaworks.redis.RedisAsyncConnection
Initialize a new connection.
RedisClient - Class in com.lambdaworks.redis
A scalable thread-safe Redis client.
RedisClient(EventLoopGroup, String) - Constructor for class com.lambdaworks.redis.RedisClient
Create a new client that connects to the supplied host on the default port.
RedisClient(EventLoopGroup, String, int) - Constructor for class com.lambdaworks.redis.RedisClient
Create a new client that connects to the supplied host and port.
RedisCodec<K,V> - Class in com.lambdaworks.redis.codec
A RedisCodec encodes keys and values sent to redis, and decodes keys and values in the command output.
RedisCodec() - Constructor for class com.lambdaworks.redis.codec.RedisCodec
 
RedisCodecWrapper - Class in org.redisson.codec
 
RedisCodecWrapper(RedissonCodec) - Constructor for class org.redisson.codec.RedisCodecWrapper
 
RedisCommandInterruptedException - Exception in com.lambdaworks.redis
Exception thrown when the thread executing a redis command is interrupted.
RedisCommandInterruptedException(Throwable) - Constructor for exception com.lambdaworks.redis.RedisCommandInterruptedException
 
RedisConnection<K,V> - Class in com.lambdaworks.redis
A synchronous thread-safe connection to a redis server.
RedisConnection(RedisAsyncConnection<K, V>) - Constructor for class com.lambdaworks.redis.RedisConnection
Initialize a new connection.
RedisConnectionException - Exception in com.lambdaworks.redis
 
RedisConnectionException(String, Throwable) - Constructor for exception com.lambdaworks.redis.RedisConnectionException
 
RedisException - Exception in com.lambdaworks.redis
Exception thrown when redis returns an error message, or when the client fails for any reason.
RedisException(String) - Constructor for exception com.lambdaworks.redis.RedisException
 
RedisException(String, Throwable) - Constructor for exception com.lambdaworks.redis.RedisException
 
RedisPubSubAdapter<V> - Class in com.lambdaworks.redis.pubsub
Convenience adapter with an empty implementation of all RedisPubSubListener callback methods.
RedisPubSubAdapter() - Constructor for class com.lambdaworks.redis.pubsub.RedisPubSubAdapter
 
RedisPubSubConnection<K,V> - Class in com.lambdaworks.redis.pubsub
An asynchronous thread-safe pub/sub connection to a redis server.
RedisPubSubConnection(RedisClient, BlockingQueue<Command<K, V, ?>>, RedisCodec<K, V>, long, TimeUnit, EventLoopGroup) - Constructor for class com.lambdaworks.redis.pubsub.RedisPubSubConnection
Initialize a new connection.
RedisPubSubListener<V> - Interface in com.lambdaworks.redis.pubsub
Interface for redis pub/sub listeners.
RedisPubSubTopicListenerWrapper<V> - Class in org.redisson
 
RedisPubSubTopicListenerWrapper(MessageListener<V>, String) - Constructor for class org.redisson.RedisPubSubTopicListenerWrapper
 
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
Distributed alternative to the AtomicLong
RedissonBucket<V> - Class in org.redisson
 
RedissonCodec - Interface in org.redisson.codec
 
RedissonCountDownLatch - Class in org.redisson
Distributed alternative to the CountDownLatch It has a advantage over CountDownLatch -- count can be reset via RedissonCountDownLatch.trySetCount(long).
RedissonCountDownLatchEntry - Class in org.redisson
 
RedissonCountDownLatchEntry(RedissonCountDownLatchEntry) - Constructor for class org.redisson.RedissonCountDownLatchEntry
 
RedissonCountDownLatchEntry(Promise<Boolean>) - Constructor for class org.redisson.RedissonCountDownLatchEntry
 
RedissonDeque<V> - Class in org.redisson
Distributed and concurrent implementation of Queue
RedissonHyperLogLog<V> - Class in org.redisson
 
RedissonList<V> - Class in org.redisson
Distributed and concurrent implementation of List
RedissonLock - Class in org.redisson
Distributed implementation of Lock Implements reentrant lock.
RedissonLock.LockValue - Class in org.redisson
 
RedissonLock.LockValue() - Constructor for class org.redisson.RedissonLock.LockValue
 
RedissonLock.LockValue(UUID, Long) - Constructor for class org.redisson.RedissonLock.LockValue
 
RedissonLockEntry - Class in org.redisson
 
RedissonLockEntry(RedissonLockEntry) - Constructor for class org.redisson.RedissonLockEntry
 
RedissonLockEntry(Promise<Boolean>) - Constructor for class org.redisson.RedissonLockEntry
 
RedissonMap<K,V> - Class in org.redisson
Distributed and concurrent implementation of ConcurrentMap and Map
RedissonQueue<V> - Class in org.redisson
Distributed and concurrent implementation of Queue
RedissonSet<V> - Class in org.redisson
Distributed and concurrent implementation of Set
RedissonSortedSet<V> - Class in org.redisson
 
RedissonSortedSet.BinarySearchResult<V> - Class in org.redisson
 
RedissonSortedSet.BinarySearchResult(V, double) - Constructor for class org.redisson.RedissonSortedSet.BinarySearchResult
 
RedissonSortedSet.BinarySearchResult() - Constructor for class org.redisson.RedissonSortedSet.BinarySearchResult
 
RedissonSortedSet.NewScore - Class in org.redisson
 
RedissonSortedSet.NewScore(Double, Double, Double) - Constructor for class org.redisson.RedissonSortedSet.NewScore
 
RedissonTopic<M> - Class in org.redisson
Distributed topic implementation.
RedisStateMachine<K,V> - Class in com.lambdaworks.redis.protocol
State machine that decodes redis server responses encoded according to the Unified Request Protocol.
RedisStateMachine() - Constructor for class com.lambdaworks.redis.protocol.RedisStateMachine
Initialize a new instance.
ReferenceMap<K,V> - Class in org.redisson.misc
Concurrent hash map that wraps keys and/or values in SOFT or WEAK references.
ReferenceMap(ReferenceMap.ReferenceType, ReferenceMap.ReferenceType) - Constructor for class org.redisson.misc.ReferenceMap
 
ReferenceMap(ReferenceMap.ReferenceType, ReferenceMap.ReferenceType, ReferenceMap.RemoveValueListener<V>) - Constructor for class org.redisson.misc.ReferenceMap
Concurrent hash map that wraps keys and/or values based on specified reference types.
ReferenceMap.ReferenceType - Enum in org.redisson.misc
 
ReferenceMap.RemoveValueListener<V> - Interface in org.redisson.misc
 
ReferenceMap.Strategy - Interface in org.redisson.misc
 
release() - Method in class org.redisson.connection.PubSubConnectionEntry
 
release() - Method in class org.redisson.RedissonCountDownLatchEntry
 
release() - Method in class org.redisson.RedissonLockEntry
 
releaseRead(RedisConnection) - Method in interface org.redisson.connection.ConnectionManager
 
releaseRead(RedisConnection) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
releaseRead(RedisConnection) - Method in class org.redisson.connection.SingleConnectionManager
 
releaseWrite(RedisConnection) - Method in interface org.redisson.connection.ConnectionManager
 
releaseWrite(RedisConnection) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
remainTimeToLive() - Method in interface org.redisson.core.RExpirable
Remaining time to live of Redisson object that has a timeout
remove(Object) - Method in class org.redisson.misc.ReferenceMap
 
remove(Object, Object) - Method in class org.redisson.misc.ReferenceMap
 
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.RedissonQueue
 
remove(Object) - Method in class org.redisson.RedissonSet
 
remove(Object) - Method in class org.redisson.RedissonSortedSet
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonList
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonSet
 
removeAll(Collection<?>) - Method in class org.redisson.RedissonSortedSet
 
removeAsync(K) - Method in interface org.redisson.core.RMap
 
removeAsync(V) - Method in interface org.redisson.core.RSet
 
removeAsync(V) - Method in interface org.redisson.core.RSortedSet
 
removeAsync(K) - Method in class org.redisson.RedissonMap
 
removeAsync(V) - Method in class org.redisson.RedissonSet
 
removeAsync(V) - Method in class org.redisson.RedissonSortedSet
 
removeFirst() - Method in class org.redisson.RedissonQueue
 
removeFirstOccurrence(Object) - Method in class org.redisson.RedissonDeque
 
removeLast() - Method in class org.redisson.RedissonDeque
 
removeLastOccurrence(Object) - Method in class org.redisson.RedissonDeque
 
removeListener(RedisPubSubListener<V>) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubConnection
Remove an existing listener.
removeListener(String, int) - Method in class org.redisson.connection.PubSubConnectionEntry
 
removeListener(String, RedisPubSubListener) - Method in class org.redisson.connection.PubSubConnectionEntry
 
removeListener(int) - Method in interface org.redisson.core.RTopic
Removes the listener by id for listening this topic
removeListener(int) - Method in class org.redisson.RedissonTopic
 
rename(K, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
rename(K, K) - Method in class com.lambdaworks.redis.RedisConnection
 
renamenx(K, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
renamenx(K, K) - Method in class com.lambdaworks.redis.RedisConnection
 
replace(K, V, V) - Method in class org.redisson.misc.ReferenceMap
 
replace(K, V) - Method in class org.redisson.misc.ReferenceMap
 
replace(K, V, V) - Method in class org.redisson.RedissonMap
 
replace(K, V) - Method in class org.redisson.RedissonMap
 
restore(K, long, byte[]) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
restore(K, long, byte[]) - Method in class com.lambdaworks.redis.RedisConnection
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonList
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonSet
 
retainAll(Collection<?>) - Method in class org.redisson.RedissonSortedSet
 
returnConnection(RedisConnection) - Method in interface org.redisson.connection.LoadBalancer
 
returnSubscribeConnection(RedisPubSubConnection) - Method in interface org.redisson.connection.LoadBalancer
 
returnSubscribeConnection(PubSubConnectionEntry) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
returnSubscribeConnection(PubSubConnectionEntry) - Method in class org.redisson.connection.SingleConnectionManager
 
RExpirable - Interface in org.redisson.core
Interface with expiration support for Redisson objects.
RHyperLogLog<V> - Interface in org.redisson.core
 
RList<V> - Interface in org.redisson.core
Distributed and concurrent implementation of List
RLock - Interface in org.redisson.core
Distributed implementation of Lock Implements reentrant lock.
RMap<K,V> - Interface in org.redisson.core
Distributed and concurrent implementation of ConcurrentMap and Map
RObject - Interface in org.redisson.core
Base interface for all Redisson objects
RoundRobinLoadBalancer - Class in org.redisson.connection
 
RoundRobinLoadBalancer() - Constructor for class org.redisson.connection.RoundRobinLoadBalancer
 
rpop(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
rpop(K) - Method in class com.lambdaworks.redis.RedisConnection
 
rpoplpush(K, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
rpoplpush(K, K) - Method in class com.lambdaworks.redis.RedisConnection
 
rpush(K, V...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
rpush(K, V...) - Method in class com.lambdaworks.redis.RedisConnection
 
rpushx(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
rpushx(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
RQueue<V> - Interface in org.redisson.core
Queue backed by Redis
RSet<V> - Interface in org.redisson.core
Distributed and concurrent implementation of Set
rsm - Variable in class com.lambdaworks.redis.protocol.CommandHandler
 
RSortedSet<V> - Interface in org.redisson.core
 
RTopic<M> - Interface in org.redisson.core
Distributed topic.

S

sadd(K, V...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sadd(K, V...) - Method in class com.lambdaworks.redis.RedisConnection
 
save() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
save() - Method in class com.lambdaworks.redis.RedisConnection
 
ScanOutput<K,V> - Class in com.lambdaworks.redis.output
 
ScanOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.ScanOutput
 
ScanResult<V> - Class in com.lambdaworks.redis.output
 
ScanResult() - Constructor for class com.lambdaworks.redis.output.ScanResult
 
scard(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
scard(K) - Method in class com.lambdaworks.redis.RedisConnection
 
score - Variable in class com.lambdaworks.redis.ScoredValue
 
ScoredValue<V> - Class in com.lambdaworks.redis
A value and its associated score from a ZSET.
ScoredValue(double, V) - Constructor for class com.lambdaworks.redis.ScoredValue
 
ScoredValueListOutput<K,V> - Class in com.lambdaworks.redis.output
List of values and their associated scores.
ScoredValueListOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.ScoredValueListOutput
 
scriptExists(String...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
scriptExists(String...) - Method in class com.lambdaworks.redis.RedisConnection
 
scriptFlush() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
scriptFlush() - Method in class com.lambdaworks.redis.RedisConnection
 
scriptKill() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
scriptKill() - Method in class com.lambdaworks.redis.RedisConnection
 
scriptLoad(V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
scriptLoad(V) - Method in class com.lambdaworks.redis.RedisConnection
 
ScriptOutputType - Enum in com.lambdaworks.redis
A Lua script returns one of the following types: ScriptOutputType.BOOLEAN boolean ScriptOutputType.INTEGER 64-bit integer ScriptOutputType.STATUS status string ScriptOutputType.VALUE value ScriptOutputType.MULTI of these types.
sdiff(K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sdiff(K...) - Method in class com.lambdaworks.redis.RedisConnection
 
sdiffstore(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sdiffstore(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
select(int) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
select(int) - Method in class com.lambdaworks.redis.RedisConnection
 
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(long) - Method in class com.lambdaworks.redis.output.BooleanListOutput
 
set(long) - Method in class com.lambdaworks.redis.output.BooleanOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.BooleanOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.ByteArrayOutput
 
set(long) - Method in class com.lambdaworks.redis.output.DateOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.DoubleOutput
 
set(long) - Method in class com.lambdaworks.redis.output.IntegerOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.IntegerOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.KeyListOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.KeyOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.KeyValueOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.ListMapOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.MapKeyListOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.MapOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.MapValueListOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.MapValueOutput
 
set(long) - Method in class com.lambdaworks.redis.output.MultiOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.MultiOutput
 
set(long) - Method in class com.lambdaworks.redis.output.NestedMultiOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.NestedMultiOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.ScanOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.ScoredValueListOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.StatusOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.StringListOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.ValueListOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.ValueOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.output.ValueSetOutput
 
set(ByteBuffer) - Method in class com.lambdaworks.redis.protocol.CommandOutput
Set the command output to a sequence of bytes, or null.
set(long) - Method in class com.lambdaworks.redis.protocol.CommandOutput
Set the command output to a 64-bit signed integer.
set(ByteBuffer) - Method in class com.lambdaworks.redis.pubsub.PubSubOutput
 
set(long) - Method in class com.lambdaworks.redis.pubsub.PubSubOutput
 
set(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
set(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
set(long) - Method in interface org.redisson.core.RAtomicLong
Atomically sets the given value.
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(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.SingleServerConfig
Set server address.
setAsync(V) - Method in interface org.redisson.core.RBucket
 
setAsync(V, long, TimeUnit) - Method in interface org.redisson.core.RBucket
 
setAsync(V) - Method in class org.redisson.RedissonBucket
 
setAsync(V, long, TimeUnit) - Method in class org.redisson.RedissonBucket
 
setbit(K, long, int) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
setbit(K, long, int) - Method in class com.lambdaworks.redis.RedisConnection
 
setCodec(RedissonCodec) - Method in class org.redisson.Config
Redis key/value codec.
setConnectionPoolSize(int) - Method in class org.redisson.SingleServerConfig
Redis connection pool size Default is 100
setDefaultTimeout(long, TimeUnit) - Method in class com.lambdaworks.redis.RedisClient
Set the default timeout for connections created by this client.
setError(ByteBuffer) - Method in class com.lambdaworks.redis.output.MultiOutput
 
setError(ByteBuffer) - Method in class com.lambdaworks.redis.output.NestedMultiOutput
 
setError(ByteBuffer) - Method in class com.lambdaworks.redis.protocol.CommandOutput
Set command output to an error message from the server.
setError(String) - Method in class com.lambdaworks.redis.protocol.CommandOutput
Set command output to an error message from the client.
setex(K, long, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
setex(K, long, V) - Method in class com.lambdaworks.redis.RedisConnection
 
setFreezed(boolean) - Method in class org.redisson.connection.ConnectionEntry
 
setIndex(int) - Method in class org.redisson.RedissonSortedSet.BinarySearchResult
 
setLoadBalancer(LoadBalancer) - Method in class org.redisson.MasterSlaveServersConfig
Сonnection load balancer to multiple Redis slave servers.
setMasterAddress(String) - Method in class org.redisson.MasterSlaveServersConfig
Set Redis master server address.
setMasterConnectionPoolSize(int) - Method in class org.redisson.MasterSlaveServersConfig
Redis 'master' server connection pool size Default is 100
setMasterName(String) - Method in class org.redisson.SentinelServersConfig
 
setnx(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
setnx(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
setPos(Long) - Method in class com.lambdaworks.redis.output.ScanResult
 
setrange(K, long, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
setrange(K, long, V) - Method in class com.lambdaworks.redis.RedisConnection
 
setReconnect(boolean) - Method in class com.lambdaworks.redis.protocol.ConnectionWatchdog
 
setSlaveConnectionPoolSize(int) - Method in class org.redisson.MasterSlaveServersConfig
Redis 'slave' servers connection pool size for each slave node Default is 100
setSlaveSubscriptionConnectionPoolSize(int) - Method in class org.redisson.MasterSlaveServersConfig
Redis 'slave' servers subscription connection pool size for each slave node Default is 25
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
 
setTimeout(long, TimeUnit) - Method in class com.lambdaworks.redis.RedisAsyncConnection
Set the command timeout for this connection.
setTimeout(long, TimeUnit) - Method in class com.lambdaworks.redis.RedisConnection
Set the command timeout for this connection.
shutdown() - Method in class com.lambdaworks.redis.RedisAsyncConnection
Deprecated.
shutdown(boolean) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
shutdown() - Method in class com.lambdaworks.redis.RedisClient
Shutdown this client and close all open connections.
shutdown() - Method in class com.lambdaworks.redis.RedisConnection
Deprecated.
shutdown(boolean) - Method in class com.lambdaworks.redis.RedisConnection
 
shutdown() - Method in class org.redisson.connection.ConnectionEntry
 
shutdown() - Method in interface org.redisson.connection.ConnectionManager
 
shutdown() - Method in interface org.redisson.connection.LoadBalancer
 
shutdown() - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
shutdown() - Method in class org.redisson.connection.SentinelConnectionManager
 
shutdown() - Method in class org.redisson.Redisson
Shuts down Redisson instance NOT Redis server
SingleConnectionManager - Class in org.redisson.connection
 
SingleConnectionManager(SingleServerConfig, Config) - Constructor for class org.redisson.connection.SingleConnectionManager
 
SingleServerConfig - Class in org.redisson
 
sinter(K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sinter(K...) - Method in class com.lambdaworks.redis.RedisConnection
 
sinterstore(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sinterstore(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
sismember(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sismember(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
size() - Method in class org.redisson.misc.ReferenceMap
 
size() - Method in class org.redisson.RedissonList
 
size() - Method in class org.redisson.RedissonMap
 
size() - Method in class org.redisson.RedissonSet
 
size() - Method in class org.redisson.RedissonSortedSet
 
slaveDown(String, int) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
slaveof(String, int) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
slaveof(String, int) - Method in class com.lambdaworks.redis.RedisConnection
 
slaveofNoOne() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
slaveofNoOne() - Method in class com.lambdaworks.redis.RedisConnection
 
slaves(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
slaveUp(String, int) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
slowlogGet() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
slowlogGet(int) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
slowlogGet() - Method in class com.lambdaworks.redis.RedisConnection
 
slowlogGet(int) - Method in class com.lambdaworks.redis.RedisConnection
 
slowlogLen() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
slowlogLen() - Method in class com.lambdaworks.redis.RedisConnection
 
slowlogReset() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
slowlogReset() - Method in class com.lambdaworks.redis.RedisConnection
 
smembers(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
smembers(K) - Method in class com.lambdaworks.redis.RedisConnection
 
smove(K, K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
smove(K, K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
sort(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sort(K, SortArgs) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sort(K) - Method in class com.lambdaworks.redis.RedisConnection
 
sort(K, SortArgs) - Method in class com.lambdaworks.redis.RedisConnection
 
SortArgs - Class in com.lambdaworks.redis
Argument list builder for the redis SORT command.
SortArgs() - Constructor for class com.lambdaworks.redis.SortArgs
 
SortArgs.Builder - Class in com.lambdaworks.redis
Static builder methods.
SortArgs.Builder() - Constructor for class com.lambdaworks.redis.SortArgs.Builder
 
sortStore(K, SortArgs, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sortStore(K, SortArgs, K) - Method in class com.lambdaworks.redis.RedisConnection
 
spop(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
spop(K) - Method in class com.lambdaworks.redis.RedisConnection
 
srandmember(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
srandmember(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
srandmember(K) - Method in class com.lambdaworks.redis.RedisConnection
 
srandmember(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
srem(K, V...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
srem(K, V...) - Method in class com.lambdaworks.redis.RedisConnection
 
sscan(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sscan(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
StatusOutput<K,V> - Class in com.lambdaworks.redis.output
Status message output.
StatusOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.StatusOutput
 
string(double) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
StringCodec - Class in org.redisson.codec
 
StringCodec() - Constructor for class org.redisson.codec.StringCodec
 
StringListOutput<K,V> - Class in com.lambdaworks.redis.output
List of string output.
StringListOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.StringListOutput
 
strlen(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
strlen(K) - Method in class com.lambdaworks.redis.RedisConnection
 
subList(int, int) - Method in class org.redisson.RedissonList
 
subscribe(String...) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubConnection
 
subscribe(String) - Method in interface org.redisson.connection.ConnectionManager
 
subscribe(RedisPubSubAdapter<V>, String) - Method in interface org.redisson.connection.ConnectionManager
 
subscribe(String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
subscribe(RedisPubSubAdapter<V>, String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
subscribe(String) - Method in class org.redisson.connection.PubSubConnectionEntry
 
subscribe(RedisPubSubAdapter, String) - Method in class org.redisson.connection.PubSubConnectionEntry
 
subscribed(String, long) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubAdapter
 
subscribed(String, long) - Method in interface com.lambdaworks.redis.pubsub.RedisPubSubListener
Subscribed to a channel.
subSet(V, V) - Method in class org.redisson.RedissonSortedSet
 
sum() - Static method in class com.lambdaworks.redis.ZStoreArgs.Builder
 
sum() - Method in class com.lambdaworks.redis.ZStoreArgs
 
sunion(K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sunion(K...) - Method in class com.lambdaworks.redis.RedisConnection
 
sunionstore(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sunionstore(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
sync() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
sync() - Method in class com.lambdaworks.redis.RedisConnection
 

T

tailSet(V) - Method in class org.redisson.RedissonSortedSet
 
timeout - Variable in class com.lambdaworks.redis.RedisAsyncConnection
 
timeout - Variable in class com.lambdaworks.redis.RedisConnection
 
toArray() - Method in class org.redisson.RedissonList
 
toArray(T[]) - Method in class org.redisson.RedissonList
 
toArray() - Method in class org.redisson.RedissonSet
 
toArray(T[]) - Method in class org.redisson.RedissonSet
 
toArray() - Method in class org.redisson.RedissonSortedSet
 
toArray(T[]) - Method in class org.redisson.RedissonSortedSet
 
toString() - Method in class com.lambdaworks.redis.KeyValue
 
toString() - Method in class com.lambdaworks.redis.RedisClient
 
toString() - Method in class com.lambdaworks.redis.ScoredValue
 
toString() - Method in class org.redisson.misc.ReclosableLatch
 
toString() - Method in class org.redisson.RedissonAtomicLong
 
toString() - Method in class org.redisson.RedissonList
 
toString() - Method in class org.redisson.RedissonSortedSet
 
tryAcquire() - Method in class org.redisson.connection.PubSubConnectionEntry
 
tryAcquireShared(int) - Method in class org.redisson.misc.ReclosableLatch
 
tryClose() - Method in class org.redisson.connection.PubSubConnectionEntry
 
tryLock() - Method in class org.redisson.RedissonLock
 
tryLock(long, TimeUnit) - Method in class org.redisson.RedissonLock
 
tryReleaseShared(int) - Method in class org.redisson.misc.ReclosableLatch
 
trySetComparator(Comparator<? super V>) - Method in interface org.redisson.core.RSortedSet
Sets new comparator only if current set is empty
trySetComparator(Comparator<? super V>) - Method in class org.redisson.RedissonSortedSet
 
trySetCount(long) - Method in interface org.redisson.core.RCountDownLatch
Sets new count value only if previous count already has reached zero or not been setted at all.
trySetCount(long) - Method in class org.redisson.RedissonCountDownLatch
 
ttl(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
ttl(K) - Method in class com.lambdaworks.redis.RedisConnection
 
type - Variable in class com.lambdaworks.redis.protocol.Command
 
type() - Method in class com.lambdaworks.redis.pubsub.PubSubOutput
 
type(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
type(K) - Method in class com.lambdaworks.redis.RedisConnection
 

U

unfreeze(String, int) - Method in interface org.redisson.connection.LoadBalancer
 
unit - Variable in class com.lambdaworks.redis.RedisAsyncConnection
 
unit - Variable in class com.lambdaworks.redis.RedisConnection
 
unlock() - Method in class org.redisson.RedissonLock
 
unsubscribe(String...) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubConnection
 
unsubscribe(String) - Method in interface org.redisson.connection.ConnectionManager
 
unsubscribe(String) - Method in class org.redisson.connection.MasterSlaveConnectionManager
 
unsubscribe(String) - Method in class org.redisson.connection.PubSubConnectionEntry
 
unsubscribed(String, long) - Method in class com.lambdaworks.redis.pubsub.RedisPubSubAdapter
 
unsubscribed(String, long) - Method in interface com.lambdaworks.redis.pubsub.RedisPubSubListener
Unsubscribed from a channel.
unwatch() - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
unwatch() - Method in class com.lambdaworks.redis.RedisConnection
 
useMasterSlaveConnection() - Method in class org.redisson.Config
 
useSentinelConnection() - Method in class org.redisson.Config
 
useSingleServer() - Method in class org.redisson.Config
 
Utf8StringCodec - Class in com.lambdaworks.redis.codec
A RedisCodec that handles UTF-8 encoded keys and values.
Utf8StringCodec() - Constructor for class com.lambdaworks.redis.codec.Utf8StringCodec
Initialize a new instance that encodes and decodes strings using the UTF-8 charset;

V

value - Variable in class com.lambdaworks.redis.KeyValue
 
value - Variable in class com.lambdaworks.redis.ScoredValue
 
ValueListOutput<K,V> - Class in com.lambdaworks.redis.output
List of values output.
ValueListOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.ValueListOutput
 
valueOf(String) - Static method in enum com.lambdaworks.redis.protocol.CommandKeyword
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.lambdaworks.redis.protocol.CommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.lambdaworks.redis.ScriptOutputType
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.misc.ReferenceMap.ReferenceType
Returns the enum constant of this type with the specified name.
ValueOutput<K,V> - Class in com.lambdaworks.redis.output
Value output.
ValueOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.ValueOutput
 
valueReferenceType - Variable in class org.redisson.misc.ReferenceMap
 
values() - Static method in enum com.lambdaworks.redis.protocol.CommandKeyword
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.lambdaworks.redis.protocol.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.lambdaworks.redis.ScriptOutputType
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.misc.ReferenceMap.ReferenceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.redisson.RedissonMap
 
ValueSetOutput<K,V> - Class in com.lambdaworks.redis.output
Set of value output.
ValueSetOutput(RedisCodec<K, V>) - Constructor for class com.lambdaworks.redis.output.ValueSetOutput
 

W

watch(K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
watch(K...) - Method in class com.lambdaworks.redis.RedisConnection
 
weights(long...) - Static method in class com.lambdaworks.redis.ZStoreArgs.Builder
 
weights(long...) - Method in class com.lambdaworks.redis.ZStoreArgs
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.lambdaworks.redis.protocol.CommandHandler
 
writeInt(ByteBuf, int) - Static method in class com.lambdaworks.redis.protocol.Command
Write the textual value of a positive integer to the supplied buffer.

Y

yield(Kryo) - Method in interface org.redisson.codec.KryoCodec.KryoPool
 
yield(Kryo) - Method in class org.redisson.codec.KryoCodec.KryoPoolImpl
 

Z

zadd(K, double, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zadd(K, Object...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zadd(K, double, V) - Method in class com.lambdaworks.redis.RedisConnection
 
zadd(K, Object...) - Method in class com.lambdaworks.redis.RedisConnection
 
zcard(K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zcard(K) - Method in class com.lambdaworks.redis.RedisConnection
 
zcount(K, double, double) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zcount(K, String, String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zcount(K, double, double) - Method in class com.lambdaworks.redis.RedisConnection
 
zcount(K, String, String) - Method in class com.lambdaworks.redis.RedisConnection
 
zincrby(K, double, K) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zincrby(K, double, K) - Method in class com.lambdaworks.redis.RedisConnection
 
zinterstore(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zinterstore(K, ZStoreArgs, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zinterstore(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
zinterstore(K, ZStoreArgs, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
zrange(K, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrange(K, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrangebyscore(K, double, double) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrangebyscore(K, String, String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrangebyscore(K, double, double, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrangebyscore(K, String, String, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrangebyscore(K, double, double) - Method in class com.lambdaworks.redis.RedisConnection
 
zrangebyscore(K, String, String) - Method in class com.lambdaworks.redis.RedisConnection
 
zrangebyscore(K, double, double, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrangebyscore(K, String, String, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrangebyscoreWithScores(K, double, double) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrangebyscoreWithScores(K, String, String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrangebyscoreWithScores(K, double, double, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrangebyscoreWithScores(K, String, String, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrangebyscoreWithScores(K, double, double) - Method in class com.lambdaworks.redis.RedisConnection
 
zrangebyscoreWithScores(K, String, String) - Method in class com.lambdaworks.redis.RedisConnection
 
zrangebyscoreWithScores(K, double, double, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrangebyscoreWithScores(K, String, String, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrangeWithScores(K, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrangeWithScores(K, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrank(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrank(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
zrem(K, V...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrem(K, V...) - Method in class com.lambdaworks.redis.RedisConnection
 
zremrangebyrank(K, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zremrangebyrank(K, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zremrangebyscore(K, double, double) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zremrangebyscore(K, String, String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zremrangebyscore(K, double, double) - Method in class com.lambdaworks.redis.RedisConnection
 
zremrangebyscore(K, String, String) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrange(K, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrange(K, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrangebyscore(K, double, double) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrangebyscore(K, String, String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrangebyscore(K, double, double, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrangebyscore(K, String, String, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrangebyscore(K, double, double) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrangebyscore(K, String, String) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrangebyscore(K, double, double, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrangebyscore(K, String, String, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrangebyscoreWithScores(K, double, double) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrangebyscoreWithScores(K, String, String) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrangebyscoreWithScores(K, double, double, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrangebyscoreWithScores(K, String, String, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrangebyscoreWithScores(K, double, double) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrangebyscoreWithScores(K, String, String) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrangebyscoreWithScores(K, double, double, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrangebyscoreWithScores(K, String, String, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrangeWithScores(K, long, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrangeWithScores(K, long, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zrevrank(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zrevrank(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
zscan(K, long) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zscan(K, long) - Method in class com.lambdaworks.redis.RedisConnection
 
zscore(K, V) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zscore(K, V) - Method in class com.lambdaworks.redis.RedisConnection
 
ZStoreArgs - Class in com.lambdaworks.redis
Argument list builder for the redis ZUNIONSTORE and ZINTERSTORE commands.
ZStoreArgs() - Constructor for class com.lambdaworks.redis.ZStoreArgs
 
ZStoreArgs.Builder - Class in com.lambdaworks.redis
Static builder methods.
ZStoreArgs.Builder() - Constructor for class com.lambdaworks.redis.ZStoreArgs.Builder
 
zunionstore(K, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zunionstore(K, ZStoreArgs, K...) - Method in class com.lambdaworks.redis.RedisAsyncConnection
 
zunionstore(K, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
zunionstore(K, ZStoreArgs, K...) - Method in class com.lambdaworks.redis.RedisConnection
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 

Copyright © 2014. All rights reserved.