public interface StringRedisConnection extends RedisConnection
RedisConnection that accepts and returns Strings instead of byte arrays.
 Uses a RedisSerializer underneath to perform the conversion.RedisCallback, 
RedisSerializer, 
StringRedisTemplate| Modifier and Type | Interface and Description | 
|---|---|
| static interface  | StringRedisConnection.StringTupleString-friendly ZSet tuple. | 
RedisStringCommands.BitOperation, RedisStringCommands.SetOptionRedisListCommands.PositionRedisZSetCommands.Aggregate, RedisZSetCommands.Limit, RedisZSetCommands.Range, RedisZSetCommands.Tuple, RedisZSetCommands.WeightsRedisServerCommands.MigrateOption, RedisServerCommands.ShutdownOptionRedisGeoCommands.DistanceUnit, RedisGeoCommands.GeoLocation<T>, RedisGeoCommands.GeoRadiusCommandArgs| Modifier and Type | Method and Description | 
|---|---|
| Long | append(String key,
      String value)Append a  valuetokey. | 
| Long | bitCount(String key)Count the number of set bits (population counting) in value stored at  key. | 
| Long | bitCount(String key,
        long start,
        long end)Count the number of set bits (population counting) of value stored at  keybetweenstartandend. | 
| List<Long> | bitfield(String key,
        BitFieldSubCommands command)Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored
 at a given  key. | 
| Long | bitOp(RedisStringCommands.BitOperation op,
     String destination,
     String... keys)Perform bitwise operations between strings. | 
| default Long | bitPos(String key,
      boolean bit)Return the position of the first bit set to given  bitin a string. | 
| Long | bitPos(String key,
      boolean bit,
      Range<Long> range)Return the position of the first bit set to given  bitin a string. | 
| List<String> | bLPop(int timeout,
     String... keys)Removes and returns first element from lists stored at  keys(see:RedisListCommands.lPop(byte[])). | 
| List<String> | bRPop(int timeout,
     String... keys)Removes and returns last element from lists stored at  keys(see:RedisListCommands.rPop(byte[])). | 
| String | bRPopLPush(int timeout,
          String srcKey,
          String dstKey)Remove the last element from list at  srcKey, append it todstKeyand return its value (seeRedisListCommands.rPopLPush(byte[], byte[])). | 
| Long | decr(String key)Decrement an integer value stored as string value of  keyby 1. | 
| Long | decrBy(String key,
      long value)Decrement an integer value stored as string value of  keybyvalue. | 
| Long | del(String... keys)Delete given  keys. | 
| String | echo(String message)Returns  messagevia server roundtrip. | 
| ValueEncoding | encodingOf(String key)Get the type of internal representation used for storing the value at the given  key. | 
| <T> T | eval(String script,
    ReturnType returnType,
    int numKeys,
    String... keysAndArgs)Evaluate given  script. | 
| <T> T | evalSha(String scriptSha,
       ReturnType returnType,
       int numKeys,
       String... keysAndArgs)Evaluate given  scriptSha. | 
| Object | execute(String command)'Native' or 'raw' execution of the given command along-side the given arguments. | 
| Object | execute(String command,
       String... args)'Native' or 'raw' execution of the given command along-side the given arguments. | 
| Long | exists(String... keys)Count how many of the given  keysexist. | 
| Boolean | exists(String key)Determine if given  keyexists. | 
| Boolean | expire(String key,
      long seconds)Set time to live for given  keyin seconds. | 
| Boolean | expireAt(String key,
        long unixTime)Set the expiration for given  keyas a UNIX timestamp. | 
| Long | geoAdd(String key,
      Iterable<RedisGeoCommands.GeoLocation<String>> locations)Add  GeoLocations to key | 
| Long | geoAdd(String key,
      Map<String,Point> memberCoordinateMap) | 
| Long | geoAdd(String key,
      Point point,
      String member)Add  Pointwith given member name to key. | 
| Long | geoAdd(String key,
      RedisGeoCommands.GeoLocation<String> location)Add  GeoLocationto key. | 
| Distance | geoDist(String key,
       String member1,
       String member2)Get the  Distancebetween member1 and member2. | 
| Distance | geoDist(String key,
       String member1,
       String member2,
       Metric metric) | 
| List<String> | geoHash(String key,
       String... members)Get geohash representation of the position for one or more members. | 
| List<Point> | geoPos(String key,
      String... members)Get the  Pointrepresentation of positions for one or more members. | 
| GeoResults<RedisGeoCommands.GeoLocation<String>> | geoRadius(String key,
         Circle within)Get the members within the boundaries of a given  Circle. | 
| GeoResults<RedisGeoCommands.GeoLocation<String>> | geoRadius(String key,
         Circle within,
         RedisGeoCommands.GeoRadiusCommandArgs args)Get the members within the boundaries of a given  CircleapplyingGeoRadiusCommandArgs. | 
| GeoResults<RedisGeoCommands.GeoLocation<String>> | geoRadiusByMember(String key,
                 String member,
                 Distance radius)Get the members within the circle defined by the members coordinates and given
  Distance. | 
| GeoResults<RedisGeoCommands.GeoLocation<String>> | geoRadiusByMember(String key,
                 String member,
                 Distance radius,
                 RedisGeoCommands.GeoRadiusCommandArgs args)Get the members within the circle defined by the members coordinates and given
  DistanceandGeoRadiusCommandArgs. | 
| GeoResults<RedisGeoCommands.GeoLocation<String>> | geoRadiusByMember(String key,
                 String member,
                 double radius)Get the members within the circle defined by the members coordinates and given
 radius. | 
| Long | geoRemove(String key,
         String... members)Remove the members. | 
| String | get(String key)Get the value of  key. | 
| Boolean | getBit(String key,
      long offset)Get the bit value at  offsetof value atkey. | 
| List<RedisClientInfo> | getClientList()Request information and statistics about connected clients. | 
| String | getRange(String key,
        long start,
        long end)Get a substring of value of  keybetweenstartandend. | 
| String | getSet(String key,
      String value)Set  valueofkeyand return its old value. | 
| Long | hDel(String key,
    String... fields)Delete given hash  fields. | 
