t

effredis

RedisCommand

trait RedisCommand[F[+_]] extends Redis[F] with StringOperations[F] with BaseOperations[F] with ListOperations[F] with SetOperations[F] with HashOperations[F] with SortedSetOperations[F] with NodeOperations[F] with GeoOperations[F] with EvalOperations[F] with HyperLogLogOperations[F] with TransactionOperations[F] with AutoCloseable

Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. RedisCommand
  2. AutoCloseable
  3. TransactionOperations
  4. TransactionApi
  5. HyperLogLogOperations
  6. HyperLogLogApi
  7. EvalOperations
  8. EvalApi
  9. GeoOperations
  10. GeoApi
  11. NodeOperations
  12. NodeApi
  13. SortedSetOperations
  14. SortedSetApi
  15. HashOperations
  16. HashApi
  17. SetOperations
  18. SetApi
  19. ListOperations
  20. ListApi
  21. BaseOperations
  22. BaseApi
  23. StringOperations
  24. StringApi
  25. Redis
  26. Protocol
  27. R
  28. Reply
  29. RedisIO
  30. AnyRef
  31. Any
Implicitly
  1. by any2stringadd
  2. by StringFormat
  3. by Ensuring
  4. by ArrowAssoc
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. type FoldReply = PartialFunction[(Char, Array[Byte], Option[GeoRadiusMember]), Option[GeoRadiusMember]]

    The following partial functions intend to manage the response from the GEORADIUS and GEORADIUSBYMEMBER commands.

    The following partial functions intend to manage the response from the GEORADIUS and GEORADIUSBYMEMBER commands. The code is not as generic as the previous ones as the exposed types are quite complex and really specific to these two commands

    Definition Classes
    Reply
  2. type MultiNestedReply = PartialFunction[(Char, Array[Byte]), Option[List[Option[List[Option[Array[Byte]]]]]]]
    Definition Classes
    Reply
  3. type MultiReply = PartialFunction[(Char, Array[Byte]), Option[List[Option[Array[Byte]]]]]
    Definition Classes
    Reply
  4. type PairReply = PartialFunction[(Char, Array[Byte]), Option[(Option[Array[Byte]], Option[List[Option[Array[Byte]]]])]]
    Definition Classes
    Reply
  5. type Reply[+T] = PartialFunction[(Char, Array[Byte]), T]
    Definition Classes
    Reply
  6. type SingleReply = PartialFunction[(Char, Array[Byte]), Option[Array[Byte]]]
    Definition Classes
    Reply

Abstract Value Members

  1. implicit abstract def blocker: Blocker
    Definition Classes
    TransactionOperations
  2. abstract def close(): Unit
    Definition Classes
    AutoCloseable
    Annotations
    @throws( classOf[java.lang.Exception] )
  3. implicit abstract def conc: Concurrent[F]
    Definition Classes
    HyperLogLogOperations
  4. implicit abstract def ctx: ContextShift[F]
    Definition Classes
    HyperLogLogOperations
  5. abstract val host: String
    Definition Classes
    RedisIO
  6. abstract val port: Int
    Definition Classes
    RedisIO
  7. abstract val timeout: Int
    Definition Classes
    RedisIO

