Class RedisModulesReactiveCommandsImpl<K,V>

java.lang.Object
io.lettuce.core.AbstractRedisReactiveCommands<K,V>
io.lettuce.core.RedisReactiveCommandsImpl<K,V>
com.redis.lettucemod.RedisModulesReactiveCommandsImpl<K,V>
All Implemented Interfaces:
RediSearchReactiveCommands<K,V>, RedisGearsReactiveCommands<K,V>, RedisJSONReactiveCommands<K,V>, RedisModulesReactiveCommands<K,V>, RedisTimeSeriesReactiveCommands<K,V>, io.lettuce.core.api.reactive.BaseRedisReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisAclReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisGeoReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisHashReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisHLLReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisKeyReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisListReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisScriptingReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisServerReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisSetReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisSortedSetReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisStreamReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisStringReactiveCommands<K,V>, io.lettuce.core.api.reactive.RedisTransactionalReactiveCommands<K,V>, io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands<K,V>

public class RedisModulesReactiveCommandsImpl<K,V> extends io.lettuce.core.RedisReactiveCommandsImpl<K,V> implements RedisModulesReactiveCommands<K,V>
  • Constructor Summary

    Constructors
    Constructor
    Description
    RedisModulesReactiveCommandsImpl(StatefulRedisModulesConnection<K,V> connection, io.lettuce.core.codec.RedisCodec<K,V> codec)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    reactor.core.publisher.Mono<AggregateResults<K>>
    ftAggregate(K index, V query)
     
    reactor.core.publisher.Mono<AggregateResults<K>>
    ftAggregate(K index, V query, AggregateOptions<K,V> options)
     
    reactor.core.publisher.Mono<AggregateWithCursorResults<K>>
    ftAggregate(K index, V query, CursorOptions cursor)
     
    reactor.core.publisher.Mono<AggregateWithCursorResults<K>>
    ftAggregate(K index, V query, CursorOptions cursor, AggregateOptions<K,V> options)
     
    reactor.core.publisher.Mono<String>
    ftAliasadd(K name, K index)
     
    reactor.core.publisher.Mono<String>
    ftAliasdel(K name)
     
    reactor.core.publisher.Mono<String>
    ftAliasupdate(K name, K index)
     
    reactor.core.publisher.Mono<String>
    ftAlter(K index, Field<K> field)
     
    reactor.core.publisher.Mono<String>
    ftCreate(K index, CreateOptions<K,V> options, Field<K>... fields)
     
    reactor.core.publisher.Mono<String>
    ftCreate(K index, Field<K>... fields)
     
    reactor.core.publisher.Mono<String>
    ftCursorDelete(K index, long cursor)
     
    reactor.core.publisher.Mono<AggregateWithCursorResults<K>>
    ftCursorRead(K index, long cursor)
     
    reactor.core.publisher.Mono<AggregateWithCursorResults<K>>
    ftCursorRead(K index, long cursor, long count)
     
    reactor.core.publisher.Mono<Long>
    ftDictadd(K dict, V... terms)
     
    reactor.core.publisher.Mono<Long>
    ftDictdel(K dict, V... terms)
     
    reactor.core.publisher.Flux<V>
    ftDictdump(K dict)
     
    reactor.core.publisher.Mono<String>
    ftDropindex(K index)
     
    reactor.core.publisher.Mono<String>
     
    reactor.core.publisher.Flux<Object>
    ftInfo(K index)
     
    reactor.core.publisher.Flux<K>
     
    reactor.core.publisher.Mono<SearchResults<K,V>>
    ftSearch(K index, V query)
     
    reactor.core.publisher.Mono<SearchResults<K,V>>
    ftSearch(K index, V query, SearchOptions<K,V> options)
     
    reactor.core.publisher.Mono<Long>
    ftSugadd(K key, Suggestion<V> suggestion)
     
    reactor.core.publisher.Mono<Long>
    ftSugaddIncr(K key, Suggestion<V> suggestion)
     
    reactor.core.publisher.Mono<Boolean>
    ftSugdel(K key, V string)
     
    reactor.core.publisher.Flux<Suggestion<V>>
    ftSugget(K key, V prefix)
     
    reactor.core.publisher.Flux<Suggestion<V>>
    ftSugget(K key, V prefix, SuggetOptions options)
     
    reactor.core.publisher.Mono<Long>
    ftSuglen(K key)
     
    reactor.core.publisher.Flux<V>
    ftTagvals(K index, K field)
     
     
    reactor.core.publisher.Mono<Long>
    jsonArrappend(K key, String path, V... jsons)
     
    reactor.core.publisher.Mono<Long>
    jsonArrindex(K key, String path, V scalar)
     
    reactor.core.publisher.Mono<Long>
    jsonArrindex(K key, String path, V scalar, Slice slice)
     
    reactor.core.publisher.Mono<Long>
    jsonArrinsert(K key, String path, long index, V... jsons)
     
    reactor.core.publisher.Mono<Long>
     
    reactor.core.publisher.Mono<Long>
    jsonArrlen(K key, String path)
     
    reactor.core.publisher.Mono<V>
     
    reactor.core.publisher.Mono<V>
    jsonArrpop(K key, ArrpopOptions<K> options)
     
    reactor.core.publisher.Mono<Long>
    jsonArrtrim(K key, String path, long start, long stop)
     
    reactor.core.publisher.Mono<Long>
    jsonDel(K key)
     
    reactor.core.publisher.Mono<Long>
    jsonDel(K key, String path)
     
    reactor.core.publisher.Mono<V>
    jsonGet(K key, GetOptions options, K... paths)
     
    reactor.core.publisher.Mono<V>
    jsonGet(K key, K... paths)
     
    reactor.core.publisher.Flux<io.lettuce.core.KeyValue<K,V>>
    jsonMget(String path, Iterable<K> keys)
     
    reactor.core.publisher.Flux<io.lettuce.core.KeyValue<K,V>>
    jsonMget(String path, K... keys)
     
    reactor.core.publisher.Mono<V>
    jsonNumincrby(K key, String path, double number)
     
    reactor.core.publisher.Mono<V>
    jsonNummultby(K key, String path, double number)
     
    reactor.core.publisher.Flux<K>
     
    reactor.core.publisher.Flux<K>
    jsonObjkeys(K key, String path)
     
    reactor.core.publisher.Mono<Long>
     
    reactor.core.publisher.Mono<Long>
    jsonObjlen(K key, String path)
     
    reactor.core.publisher.Mono<String>
    jsonSet(K key, String path, V json)
     
    reactor.core.publisher.Mono<String>
    jsonSet(K key, String path, V json, SetMode mode)
     
    reactor.core.publisher.Mono<Long>
    jsonStrappend(K key, String path, V json)
     
    reactor.core.publisher.Mono<Long>
    jsonStrappend(K key, V json)
     
    reactor.core.publisher.Mono<Long>
    jsonStrlen(K key, String path)
     
    reactor.core.publisher.Mono<String>
    jsonType(K key)
     
    reactor.core.publisher.Mono<String>
    jsonType(K key, String path)
     
    reactor.core.publisher.Mono<String>
     
    reactor.core.publisher.Flux<V>
    rgConfigget(K... keys)
     
    reactor.core.publisher.Flux<V>
     
    reactor.core.publisher.Mono<String>
     
    reactor.core.publisher.Flux<Execution>
     
    reactor.core.publisher.Flux<Registration>
     
    reactor.core.publisher.Mono<ExecutionDetails>
     
    reactor.core.publisher.Mono<ExecutionDetails>
     
    reactor.core.publisher.Mono<ExecutionResults>
     
    reactor.core.publisher.Mono<ExecutionResults>
     
    reactor.core.publisher.Mono<ExecutionResults>
    rgPyexecute(String function, V... requirements)
     
    reactor.core.publisher.Mono<String>
    rgPyexecuteUnblocking(String function, V... requirements)
     
    reactor.core.publisher.Flux<Object>
    rgTrigger(String trigger, V... args)
     
    reactor.core.publisher.Mono<String>
     
    reactor.core.publisher.Mono<Long>
    tsAdd(K key, Sample sample)
     
    reactor.core.publisher.Mono<Long>
    tsAdd(K key, Sample sample, AddOptions<K,V> options)
     
    reactor.core.publisher.Mono<String>
    tsAlter(K key, AlterOptions<K,V> options)
     
    reactor.core.publisher.Mono<String>
    tsCreate(K key, CreateOptions<K,V> options)
     
    reactor.core.publisher.Mono<String>
    tsCreaterule(K sourceKey, K destKey, CreateRuleOptions options)
     
    reactor.core.publisher.Mono<Long>
    tsDecrby(K key, double value)
     
    reactor.core.publisher.Mono<Long>
    tsDecrby(K key, double value, IncrbyOptions<K,V> options)
     
    reactor.core.publisher.Mono<Long>
    tsDel(K key, TimeRange timeRange)
     
    reactor.core.publisher.Mono<String>
    tsDeleterule(K sourceKey, K destKey)
     
    reactor.core.publisher.Mono<Sample>
    tsGet(K key)
     
    reactor.core.publisher.Mono<Long>
    tsIncrby(K key, double value)
     
    reactor.core.publisher.Mono<Long>
    tsIncrby(K key, double value, IncrbyOptions<K,V> options)
     
    reactor.core.publisher.Flux<Object>
    tsInfo(K key)
     
    reactor.core.publisher.Flux<Object>
     
    reactor.core.publisher.Flux<Long>
    tsMadd(KeySample<K>... samples)
     
    reactor.core.publisher.Flux<GetResult<K,V>>
    tsMget(MGetOptions<K,V> options)
     
    reactor.core.publisher.Flux<GetResult<K,V>>
    tsMget(V... filters)
     
    reactor.core.publisher.Flux<GetResult<K,V>>
    tsMgetWithLabels(V... filters)
     
    reactor.core.publisher.Flux<RangeResult<K,V>>
     
    reactor.core.publisher.Flux<RangeResult<K,V>>
    tsMrange(TimeRange range, MRangeOptions<K,V> options)
     
    reactor.core.publisher.Flux<RangeResult<K,V>>
     
    reactor.core.publisher.Flux<RangeResult<K,V>>
     
    reactor.core.publisher.Flux<V>
    tsQueryIndex(V... filters)
     
    reactor.core.publisher.Flux<Sample>
    tsRange(K key, TimeRange range)
     
    reactor.core.publisher.Flux<Sample>
    tsRange(K key, TimeRange range, RangeOptions options)
     
    reactor.core.publisher.Flux<Sample>
    tsRevrange(K key, TimeRange range)
     
    reactor.core.publisher.Flux<Sample>
    tsRevrange(K key, TimeRange range, RangeOptions options)
     

    Methods inherited from class io.lettuce.core.AbstractRedisReactiveCommands

    aclCat, aclCat, aclDeluser, aclDryRun, aclDryRun, aclGenpass, aclGenpass, aclGetuser, aclList, aclLoad, aclLog, aclLog, aclLogReset, aclSave, aclSetuser, aclUsers, aclWhoami, append, asking, auth, auth, bgrewriteaof, bgsave, bitcount, bitcount, bitfield, bitopAnd, bitopNot, bitopOr, bitopXor, bitpos, bitpos, bitpos, blmove, blmove, blmpop, blmpop, blpop, blpop, brpop, brpop, brpoplpush, brpoplpush, bzpopmax, bzpopmax, bzpopmin, bzpopmin, clientCaching, clientGetname, clientGetredir, clientId, clientKill, clientKill, clientList, clientNoEvict, clientPause, clientSetname, clientTracking, clientUnblock, close, clusterAddSlots, clusterAddSlotsRange, clusterBumpepoch, clusterCountFailureReports, clusterCountKeysInSlot, clusterDelSlots, clusterDelSlotsRange, clusterFailover, clusterFailover, clusterFlushslots, clusterForget, clusterGetKeysInSlot, clusterInfo, clusterKeyslot, clusterMeet, clusterMyId, clusterNodes, clusterReplicas, clusterReplicate, clusterReset, clusterSaveconfig, clusterSetConfigEpoch, clusterSetSlotImporting, clusterSetSlotMigrating, clusterSetSlotNode, clusterSetSlotStable, clusterShards, clusterSlaves, clusterSlots, command, commandCount, commandInfo, commandInfo, configGet, configGet, configResetstat, configRewrite, configSet, configSet, copy, copy, createDissolvingFlux, createFlux, createMono, createMono, dbsize, debugCrashAndRecover, debugHtstats, debugObject, debugOom, debugReload, debugRestart, debugSdslen, debugSegfault, decr, decrby, del, del, digest, digest, discard, dispatch, dispatch, dump, echo, eval, eval, eval, eval, evalReadOnly, evalsha, evalsha, evalshaReadOnly, exec, exists, exists, exists, expire, expire, expire, expire, expireat, expireat, expireat, expireat, expireat, expireat, expiretime, flushall, flushall, flushallAsync, flushCommands, flushdb, flushdb, flushdbAsync, geoadd, geoadd, geoadd, geoadd, geoadd, geoadd, geodist, geohash, geopos, georadius, georadius, georadius, georadius_ro, georadius_ro, georadiusbymember, georadiusbymember, georadiusbymember, georadiusbymember_ro, georadiusbymember_ro, geosearch, geosearch, geosearchstore, get, getbit, getConnection, getdel, getex, getrange, getset, hdel, hexists, hget, hgetall, hgetall, hincrby, hincrbyfloat, hkeys, hkeys, hlen, hmget, hmget, hmset, hrandfield, hrandfield, hrandfieldWithvalues, hrandfieldWithvalues, hscan, hscan, hscan, hscan, hscan, hscan, hscan, hscan, hset, hset, hsetnx, hstrlen, hvals, hvals, incr, incrby, incrbyfloat, info, info, isOpen, keys, keys, lastsave, lindex, linsert, llen, lmove, lmpop, lpop, lpop, lpos, lpos, lpos, lpos, lpush, lpushx, lrange, lrange, lrem, lset, ltrim, memoryUsage, mget, mget, mget, mget, mget, migrate, migrate, move, mset, msetnx, multi, objectEncoding, objectFreq, objectIdletime, objectRefcount, persist, pexpire, pexpire, pexpire, pexpire, pexpireat, pexpireat, pexpireat, pexpireat, pexpireat, pexpireat, pexpiretime, pfadd, pfadd, pfcount, pfcount, pfmerge, pfmerge, ping, psetex, pttl, publish, pubsubChannels, pubsubChannels, pubsubNumpat, pubsubNumsub, quit, randomkey, readOnly, readWrite, rename, renamenx, replicaof, replicaofNoOne, reset, restore, restore, role, rpop, rpop, rpoplpush, rpush, rpushx, sadd, save, scan, scan, scan, scan, scan, scan, scan, scan, scard, scriptExists, scriptFlush, scriptFlush, scriptKill, scriptLoad, scriptLoad, sdiff, sdiff, sdiffstore, select, set, set, setAutoFlushCommands, setbit, setex, setGet, setGet, setnx, setrange, setTimeout, shutdown, shutdown, sinter, sinter, sintercard, sintercard, sinterstore, sismember, slaveof, slaveofNoOne, slowlogGet, slowlogGet, slowlogLen, slowlogReset, smembers, smembers, smismember, smove, sort, sort, sort, sort, sortReadOnly, sortReadOnly, sortReadOnly, sortReadOnly, sortStore, spop, spop, srandmember, srandmember, srandmember, srem, sscan, sscan, sscan, sscan, sscan, sscan, sscan, sscan, stralgoLcs, strlen, sunion, sunion, sunionstore, swapdb, time, touch, touch, ttl, type, unlink, unlink, unwatch, waitForReplication, watch, xack, xadd, xadd, xadd, xadd, xautoclaim, xclaim, xclaim, xdel, xgroupCreate, xgroupCreate, xgroupCreateconsumer, xgroupDelconsumer, xgroupDestroy, xgroupSetid, xinfoConsumers, xinfoGroups, xinfoStream, xlen, xpending, xpending, xpending, xpending, xrange, xrange, xread, xread, xreadgroup, xreadgroup, xrevrange, xrevrange, xtrim, xtrim, xtrim, zadd, zadd, zadd, zadd, zadd, zadd, zaddincr, zaddincr, zcard, zcount, zcount, zcount, zdiff, zdiffstore, zdiffWithScores, zincrby, zinter, zinter, zintercard, zintercard, zinterstore, zinterstore, zinterWithScores, zinterWithScores, zlexcount, zlexcount, zmscore, zpopmax, zpopmax, zpopmin, zpopmin, zrandmember, zrandmember, zrandmemberWithScores, zrandmemberWithScores, zrange, zrange, zrangebylex, zrangebylex, zrangebylex, zrangebylex, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangestore, zrangestorebylex, zrangestorebyscore, zrangeWithScores, zrangeWithScores, zrank, zrem, zremrangebylex, zremrangebylex, zremrangebyrank, zremrangebyscore, zremrangebyscore, zremrangebyscore, zrevrange, zrevrange, zrevrangebylex, zrevrangebylex, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangestore, zrevrangestorebylex, zrevrangestorebyscore, zrevrangeWithScores, zrevrangeWithScores, zrevrank, zscan, zscan, zscan, zscan, zscan, zscan, zscan, zscan, zscore, zunion, zunion, zunionstore, zunionstore, zunionWithScores, zunionWithScores

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait

    Methods inherited from interface io.lettuce.core.api.reactive.BaseRedisReactiveCommands

    dispatch, dispatch, echo, flushCommands, isOpen, ping, publish, pubsubChannels, pubsubChannels, pubsubNumpat, pubsubNumsub, quit, reset, role, setAutoFlushCommands, waitForReplication

    Methods inherited from interface io.lettuce.core.api.reactive.RedisAclReactiveCommands

    aclCat, aclCat, aclDeluser, aclDryRun, aclDryRun, aclGenpass, aclGenpass, aclGetuser, aclList, aclLoad, aclLog, aclLog, aclLogReset, aclSave, aclSetuser, aclUsers, aclWhoami

    Methods inherited from interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands

    asking, clusterAddSlots, clusterAddSlotsRange, clusterBumpepoch, clusterCountFailureReports, clusterCountKeysInSlot, clusterDelSlots, clusterDelSlotsRange, clusterFailover, clusterFailover, clusterFlushslots, clusterForget, clusterGetKeysInSlot, clusterInfo, clusterKeyslot, clusterMeet, clusterMyId, clusterNodes, clusterReplicas, clusterReplicate, clusterReset, clusterSaveconfig, clusterSetConfigEpoch, clusterSetSlotImporting, clusterSetSlotMigrating, clusterSetSlotNode, clusterSetSlotStable, clusterShards, clusterSlaves, clusterSlots, readOnly, readWrite, setTimeout

    Methods inherited from interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands

    geoadd, geoadd, geoadd, geoadd, geoadd, geoadd, geodist, geohash, geopos, georadius, georadius, georadius, georadiusbymember, georadiusbymember, georadiusbymember, geosearch, geosearch, geosearchstore

    Methods inherited from interface io.lettuce.core.api.reactive.RedisHashReactiveCommands

    hdel, hexists, hget, hgetall, hgetall, hincrby, hincrbyfloat, hkeys, hkeys, hlen, hmget, hmget, hmset, hrandfield, hrandfield, hrandfieldWithvalues, hrandfieldWithvalues, hscan, hscan, hscan, hscan, hscan, hscan, hscan, hscan, hset, hset, hsetnx, hstrlen, hvals, hvals

    Methods inherited from interface io.lettuce.core.api.reactive.RedisHLLReactiveCommands

    pfadd, pfcount, pfmerge

    Methods inherited from interface io.lettuce.core.api.reactive.RedisKeyReactiveCommands

    copy, copy, del, dump, exists, expire, expire, expire, expire, expireat, expireat, expireat, expireat, expireat, expireat, expiretime, keys, keys, migrate, migrate, move, objectEncoding, objectFreq, objectIdletime, objectRefcount, persist, pexpire, pexpire, pexpire, pexpire, pexpireat, pexpireat, pexpireat, pexpireat, pexpireat, pexpireat, pexpiretime, pttl, randomkey, rename, renamenx, restore, restore, scan, scan, scan, scan, scan, scan, scan, scan, sort, sort, sort, sort, sortReadOnly, sortReadOnly, sortReadOnly, sortReadOnly, sortStore, touch, ttl, type, unlink

    Methods inherited from interface io.lettuce.core.api.reactive.RedisListReactiveCommands

    blmove, blmove, blmpop, blmpop, blpop, blpop, brpop, brpop, brpoplpush, brpoplpush, lindex, linsert, llen, lmove, lmpop, lpop, lpop, lpos, lpos, lpos, lpos, lpush, lpushx, lrange, lrange, lrem, lset, ltrim, rpop, rpop, rpoplpush, rpush, rpushx

    Methods inherited from interface io.lettuce.core.api.reactive.RedisReactiveCommands

    auth, auth, select, swapdb

    Methods inherited from interface io.lettuce.core.api.reactive.RedisScriptingReactiveCommands

    digest, digest, eval, eval, eval, eval, evalReadOnly, evalsha, evalsha, evalshaReadOnly, scriptExists, scriptFlush, scriptFlush, scriptKill, scriptLoad, scriptLoad

    Methods inherited from interface io.lettuce.core.api.reactive.RedisServerReactiveCommands

    bgrewriteaof, bgsave, clientCaching, clientGetname, clientGetredir, clientId, clientKill, clientKill, clientList, clientNoEvict, clientPause, clientSetname, clientTracking, clientUnblock, command, commandCount, commandInfo, commandInfo, configGet, configGet, configResetstat, configRewrite, configSet, configSet, dbsize, debugCrashAndRecover, debugHtstats, debugObject, debugOom, debugReload, debugRestart, debugSdslen, debugSegfault, flushall, flushall, flushallAsync, flushdb, flushdb, flushdbAsync, info, info, lastsave, memoryUsage, replicaof, replicaofNoOne, save, shutdown, shutdown, slaveof, slaveofNoOne, slowlogGet, slowlogGet, slowlogLen, slowlogReset, time

    Methods inherited from interface io.lettuce.core.api.reactive.RedisSetReactiveCommands

    sadd, scard, sdiff, sdiff, sdiffstore, sinter, sinter, sintercard, sintercard, sinterstore, sismember, smembers, smembers, smismember, smove, spop, spop, srandmember, srandmember, srandmember, srem, sscan, sscan, sscan, sscan, sscan, sscan, sscan, sscan, sunion, sunion, sunionstore

    Methods inherited from interface io.lettuce.core.api.reactive.RedisSortedSetReactiveCommands

    bzpopmax, bzpopmax, bzpopmin, bzpopmin, zadd, zadd, zadd, zadd, zadd, zadd, zaddincr, zaddincr, zcard, zcount, zcount, zcount, zdiff, zdiffstore, zdiffWithScores, zincrby, zinter, zinter, zintercard, zintercard, zinterstore, zinterstore, zinterWithScores, zinterWithScores, zlexcount, zlexcount, zmscore, zpopmax, zpopmax, zpopmin, zpopmin, zrandmember, zrandmember, zrandmemberWithScores, zrandmemberWithScores, zrange, zrange, zrangebylex, zrangebylex, zrangebylex, zrangebylex, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscore, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangebyscoreWithScores, zrangestore, zrangestorebylex, zrangestorebyscore, zrangeWithScores, zrangeWithScores, zrank, zrem, zremrangebylex, zremrangebylex, zremrangebyrank, zremrangebyscore, zremrangebyscore, zremrangebyscore, zrevrange, zrevrange, zrevrangebylex, zrevrangebylex, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscore, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangebyscoreWithScores, zrevrangestore, zrevrangestorebylex, zrevrangestorebyscore, zrevrangeWithScores, zrevrangeWithScores, zrevrank, zscan, zscan, zscan, zscan, zscan, zscan, zscan, zscan, zscore, zunion, zunion, zunionstore, zunionstore, zunionWithScores, zunionWithScores

    Methods inherited from interface io.lettuce.core.api.reactive.RedisStreamReactiveCommands

    xack, xadd, xadd, xadd, xadd, xautoclaim, xclaim, xclaim, xdel, xgroupCreate, xgroupCreate, xgroupCreateconsumer, xgroupDelconsumer, xgroupDestroy, xgroupSetid, xinfoConsumers, xinfoGroups, xinfoStream, xlen, xpending, xpending, xpending, xpending, xrange, xrange, xread, xread, xreadgroup, xreadgroup, xrevrange, xrevrange, xtrim, xtrim, xtrim

    Methods inherited from interface io.lettuce.core.api.reactive.RedisStringReactiveCommands

    append, bitcount, bitcount, bitfield, bitopAnd, bitopNot, bitopOr, bitopXor, bitpos, bitpos, bitpos, decr, decrby, get, getbit, getdel, getex, getrange, getset, incr, incrby, incrbyfloat, mget, mget, mset, msetnx, psetex, set, set, setbit, setex, setGet, setGet, setnx, setrange, stralgoLcs, strlen

    Methods inherited from interface io.lettuce.core.api.reactive.RedisTransactionalReactiveCommands

    discard, exec, multi, unwatch, watch