| Boolean | hExists(String key,
       String field)Determine if given hash  fieldexists. | 
| String | hGet(String key,
    String field)Get value for given  fieldfrom hash atkey. | 
| Map<String,String> | hGetAll(String key)Get entire hash stored at  key. | 
| Double | hIncrBy(String key,
       String field,
       double delta)Increment  valueof a hashfieldby the givendelta. | 
| Long | hIncrBy(String key,
       String field,
       long delta)Increment  valueof a hashfieldby the givendelta. | 
| Set<String> | hKeys(String key)Get key set (fields) of hash at  key. | 
| Long | hLen(String key)Get size of hash at  key. | 
| List<String> | hMGet(String key,
     String... fields)Get values for given  fieldsfrom hash atkey. | 
| void | hMSet(String key,
     Map<String,String> hashes)Set multiple hash fields to multiple values using data provided in  hashes | 
| Cursor<Map.Entry<String,String>> | hScan(String key,
     ScanOptions options)Use a  Cursorto iterate over entries in hash atkey. | 
| Boolean | hSet(String key,
    String field,
    String value)Set the  valueof a hashfield. | 
| Boolean | hSetNX(String key,
      String field,
      String value)Set the  valueof a hashfieldonly iffielddoes not exist. | 
| Long | hStrLen(String key,
       String field)Returns the length of the value associated with  fieldin the hash stored atkey. | 
| List<String> | hVals(String key)Get entry set (values) of hash at  field. | 
| Duration | idletime(String key)Get the  Durationsince the object stored at the givenkeyis idle. | 
| Long | incr(String key)Increment an integer value stored as string value of  keyby 1. | 
| Double | incrBy(String key,
      double value)Increment a floating point number value of  keybydelta. | 
| Long | incrBy(String key,
      long value)Increment an integer value stored of  keybydelta. | 
| Collection<String> | keys(String pattern)Find all keys matching the given  pattern. | 
| String | lIndex(String key,
      long index)Get element at  indexform list atkey. | 
| Long | lInsert(String key,
       RedisListCommands.Position where,
       String pivot,
       String value)Insert  valuePosition#BEFOREorPosition#AFTERexistingpivotforkey. | 
| Long | lLen(String key)Get the size of list stored at  key. | 
| String | lPop(String key)Removes and returns first element in list stored at  key. | 
| Long | lPush(String key,
     String... values)Prepend  valuestokey. | 
| Long | lPushX(String key,
      String value)Prepend  valuestokeyonly if the list exists. | 
| List<String> | lRange(String key,
      long start,
      long end)Get elements between  startandendfrom list atkey. | 
| Long | lRem(String key,
    long count,
    String value)Removes the first  countoccurrences ofvaluefrom the list stored atkey. | 
| void | lSet(String key,
    long index,
    String value)Set the  valuelist element atindex. | 
| void | lTrim(String key,
     long start,
     long end)Trim list at  keyto elements betweenstartandend. | 
| List<String> | mGet(String... keys)Get multiple  keys. | 
| Boolean | move(String key,
    int dbIndex)Move given  keyto database withindex. | 
| Boolean | mSetNXString(Map<String,String> tuple)Set multiple keys to multiple values using key-value pairs provided in  tupleonly if the provided key does
 not exist. | 
| Boolean | mSetString(Map<String,String> tuple)Set multiple keys to multiple values using key-value pairs provided in  tuple. | 
| Boolean | persist(String key)Remove the expiration from given  key. | 
| Boolean | pExpire(String key,
       long millis)Set time to live for given  keyin milliseconds. | 
| Boolean | pExpireAt(String key,
         long unixTimeInMillis)Set the expiration for given  keyas a UNIX timestamp in milliseconds. | 
| Long | pfAdd(String key,
     String... values)Adds given values to the HyperLogLog stored at given key. | 
| Long | pfCount(String... keys)Return the approximated cardinality of the structures observed by the HyperLogLog at key(s). | 
| void | pfMerge(String destinationKey,
       String... sourceKeys)Merge N different HyperLogLogs at sourceKeys into a single destinationKey. | 
| Boolean | pSetEx(String key,
      long milliseconds,
      String value)Set the  valueand expiration inmillisecondsforkey. | 
| void | pSubscribe(MessageListener listener,
          String... patterns)Subscribes the connection to all channels matching the given patterns. | 
| Long | pTtl(String key)Get the precise time to live for  keyin milliseconds. | 
| Long | pTtl(String key,
    TimeUnit timeUnit)Get the precise time to live for  keyin and convert it to the givenTimeUnit. | 
| Long | publish(String channel,
       String message)Publishes the given message to the given channel. | 
| Long | refcount(String key)Get the number of references of the value associated with the specified  key. | 
| void | rename(String oldName,
      String newName)Rename key  oleNametonewName. | 
| Boolean | renameNX(String oldName,
        String newName)Rename key  oleNametonewNameonly ifnewNamedoes not exist. | 
| String | rPop(String key)Removes and returns last element in list stored at  key. | 
| String | rPopLPush(String srcKey,
         String dstKey)Remove the last element from list at  srcKey, append it todstKeyand return its value. | 
| Long | rPush(String key,
     String... values)Append  valuestokey. | 
| Long | rPushX(String key,
      String value)Append  valuestokeyonly if the list exists. | 
| Long | sAdd(String key,
    String... values)Add given  valuesto set atkey. | 
| Long | sCard(String key)Get size of set at  key. | 
| String | scriptLoad(String script)Load lua script into scripts cache, without executing it. | 
| Set<String> | sDiff(String... keys)Diff all sets for given  keys. | 
| Long | sDiffStore(String destKey,
          String... keys)Diff all sets for given  keysand store result indestKey. | 
| Boolean | set(String key,
   String value)Set  valueforkey. | 
| Boolean | set(String key,
   String value,
   Expiration expiration,
   RedisStringCommands.SetOption option)Set  valueforkeyapplying timeouts fromexpirationif set and inserting/updating values
 depending onoption. | 
| Boolean | setBit(String key,
      long offset,
      boolean value)Sets the bit at  offsetin value stored atkey. | 