Concrete Value Members

  1. def append(key: Any, value: Any)(implicit format: Format): F[Resp[Option[Long]]]

    appends the key value with the specified value.

    appends the key value with the specified value.

    Definition Classes
    StringOperationsStringApi
  2. def asAny: Option[Any]
    Definition Classes
    R
  3. def asBoolean: Boolean
    Definition Classes
    R
  4. def asBulk[T](implicit parse: Parse[T]): Option[T]
    Definition Classes
    R
  5. def asBulkWithTime[T](implicit parse: Parse[T]): Option[T]
    Definition Classes
    R
  6. def asExec(handlers: Seq[() ⇒ Any]): Option[List[Any]]
    Definition Classes
    R
  7. def asInt: Option[Int]
    Definition Classes
    R
  8. def asList[T](implicit parse: Parse[T]): Option[List[Option[T]]]
    Definition Classes
    R
  9. def asListPairs[A, B](implicit parseA: Parse[A], parseB: Parse[B]): Option[List[Option[(A, B)]]]
    Definition Classes
    R
  10. def asLong: Option[Long]
    Definition Classes
    R
  11. def asPair[T](implicit parse: Parse[T]): Option[(Option[Int], Option[List[Option[T]]])]
    Definition Classes
    R
  12. def asQueuedList: Option[List[Option[String]]]
    Definition Classes
    R
  13. def asSet[T](implicit arg0: Parse[T]): Option[Set[Option[T]]]
    Definition Classes
    R
  14. def asString: Option[String]
    Definition Classes
    R
  15. def auth(secret: Any)(implicit format: Format): F[Resp[Boolean]]

    auths with the server.

    auths with the server.

    Definition Classes
    BaseOperationsBaseApi
  16. def bgrewriteaof: F[Resp[Boolean]]
    Definition Classes
    NodeOperationsNodeApi
  17. def bgsave: F[Resp[Boolean]]

    save the DB in the background.

    save the DB in the background.

    Definition Classes
    NodeOperationsNodeApi
  18. def bitcount(key: Any, range: Option[(Int, Int)] = None)(implicit format: Format): F[Resp[Option[Int]]]

    Count the number of set bits in the given key within the optional range

    Count the number of set bits in the given key within the optional range

    Definition Classes
    StringOperationsStringApi
  19. def bitop(op: String, destKey: Any, srcKeys: Any*)(implicit format: Format): F[Resp[Option[Int]]]

    Perform a bitwise operation between multiple keys (containing string values) and store the result in the destination key.

    Perform a bitwise operation between multiple keys (containing string values) and store the result in the destination key.

    Definition Classes
    StringOperationsStringApi
  20. def blpop[K, V](timeoutInSeconds: Int, key: K, keys: K*)(implicit format: Format, parseK: Parse[K], parseV: Parse[V]): F[Resp[Option[(K, V)]]]
    Definition Classes
    ListOperationsListApi
  21. def brpop[K, V](timeoutInSeconds: Int, key: K, keys: K*)(implicit format: Format, parseK: Parse[K], parseV: Parse[V]): F[Resp[Option[(K, V)]]]
    Definition Classes
    ListOperationsListApi
  22. def brpoplpush[A](srcKey: Any, dstKey: Any, timeoutInSeconds: Int)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
    Definition Classes
    ListOperationsListApi
  23. def bulkRead(s: Array[Byte]): Option[Array[Byte]]
    Definition Classes
    Reply
  24. val bulkReply: SingleReply
    Definition Classes
    Reply
  25. def clearFd(): Unit
    Definition Classes
    RedisIO
  26. def cmd(args: Seq[Array[Byte]]): Array[Byte]
    Definition Classes
    Redis
  27. def connect: Boolean
    Definition Classes
    RedisIO
  28. def connected: Boolean
    Definition Classes
    RedisIO
  29. val database: Int
  30. val db: Int
    Definition Classes
    RedisIO
  31. def dbsize: F[Resp[Option[Long]]]

    returns the size of the db.

    returns the size of the db.

    Definition Classes
    BaseOperationsBaseApi
  32. def decr(key: Any)(implicit format: Format): F[Resp[Option[Long]]]

    decrements the specified key by 1

    decrements the specified key by 1

    Definition Classes
    StringOperationsStringApi
  33. def decrby(key: Any, increment: Long)(implicit format: Format): F[Resp[Option[Long]]]

    decrements the specified key by increment

    decrements the specified key by increment

    Definition Classes
    StringOperationsStringApi
  34. def del(key: Any, keys: Any*)(implicit format: Format): F[Resp[Option[Long]]]

    deletes the specified keys.

    deletes the specified keys.

    Definition Classes
    BaseOperationsBaseApi
  35. def discard: F[Resp[Boolean]]

    discard transaction

    discard transaction

    Definition Classes
    TransactionOperationsTransactionApi
  36. def disconnect: Boolean
    Definition Classes
    RedisIO
  37. def echo(message: Any)(implicit format: Format): F[Resp[Option[String]]]
    Definition Classes
    BaseOperationsBaseApi
  38. val errReply: Reply[Nothing]
    Definition Classes
    Reply
  39. def evalBulk[A](luaCode: String, keys: List[Any], args: List[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
    Definition Classes
    EvalOperationsEvalApi
  40. def evalInt(luaCode: String, keys: List[Any], args: List[Any]): F[Resp[Option[Int]]]
    Definition Classes
    EvalOperationsEvalApi
  41. def evalMultiBulk[A](luaCode: String, keys: List[Any], args: List[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[A]]]]]

    evaluates lua code on the server.

    evaluates lua code on the server.

    Definition Classes
    EvalOperationsEvalApi
  42. def evalMultiSHA[A](shahash: String, keys: List[Any], args: List[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[A]]]]]
    Definition Classes
    EvalOperationsEvalApi
  43. def evalSHA[A](shahash: String, keys: List[Any], args: List[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
    Definition Classes
    EvalOperationsEvalApi
  44. def evalSHABulk[A](shahash: String, keys: List[Any], args: List[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
    Definition Classes
    EvalOperationsEvalApi
  45. def evaluate[F[_], In <: HList, Out <: HList](commands: In, res: Out)(implicit arg0: Concurrent[F], arg1: ContextShift[F]): F[Any]
    Definition Classes
    Reply
  46. def exec(hs: Seq[() ⇒ Any]): F[Resp[Option[List[Any]]]]

    exec to complete the transaction

    exec to complete the transaction

    Definition Classes
    TransactionOperationsTransactionApi
  47. def execReply(handlers: Seq[() ⇒ Any]): PartialFunction[(Char, Array[Byte]), Option[List[Any]]]
    Definition Classes
    Reply
  48. def exists(key: Any)(implicit format: Format): F[Resp[Boolean]]

    test if the specified key exists.

    test if the specified key exists.

    Definition Classes
    BaseOperationsBaseApi
  49. def expire(key: Any, ttl: Int)(implicit format: Format): F[Resp[Boolean]]

    sets the expire time (in sec.) for the specified key.

    sets the expire time (in sec.) for the specified key.

    Definition Classes
    BaseOperationsBaseApi
  50. def expireat(key: Any, timestamp: Long)(implicit format: Format): F[Resp[Boolean]]

    sets the expire time for the specified key.

    sets the expire time for the specified key.

    Definition Classes
    BaseOperationsBaseApi
  51. def flushall: F[Resp[Boolean]]

    removes data from all the DB's.

    removes data from all the DB's.

    Definition Classes
    BaseOperationsBaseApi
  52. def flushdb: F[Resp[Boolean]]

    removes all the DB data.

    removes all the DB data.

    Definition Classes
    BaseOperationsBaseApi
  53. val geoRadiusMemberReply: Reply[Option[List[Option[GeoRadiusMember]]]]

    Entry point for GEORADIUS result analysis.

    Entry point for GEORADIUS result analysis. The analysis is done in three steps.

    First step : we are expecting a MULTI structure and will iterate trivially on it.

    Definition Classes
    Reply
  54. def geoadd(key: Any, members: Iterable[Product3[Any, Any, Any]]): F[Resp[Option[Int]]]

    Add the given members in the key geo sorted set

    Add the given members in the key geo sorted set

    key

    The geo sorted set

    members

    The members to be added. Format is (longitude, latitude, member)

    returns

    The number of elements added to the index. Repeated elements are not added.

    Definition Classes
    GeoOperationsGeoApi
  55. def geodist(key: Any, m1: Any, m2: Any, unit: Option[Any]): F[Resp[Option[String]]]
    Definition Classes
    GeoOperationsGeoApi
  56. def geohash[A](key: Any, members: Iterable[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[A]]]]]

    Get the geohash for each member in the key geo index.

    Get the geohash for each member in the key geo index.

    returns

    The geohash of each queried member.

    Definition Classes
    GeoOperationsGeoApi
  57. def geopos[A](key: Any, members: Iterable[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[List[Option[A]]]]]]]

    Retrieve the position of the members in the key geo sorted set.

    Retrieve the position of the members in the key geo sorted set. Note that if a member is not part of the set, None will be returned for this element.

    returns

    the coordinates of the input members in the same order.

    Definition Classes
    GeoOperationsGeoApi
  58. def georadius(key: Any, longitude: Any, latitude: Any, radius: Any, unit: Any, withCoord: Boolean, withDist: Boolean, withHash: Boolean, count: Option[Int], sort: Option[Any], store: Option[Any], storeDist: Option[Any]): F[Resp[Option[List[Option[GeoRadiusMember]]]]]

    Search for members around an origin point in the key geo sorted set

    Search for members around an origin point in the key geo sorted set

    key

    The geo index we are searching in

    longitude

    The base longitude for distance computation

    latitude

    The base latitude for distance computation

    radius

    The radius of the circle we want to search in

    unit

    The unit of the radius. Can be m (meters), km (kilometers), mi (miles), ft (feet)

    withCoord

    If true, the coordinate of the found members will be returned in the result

    withDist

    If true, the distance between the origin and the found members will be returned in the result

    withHash

    If true, the hash of the found members will be returned in the result

    count

    Max number of expected results

    sort

    The sorting strategy. If empty, order is not guaranteed. Can be ASC (ascending) or DESC (descending)

    store

    The Redis store we want to write the result in

    storeDist

    The redis storedist we want to write the result in

    returns

    The found members as GeoRadiusMember instances

    Definition Classes
    GeoOperationsGeoApi
  59. def georadiusbymember[A](key: Any, member: Any, radius: Any, unit: Any, withCoord: Boolean, withDist: Boolean, withHash: Boolean, count: Option[Int], sort: Option[Any], store: Option[Any], storeDist: Option[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[GeoRadiusMember]]]]]

    Search for members around a specific memberin the key geo sorted set

    Search for members around a specific memberin the key geo sorted set

    key

    The geo index we are searching in

    member

    The member we are searching around

    radius

    The radius of the circle we want to search in

    unit

    The unit of the radius. Can be m (meters), km (kilometers), mi (miles), ft (feet)

    withCoord

    If true, the coordinate of the found members will be returned in the result

    withDist

    If true, the distance between the origin and the found members will be returned in the result

    withHash

    If true, the hash of the found members will be returned in the result

    count

    Max number of expected results

    sort

    The sorting strategy. If empty, order is not guaranteed. Can be ASC (ascending) or DESC (descending)

    store

    The Redis store we want to write the result in

    storeDist

    The redis storedist we want to write the result in

    returns

    The found members as GeoRadiusMember instances

    Definition Classes
    GeoOperationsGeoApi
  60. def get[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]

    gets the value for the specified key.

    gets the value for the specified key.

    Definition Classes
    StringOperationsStringApi
  61. def getConfig(key: Any = "*")(implicit format: Format): F[Resp[Option[Map[String, Option[String]]]]]

    CONFIG GET

    CONFIG GET

    Definition Classes
    BaseOperationsBaseApi
  62. def getType(key: Any)(implicit format: Format): F[Resp[Option[String]]]

    returns the type of the value stored at key in form of a string.

    returns the type of the value stored at key in form of a string.

    Definition Classes
    BaseOperationsBaseApi
  63. def getbit(key: Any, offset: Int)(implicit format: Format): F[Resp[Option[Int]]]

    Returns the bit value at offset in the string value stored at key

    Returns the bit value at offset in the string value stored at key

    Definition Classes
    StringOperationsStringApi
  64. def getrange[A](key: Any, start: Int, end: Int)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]

    Returns the substring of the string value stored at key, determined by the offsets start and end (both are inclusive).

    Returns the substring of the string value stored at key, determined by the offsets start and end (both are inclusive).

    Definition Classes
    StringOperationsStringApi
  65. def getset[A](key: Any, value: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]

    is an atomic set this value and return the old value command.

    is an atomic set this value and return the old value command.

    Definition Classes
    StringOperationsStringApi
  66. def hdel(key: Any, field: Any, fields: Any*)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    HashOperationsHashApi
  67. def hexists(key: Any, field: Any)(implicit format: Format): F[Resp[Boolean]]
    Definition Classes
    HashOperationsHashApi
  68. def hget[A](key: Any, field: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
    Definition Classes
    HashOperationsHashApi
  69. def hgetall[K, V](key: Any)(implicit format: Format, parseK: Parse[K], parseV: Parse[V]): F[Resp[Option[Map[K, V]]]]
    Definition Classes
    HashOperationsHashApi
  70. def hgetall1[K, V](key: Any)(implicit format: Format, parseK: Parse[K], parseV: Parse[V]): F[Resp[Option[Map[K, V]]]]
    Definition Classes
    HashOperationsHashApi
  71. def hincrby(key: Any, field: Any, value: Long)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    HashOperationsHashApi
  72. def hincrbyfloat(key: Any, field: Any, value: Float)(implicit format: Format): F[Resp[Option[Float]]]
    Definition Classes
    HashOperationsHashApi
  73. def hkeys[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[A]]]]
    Definition Classes
    HashOperationsHashApi
  74. def hlen(key: Any)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    HashOperationsHashApi
  75. def hmget[K, V](key: Any, fields: K*)(implicit format: Format, parseV: Parse[V]): F[Resp[Option[Map[K, V]]]]
    Definition Classes
    HashOperationsHashApi
  76. def hmset(key: Any, map: Iterable[Product2[Any, Any]])(implicit format: Format): F[Resp[Boolean]]

    Sets the specified fields to their respective values in the hash stored at key.

    Sets the specified fields to their respective values in the hash stored at key. This command overwrites any existing fields in the hash. If key does not exist, a new key holding a hash is created.

    map

    from fields to values

    returns

    True if operation completed successfully, False otherwise.

    Definition Classes
    HashOperationsHashApi
    See also

    HMSET documentation

  77. def hscan[A](key: Any, cursor: Int, pattern: Any = "*", count: Int = 10)(implicit format: Format, parse: Parse[A]): F[Resp[Option[(Option[Int], Option[List[Option[A]]])]]]

    Incrementally iterate hash fields and associated values (since 2.8)

    Incrementally iterate hash fields and associated values (since 2.8)

    Definition Classes
    HashOperationsHashApi
  78. def hset1(key: Any, field: Any, value: Any)(implicit format: Format): F[Resp[Option[Long]]]

    Sets field in the hash stored at key to value.

    Sets field in the hash stored at key to value. If key does not exist, a new key holding a hash is created. If field already exists in the hash, it is overwritten.

    returns

    Some(0) if field is a new field in the hash and value was set, Some(1) if field already exists in the hash and the value was updated.

    Definition Classes
    HashOperationsHashApi
    See also

    HSET documentation

  79. def hsetnx(key: Any, field: Any, value: Any)(implicit format: Format): F[Resp[Boolean]]

    Sets field in the hash stored at key to value, only if field does not yet exist.

    Sets field in the hash stored at key to value, only if field does not yet exist. If key does not exist, a new key holding a hash is created. If field already exists, this operation has no effect.

    returns

    True if field is a new field in the hash and value was set. False if field exists in the hash and no operation was performed.

    Definition Classes
    HashOperationsHashApi
    See also

    HSETNX documentation

  80. def hvals[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[A]]]]
    Definition Classes
    HashOperationsHashApi
  81. val in: InputStream
    Definition Classes
    RedisIO
  82. def incr(key: Any)(implicit format: Format): F[Resp[Option[Long]]]

    increments the specified key by 1

    increments the specified key by 1

    Definition Classes
    StringOperationsStringApi
  83. def incrby(key: Any, increment: Long)(implicit format: Format): F[Resp[Option[Long]]]

    increments the specified key by increment

    increments the specified key by increment

    Definition Classes
    StringOperationsStringApi
  84. def incrbyfloat(key: Any, increment: Float)(implicit format: Format): F[Resp[Option[Float]]]
    Definition Classes
    StringOperationsStringApi
  85. def info: F[Resp[Option[String]]]

    The info command returns different information and statistics about the server.

    The info command returns different information and statistics about the server.

    Definition Classes
    NodeOperationsNodeApi
  86. val integerReply: Reply[Option[Int]]
    Definition Classes
    Reply
  87. def keys[A](pattern: Any = "*")(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[A]]]]]

    returns all the keys matching the glob-style pattern.

    returns all the keys matching the glob-style pattern.

    Definition Classes
    BaseOperationsBaseApi
  88. def lastsave: F[Resp[Option[Long]]]

    return the UNIX TIME of the last DB SAVE executed with success.

    return the UNIX TIME of the last DB SAVE executed with success.

    Definition Classes
    NodeOperationsNodeApi
  89. def lindex[A](key: Any, index: Int)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]

    return the especified element of the list stored at the specified key.

    return the especified element of the list stored at the specified key. Negative indexes are supported, for example -1 is the last element, -2 the penultimate and so on.

    Definition Classes
    ListOperationsListApi
  90. def llen(key: Any)(implicit format: Format): F[Resp[Option[Long]]]

    return the length of the list stored at the specified key.

    return the length of the list stored at the specified key. If the key does not exist zero is returned (the same behaviour as for empty lists). If the value stored at key is not a list an error is returned.

    Definition Classes
    ListOperationsListApi
  91. val longReply: Reply[Option[Long]]
    Definition Classes
    Reply
  92. def lpop[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]

    atomically return and remove the first (LPOP) or last (RPOP) element of the list

    atomically return and remove the first (LPOP) or last (RPOP) element of the list

    Definition Classes
    ListOperationsListApi
  93. def lpush(key: Any, value: Any, values: Any*)(implicit format: Format): F[Resp[Option[Long]]]

    add values to the head of the list stored at key (Variadic: >= 2.4)

    add values to the head of the list stored at key (Variadic: >= 2.4)

    Definition Classes
    ListOperationsListApi
  94. def lpushx(key: Any, value: Any)(implicit format: Format): F[Resp[Option[Long]]]

    add value to the head of the list stored at key (Variadic: >= 2.4)

    add value to the head of the list stored at key (Variadic: >= 2.4)

    Definition Classes
    ListOperationsListApi
  95. def lrange[A](key: Any, start: Int, end: Int)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[A]]]]]

    return the specified elements of the list stored at the specified key.

    return the specified elements of the list stored at the specified key. Start and end are zero-based indexes.

    Definition Classes
    ListOperationsListApi
  96. def lrem(key: Any, count: Int, value: Any)(implicit format: Format): F[Resp[Option[Long]]]

    Remove the first count occurrences of the value element from the list.

    Remove the first count occurrences of the value element from the list.

    Definition Classes
    ListOperationsListApi
  97. def lset(key: Any, index: Int, value: Any)(implicit format: Format): F[Resp[Boolean]]

    set the list element at index with the new value.

    set the list element at index with the new value. Out of range indexes will generate an error

    Definition Classes
    ListOperationsListApi
  98. def ltrim(key: Any, start: Int, end: Int)(implicit format: Format): F[Resp[Boolean]]

    Trim an existing list so that it will contain only the specified range of elements specified.

    Trim an existing list so that it will contain only the specified range of elements specified.

    Definition Classes
    ListOperationsListApi
  99. def mget[A](key: Any, keys: Any*)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[A]]]]]

    get the values of all the specified keys.

    get the values of all the specified keys.

    Definition Classes
    StringOperationsStringApi
  100. def monitor: F[Resp[Boolean]]

    is a debugging command that outputs the whole sequence of commands received by the Redis server.

    is a debugging command that outputs the whole sequence of commands received by the Redis server.

    Definition Classes
    NodeOperationsNodeApi
  101. def move(key: Any, db: Int)(implicit format: Format): F[Resp[Boolean]]

    Move the specified key from the currently selected DB to the specified destination DB.

    Move the specified key from the currently selected DB to the specified destination DB.

    Definition Classes
    BaseOperationsBaseApi
  102. def mset(kvs: (Any, Any)*)(implicit format: Format): F[Resp[Boolean]]

    set the respective key value pairs.

    set the respective key value pairs. Overwrite value if key exists

    Definition Classes
    StringOperationsStringApi
  103. def msetnx(kvs: (Any, Any)*)(implicit format: Format): F[Resp[Boolean]]

    set the respective key value pairs.

    set the respective key value pairs. Noop if any key exists

    Definition Classes
    StringOperationsStringApi
  104. def multi: F[Resp[Option[String]]]

    multi to start the transaction

    multi to start the transaction

    Definition Classes
    TransactionOperationsTransactionApi
  105. val multiBulkNested: MultiNestedReply
    Definition Classes
    Reply
  106. val multiBulkReply: MultiReply
    Definition Classes
    Reply
  107. def onConnect(): Unit
    Definition Classes
    RedisCommandRedisIO
  108. val out: OutputStream
    Definition Classes
    RedisIO
  109. val pairBulkReply: PairReply
    Definition Classes
    Reply
  110. def persist(key: Any)(implicit format: Format): F[Resp[Boolean]]

    Remove the existing timeout on key, turning the key from volatile (a key with an expire set) to persistent (a key that will never expire as no timeout is associated).

    Remove the existing timeout on key, turning the key from volatile (a key with an expire set) to persistent (a key that will never expire as no timeout is associated).

    Definition Classes
    BaseOperationsBaseApi
  111. def pexpire(key: Any, ttlInMillis: Int)(implicit format: Format): F[Resp[Boolean]]

    sets the expire time (in milli sec.) for the specified key.

    sets the expire time (in milli sec.) for the specified key.

    Definition Classes
    BaseOperationsBaseApi
  112. def pexpireat(key: Any, timestampInMillis: Long)(implicit format: Format): F[Resp[Boolean]]

    sets the expire timestamp in millis for the specified key.

    sets the expire timestamp in millis for the specified key.

    Definition Classes
    BaseOperationsBaseApi
  113. def pfadd(key: Any, value: Any, values: Any*): F[Resp[Option[Long]]]

    Add a value to the hyperloglog (>= 2.8.9)

    Add a value to the hyperloglog (>= 2.8.9)

    Definition Classes
    HyperLogLogOperationsHyperLogLogApi
  114. def pfcount(keys: Any*): F[Resp[Option[Long]]]

    Get the estimated cardinality from one or more keys (>= 2.8.9)

    Get the estimated cardinality from one or more keys (>= 2.8.9)

    Definition Classes
    HyperLogLogOperationsHyperLogLogApi
  115. def pfmerge(destination: Any, sources: Any*): F[Resp[Boolean]]

    Merge existing keys (>= 2.8.9)

    Merge existing keys (>= 2.8.9)

    Definition Classes
    HyperLogLogOperationsHyperLogLogApi
  116. def ping: F[Resp[Option[String]]]

    ping

    ping

    Definition Classes
    BaseOperationsBaseApi
  117. def psetex(key: Any, expiryInMillis: Long, value: Any)(implicit format: Format): F[Resp[Boolean]]
    Definition Classes
    StringOperationsStringApi
  118. def pttl(key: Any)(implicit format: Format): F[Resp[Option[Long]]]

    returns the remaining time to live of a key that has a timeout in millis

    returns the remaining time to live of a key that has a timeout in millis

    Definition Classes
    BaseOperationsBaseApi
  119. def queuedReplyInt: Reply[Option[Int]]
    Definition Classes
    Reply
  120. def queuedReplyList: MultiReply
    Definition Classes
    Reply
  121. def queuedReplyLong: Reply[Option[Long]]
    Definition Classes
    Reply
  122. def quit: F[Resp[Boolean]]

    exits the server.

    exits the server.

    Definition Classes
    BaseOperationsBaseApi
  123. def randomkey[A](implicit parse: Parse[A]): F[Resp[Option[A]]]

    returns a randomly selected key from the currently selected DB.

    returns a randomly selected key from the currently selected DB.

    Definition Classes
    BaseOperationsBaseApi
  124. def readCounted(count: Int): Array[Byte]
    Definition Classes
    RedisIO
  125. def readLine: Array[Byte]
    Definition Classes
    RedisIO
  126. def receive[T](pf: Reply[T]): T
    Definition Classes
    Reply
  127. def rename(oldkey: Any, newkey: Any)(implicit format: Format): F[Resp[Boolean]]

    atomically renames the key oldkey to newkey.

    atomically renames the key oldkey to newkey.

    Definition Classes
    BaseOperationsBaseApi
  128. def renamenx(oldkey: Any, newkey: Any)(implicit format: Format): F[Resp[Boolean]]

    rename oldkey into newkey but fails if the destination key newkey already exists.

    rename oldkey into newkey but fails if the destination key newkey already exists.

    Definition Classes
    BaseOperationsBaseApi
  129. def rpop[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]

    atomically return and remove the first (LPOP) or last (RPOP) element of the list

    atomically return and remove the first (LPOP) or last (RPOP) element of the list

    Definition Classes
    ListOperationsListApi
  130. def rpoplpush[A](srcKey: Any, dstKey: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]

    Remove the first count occurrences of the value element from the list.

    Remove the first count occurrences of the value element from the list.

    Definition Classes
    ListOperationsListApi
  131. def rpush(key: Any, value: Any, values: Any*)(implicit format: Format): F[Resp[Option[Long]]]

    add values to the tail of the list stored at key (Variadic: >= 2.4)

    add values to the tail of the list stored at key (Variadic: >= 2.4)

    Definition Classes
    ListOperationsListApi
  132. def rpushx(key: Any, value: Any)(implicit format: Format): F[Resp[Option[Long]]]

    add value to the tail of the list stored at key (Variadic: >= 2.4)

    add value to the tail of the list stored at key (Variadic: >= 2.4)

    Definition Classes
    ListOperationsListApi
  133. def sadd(key: Any, value: Any, values: Any*)(implicit format: Format): F[Resp[Option[Long]]]

    Add the specified members to the set value stored at key.

    Add the specified members to the set value stored at key. (VARIADIC: >= 2.4)

    Definition Classes
    SetOperationsSetApi
  134. def save: F[Resp[Boolean]]

    save the DB on disk now.

    save the DB on disk now.

    Definition Classes
    NodeOperationsNodeApi
  135. def scan[A](cursor: Int, pattern: Any = "*", count: Int = 10)(implicit format: Format, parse: Parse[A]): F[Resp[Option[(Option[Int], Option[List[Option[A]]])]]]

    Incrementally iterate the keys space (since 2.8)

    Incrementally iterate the keys space (since 2.8)

    Definition Classes
    BaseOperationsBaseApi
  136. def scard(key: Any)(implicit format: Format): F[Resp[Option[Long]]]

    Return the number of elements (the cardinality) of the Set at key.

    Return the number of elements (the cardinality) of the Set at key.

    Definition Classes
    SetOperationsSetApi
  137. def scriptExists(shahash: String): F[Resp[Option[Int]]]
    Definition Classes
    EvalOperationsEvalApi
  138. def scriptFlush: F[Resp[Option[String]]]
    Definition Classes
    EvalOperationsEvalApi
  139. def scriptLoad(luaCode: String): F[Resp[Option[String]]]
    Definition Classes
    EvalOperationsEvalApi
  140. def sdiff[A](key: Any, keys: Any*)(implicit format: Format, parse: Parse[A]): F[Resp[Option[Set[Option[A]]]]]

    Return the difference between the Set stored at key1 and all the Sets key2, ..., keyN.

    Return the difference between the Set stored at key1 and all the Sets key2, ..., keyN.

    Definition Classes
    SetOperationsSetApi
  141. def sdiffstore(key: Any, keys: Any*)(implicit format: Format): F[Resp[Option[Long]]]

    Compute the difference between the Set key1 and all the Sets key2, ..., keyN, and store the resulting Set at dstkey.

    Compute the difference between the Set key1 and all the Sets key2, ..., keyN, and store the resulting Set at dstkey.

    Definition Classes
    SetOperationsSetApi
  142. val secret: Option[Any]
  143. def select(index: Int): F[Resp[Boolean]]

    selects the DB to connect, defaults to 0 (zero).

    selects the DB to connect, defaults to 0 (zero).

    Definition Classes
    BaseOperationsBaseApi
  144. def send[A](command: String, pipelineMode: Boolean = false)(result: ⇒ A)(implicit blocker: Blocker): F[Resp[A]]
    Definition Classes
    Redis
  145. def send[A](command: String, args: Seq[Any])(result: ⇒ A)(implicit format: Format, blocker: Blocker): F[Resp[A]]
    Definition Classes
    Redis
  146. def set(key: Any, value: Any, whenSet: SetBehaviour = Always, expire: Duration = null, keepTTL: Boolean = false)(implicit format: Format): F[Resp[Boolean]]

    sets the key with the specified value.

    sets the key with the specified value. Starting with Redis 2.6.12 SET supports a set of options that modify its behavior:

    NX -- Only set the key if it does not already exist. XX -- Only set the key if it already exist. PX milliseconds -- Set the specified expire time, in milliseconds.

    Definition Classes
    StringOperationsStringApi
  147. def setConfig(key: Any, value: Any)(implicit format: Format): F[Resp[Option[String]]]

    CONFIG SET

    CONFIG SET

    Definition Classes
    BaseOperationsBaseApi
  148. def setbit(key: Any, offset: Int, value: Any)(implicit format: Format): F[Resp[Option[Int]]]

    Sets or clears the bit at offset in the string value stored at key

    Sets or clears the bit at offset in the string value stored at key

    Definition Classes
    StringOperationsStringApi
  149. def setex(key: Any, expiry: Long, value: Any)(implicit format: Format): F[Resp[Boolean]]
    Definition Classes
    StringOperationsStringApi
  150. def setnx(key: Any, value: Any)(implicit format: Format): F[Resp[Boolean]]

    sets the value for the specified key, only if the key is not there.

    sets the value for the specified key, only if the key is not there.

    Definition Classes
    StringOperationsStringApi
  151. def setrange(key: Any, offset: Int, value: Any)(implicit format: Format): F[Resp[Option[Long]]]

    SETRANGE key offset value Overwrites part of the string stored at key, starting at the specified offset, for the entire length of value.

    SETRANGE key offset value Overwrites part of the string stored at key, starting at the specified offset, for the entire length of value.

    Definition Classes
    StringOperationsStringApi
  152. def shutdown: F[Resp[Boolean]]

    Stop all the clients, save the DB, then quit the server.

    Stop all the clients, save the DB, then quit the server.

    Definition Classes
    NodeOperationsNodeApi
  153. val singleLineReply: SingleReply
    Definition Classes
    Reply
  154. def sinter[A](key: Any, keys: Any*)(implicit format: Format, parse: Parse[A]): F[Resp[Option[Set[Option[A]]]]]

    Return the intersection between the Sets stored at key1, key2, ..., keyN.

    Return the intersection between the Sets stored at key1, key2, ..., keyN.

    Definition Classes
    SetOperationsSetApi
  155. def sinterstore(key: Any, keys: Any*)(implicit format: Format): F[Resp[Option[Long]]]

    Compute the intersection between the Sets stored at key1, key2, ..., keyN, and store the resulting Set at dstkey.

    Compute the intersection between the Sets stored at key1, key2, ..., keyN, and store the resulting Set at dstkey. SINTERSTORE returns the size of the intersection, unlike what the documentation says refer http://code.google.com/p/redis/issues/detail?id=121

    Definition Classes
    SetOperationsSetApi
  156. def sismember(key: Any, value: Any)(implicit format: Format): F[Resp[Boolean]]

    Test if the specified value is a member of the Set at key.

    Test if the specified value is a member of the Set at key.

    Definition Classes
    SetOperationsSetApi
  157. def slaveof(options: Any): F[Resp[Boolean]]

    The SLAVEOF command can change the replication settings of a slave on the fly.

    The SLAVEOF command can change the replication settings of a slave on the fly.

    Definition Classes
    NodeOperationsNodeApi
  158. def smembers[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[Set[Option[A]]]]]

    Return all the members of the Set value at key.

    Return all the members of the Set value at key.

    Definition Classes
    SetOperationsSetApi
  159. def smove(sourceKey: Any, destKey: Any, value: Any)(implicit format: Format): F[Resp[Option[Long]]]

    Move the specified member from one Set to another atomically.

    Move the specified member from one Set to another atomically.

    Definition Classes
    SetOperationsSetApi
  160. val socket: Socket
    Definition Classes
    RedisIO
  161. def sort[A](key: String, limit: Option[(Int, Int)] = None, desc: Boolean = false, alpha: Boolean = false, by: Option[String] = None, get: List[String] = Nil)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[A]]]]]

    sort keys in a set, and optionally pull values for them

    sort keys in a set, and optionally pull values for them

    Definition Classes
    BaseOperationsBaseApi
  162. def sortNStore[A](key: String, limit: Option[(Int, Int)] = None, desc: Boolean = false, alpha: Boolean = false, by: Option[String] = None, get: List[String] = Nil, storeAt: String)(implicit format: Format, parse: Parse[A]): F[Resp[Option[Long]]]

    sort keys in a set, and stores result in the supplied key

    sort keys in a set, and stores result in the supplied key

    Definition Classes
    BaseOperationsBaseApi
  163. def spop[A](key: Any, count: Int)(implicit format: Format, parse: Parse[A]): F[Resp[Option[Set[Option[A]]]]]

    Remove and return multiple random elements (pop) from the Set value at key since (3.2).

    Remove and return multiple random elements (pop) from the Set value at key since (3.2).

    Definition Classes
    SetOperationsSetApi
  164. def spop[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]

    Remove and return (pop) a random element from the Set value at key.

    Remove and return (pop) a random element from the Set value at key.

    Definition Classes
    SetOperationsSetApi
  165. def srandmember[A](key: Any, count: Int)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[A]]]]]

    Return multiple random elements from a Set (since 2.6)

    Return multiple random elements from a Set (since 2.6)

    Definition Classes
    SetOperationsSetApi
  166. def srandmember[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]

    Return a random element from a Set

    Return a random element from a Set

    Definition Classes
    SetOperationsSetApi
  167. def srem(key: Any, value: Any, values: Any*)(implicit format: Format): F[Resp[Option[Long]]]

    Remove the specified members from the set value stored at key.

    Remove the specified members from the set value stored at key. (VARIADIC: >= 2.4)

    Definition Classes
    SetOperationsSetApi
  168. def sscan[A](key: Any, cursor: Int, pattern: Any = "*", count: Int = 10)(implicit format: Format, parse: Parse[A]): F[Resp[Option[(Option[Int], Option[List[Option[A]]])]]]

    Incrementally iterate Set elements (since 2.8)

    Incrementally iterate Set elements (since 2.8)

    Definition Classes
    SetOperationsSetApi
  169. val sslContext: Option[SSLContext]
    Definition Classes
    RedisIO
  170. def strlen(key: Any)(implicit format: Format): F[Resp[Option[Long]]]

    gets the length of the value associated with the key

    gets the length of the value associated with the key

    Definition Classes
    StringOperationsStringApi
  171. def sunion[A](key: Any, keys: Any*)(implicit format: Format, parse: Parse[A]): F[Resp[Option[Set[Option[A]]]]]

    Return the union between the Sets stored at key1, key2, ..., keyN.

    Return the union between the Sets stored at key1, key2, ..., keyN.

    Definition Classes
    SetOperationsSetApi
  172. def sunionstore(key: Any, keys: Any*)(implicit format: Format): F[Resp[Option[Long]]]

    Compute the union between the Sets stored at key1, key2, ..., keyN, and store the resulting Set at dstkey.

    Compute the union between the Sets stored at key1, key2, ..., keyN, and store the resulting Set at dstkey. SUNIONSTORE returns the size of the union, unlike what the documentation says refer http://code.google.com/p/redis/issues/detail?id=121

    Definition Classes
    SetOperationsSetApi
  173. def time[A](implicit format: Format, parse: Parse[A]): F[Resp[Option[List[Option[A]]]]]

    returns the current server time as a two items lists: a Unix timestamp and the amount of microseconds already elapsed in the current second.

    returns the current server time as a two items lists: a Unix timestamp and the amount of microseconds already elapsed in the current second.

    Definition Classes
    BaseOperationsBaseApi
  174. def ttl(key: Any)(implicit format: Format): F[Resp[Option[Long]]]

    returns the remaining time to live of a key that has a timeout

    returns the remaining time to live of a key that has a timeout

    Definition Classes
    BaseOperationsBaseApi
  175. def unwatch(): F[Resp[Boolean]]

    Flushes all the previously watched keys for a transaction

    Flushes all the previously watched keys for a transaction

    Definition Classes
    BaseOperationsBaseApi
  176. def watch(key: Any, keys: Any*)(implicit format: Format): F[Resp[Boolean]]

    Marks the given keys to be watched for conditional execution of a transaction.

    Marks the given keys to be watched for conditional execution of a transaction.

    Definition Classes
    BaseOperationsBaseApi
  177. def write(data: Array[Byte]): Unit
    Definition Classes
    RedisIO
  178. def write_to_socket(op: (OutputStream) ⇒ Unit): Unit
    Definition Classes
    RedisIO
  179. def zadd(key: Any, score: Double, member: Any, scoreVals: (Double, Any)*)(implicit format: Format): F[Resp[Option[Long]]]

    Add the specified members having the specified score to the sorted set stored at key.

    Add the specified members having the specified score to the sorted set stored at key. (Variadic: >= 2.4)

    Definition Classes
    SortedSetOperationsSortedSetApi
  180. def zcard(key: Any)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  181. def zcount(key: Any, min: Double = Double.NegativeInfinity, max: Double = Double.PositiveInfinity, minInclusive: Boolean = true, maxInclusive: Boolean = true)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  182. def zincrby(key: Any, incr: Double, member: Any)(implicit format: Format): F[Resp[Option[Double]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  183. def zinterstore(dstKey: Any, keys: Iterable[Any], aggregate: Aggregate = SUM)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  184. def zinterstoreWeighted(dstKey: Any, kws: Iterable[Product2[Any, Double]], aggregate: Aggregate = SUM)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  185. def zrange[A](key: Any, start: Int = 0, end: Int = -1, sortAs: SortOrder = ASC)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[A]]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  186. def zrangeWithScore[A](key: Any, start: Int = 0, end: Int = -1, sortAs: SortOrder = ASC)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[(A, Double)]]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  187. def zrangebylex[A](key: Any, min: String, max: String, limit: Option[(Int, Int)])(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[A]]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  188. def zrangebyscore[A](key: Any, min: Double = Double.NegativeInfinity, minInclusive: Boolean = true, max: Double = Double.PositiveInfinity, maxInclusive: Boolean = true, limit: Option[(Int, Int)], sortAs: SortOrder = ASC)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[A]]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  189. def zrangebyscoreWithScore[A](key: Any, min: Double = Double.NegativeInfinity, minInclusive: Boolean = true, max: Double = Double.PositiveInfinity, maxInclusive: Boolean = true, limit: Option[(Int, Int)], sortAs: SortOrder = ASC)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[(A, Double)]]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  190. def zrank(key: Any, member: Any, reverse: Boolean = false)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  191. def zrem(key: Any, member: Any, members: Any*)(implicit format: Format): F[Resp[Option[Long]]]

    Remove the specified members from the sorted set value stored at key.

    Remove the specified members from the sorted set value stored at key. (Variadic: >= 2.4)

    Definition Classes
    SortedSetOperationsSortedSetApi
  192. def zremrangebyrank(key: Any, start: Int = 0, end: Int = -1)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  193. def zremrangebyscore(key: Any, start: Double = Double.NegativeInfinity, end: Double = Double.PositiveInfinity)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  194. def zscan[A](key: Any, cursor: Int, pattern: Any = "*", count: Int = 10)(implicit format: Format, parse: Parse[A]): F[Resp[Option[(Option[Int], Option[List[Option[A]]])]]]

    Incrementally iterate sorted sets elements and associated scores (since 2.8)

    Incrementally iterate sorted sets elements and associated scores (since 2.8)

    Definition Classes
    SortedSetOperationsSortedSetApi
  195. def zscore(key: Any, element: Any)(implicit format: Format): F[Resp[Option[Double]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  196. def zunionstore(dstKey: Any, keys: Iterable[Any], aggregate: Aggregate = SUM)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    SortedSetOperationsSortedSetApi
  197. def zunionstoreWeighted(dstKey: Any, kws: Iterable[Product2[Any, Double]], aggregate: Aggregate = SUM)(implicit format: Format): F[Resp[Option[Long]]]
    Definition Classes
    SortedSetOperationsSortedSetApi

Deprecated Value Members

  1. def hset(key: Any, field: Any, value: Any)(implicit format: Format): F[Resp[Boolean]]

    Sets field in the hash stored at key to value.

    Sets field in the hash stored at key to value. If key does not exist, a new key holding a hash is created. If field already exists in the hash, it is overwritten.

    returns

    True if field is a new field in the hash and value was set, False if field already exists in the hash and the value was updated.

    Definition Classes
    HashOperationsHashApi
    Deprecated

    return value semantics is inconsistent with effredis.HashOperations#hsetnx and effredis.HashOperations#hmset. Use effredis.HashOperations#hset1 instead

    See also

    HSET documentation

  2. def randkey[A](implicit parse: Parse[A]): F[Resp[Option[A]]]
    Definition Classes
    BaseOperations
    Annotations
    @deprecated
    Deprecated

    (Since version 2.8) use randomkey

  3. def slaveOf(options: Any): F[Resp[Boolean]]
    Definition Classes
    NodeOperations
    Annotations
    @deprecated
    Deprecated

    (Since version 1.2.0) use slaveof