public class LettuceClusterConnection extends LettuceConnection implements RedisClusterConnection
Modifier and Type | Class and Description |
---|---|
protected static interface |
LettuceClusterConnection.LettuceClusterCommandCallback<T>
Lettuce specific implementation of
ClusterCommandExecutor.ClusterCommandCallback . |
protected static interface |
LettuceClusterConnection.LettuceMultiKeyClusterCommandCallback<T>
Lettuce specific implementation of
ClusterCommandExecutor.MultiKeyClusterCommandCallback . |
RedisStringCommands.BitOperation, RedisStringCommands.SetOption
RedisListCommands.Position
RedisZSetCommands.Aggregate, RedisZSetCommands.Limit, RedisZSetCommands.Range, RedisZSetCommands.Tuple
RedisServerCommands.MigrateOption, RedisServerCommands.ShutdownOption
RedisGeoCommands.DistanceUnit, RedisGeoCommands.GeoLocation<T>, RedisGeoCommands.GeoRadiusCommandArgs
RedisClusterCommands.AddSlots
Constructor and Description |
---|
LettuceClusterConnection(com.lambdaworks.redis.cluster.RedisClusterClient clusterClient)
Creates new
LettuceClusterConnection using RedisClusterClient . |
LettuceClusterConnection(com.lambdaworks.redis.cluster.RedisClusterClient clusterClient,
ClusterCommandExecutor executor)
Creates new
LettuceClusterConnection using RedisClusterClient running commands across the cluster
via given ClusterCommandExecutor . |
Modifier and Type | Method and Description |
---|---|
void |
bgReWriteAof(RedisClusterNode node) |
void |
bgSave(RedisClusterNode node) |
List<byte[]> |
bLPop(int timeout,
byte[]... keys)
Removes and returns first element from lists stored at
keys (see: RedisListCommands.lPop(byte[]) ). |
List<byte[]> |
bRPop(int timeout,
byte[]... keys)
Removes and returns last element from lists stored at
keys (see: RedisListCommands.rPop(byte[]) ). |
byte[] |
bRPopLPush(int timeout,
byte[] srcKey,
byte[] dstKey)
Remove the last element from list at
srcKey , append it to dstKey and return its value (see
RedisListCommands.rPopLPush(byte[], byte[]) ). |
void |
clusterAddSlots(RedisClusterNode node,
int... slots)
Assign slots to given
RedisClusterNode . |
void |
clusterAddSlots(RedisClusterNode node,
RedisClusterNode.SlotRange range)
Assign
RedisClusterNode.SlotRange.getSlotsArray() to given RedisClusterNode . |
Long |
clusterCountKeysInSlot(int slot)
Count the number of keys assigned to one slot.
|
void |
clusterDeleteSlots(RedisClusterNode node,
int... slots)
Remove slots from
RedisClusterNode . |
void |
clusterDeleteSlotsInRange(RedisClusterNode node,
RedisClusterNode.SlotRange range)
Removes
RedisClusterNode.SlotRange.getSlotsArray() from given RedisClusterNode . |
void |
clusterForget(RedisClusterNode node)
Remove given node from cluster.
|
ClusterInfo |
clusterGetClusterInfo()
Get cluster information.
|
List<byte[]> |
clusterGetKeysInSlot(int slot,
Integer count)
Get keys served by slot.
|
Map<RedisClusterNode,Collection<RedisClusterNode>> |
clusterGetMasterSlaveMap()
Retrieve information about masters and their connected slaves.
|
RedisClusterNode |
clusterGetNodeForKey(byte[] key)
Find the
RedisClusterNode serving given key. |
RedisClusterNode |
clusterGetNodeForSlot(int slot)
Find the
RedisClusterNode serving given slot. |
List<RedisClusterNode> |
clusterGetNodes()
Retrieve cluster node information such as id, host, port and slots.
|
Set<RedisClusterNode> |
clusterGetSlaves(RedisClusterNode master)
Retrieve information about connected slaves for given master node.
|
Integer |
clusterGetSlotForKey(byte[] key)
Find the slot for a given
key . |
void |
clusterMeet(RedisClusterNode node)
Add given node to cluster.
|
void |
clusterReplicate(RedisClusterNode master,
RedisClusterNode slave)
Assign a slave to given master.
|
void |
clusterSetSlot(RedisClusterNode node,
int slot,
RedisClusterCommands.AddSlots mode) |
Long |
dbSize()
Get the total number of available keys in currently selected database.
|
Long |
dbSize(RedisClusterNode node) |
Long |
del(byte[]... keys)
Delete given
keys . |
protected com.lambdaworks.redis.api.StatefulConnection<byte[],byte[]> |
doGetAsyncDedicatedConnection() |
void |
flushAll()
Delete all all keys from all databases.
|
void |
flushAll(RedisClusterNode node) |
void |
flushDb()
Delete all keys of the currently selected database.
|
void |
flushDb(RedisClusterNode node) |
List<RedisClientInfo> |
getClientList()
Request information and statistics about connected clients.
|
List<RedisClientInfo> |
getClientList(RedisClusterNode node) |
List<String> |
getConfig(RedisClusterNode node,
String pattern) |
List<String> |
getConfig(String pattern)
Load configuration parameters for given
pattern from server. |
Properties |
info()
Load default server information like
mempory
cpu utilization
replication
See http://redis.io/commands/info
|
Properties |
info(RedisClusterNode node) |
Properties |
info(RedisClusterNode node,
String section) |
Properties |
info(String section)
Load server information for given
selection . |
Set<byte[]> |
keys(byte[] pattern)
Find all keys matching the given
pattern . |
Set<byte[]> |
keys(RedisClusterNode node,
byte[] pattern) |
Long |
lastSave(RedisClusterNode node) |
List<byte[]> |
mGet(byte[]... keys)
Get the values of all given
keys . |
Boolean |
move(byte[] key,
int dbIndex)
Move given
key to database with index . |
void |
mSet(Map<byte[],byte[]> tuples)
Set multiple keys to multiple values using key-value pairs provided in
tuple . |
Boolean |
mSetNX(Map<byte[],byte[]> tuples)
Set multiple keys to multiple values using key-value pairs provided in
tuple only if the provided key does
not exist. |
void |
multi()
Mark the start of a transaction block.
|
Long |
pfCount(byte[]... keys)
Return the approximated cardinality of the structures observed by the HyperLogLog at key(s).
|
void |
pfMerge(byte[] destinationKey,
byte[]... sourceKeys)
Merge N different HyperLogLogs at sourceKeys into a single destinationKey.
|
String |
ping()
Test connection.
|
String |
ping(RedisClusterNode node) |
byte[] |
randomKey()
Return a random key from the keyspace.
|
byte[] |
randomKey(RedisClusterNode node) |
void |
rename(byte[] oldName,
byte[] newName)
Rename key
oleName to newName . |
Boolean |
renameNX(byte[] oldName,
byte[] newName)
Rename key
oleName to newName only if newName does not exist. |
void |
resetConfigStats()
Reset statistic counters on server.
|
void |
resetConfigStats(RedisClusterNode node) |
byte[] |
rPopLPush(byte[] srcKey,
byte[] dstKey)
Remove the last element from list at
srcKey , append it to dstKey and return its value. |
void |
save(RedisClusterNode node) |
Cursor<byte[]> |
scan(long cursorId,
ScanOptions options) |
Set<byte[]> |
sDiff(byte[]... keys)
Diff all sets for given
keys . |
Long |
sDiffStore(byte[] destKey,
byte[]... keys)
Diff all sets for given
keys and store result in destKey
See http://redis.io/commands/sdiffstore |
void |
select(int dbIndex)
Select the DB with given positive
dbIndex . |
void |
setConfig(RedisClusterNode node,
String param,
String value) |
void |
setConfig(String param,
String value)
Set server configuration for
param to value . |
void |
shutdown(RedisClusterNode node) |
Set<byte[]> |
sInter(byte[]... keys)
Returns the members intersecting all given sets at
keys . |
Long |
sInterStore(byte[] destKey,
byte[]... keys)
Intersect all given sets at
keys and store result in destKey . |
Boolean |
sMove(byte[] srcKey,
byte[] destKey,
byte[] value)
Move
value from srcKey to destKey
See http://redis.io/commands/smove |
Long |
sort(byte[] key,
SortParameters params,
byte[] storeKey)
Sort the elements for
key and store result in storeKey . |
Set<byte[]> |
sUnion(byte[]... keys)
Union all sets at given
keys . |
Long |
sUnionStore(byte[] destKey,
byte[]... keys)
Union all sets at given
keys and store result in destKey . |
Long |
time()
Request server timestamp using
TIME command. |
Long |
time(RedisClusterNode node) |
void |
unwatch()
Flushes all the previously
#watch(byte[]) keys. |
void |
watch(byte[]... keys)
Watch given
keys for modifications during transaction started with RedisTxCommands.multi() . |
append, bgReWriteAof, bgSave, bgWriteAof, bitCount, bitCount, bitOp, close, closePipeline, convertLettuceAccessException, decr, decrBy, discard, dump, echo, eval, evalSha, evalSha, exec, execute, execute, exists, expire, expireAt, geoAdd, geoAdd, geoAdd, geoAdd, geoDist, geoDist, geoHash, geoPos, geoRadius, geoRadius, geoRadiusByMember, geoRadiusByMember, geoRadiusByMember, geoRemove, get, getAsyncDedicatedConnection, getBit, getClientName, getConnection, getNativeConnection, getRange, getSentinelConnection, getSet, getSubscription, hDel, hExists, hGet, hGetAll, hIncrBy, hIncrBy, hKeys, hLen, hMGet, hMSet, hScan, hScan, hSet, hSetNX, hVals, incr, incrBy, incrBy, isActive, isClosed, isPipelined, isQueueing, isSubscribed, killClient, lastSave, lIndex, lInsert, lLen, lPop, lPush, lPushX, lRange, lRem, lSet, lTrim, migrate, migrate, openPipeline, persist, pExpire, pExpireAt, pfAdd, pSetEx, pSubscribe, pTtl, pTtl, publish, restore, rPop, rPush, rPushX, sAdd, save, scan, scan, sCard, scriptExists, scriptFlush, scriptKill, scriptLoad, set, set, setBit, setClientName, setConvertPipelineAndTxResults, setEx, setNX, setRange, shutdown, shutdown, sIsMember, slaveOf, slaveOfNoOne, sMembers, sort, sPop, sRandMember, sRandMember, sRem, sScan, sScan, strLen, subscribe, ttl, ttl, type, zAdd, zAdd, zCard, zCount, zCount, zIncrBy, zInterStore, zInterStore, zRange, zRangeByLex, zRangeByLex, zRangeByLex, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScoreWithScores, zRangeByScoreWithScores, zRangeByScoreWithScores, zRangeByScoreWithScores, zRangeWithScores, zRank, zRem, zRemRange, zRemRangeByScore, zRemRangeByScore, zRevRange, zRevRangeByScore, zRevRangeByScore, zRevRangeByScore, zRevRangeByScore, zRevRangeByScoreWithScores, zRevRangeByScoreWithScores, zRevRangeByScoreWithScores, zRevRangeByScoreWithScores, zRevRangeWithScores, zRevRank, zScan, zScan, zScore, zUnionStore, zUnionStore
getSentinelConnection, hasRedisSentinelConfigured, setSentinelConfiguration
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
close, closePipeline, getNativeConnection, getSentinelConnection, isClosed, isPipelined, isQueueing, openPipeline
execute
dump, exists, expire, expireAt, persist, pExpire, pExpireAt, pTtl, pTtl, restore, scan, sort, ttl, ttl, type
append, bitCount, bitCount, bitOp, decr, decrBy, get, getBit, getRange, getSet, incr, incrBy, incrBy, pSetEx, set, set, setBit, setEx, setNX, setRange, strLen
lIndex, lInsert, lLen, lPop, lPush, lPushX, lRange, lRem, lSet, lTrim, rPop, rPush, rPushX
sAdd, sCard, sIsMember, sMembers, sPop, sRandMember, sRandMember, sRem, sScan
zAdd, zAdd, zCard, zCount, zCount, zIncrBy, zInterStore, zInterStore, zRange, zRangeByLex, zRangeByLex, zRangeByLex, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScore, zRangeByScoreWithScores, zRangeByScoreWithScores, zRangeByScoreWithScores, zRangeByScoreWithScores, zRangeWithScores, zRank, zRem, zRemRange, zRemRangeByScore, zRemRangeByScore, zRevRange, zRevRangeByScore, zRevRangeByScore, zRevRangeByScore, zRevRangeByScore, zRevRangeByScoreWithScores, zRevRangeByScoreWithScores, zRevRangeByScoreWithScores, zRevRangeByScoreWithScores, zRevRangeWithScores, zRevRank, zScan, zScore, zUnionStore, zUnionStore
hDel, hExists, hGet, hGetAll, hIncrBy, hIncrBy, hKeys, hLen, hMGet, hMSet, hScan, hSet, hSetNX, hVals
discard, exec
getSubscription, isSubscribed, pSubscribe, publish, subscribe
echo
bgReWriteAof, bgSave, bgWriteAof, getClientName, killClient, lastSave, migrate, migrate, save, setClientName, shutdown, shutdown, slaveOf, slaveOfNoOne
eval, evalSha, evalSha, scriptExists, scriptFlush, scriptKill, scriptLoad
geoAdd, geoAdd, geoAdd, geoAdd, geoDist, geoDist, geoHash, geoPos, geoRadius, geoRadius, geoRadiusByMember, geoRadiusByMember, geoRadiusByMember, geoRemove
pfAdd
public LettuceClusterConnection(com.lambdaworks.redis.cluster.RedisClusterClient clusterClient)
LettuceClusterConnection
using RedisClusterClient
.clusterClient
- must not be null.public LettuceClusterConnection(com.lambdaworks.redis.cluster.RedisClusterClient clusterClient, ClusterCommandExecutor executor)
LettuceClusterConnection
using RedisClusterClient
running commands across the cluster
via given ClusterCommandExecutor
.clusterClient
- must not be null.executor
- must not be null.public Cursor<byte[]> scan(long cursorId, ScanOptions options)
scan
in class LettuceConnection
public Set<byte[]> keys(byte[] pattern)
RedisKeyCommands
pattern
.
See http://redis.io/commands/keys
keys
in interface RedisKeyCommands
keys
in class LettuceConnection
public void flushAll()
RedisServerCommands
See http://redis.io/commands/flushall
flushAll
in interface RedisServerCommands
flushAll
in class LettuceConnection
public void flushDb()
RedisServerCommands
See http://redis.io/commands/flushdb
flushDb
in interface RedisServerCommands
flushDb
in class LettuceConnection
public Long dbSize()
RedisServerCommands
See http://redis.io/commands/dbsize
dbSize
in interface RedisServerCommands
dbSize
in class LettuceConnection
public Properties info()
RedisServerCommands
See http://redis.io/commands/info
info
in interface RedisServerCommands
info
in class LettuceConnection
public Properties info(String section)
RedisServerCommands
selection
.
See http://redis.io/commands/info
info
in interface RedisServerCommands
info
in class LettuceConnection
public Properties info(RedisClusterNode node, String section)
info
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.info(String)
public Boolean move(byte[] key, int dbIndex)
RedisKeyCommands
key
to database with index
.
See http://redis.io/commands/move
move
in interface RedisKeyCommands
move
in class LettuceConnection
public Long del(byte[]... keys)
RedisKeyCommands
keys
.
See http://redis.io/commands/del
del
in interface RedisKeyCommands
del
in class LettuceConnection
public Set<RedisClusterNode> clusterGetSlaves(RedisClusterNode master)
RedisClusterCommands
clusterGetSlaves
in interface RedisClusterCommands
master
- must not be null.public Integer clusterGetSlotForKey(byte[] key)
RedisClusterCommands
key
.clusterGetSlotForKey
in interface RedisClusterCommands
key
- must not be null.public RedisClusterNode clusterGetNodeForSlot(int slot)
RedisClusterCommands
RedisClusterNode
serving given slot.clusterGetNodeForSlot
in interface RedisClusterCommands
public RedisClusterNode clusterGetNodeForKey(byte[] key)
RedisClusterCommands
RedisClusterNode
serving given key.clusterGetNodeForKey
in interface RedisClusterCommands
key
- must not be null.public ClusterInfo clusterGetClusterInfo()
RedisClusterCommands
clusterGetClusterInfo
in interface RedisClusterCommands
public void clusterAddSlots(RedisClusterNode node, int... slots)
RedisClusterCommands
RedisClusterNode
.clusterAddSlots
in interface RedisClusterCommands
node
- must not be null.public void clusterAddSlots(RedisClusterNode node, RedisClusterNode.SlotRange range)
RedisClusterCommands
RedisClusterNode.SlotRange.getSlotsArray()
to given RedisClusterNode
.clusterAddSlots
in interface RedisClusterCommands
node
- must not be null.range
- must not be null.public void clusterDeleteSlots(RedisClusterNode node, int... slots)
RedisClusterCommands
RedisClusterNode
.clusterDeleteSlots
in interface RedisClusterCommands
node
- must not be null.public void clusterDeleteSlotsInRange(RedisClusterNode node, RedisClusterNode.SlotRange range)
RedisClusterCommands
RedisClusterNode.SlotRange.getSlotsArray()
from given RedisClusterNode
.clusterDeleteSlotsInRange
in interface RedisClusterCommands
node
- must not be null.range
- must not be null.public void clusterForget(RedisClusterNode node)
RedisClusterCommands
clusterForget
in interface RedisClusterCommands
node
- must not be null.public void clusterMeet(RedisClusterNode node)
RedisClusterCommands
clusterMeet
in interface RedisClusterCommands
node
- must contain host
and RedisNode.getPort()
and must
not be null.public void clusterSetSlot(RedisClusterNode node, int slot, RedisClusterCommands.AddSlots mode)
clusterSetSlot
in interface RedisClusterCommands
node
- must not be null.mode
- must not benull.public List<byte[]> clusterGetKeysInSlot(int slot, Integer count)
RedisClusterCommands
clusterGetKeysInSlot
in interface RedisClusterCommands
count
- must not be null.public Long clusterCountKeysInSlot(int slot)
RedisClusterCommands
clusterCountKeysInSlot
in interface RedisClusterCommands
public void clusterReplicate(RedisClusterNode master, RedisClusterNode slave)
RedisClusterCommands
clusterReplicate
in interface RedisClusterCommands
master
- must not be null.slave
- must not be null.public String ping()
RedisConnectionCommands
See http://redis.io/commands/ping
ping
in interface RedisConnectionCommands
ping
in class LettuceConnection
public String ping(RedisClusterNode node)
ping
in interface RedisClusterConnection
node
- must not be null.RedisConnectionCommands.ping()
public void bgReWriteAof(RedisClusterNode node)
bgReWriteAof
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.bgReWriteAof()
public void bgSave(RedisClusterNode node)
bgSave
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.bgSave()
public Long lastSave(RedisClusterNode node)
lastSave
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.lastSave()
public void save(RedisClusterNode node)
save
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.save()
public Long dbSize(RedisClusterNode node)
dbSize
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.dbSize()
public void flushDb(RedisClusterNode node)
flushDb
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.flushDb()
public void flushAll(RedisClusterNode node)
flushAll
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.flushAll()
public Properties info(RedisClusterNode node)
info
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.info()
public Set<byte[]> keys(RedisClusterNode node, byte[] pattern)
keys
in interface RedisClusterConnection
node
- must not be null.pattern
- must not be null.RedisKeyCommands.keys(byte[])
public byte[] randomKey(RedisClusterNode node)
randomKey
in interface RedisClusterConnection
node
- must not be null.RedisKeyCommands.randomKey()
public byte[] randomKey()
RedisKeyCommands
See http://redis.io/commands/randomkey
randomKey
in interface RedisKeyCommands
randomKey
in class LettuceConnection
public void rename(byte[] oldName, byte[] newName)
RedisKeyCommands
oleName
to newName
.
See http://redis.io/commands/rename
rename
in interface RedisKeyCommands
rename
in class LettuceConnection
public Boolean renameNX(byte[] oldName, byte[] newName)
RedisKeyCommands
oleName
to newName
only if newName
does not exist.
See http://redis.io/commands/renamenx
renameNX
in interface RedisKeyCommands
renameNX
in class LettuceConnection
public void shutdown(RedisClusterNode node)
shutdown
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.shutdown()
public Long sort(byte[] key, SortParameters params, byte[] storeKey)
RedisKeyCommands
key
and store result in storeKey
.
See http://redis.io/commands/sort
sort
in interface RedisKeyCommands
sort
in class LettuceConnection
public List<byte[]> mGet(byte[]... keys)
RedisStringCommands
keys
.
See http://redis.io/commands/mget
mGet
in interface RedisStringCommands
mGet
in class LettuceConnection
public void mSet(Map<byte[],byte[]> tuples)
RedisStringCommands
tuple
.
See http://redis.io/commands/mset
mSet
in interface RedisStringCommands
mSet
in class LettuceConnection
public Boolean mSetNX(Map<byte[],byte[]> tuples)
RedisStringCommands
tuple
only if the provided key does
not exist.
See http://redis.io/commands/msetnx
mSetNX
in interface RedisStringCommands
mSetNX
in class LettuceConnection
public List<byte[]> bLPop(int timeout, byte[]... keys)
RedisListCommands
keys
(see: RedisListCommands.lPop(byte[])
). timeout
reached.
See http://redis.io/commands/blpop
bLPop
in interface RedisListCommands
bLPop
in class LettuceConnection
public List<byte[]> bRPop(int timeout, byte[]... keys)
RedisListCommands
keys
(see: RedisListCommands.rPop(byte[])
). timeout
reached.
See http://redis.io/commands/brpop
bRPop
in interface RedisListCommands
bRPop
in class LettuceConnection
public byte[] rPopLPush(byte[] srcKey, byte[] dstKey)
RedisListCommands
srcKey
, append it to dstKey
and return its value.
See http://redis.io/commands/rpoplpush
rPopLPush
in interface RedisListCommands
rPopLPush
in class LettuceConnection
public byte[] bRPopLPush(int timeout, byte[] srcKey, byte[] dstKey)
RedisListCommands
srcKey
, append it to dstKey
and return its value (see
RedisListCommands.rPopLPush(byte[], byte[])
). timeout
reached.
See http://redis.io/commands/brpoplpush
bRPopLPush
in interface RedisListCommands
bRPopLPush
in class LettuceConnection
public void select(int dbIndex)
RedisConnectionCommands
dbIndex
.
See http://redis.io/commands/select
select
in interface RedisConnectionCommands
select
in class LettuceConnection
public Boolean sMove(byte[] srcKey, byte[] destKey, byte[] value)
RedisSetCommands
value
from srcKey
to destKey
See http://redis.io/commands/smove
sMove
in interface RedisSetCommands
sMove
in class LettuceConnection
public Set<byte[]> sInter(byte[]... keys)
RedisSetCommands
keys
.
See http://redis.io/commands/sinter
sInter
in interface RedisSetCommands
sInter
in class LettuceConnection
public Long sInterStore(byte[] destKey, byte[]... keys)
RedisSetCommands
keys
and store result in destKey
.
See http://redis.io/commands/sinterstore
sInterStore
in interface RedisSetCommands
sInterStore
in class LettuceConnection
public Set<byte[]> sUnion(byte[]... keys)
RedisSetCommands
keys
.
See http://redis.io/commands/sunion
sUnion
in interface RedisSetCommands
sUnion
in class LettuceConnection
public Long sUnionStore(byte[] destKey, byte[]... keys)
RedisSetCommands
keys
and store result in destKey
.
See http://redis.io/commands/sunionstore
sUnionStore
in interface RedisSetCommands
sUnionStore
in class LettuceConnection
public Set<byte[]> sDiff(byte[]... keys)
RedisSetCommands
keys
.
See http://redis.io/commands/sdiff
sDiff
in interface RedisSetCommands
sDiff
in class LettuceConnection
public Long sDiffStore(byte[] destKey, byte[]... keys)
RedisSetCommands
keys
and store result in destKey
See http://redis.io/commands/sdiffstore
sDiffStore
in interface RedisSetCommands
sDiffStore
in class LettuceConnection
protected com.lambdaworks.redis.api.StatefulConnection<byte[],byte[]> doGetAsyncDedicatedConnection()
doGetAsyncDedicatedConnection
in class LettuceConnection
public List<RedisClusterNode> clusterGetNodes()
RedisClusterCommands
clusterGetNodes
in interface RedisClusterCommands
public Long pfCount(byte[]... keys)
HyperLogLogCommands
pfCount
in interface HyperLogLogCommands
pfCount
in class LettuceConnection
public void pfMerge(byte[] destinationKey, byte[]... sourceKeys)
HyperLogLogCommands
pfMerge
in interface HyperLogLogCommands
pfMerge
in class LettuceConnection
public void watch(byte[]... keys)
RedisTxCommands
keys
for modifications during transaction started with RedisTxCommands.multi()
.
See http://redis.io/commands/watch
watch
in interface RedisTxCommands
watch
in class LettuceConnection
public void unwatch()
RedisTxCommands
#watch(byte[])
keys.
See http://redis.io/commands/unwatch
unwatch
in interface RedisTxCommands
unwatch
in class LettuceConnection
public void multi()
RedisTxCommands
RedisTxCommands.exec()
or rolled back using RedisTxCommands.discard()
See http://redis.io/commands/multi
multi
in interface RedisTxCommands
multi
in class LettuceConnection
public List<String> getConfig(String pattern)
RedisServerCommands
pattern
from server.
See http://redis.io/commands/config-get
getConfig
in interface RedisServerCommands
getConfig
in class LettuceConnection
public List<String> getConfig(RedisClusterNode node, String pattern)
getConfig
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.getConfig(String)
public void setConfig(String param, String value)
RedisServerCommands
param
to value
.
See http://redis.io/commands/config-set
setConfig
in interface RedisServerCommands
setConfig
in class LettuceConnection
public void setConfig(RedisClusterNode node, String param, String value)
setConfig
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.setConfig(String, String)
public void resetConfigStats()
RedisServerCommands
RedisServerCommands.info()
.
See http://redis.io/commands/config-resetstat
resetConfigStats
in interface RedisServerCommands
resetConfigStats
in class LettuceConnection
public void resetConfigStats(RedisClusterNode node)
resetConfigStats
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.resetConfigStats()
public Long time()
RedisServerCommands
TIME
command.time
in interface RedisServerCommands
time
in class LettuceConnection
public Long time(RedisClusterNode node)
time
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.time()
public List<RedisClientInfo> getClientList()
RedisServerCommands
See http://redis.io/commands/client-list
getClientList
in interface RedisServerCommands
getClientList
in class LettuceConnection
List
of RedisClientInfo
objects.public List<RedisClientInfo> getClientList(RedisClusterNode node)
getClientList
in interface RedisClusterConnection
node
- must not be null.RedisServerCommands.getClientList()
public Map<RedisClusterNode,Collection<RedisClusterNode>> clusterGetMasterSlaveMap()
RedisClusterCommands
clusterGetMasterSlaveMap
in interface RedisClusterCommands
Copyright © 2011-2016–2016 Pivotal Software, Inc.. All rights reserved.