| void | setClientName(String name)Assign given name to current connection. | 
| Boolean | setEx(String key,
     long seconds,
     String value)Set the  valueand expiration insecondsforkey. | 
| Boolean | setNX(String key,
     String value)Set  valueforkey, only ifkeydoes not exist. | 
| void | setRange(String key,
        String value,
        long offset)Overwrite parts of  keystarting at the specifiedoffsetwith givenvalue. | 
| Set<String> | sInter(String... keys)Returns the members intersecting all given sets at  keys. | 
| Long | sInterStore(String destKey,
           String... keys)Intersect all given sets at  keysand store result indestKey. | 
| Boolean | sIsMember(String key,
         String value)Check if set at  keycontainsvalue. | 
| Set<String> | sMembers(String key)Get all elements of set at  key. | 
| Boolean | sMove(String srcKey,
     String destKey,
     String value)Move  valuefromsrcKeytodestKey | 
| List<String> | sort(String key,
    SortParameters params)Sort the elements for  key. | 
| Long | sort(String key,
    SortParameters params,
    String storeKey)Sort the elements for  keyand store result instoreKey. | 
| String | sPop(String key)Remove and return a random member from set at  key. | 
| List<String> | sPop(String key,
    long count)Remove and return  countrandom members from set atkey. | 
| String | sRandMember(String key)Get random element from set at  key. | 
| List<String> | sRandMember(String key,
           long count)Get  countrandom elements from set atkey. | 
| Long | sRem(String key,
    String... values)Remove given  valuesfrom set atkeyand return the number of removed elements. | 
| Cursor<String> | sScan(String key,
     ScanOptions options)Use a  Cursorto iterate over elements in set atkey. | 
| Long | strLen(String key)Get the length of the value stored at  key. | 
| void | subscribe(MessageListener listener,
         String... channels)Subscribes the connection to the given channels. | 
| Set<String> | sUnion(String... keys)Union all sets at given  keys. | 
| Long | sUnionStore(String destKey,
           String... keys)Union all sets at given  keysand store result indestKey. | 
| Long | touch(String... keys)Alter the last access time of given  key(s). | 
| Long | ttl(String key)Get the time to live for  keyin seconds. | 
| Long | ttl(String key,
   TimeUnit timeUnit)Get the time to live for  keyin and convert it to the givenTimeUnit. | 
| DataType | type(String key)Determine the type stored at  key. | 
| Long | unlink(String... keys)Unlink the  keysfrom the keyspace. | 
| Boolean | zAdd(String key,
    double score,
    String value)Add  valueto a sorted set atkey, or update itsscoreif it already exists. | 
| Long | zAdd(String key,
    Set<StringRedisConnection.StringTuple> tuples)Add  tuplesto a sorted set atkey, or update itsscoreif it already exists. | 
| Long | zCard(String key)Get the size of sorted set with  key. | 
| Long | zCount(String key,
      double min,
      double max)Count number of elements within sorted set with scores between  minandmax. | 
| Double | zIncrBy(String key,
       double increment,
       String value)Increment the score of element with  valuein sorted set byincrement. | 
| Long | zInterStore(String destKey,
           RedisZSetCommands.Aggregate aggregate,
           int[] weights,
           String... sets)Intersect sorted  setsand store result in destinationkey. | 
| Long | zInterStore(String destKey,
           String... sets)Intersect sorted  setsand store result in destinationkey. | 
| Set<String> | zRange(String key,
      long start,
      long end)Get elements between  startandendfrom sorted set. | 
| Set<String> | zRangeByLex(String key)Get all the elements in the sorted set at key in lexicographical ordering. | 
| Set<String> | zRangeByLex(String key,
           RedisZSetCommands.Range range)Get all the elements in  Rangefrom the sorted set at key in lexicographical ordering. | 
| Set<String> | zRangeByLex(String key,
           RedisZSetCommands.Range range,
           RedisZSetCommands.Limit limit)Get all the elements in  Rangefrom the sorted set at key in lexicographical ordering. | 
| Set<String> | zRangeByScore(String key,
             double min,
             double max)Get elements where score is between  minandmaxfrom sorted set. | 
| Set<String> | zRangeByScore(String key,
             double min,
             double max,
             long offset,
             long count)Get elements in range from  starttoendwhere score is betweenminandmaxfrom
 sorted set. | 
| Set<String> | zRangeByScore(String key,
             String min,
             String max)Get elements where score is between  minandmaxfrom sorted set. | 
| Set<String> | zRangeByScore(String key,
             String min,
             String max,
             long offset,
             long count)Get elements in range from  starttoendwhere score is betweenminandmaxfrom
 sorted set. | 
| Set<StringRedisConnection.StringTuple> | zRangeByScoreWithScores(String key,
                       double min,
                       double max)Get set of  Tuples where score is betweenminandmaxfrom sorted set. | 
| Set<StringRedisConnection.StringTuple> | zRangeByScoreWithScores(String key,
                       double min,
                       double max,
                       long offset,
                       long count)Get set of  Tuples in range fromstarttoendwhere score is betweenminandmaxfrom sorted set. | 
| Set<StringRedisConnection.StringTuple> | zRangeWithScores(String key,
                long start,
                long end)Get set of  Tuples betweenstartandendfrom sorted set. | 
| Long | zRank(String key,
     String value)Determine the index of element with  valuein a sorted set. | 
| Long | zRem(String key,
    String... values)Remove  valuesfrom sorted set. | 
| Long | zRemRange(String key,
         long start,
         long end)Remove elements in range between  startandendfrom sorted set withkey. | 
| Long | zRemRangeByScore(String key,
                double min,
                double max)Remove elements with scores between  minandmaxfrom sorted set withkey. | 
| Set<String> | zRevRange(String key,
         long start,
         long end)Get elements in range from  starttoendfrom sorted set ordered from high to low. | 
| Set<String> | zRevRangeByScore(String key,
                double min,
                double max)Get elements where score is between  minandmaxfrom sorted set ordered from high to low. | 
| Set<String> | zRevRangeByScore(String key,
                double min,
                double max,
                long offset,
                long count)Get elements in range from  starttoendwhere score is betweenminandmaxfrom
 sorted set ordered high -> low. | 
| Set<StringRedisConnection.StringTuple> | zRevRangeByScoreWithScores(String key,
                          double min,
                          double max)Get set of  Tuplewhere score is betweenminandmaxfrom sorted set ordered from high to
 low. | 
| Set<StringRedisConnection.StringTuple> | zRevRangeByScoreWithScores(String key,
                          double min,
                          double max,
                          long offset,
                          long count)Get set of  Tuplein range fromstarttoendwhere score is betweenminandmaxfrom sorted set ordered high -> low. | 
| Set<StringRedisConnection.StringTuple> | zRevRangeWithScores(String key,
                   long start,
                   long end)Get set of  Tuples in range fromstarttoendfrom sorted set ordered from high to low. | 
| Long | zRevRank(String key,
        String value)Determine the index of element with  valuein a sorted set when scored high to low. | 
| Cursor<StringRedisConnection.StringTuple> | zScan(String key,
     ScanOptions options)Use a  Cursorto iterate over elements in sorted set atkey. | 
| Double | zScore(String key,
      String value)Get the score of element with  valuefrom sorted set with keykey. | 
| Long | zUnionStore(String destKey,
           RedisZSetCommands.Aggregate aggregate,
           int[] weights,
           String... sets)Union sorted  setsand store result in destinationkey. | 
| Long | zUnionStore(String destKey,
           String... sets)Union sorted  setsand store result in destinationkey. | 
close, closePipeline, geoCommands, getNativeConnection, getSentinelConnection, hashCommands, hyperLogLogCommands, isClosed, isPipelined, isQueueing, keyCommands, listCommands, openPipeline, scriptingCommands, serverCommands, setCommands, stringCommands, zSetCommandsexecutedel, dump, encodingOf, exists, exists, expire, expireAt, idletime, keys, move, persist, pExpire, pExpireAt, pTtl, pTtl, randomKey, refcount, rename, renameNX, restore, restore, scan, sort, sort, touch, ttl, ttl, type, unlinkappend, bitCount, bitCount, bitField, bitOp, bitPos, bitPos, decr, decrBy, get, getBit, getRange, getSet, incr, incrBy, incrBy, mGet, mSet, mSetNX, pSetEx, set, set, setBit, setEx, setNX, setRange, strLenbLPop, bRPop, bRPopLPush, lIndex, lInsert, lLen, lPop, lPush, lPushX, lRange, lRem, lSet, lTrim, rPop, rPopLPush, rPush, rPushXsAdd, sCard, sDiff, sDiffStore, sInter, sInterStore, sIsMember, sMembers, sMove, sPop, sPop, sRandMember, sRandMember, sRem, sScan, sUnion, sUnionStorezAdd, zAdd, zCard, zCount, zCount, zIncrBy, zInterStore, 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, zUnionStorehDel, hExists, hGet, hGetAll, hIncrBy, hIncrBy, hKeys, hLen, hMGet, hMSet, hScan, hSet, hSetNX, hStrLen, hValsdiscard, exec, multi, unwatch, watchgetSubscription, isSubscribed, pSubscribe, publish, subscribeecho, ping, selectbgReWriteAof, bgSave, bgWriteAof, dbSize, flushAll, flushDb, getClientName, getConfig, info, info, killClient, lastSave, migrate, migrate, resetConfigStats, save, setClientName, setConfig, shutdown, shutdown, slaveOf, slaveOfNoOne, timeeval, evalSha, evalSha, scriptExists, scriptFlush, scriptKill, scriptLoadgeoAdd, geoAdd, geoAdd, geoAdd, geoDist, geoDist, geoHash, geoPos, geoRadius, geoRadius, geoRadiusByMember, geoRadiusByMember, geoRadiusByMember, geoRemovepfAdd, pfCount, pfMergeObject execute(String command, String... args)
command - Command to executeargs - Possible command arguments (may be null)RedisCommands#execute(String, byte[]...)Object execute(String command)
command - Command to executeRedisCommands#execute(String, byte[]...)Boolean exists(String key)
key exists.key - must not be null.RedisKeyCommands.exists(byte[])@Nullable Long exists(String... keys)
keys exist.keys - must not be null.RedisKeyCommands.exists(byte[][])Long del(String... keys)
keys.keys - must not be null.RedisKeyCommands#del(byte[]...)@Nullable Long unlink(String... keys)
keys from the keyspace. Unlike with del(String...) the actual memory reclaiming here
 happens asynchronously.keys - must not be null.DataType type(String key)
key.key - must not be null.RedisKeyCommands.type(byte[])@Nullable Long touch(String... keys)
key(s).keys - must not be null.Collection<String> keys(String pattern)
pattern.pattern - must not be null.RedisKeyCommands.keys(byte[])void rename(String oldName, String newName)
oleName to newName.oldName - must not be null.newName - must not be null.RedisKeyCommands.rename(byte[], byte[])Boolean renameNX(String oldName, String newName)
oleName to newName only if newName does not exist.oldName - must not be null.newName - must not be null.RedisKeyCommands.renameNX(byte[], byte[])Boolean expire(String key, long seconds)
key in seconds.key - must not be null.seconds - RedisKeyCommands.expire(byte[], long)Boolean pExpire(String key, long millis)
key in milliseconds.key - must not be null.millis - RedisKeyCommands.pExpire(byte[], long)Boolean expireAt(String key, long unixTime)
key as a UNIX timestamp.key - must not be null.unixTime - RedisKeyCommands.expireAt(byte[], long)Boolean pExpireAt(String key, long unixTimeInMillis)
key as a UNIX timestamp in milliseconds.key - must not be null.unixTimeInMillis - RedisKeyCommands.pExpireAt(byte[], long)Boolean persist(String key)
key.key - must not be null.RedisKeyCommands.persist(byte[])Boolean move(String key, int dbIndex)
key to database with index.key - must not be null.dbIndex - RedisKeyCommands.move(byte[], int)Long ttl(String key)
key in seconds.key - must not be null.RedisKeyCommands.ttl(byte[])Long ttl(String key, TimeUnit timeUnit)
key in and convert it to the given TimeUnit.key - must not be null.timeUnit - must not be null.RedisKeyCommands.ttl(byte[], TimeUnit)Long pTtl(String key)
key in milliseconds.key - must not be null.RedisKeyCommands.pTtl(byte[])Long pTtl(String key, TimeUnit timeUnit)
key in and convert it to the given TimeUnit.key - must not be null.timeUnit - must not be null.RedisKeyCommands.pTtl(byte[], TimeUnit)String echo(String message)
message via server roundtrip.message - the message to echo.RedisConnectionCommands.echo(byte[])List<String> sort(String key, SortParameters params)
key.key - must not be null.params - must not be null.Long sort(String key, SortParameters params, String storeKey)
key and store result in storeKey.key - must not be null.params - must not be null.storeKey - must not be null.@Nullable ValueEncoding encodingOf(String key)
key.key - must not be null.IllegalArgumentException - if key is null.@Nullable Duration idletime(String key)
Duration since the object stored at the given key is idle.key - must not be null.IllegalArgumentException - if key is null.@Nullable Long refcount(String key)
key.key - must not be null.IllegalArgumentException - if key is null.String get(String key)
key.key - must not be null.RedisStringCommands.get(byte[])String getSet(String key, String value)
value of key and return its old value.key - must not be null.value - RedisStringCommands.getSet(byte[], byte[])List<String> mGet(String... keys)
keys. Values are returned in the order of the requested keys.keys - must not be null.RedisStringCommands#mGet(byte[]...)@Nullable Boolean set(String key, String value)
value for key.key - must not be null.value - must not be null.RedisStringCommands.set(byte[], byte[])@Nullable Boolean set(String key, String value, Expiration expiration, RedisStringCommands.SetOption option)
value for key applying timeouts from expiration if set and inserting/updating values
 depending on option.key - must not be null.value - must not be null.expiration - can be null. Defaulted to Expiration.persistent().option - can be null. Defaulted to SetOption#UPSERT.RedisStringCommands.set(byte[], byte[], Expiration, SetOption)@Nullable Boolean setNX(String key, String value)
value for key, only if key does not exist.key - must not be null.value - must not be null.RedisStringCommands.setNX(byte[], byte[])@Nullable Boolean setEx(String key, long seconds, String value)
value and expiration in seconds for key.key - must not be null.seconds - value - must not be null.RedisStringCommands.setEx(byte[], long, byte[])@Nullable Boolean pSetEx(String key, long milliseconds, String value)
value and expiration in milliseconds for key.key - must not be null.milliseconds - value - must not be null.RedisStringCommands.pSetEx(byte[], long, byte[])@Nullable Boolean mSetString(Map<String,String> tuple)
tuple.tuple - must not be null.RedisStringCommands.mSet(Map)Boolean mSetNXString(Map<String,String> tuple)
tuple only if the provided key does
 not exist.tuple - must not be null.RedisStringCommands.mSetNX(Map)Long incr(String key)
key by 1.key - must not be null.RedisStringCommands.incr(byte[])Long incrBy(String key, long value)
key by delta.key - must not be null.value - RedisStringCommands.incrBy(byte[], long)Double incrBy(String key, double value)
key by delta.key - must not be null.value - RedisStringCommands.incrBy(byte[], double)Long decr(String key)
key by 1.key - must not be null.RedisStringCommands.decr(byte[])Long decrBy(String key, long value)
key by value.key - must not be null.value - RedisStringCommands.decrBy(byte[], long)Long append(String key, String value)
value to key.key - must not be null.value - RedisStringCommands.append(byte[], byte[])String getRange(String key, long start, long end)
key between start and end.key - must not be null.start - end - RedisStringCommands.getRange(byte[], long, long)void setRange(String key, String value, long offset)
key starting at the specified offset with given value.key - must not be null.value - offset - RedisStringCommands.setRange(byte[], byte[], long)Boolean getBit(String key, long offset)
offset of value at key.key - must not be null.offset - RedisStringCommands.getBit(byte[], long)Boolean setBit(String key, long offset, boolean value)
offset in value stored at key.key - must not be null.offset - value - offset.RedisStringCommands.setBit(byte[], long, boolean)Long bitCount(String key)
key.key - must not be null.RedisStringCommands.bitCount(byte[])Long bitCount(String key, long start, long end)
key between start and
 end.key - must not be null.start - end - RedisStringCommands.bitCount(byte[], long, long)Long bitOp(RedisStringCommands.BitOperation op, String destination, String... keys)
op - must not be null.destination - must not be null.keys - must not be null.RedisStringCommands#bitOp(BitOperation, byte[], byte[]...)default Long bitPos(String key, boolean bit)
bit in a string.key - the key holding the actual String.bit - the bit value to look for.@Nullable Long bitPos(String key, boolean bit, Range<Long> range)
bit in a string.
 Range start and end can contain negative values in order to index
 bytes starting from the end of the string, where -1 is the last byte, -2 is
 the penultimate.key - the key holding the actual String.bit - the bit value to look for.range - must not be null. Use Range#unbounded() to not limit search.Long strLen(String key)
key.key - must not be null.RedisStringCommands.strLen(byte[])Long rPush(String key, String... values)
values to key.key - must not be null.values - RedisListCommands#rPush(byte[], byte[]...)Long lPush(String key, String... values)
values to key.key - must not be null.values - RedisListCommands#lPush(byte[], byte[]...)Long rPushX(String key, String value)
values to key only if the list exists.key - must not be null.value - RedisListCommands.rPushX(byte[], byte[])Long lPushX(String key, String value)
values to key only if the list exists.key - must not be null.value - RedisListCommands.lPushX(byte[], byte[])Long lLen(String key)
key.key - must not be null.RedisListCommands.lLen(byte[])List<String> lRange(String key, long start, long end)
start and end from list at key.key - must not be null.start - end - RedisListCommands.lRange(byte[], long, long)void lTrim(String key, long start, long end)
key to elements between start and end.key - must not be null.start - end - RedisListCommands.lTrim(byte[], long, long)String lIndex(String key, long index)
index form list at key.key - must not be null.index - RedisListCommands.lIndex(byte[], long)Long lInsert(String key, RedisListCommands.Position where, String pivot, String value)
value Position#BEFORE or Position#AFTER existing pivot for key.key - must not be null.where - must not be null.pivot - value - RedisListCommands.lIndex(byte[], long)void lSet(String key, long index, String value)
value list element at index.key - must not be null.index - value - RedisListCommands.lSet(byte[], long, byte[])Long lRem(String key, long count, String value)
count occurrences of value from the list stored at key.key - must not be null.count - value - RedisListCommands.lRem(byte[], long, byte[])String lPop(String key)
key.key - must not be null.RedisListCommands.lPop(byte[])String rPop(String key)
key.key - must not be null.RedisListCommands.rPop(byte[])List<String> bLPop(int timeout, String... keys)
keys (see: RedisListCommands.lPop(byte[])). timeout reached.timeout - keys - must not be null.RedisListCommands#bLPop(int, byte[]...)List<String> bRPop(int timeout, String... keys)
keys (see: RedisListCommands.rPop(byte[])). timeout reached.timeout - keys - must not be null.RedisListCommands#bRPop(int, byte[]...)String rPopLPush(String srcKey, String dstKey)
srcKey, append it to dstKey and return its value.srcKey - must not be null.dstKey - must not be null.RedisListCommands.rPopLPush(byte[], byte[])String bRPopLPush(int timeout, String srcKey, String dstKey)
srcKey, append it to dstKey and return its value (see
 RedisListCommands.rPopLPush(byte[], byte[])). timeout reached.timeout - srcKey - must not be null.dstKey - must not be null.RedisListCommands.bRPopLPush(int, byte[], byte[])Long sAdd(String key, String... values)
values to set at key.key - must not be null.values - RedisSetCommands#sAdd(byte[], byte[]...)Long sRem(String key, String... values)
values from set at key and return the number of removed elements.key - must not be null.values - RedisSetCommands#sRem(byte[], byte[]...)String sPop(String key)
key.key - must not be null.RedisSetCommands.sPop(byte[])List<String> sPop(String key, long count)
count random members from set at key.key - must not be null.count - the number of random members to return.List if key does not exist.RedisSetCommands.sPop(byte[], long)Boolean sMove(String srcKey, String destKey, String value)
value from srcKey to destKeysrcKey - must not be null.destKey - must not be null.value - RedisSetCommands.sMove(byte[], byte[], byte[])Long sCard(String key)
key.key - must not be null.RedisSetCommands.sCard(byte[])Boolean sIsMember(String key, String value)
key contains value.key - must not be null.value - RedisSetCommands.sIsMember(byte[], byte[])Set<String> sInter(String... keys)
keys.keys - must not be null.RedisSetCommands#sInter(byte[]...)Long sInterStore(String destKey, String... keys)
keys and store result in destKey.destKey - must not be null.keys - must not be null.RedisSetCommands#sInterStore(byte[], byte[]...)Set<String> sUnion(String... keys)
keys.keys - must not be null.RedisSetCommands#sUnion(byte[]...)Long sUnionStore(String destKey, String... keys)
keys and store result in destKey.destKey - must not be null.keys - must not be null.RedisSetCommands#sUnionStore(byte[], byte[]...)Set<String> sDiff(String... keys)
keys.keys - must not be null.RedisSetCommands#sDiff(byte[]...)Long sDiffStore(String destKey, String... keys)
keys and store result in destKey.destKey - must not be null.keys - must not be null.RedisSetCommands#sDiffStore(byte[], byte[]...)Set<String> sMembers(String key)
key.key - must not be null.RedisSetCommands.sMembers(byte[])String sRandMember(String key)
key.key - must not be null.RedisSetCommands.sRandMember(byte[])List<String> sRandMember(String key, long count)
count random elements from set at key.key - must not be null.count - RedisSetCommands#sRem(byte[], byte[]...)Cursor<String> sScan(String key, ScanOptions options)
Cursor to iterate over elements in set at key.key - must not be null.options - must not be null.RedisSetCommands.sScan(byte[], ScanOptions)Boolean zAdd(String key, double score, String value)
value to a sorted set at key, or update its score if it already exists.key - must not be null.score - the score.value - the value.RedisZSetCommands.zAdd(byte[], double, byte[])Long zAdd(String key, Set<StringRedisConnection.StringTuple> tuples)
tuples to a sorted set at key, or update its score if it already exists.key - must not be null.tuples - the tuples.RedisZSetCommands.zAdd(byte[], Set)Long zRem(String key, String... values)
values from sorted set. Return number of removed elements.key - must not be null.values - must not be null.RedisZSetCommands#zRem(byte[], byte[]...)Double zIncrBy(String key, double increment, String value)
value in sorted set by increment.key - must not be null.increment - value - the value.RedisZSetCommands.zIncrBy(byte[], double, byte[])Long zRank(String key, String value)
value in a sorted set.key - must not be null.value - the value.RedisZSetCommands.zRank(byte[], byte[])Long zRevRank(String key, String value)
value in a sorted set when scored high to low.key - must not be null.value - the value.RedisZSetCommands.zRevRank(byte[], byte[])Set<String> zRange(String key, long start, long end)
start and end from sorted set.key - must not be null.start - end - RedisZSetCommands.zRange(byte[], long, long)Set<StringRedisConnection.StringTuple> zRangeWithScores(String key, long start, long end)
Tuples between start and end from sorted set.key - must not be null.start - end - RedisZSetCommands.zRangeWithScores(byte[], long, long)Set<String> zRangeByScore(String key, double min, double max)
min and max from sorted set.key - must not be null.min - max - RedisZSetCommands.zRangeByScore(byte[], double, double)Set<StringRedisConnection.StringTuple> zRangeByScoreWithScores(String key, double min, double max)
Tuples where score is between min and max from sorted set.key - must not be null.min - max - RedisZSetCommands.zRangeByScoreWithScores(byte[], double, double)Set<String> zRangeByScore(String key, double min, double max, long offset, long count)
start to end where score is between min and max from
 sorted set.key - must not be null.min - max - offset - count - RedisZSetCommands.zRangeByScore(byte[], double, double, long, long)Set<StringRedisConnection.StringTuple> zRangeByScoreWithScores(String key, double min, double max, long offset, long count)
Tuples in range from start to end where score is between min and
 max from sorted set.key - min - max - offset - count - RedisZSetCommands.zRangeByScoreWithScores(byte[], double, double, long, long)Set<String> zRevRange(String key, long start, long end)
start to end from sorted set ordered from high to low.key - must not be null.start - end - RedisZSetCommands.zRevRange(byte[], long, long)Set<StringRedisConnection.StringTuple> zRevRangeWithScores(String key, long start, long end)
Tuples in range from start to end from sorted set ordered from high to low.key - must not be null.start - end - RedisZSetCommands.zRevRangeWithScores(byte[], long, long)Set<String> zRevRangeByScore(String key, double min, double max)
min and max from sorted set ordered from high to low.key - must not be null.min - max - RedisZSetCommands.zRevRangeByScore(byte[], double, double)Set<StringRedisConnection.StringTuple> zRevRangeByScoreWithScores(String key, double min, double max)
Tuple where score is between min and max from sorted set ordered from high to
 low.key - must not be null.min - max - RedisZSetCommands.zRevRangeByScoreWithScores(byte[], double, double)Set<String> zRevRangeByScore(String key, double min, double max, long offset, long count)
start to end where score is between min and max from
 sorted set ordered high -> low.key - must not be null.min - max - offset - count - RedisZSetCommands.zRevRangeByScore(byte[], double, double, long, long)Set<StringRedisConnection.StringTuple> zRevRangeByScoreWithScores(String key, double min, double max, long offset, long count)
Tuple in range from start to end where score is between min and
 max from sorted set ordered high -> low.key - must not be null.min - max - offset - count - RedisZSetCommands.zRevRangeByScoreWithScores(byte[], double, double, long, long)Long zCount(String key, double min, double max)
min and max.key - must not be null.min - max - RedisZSetCommands.zCount(byte[], double, double)Long zCard(String key)
key.key - must not be null.RedisZSetCommands.zCard(byte[])Double zScore(String key, String value)
value from sorted set with key key.key - must not be null.value - the value.RedisZSetCommands.zScore(byte[], byte[])Long zRemRange(String key, long start, long end)
start and end from sorted set with key.key - must not be null.start - end - RedisZSetCommands.zRemRange(byte[], long, long)Long zRemRangeByScore(String key, double min, double max)
min and max from sorted set with key.key - must not be null.min - max - RedisZSetCommands.zRemRangeByScore(byte[], double, double)Long zUnionStore(String destKey, String... sets)
sets and store result in destination key.destKey - must not be null.sets - must not be null.RedisZSetCommands#zUnionStore(byte[], byte[]...)Long zUnionStore(String destKey, RedisZSetCommands.Aggregate aggregate, int[] weights, String... sets)
sets and store result in destination key.destKey - must not be null.aggregate - must not be null.weights - sets - must not be null.RedisZSetCommands#zUnionStore(byte[], Aggregate, int[], byte[]...)Long zInterStore(String destKey, String... sets)
sets and store result in destination key.destKey - must not be null.sets - must not be null.RedisZSetCommands#zInterStore(byte[], byte[]...)Long zInterStore(String destKey, RedisZSetCommands.Aggregate aggregate, int[] weights, String... sets)
sets and store result in destination key.destKey - must not be null.aggregate - must not be null.weights - sets - must not be null.RedisZSetCommands#zInterStore(byte[], Aggregate, int[], byte[]...)Cursor<StringRedisConnection.StringTuple> zScan(String key, ScanOptions options)
Cursor to iterate over elements in sorted set at key.key - must not be null.options - must not be null.RedisZSetCommands.zScan(byte[], ScanOptions)Set<String> zRangeByScore(String key, String min, String max)
min and max from sorted set.key - must not be null.min - must not be null.max - must not be null.RedisZSetCommands.zRangeByScore(byte[], String, String)Set<String> zRangeByScore(String key, String min, String max, long offset, long count)
start to end where score is between min and max from
 sorted set.key - must not be null.min - must not be null.max - must not be null.offset - count - RedisZSetCommands.zRangeByScore(byte[], double, double, long, long)Set<String> zRangeByLex(String key)
key - must not be null.RedisZSetCommands.zRangeByLex(byte[])Set<String> zRangeByLex(String key, RedisZSetCommands.Range range)
Range from the sorted set at key in lexicographical ordering.key - must not be null.range - must not be null.RedisZSetCommands.zRangeByLex(byte[], Range)Set<String> zRangeByLex(String key, RedisZSetCommands.Range range, RedisZSetCommands.Limit limit)
Range from the sorted set at key in lexicographical ordering. Result is
 limited via Limit.key - must not be null.range - must not be null.range - can be null.RedisZSetCommands.zRangeByLex(byte[], Range, Limit)Boolean hSet(String key, String field, String value)
value of a hash field.key - must not be null.field - must not be null.value - RedisHashCommands.hSet(byte[], byte[], byte[])Boolean hSetNX(String key, String field, String value)
value of a hash field only if field does not exist.key - must not be null.field - must not be null.value - RedisHashCommands.hSetNX(byte[], byte[], byte[])String hGet(String key, String field)
field from hash at key.key - must not be null.field - must not be null.RedisHashCommands.hGet(byte[], byte[])List<String> hMGet(String key, String... fields)
fields from hash at key.key - must not be null.fields - must not be null.RedisHashCommands#hMGet(byte[], byte[]...)void hMSet(String key, Map<String,String> hashes)
hasheskey - must not be null.hashes - must not be null.RedisHashCommands#hMGet(byte[], byte[]...)Long hIncrBy(String key, String field, long delta)
value of a hash field by the given delta.key - must not be null.field - must not be null.delta - RedisHashCommands.hIncrBy(byte[], byte[], long)Double hIncrBy(String key, String field, double delta)
value of a hash field by the given delta.key - must not be null.field - delta - RedisHashCommands.hIncrBy(byte[], byte[], double)Boolean hExists(String key, String field)
field exists.key - must not be null.field - must not be null.RedisHashCommands.hExists(byte[], byte[])Long hDel(String key, String... fields)
fields.key - must not be null.fields - must not be null.RedisHashCommands#hDel(byte[], byte[]...)Long hLen(String key)
key.key - must not be null.RedisHashCommands.hLen(byte[])Set<String> hKeys(String key)
key.key - must not be null.RedisHashCommands.hKeys(byte[])List<String> hVals(String key)
field.key - must not be null.RedisHashCommands.hVals(byte[])Map<String,String> hGetAll(String key)
key.key - must not be null.RedisHashCommands.hGetAll(byte[])Cursor<Map.Entry<String,String>> hScan(String key, ScanOptions options)
Cursor to iterate over entries in hash at key.key - must not be null.options - must not be null.RedisHashCommands.hScan(byte[], ScanOptions)@Nullable Long hStrLen(String key, String field)
field in the hash stored at key. If the key or the
 field do not exist, 0 is returned.key - must not be null.field - must not be null.Long pfAdd(String key, String... values)
key - must not be null.values - must not be null.RedisHyperLogLogCommands#pfAdd(byte[], byte[]...)Long pfCount(String... keys)
keys - must not be null.RedisHyperLogLogCommands#pfCount(byte[]...)void pfMerge(String destinationKey, String... sourceKeys)
destinationKey - must not be null.sourceKeys - must not be null.RedisHyperLogLogCommands#pfMerge(byte[], byte[]...)Long geoAdd(String key, Point point, String member)
Point with given member name to key.key - must not be null.point - must not be null.member - must not be null.RedisGeoCommands.geoAdd(byte[], Point, byte[])Long geoAdd(String key, RedisGeoCommands.GeoLocation<String> location)
GeoLocation to key.key - must not be null.location - must not be null.RedisGeoCommands.geoAdd(byte[], GeoLocation)Long geoAdd(String key, Map<String,Point> memberCoordinateMap)
key - must not be null.memberCoordinateMap - must not be null.RedisGeoCommands.geoAdd(byte[], Map)Long geoAdd(String key, Iterable<RedisGeoCommands.GeoLocation<String>> locations)
GeoLocations to keykey - must not be null.locations - must not be null.RedisGeoCommands.geoAdd(byte[], Iterable)Distance geoDist(String key, String member1, String member2)
Distance between member1 and member2.key - must not be null.member1 - must not be null.member2 - must not be null.RedisGeoCommands.geoDist(byte[], byte[], byte[])Distance geoDist(String key, String member1, String member2, Metric metric)
key - must not be null.member1 - must not be null.member2 - must not be null.metric - must not be null.RedisGeoCommands.geoDist(byte[], byte[], byte[], Metric)List<String> geoHash(String key, String... members)
key - must not be null.members - must not be null.RedisGeoCommands#geoHash(byte[], byte[]...)List<Point> geoPos(String key, String... members)
Point representation of positions for one or more members.key - must not be null.members - must not be null.RedisGeoCommands#geoPos(byte[], byte[]...)GeoResults<RedisGeoCommands.GeoLocation<String>> geoRadius(String key, Circle within)
Circle.key - must not be null.within - must not be null.RedisGeoCommands.geoRadius(byte[], Circle)GeoResults<RedisGeoCommands.GeoLocation<String>> geoRadius(String key, Circle within, RedisGeoCommands.GeoRadiusCommandArgs args)
Circle applying GeoRadiusCommandArgs.key - must not be null.within - must not be null.args - must not be null.RedisGeoCommands.geoRadius(byte[], Circle, GeoRadiusCommandArgs)GeoResults<RedisGeoCommands.GeoLocation<String>> geoRadiusByMember(String key, String member, double radius)
key - must not be null.member - must not be null.radius - RedisGeoCommands.geoRadiusByMember(byte[], byte[], double)GeoResults<RedisGeoCommands.GeoLocation<String>> geoRadiusByMember(String key, String member, Distance radius)
Distance.key - must not be null.member - must not be null.radius - must not be null.RedisGeoCommands.geoRadiusByMember(byte[], byte[], Distance)GeoResults<RedisGeoCommands.GeoLocation<String>> geoRadiusByMember(String key, String member, Distance radius, RedisGeoCommands.GeoRadiusCommandArgs args)
Distance and GeoRadiusCommandArgs.key - must not be null.member - must not be null.radius - must not be null.args - must not be null.RedisGeoCommands.geoRadiusByMember(byte[], byte[], Distance, GeoRadiusCommandArgs)Long geoRemove(String key, String... members)
key - must not be null.members - must not be null.RedisGeoCommands#geoRemove(byte[], byte[]...)Long publish(String channel, String message)
channel - the channel to publish to, must not be null.message - message to publishRedisPubSubCommands.publish(byte[], byte[])void subscribe(MessageListener listener, String... channels)
Note that this operation is blocking and the current thread starts waiting for new messages immediately.
listener - message listener, must not be null.channels - channel names, must not be null.RedisPubSubCommands#subscribe(MessageListener, byte[]...)void pSubscribe(MessageListener listener, String... patterns)
Note that this operation is blocking and the current thread starts waiting for new messages immediately.
listener - message listener, must not be null.patterns - channel name patterns, must not be null.RedisPubSubCommands#pSubscribe(MessageListener, byte[]...)String scriptLoad(String script)
#evalSha(byte[], ReturnType, int, byte[]...).script - must not be null.RedisScriptingCommands.scriptLoad(byte[])<T> T eval(String script, ReturnType returnType, int numKeys, String... keysAndArgs)
script.script - must not be null.returnType - must not be null.numKeys - keysAndArgs - must not be null.RedisScriptingCommands#eval(byte[], ReturnType, int, byte[]...)<T> T evalSha(String scriptSha, ReturnType returnType, int numKeys, String... keysAndArgs)
scriptSha.scriptSha - must not be null.returnType - must not be null.numKeys - keysAndArgs - must not be null.RedisScriptingCommands#evalSha(String, ReturnType, int, byte[]...)void setClientName(String name)
name - RedisServerCommands.setClientName(byte[])List<RedisClientInfo> getClientList()
getClientList in interface RedisServerCommandsList of RedisClientInfo objects.RedisServerCommands.getClientList()List<Long> bitfield(String key, BitFieldSubCommands command)
key.key - must not be null.command - must not be null.Copyright © 2011–2020 Pivotal Software, Inc.. All rights reserved.