class SequencingDecorator[F[+_]] extends Redis[F] with RedisCommand[F]
- Alphabetic
- By Inheritance
- SequencingDecorator
- RedisCommand
- AutoCloseable
- TransactionOperations
- TransactionApi
- HyperLogLogOperations
- HyperLogLogApi
- EvalOperations
- EvalApi
- GeoOperations
- GeoApi
- NodeOperations
- NodeApi
- SortedSetOperations
- SortedSetApi
- HashOperations
- HashApi
- SetOperations
- SetApi
- ListOperations
- ListApi
- BaseOperations
- BaseApi
- StringOperations
- StringApi
- Redis
- Protocol
- R
- Reply
- RedisIO
- AnyRef
- Any
- by any2stringadd
- by StringFormat
- by Ensuring
- by ArrowAssoc
- Hide All
- Show All
- Public
- All
Instance Constructors
- new SequencingDecorator(parent: RedisClient[F], pipelineMode: Boolean = false)(implicit arg0: Concurrent[F], arg1: ContextShift[F], arg2: Log[F])
Type Members
-
abstract
class
E$F$Redis extends AnyRef
- Attributes
- protected[this]
- Definition Classes
- Redis
-
abstract
class
E$F$SequencingDecorator extends AnyRef
- Attributes
- protected[this]
-
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
-
type
MultiNestedReply = PartialFunction[(Char, Array[Byte]), Option[List[Option[List[Option[Array[Byte]]]]]]]
- Definition Classes
- Reply
-
type
MultiReply = PartialFunction[(Char, Array[Byte]), Option[List[Option[Array[Byte]]]]]
- Definition Classes
- Reply
-
type
PairReply = PartialFunction[(Char, Array[Byte]), Option[(Option[Array[Byte]], Option[List[Option[Array[Byte]]]])]]
- Definition Classes
- Reply
-
type
Reply[+T] = PartialFunction[(Char, Array[Byte]), T]
- Definition Classes
- Reply
-
type
SingleReply = PartialFunction[(Char, Array[Byte]), Option[Array[Byte]]]
- Definition Classes
- Reply
Value Members
-
final
def
!=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
final
def
##(): Int
- Definition Classes
- AnyRef → Any
-
def
+(other: String): String
- Implicit
- This member is added by an implicit conversion from SequencingDecorator[F] to any2stringadd[SequencingDecorator[F]] performed by method any2stringadd in scala.Predef.
- Definition Classes
- any2stringadd
-
def
->[B](y: B): (SequencingDecorator[F], B)
- Implicit
- This member is added by an implicit conversion from SequencingDecorator[F] to ArrowAssoc[SequencingDecorator[F]] performed by method ArrowAssoc in scala.Predef.
- Definition Classes
- ArrowAssoc
- Annotations
- @inline()
-
final
def
==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
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
- StringOperations → StringApi
-
def
asAny: Option[Any]
- Definition Classes
- R
-
def
asBoolean: Boolean
- Definition Classes
- R
-
def
asBulk[T](implicit parse: Parse[T]): Option[T]
- Definition Classes
- R
-
def
asBulkWithTime[T](implicit parse: Parse[T]): Option[T]
- Definition Classes
- R
-
def
asExec(handlers: Seq[() ⇒ Any]): Option[List[Any]]
- Definition Classes
- R
-
final
def
asInstanceOf[T0]: T0
- Definition Classes
- Any
-
def
asInt: Option[Int]
- Definition Classes
- R
-
def
asList[T](implicit parse: Parse[T]): Option[List[Option[T]]]
- Definition Classes
- R
-
def
asListPairs[A, B](implicit parseA: Parse[A], parseB: Parse[B]): Option[List[Option[(A, B)]]]
- Definition Classes
- R
-
def
asLong: Option[Long]
- Definition Classes
- R
-
def
asPair[T](implicit parse: Parse[T]): Option[(Option[Int], Option[List[Option[T]]])]
- Definition Classes
- R
-
def
asQueuedList: Option[List[Option[String]]]
- Definition Classes
- R
-
def
asSet[T](implicit arg0: Parse[T]): Option[Set[Option[T]]]
- Definition Classes
- R
-
def
asString: Option[String]
- Definition Classes
- R
-
def
auth(secret: Any)(implicit format: Format): F[Resp[Boolean]]
auths with the server.
auths with the server.
- Definition Classes
- BaseOperations → BaseApi
-
def
bgrewriteaof: F[Resp[Boolean]]
- Definition Classes
- NodeOperations → NodeApi
-
def
bgsave: F[Resp[Boolean]]
save the DB in the background.
save the DB in the background.
- Definition Classes
- NodeOperations → NodeApi
-
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
- StringOperations → StringApi
-
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
- StringOperations → StringApi
-
def
blocker: Blocker
- Definition Classes
- SequencingDecorator → TransactionOperations → HyperLogLogOperations → EvalOperations → GeoOperations → NodeOperations → SortedSetOperations → HashOperations → SetOperations → ListOperations → BaseOperations → StringOperations
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
def
brpoplpush[A](srcKey: Any, dstKey: Any, timeoutInSeconds: Int)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
- Definition Classes
- ListOperations → ListApi
-
def
bulkRead(s: Array[Byte]): Option[Array[Byte]]
- Definition Classes
- Reply
-
val
bulkReply: SingleReply
- Definition Classes
- Reply
-
def
clearFd(): Unit
- Definition Classes
- SequencingDecorator → RedisIO
-
def
clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native() @HotSpotIntrinsicCandidate()
-
def
close(): Unit
- Definition Classes
- SequencingDecorator → AutoCloseable
-
def
cmd(args: Seq[Array[Byte]]): Array[Byte]
- Definition Classes
- Redis
- var commandBuffer: StringBuffer
-
def
conc: Concurrent[F]
- Definition Classes
- SequencingDecorator → HyperLogLogOperations → EvalOperations → GeoOperations → NodeOperations → SortedSetOperations → HashOperations → SetOperations → ListOperations → BaseOperations → StringOperations
-
def
connect: Boolean
- Definition Classes
- SequencingDecorator → RedisIO
-
def
connected: Boolean
- Definition Classes
- SequencingDecorator → RedisIO
-
def
ctx: ContextShift[F]
- Definition Classes
- SequencingDecorator → HyperLogLogOperations → EvalOperations → GeoOperations → NodeOperations → SortedSetOperations → HashOperations → SetOperations → ListOperations → BaseOperations → StringOperations
-
val
database: Int
- Definition Classes
- SequencingDecorator → RedisCommand
-
val
db: Int
- Definition Classes
- RedisIO
-
def
dbsize: F[Resp[Option[Long]]]
returns the size of the db.
returns the size of the db.
- Definition Classes
- BaseOperations → BaseApi
-
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
- StringOperations → StringApi
-
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
- StringOperations → StringApi
-
def
del(key: Any, keys: Any*)(implicit format: Format): F[Resp[Option[Long]]]
deletes the specified keys.
deletes the specified keys.
- Definition Classes
- BaseOperations → BaseApi
-
def
discard: F[Resp[Boolean]]
discard transaction
discard transaction
- Definition Classes
- TransactionOperations → TransactionApi
-
def
disconnect: Boolean
- Definition Classes
- SequencingDecorator → RedisIO
-
def
echo(message: Any)(implicit format: Format): F[Resp[Option[String]]]
- Definition Classes
- BaseOperations → BaseApi
-
def
ensuring(cond: (SequencingDecorator[F]) ⇒ Boolean, msg: ⇒ Any): SequencingDecorator[F]
- Implicit
- This member is added by an implicit conversion from SequencingDecorator[F] to Ensuring[SequencingDecorator[F]] performed by method Ensuring in scala.Predef.
- Definition Classes
- Ensuring
-
def
ensuring(cond: (SequencingDecorator[F]) ⇒ Boolean): SequencingDecorator[F]
- Implicit
- This member is added by an implicit conversion from SequencingDecorator[F] to Ensuring[SequencingDecorator[F]] performed by method Ensuring in scala.Predef.
- Definition Classes
- Ensuring
-
def
ensuring(cond: Boolean, msg: ⇒ Any): SequencingDecorator[F]
- Implicit
- This member is added by an implicit conversion from SequencingDecorator[F] to Ensuring[SequencingDecorator[F]] performed by method Ensuring in scala.Predef.
- Definition Classes
- Ensuring
-
def
ensuring(cond: Boolean): SequencingDecorator[F]
- Implicit
- This member is added by an implicit conversion from SequencingDecorator[F] to Ensuring[SequencingDecorator[F]] performed by method Ensuring in scala.Predef.
- Definition Classes
- Ensuring
-
final
def
eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
def
equals(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
val
errReply: Reply[Nothing]
- Definition Classes
- Reply
-
def
evalBulk[A](luaCode: String, keys: List[Any], args: List[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
- Definition Classes
- EvalOperations → EvalApi
-
def
evalInt(luaCode: String, keys: List[Any], args: List[Any]): F[Resp[Option[Int]]]
- Definition Classes
- EvalOperations → EvalApi
-
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
- EvalOperations → EvalApi
-
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
- EvalOperations → EvalApi
-
def
evalSHA[A](shahash: String, keys: List[Any], args: List[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
- Definition Classes
- EvalOperations → EvalApi
-
def
evalSHABulk[A](shahash: String, keys: List[Any], args: List[Any])(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
- Definition Classes
- EvalOperations → EvalApi
-
def
evaluate[F[_], In <: HList, Out <: HList](commands: In, res: Out)(implicit arg0: Concurrent[F], arg1: ContextShift[F]): F[Any]
- Definition Classes
- Reply
-
def
exec(hs: Seq[() ⇒ Any]): F[Resp[Option[List[Any]]]]
exec to complete the transaction
exec to complete the transaction
- Definition Classes
- TransactionOperations → TransactionApi
-
def
execReply(handlers: Seq[() ⇒ Any]): PartialFunction[(Char, Array[Byte]), Option[List[Any]]]
- Definition Classes
- Reply
-
def
exists(key: Any)(implicit format: Format): F[Resp[Boolean]]
test if the specified key exists.
test if the specified key exists.
- Definition Classes
- BaseOperations → BaseApi
-
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
- BaseOperations → BaseApi
-
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
- BaseOperations → BaseApi
-
def
flattenPairs(in: Iterable[Product2[Any, Any]]): List[Any]
- Attributes
- protected
- Definition Classes
- Redis
-
def
flushall: F[Resp[Boolean]]
removes data from all the DB's.
removes data from all the DB's.
- Definition Classes
- BaseOperations → BaseApi
-
def
flushdb: F[Resp[Boolean]]
removes all the DB data.
removes all the DB data.
- Definition Classes
- BaseOperations → BaseApi
-
def
formatted(fmtstr: String): String
- Implicit
- This member is added by an implicit conversion from SequencingDecorator[F] to StringFormat[SequencingDecorator[F]] performed by method StringFormat in scala.Predef.
- Definition Classes
- StringFormat
- Annotations
- @inline()
-
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
-
def
geoadd(key: Any, members: Iterable[Product3[Any, Any, Any]]): F[Resp[Option[Int]]]
Add the given
members
in thekey
geo sorted setAdd the given
members
in thekey
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
- GeoOperations → GeoApi
-
def
geodist(key: Any, m1: Any, m2: Any, unit: Option[Any]): F[Resp[Option[String]]]
- Definition Classes
- GeoOperations → GeoApi
-
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
- GeoOperations → GeoApi
-
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
- GeoOperations → GeoApi
-
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
- GeoOperations → GeoApi
-
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
- GeoOperations → GeoApi
-
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
- StringOperations → StringApi
-
final
def
getClass(): Class[_]
- Definition Classes
- AnyRef → Any
- Annotations
- @native() @HotSpotIntrinsicCandidate()
-
def
getConfig(key: Any = "*")(implicit format: Format): F[Resp[Option[Map[String, Option[String]]]]]
CONFIG GET
CONFIG GET
- Definition Classes
- BaseOperations → BaseApi
-
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
- BaseOperations → BaseApi
-
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
- StringOperations → StringApi
-
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
- StringOperations → StringApi
-
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
- StringOperations → StringApi
- var handlers: Vector[(String, () ⇒ Any)]
-
def
hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native() @HotSpotIntrinsicCandidate()
-
def
hdel(key: Any, field: Any, fields: Any*)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- HashOperations → HashApi
-
def
hexists(key: Any, field: Any)(implicit format: Format): F[Resp[Boolean]]
- Definition Classes
- HashOperations → HashApi
-
def
hget[A](key: Any, field: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[A]]]
- Definition Classes
- HashOperations → HashApi
-
def
hgetall[K, V](key: Any)(implicit format: Format, parseK: Parse[K], parseV: Parse[V]): F[Resp[Option[Map[K, V]]]]
- Definition Classes
- HashOperations → HashApi
-
def
hgetall1[K, V](key: Any)(implicit format: Format, parseK: Parse[K], parseV: Parse[V]): F[Resp[Option[Map[K, V]]]]
- Definition Classes
- HashOperations → HashApi
-
def
hincrby(key: Any, field: Any, value: Long)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- HashOperations → HashApi
-
def
hincrbyfloat(key: Any, field: Any, value: Float)(implicit format: Format): F[Resp[Option[Float]]]
- Definition Classes
- HashOperations → HashApi
-
def
hkeys[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[A]]]]
- Definition Classes
- HashOperations → HashApi
-
def
hlen(key: Any)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- HashOperations → HashApi
-
def
hmget[K, V](key: Any, fields: K*)(implicit format: Format, parseV: Parse[V]): F[Resp[Option[Map[K, V]]]]
- Definition Classes
- HashOperations → HashApi
-
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
- HashOperations → HashApi
- See also
-
val
host: String
- Definition Classes
- SequencingDecorator → RedisIO
-
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
- HashOperations → HashApi
-
def
hset1(key: Any, field: Any, value: Any)(implicit format: Format): F[Resp[Option[Long]]]
Sets
field
in the hash stored atkey
tovalue
.Sets
field
in the hash stored atkey
tovalue
. Ifkey
does not exist, a new key holding a hash is created. If field already exists in the hash, it is overwritten.- returns
Some(0)
iffield
is a new field in the hash and value was set,Some(1)
iffield
already exists in the hash and the value was updated.
- Definition Classes
- HashOperations → HashApi
- See also
-
def
hsetnx(key: Any, field: Any, value: Any)(implicit format: Format): F[Resp[Boolean]]
Sets
field
in the hash stored atkey
tovalue
, only if field does not yet exist.Sets
field
in the hash stored atkey
tovalue
, 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
iffield
is a new field in the hash and value was set. False iffield
exists in the hash and no operation was performed.
- Definition Classes
- HashOperations → HashApi
- See also
-
def
hvals[A](key: Any)(implicit format: Format, parse: Parse[A]): F[Resp[Option[List[A]]]]
- Definition Classes
- HashOperations → HashApi
-
val
in: InputStream
- Definition Classes
- RedisIO
-
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
- StringOperations → StringApi
-
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
- StringOperations → StringApi
-
def
incrbyfloat(key: Any, increment: Float)(implicit format: Format): F[Resp[Option[Float]]]
- Definition Classes
- StringOperations → StringApi
-
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
- NodeOperations → NodeApi
-
val
integerReply: Reply[Option[Int]]
- Definition Classes
- Reply
-
final
def
isInstanceOf[T0]: Boolean
- Definition Classes
- Any
-
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
- BaseOperations → BaseApi
-
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
- NodeOperations → NodeApi
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
val
longReply: Reply[Option[Long]]
- Definition Classes
- Reply
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
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
- StringOperations → StringApi
-
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
- NodeOperations → NodeApi
-
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
- BaseOperations → BaseApi
-
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
- StringOperations → StringApi
-
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
- StringOperations → StringApi
-
def
multi: F[Resp[Option[String]]]
multi to start the transaction
multi to start the transaction
- Definition Classes
- TransactionOperations → TransactionApi
-
val
multiBulkNested: MultiNestedReply
- Definition Classes
- Reply
-
val
multiBulkReply: MultiReply
- Definition Classes
- Reply
-
final
def
ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
final
def
notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native() @HotSpotIntrinsicCandidate()
-
final
def
notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native() @HotSpotIntrinsicCandidate()
-
def
onConnect(): Unit
- Definition Classes
- SequencingDecorator → RedisCommand → RedisIO
-
val
out: OutputStream
- Definition Classes
- RedisIO
-
val
pairBulkReply: PairReply
- Definition Classes
- Reply
- val parent: RedisClient[F]
-
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
- BaseOperations → BaseApi
-
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
- BaseOperations → BaseApi
-
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
- BaseOperations → BaseApi
-
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
- HyperLogLogOperations → HyperLogLogApi
-
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
- HyperLogLogOperations → HyperLogLogApi
-
def
pfmerge(destination: Any, sources: Any*): F[Resp[Boolean]]
Merge existing keys (>= 2.8.9)
Merge existing keys (>= 2.8.9)
- Definition Classes
- HyperLogLogOperations → HyperLogLogApi
-
def
ping: F[Resp[Option[String]]]
ping
ping
- Definition Classes
- BaseOperations → BaseApi
-
val
pong: Option[String]
- Attributes
- protected
- Definition Classes
- BaseApi
-
val
port: Int
- Definition Classes
- SequencingDecorator → RedisIO
-
def
psetex(key: Any, expiryInMillis: Long, value: Any)(implicit format: Format): F[Resp[Boolean]]
- Definition Classes
- StringOperations → StringApi
-
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
- BaseOperations → BaseApi
-
def
queuedReplyInt: Reply[Option[Int]]
- Definition Classes
- Reply
-
def
queuedReplyList: MultiReply
- Definition Classes
- Reply
-
def
queuedReplyLong: Reply[Option[Long]]
- Definition Classes
- Reply
-
def
quit: F[Resp[Boolean]]
exits the server.
exits the server.
- Definition Classes
- BaseOperations → BaseApi
-
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
- BaseOperations → BaseApi
-
def
readCounted(count: Int): Array[Byte]
- Definition Classes
- SequencingDecorator → Reply → RedisIO
-
def
readLine: Array[Byte]
- Definition Classes
- SequencingDecorator → Reply → RedisIO
-
def
receive[T](pf: Reply[T]): T
- Definition Classes
- Reply
-
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
- BaseOperations → BaseApi
-
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
- BaseOperations → BaseApi
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
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
- ListOperations → ListApi
-
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
- SetOperations → SetApi
-
def
save: F[Resp[Boolean]]
save the DB on disk now.
save the DB on disk now.
- Definition Classes
- NodeOperations → NodeApi
-
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
- BaseOperations → BaseApi
-
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
- SetOperations → SetApi
-
def
scriptExists(shahash: String): F[Resp[Option[Int]]]
- Definition Classes
- EvalOperations → EvalApi
-
def
scriptFlush: F[Resp[Option[String]]]
- Definition Classes
- EvalOperations → EvalApi
-
def
scriptLoad(luaCode: String): F[Resp[Option[String]]]
- Definition Classes
- EvalOperations → EvalApi
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
val
secret: Option[Any]
- Definition Classes
- SequencingDecorator → RedisCommand
-
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
- BaseOperations → BaseApi
-
def
send[A](command: String, pipeline: Boolean = false)(result: ⇒ A)(implicit blocker: Blocker): F[Resp[A]]
- Definition Classes
- SequencingDecorator → Redis
-
def
send[A](command: String, args: Seq[Any])(result: ⇒ A)(implicit format: Format, blocker: Blocker): F[Resp[A]]
- Definition Classes
- SequencingDecorator → Redis
-
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
- StringOperations → StringApi
-
def
setConfig(key: Any, value: Any)(implicit format: Format): F[Resp[Option[String]]]
CONFIG SET
CONFIG SET
- Definition Classes
- BaseOperations → BaseApi
-
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
- StringOperations → StringApi
-
def
setex(key: Any, expiry: Long, value: Any)(implicit format: Format): F[Resp[Boolean]]
- Definition Classes
- StringOperations → StringApi
-
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
- StringOperations → StringApi
-
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
- StringOperations → StringApi
-
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
- NodeOperations → NodeApi
-
val
singleLineReply: SingleReply
- Definition Classes
- Reply
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
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
- NodeOperations → NodeApi
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
val
socket: Socket
- Definition Classes
- RedisIO
-
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
- BaseOperations → BaseApi
-
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
- BaseOperations → BaseApi
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
val
sslContext: Option[SSLContext]
- Definition Classes
- RedisIO
-
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
- StringOperations → StringApi
-
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
- SetOperations → SetApi
-
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
- SetOperations → SetApi
-
final
def
synchronized[T0](arg0: ⇒ T0): T0
- Definition Classes
- AnyRef
-
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
- BaseOperations → BaseApi
-
val
timeout: Int
- Definition Classes
- SequencingDecorator → RedisIO
-
def
toString(): String
- Definition Classes
- AnyRef → Any
-
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
- BaseOperations → BaseApi
-
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
- BaseOperations → BaseApi
-
final
def
wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()
-
final
def
wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
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
- BaseOperations → BaseApi
-
def
write(data: Array[Byte]): Unit
- Definition Classes
- SequencingDecorator → RedisIO
-
def
write_to_socket(op: (OutputStream) ⇒ Unit): Unit
- Definition Classes
- RedisIO
-
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
- SortedSetOperations → SortedSetApi
-
def
zcard(key: Any)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
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
- SortedSetOperations → SortedSetApi
-
def
zincrby(key: Any, incr: Double, member: Any)(implicit format: Format): F[Resp[Option[Double]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
def
zinterstore(dstKey: Any, keys: Iterable[Any], aggregate: Aggregate = SUM)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
def
zinterstoreWeighted(dstKey: Any, kws: Iterable[Product2[Any, Double]], aggregate: Aggregate = SUM)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
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
- SortedSetOperations → SortedSetApi
-
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
- SortedSetOperations → SortedSetApi
-
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
- SortedSetOperations → SortedSetApi
-
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
- SortedSetOperations → SortedSetApi
-
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
- SortedSetOperations → SortedSetApi
-
def
zrank(key: Any, member: Any, reverse: Boolean = false)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
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
- SortedSetOperations → SortedSetApi
-
def
zremrangebyrank(key: Any, start: Int = 0, end: Int = -1)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
def
zremrangebyscore(key: Any, start: Double = Double.NegativeInfinity, end: Double = Double.PositiveInfinity)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
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
- SortedSetOperations → SortedSetApi
-
def
zscore(key: Any, element: Any)(implicit format: Format): F[Resp[Option[Double]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
def
zunionstore(dstKey: Any, keys: Iterable[Any], aggregate: Aggregate = SUM)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
def
zunionstoreWeighted(dstKey: Any, kws: Iterable[Product2[Any, Double]], aggregate: Aggregate = SUM)(implicit format: Format): F[Resp[Option[Long]]]
- Definition Classes
- SortedSetOperations → SortedSetApi
-
def
→[B](y: B): (SequencingDecorator[F], B)
- Implicit
- This member is added by an implicit conversion from SequencingDecorator[F] to ArrowAssoc[SequencingDecorator[F]] performed by method ArrowAssoc in scala.Predef.
- Definition Classes
- ArrowAssoc
Deprecated Value Members
-
def
finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] ) @Deprecated
- Deprecated
-
def
hset(key: Any, field: Any, value: Any)(implicit format: Format): F[Resp[Boolean]]
Sets
field
in the hash stored atkey
tovalue
.Sets
field
in the hash stored atkey
tovalue
. Ifkey
does not exist, a new key holding a hash is created. If field already exists in the hash, it is overwritten.- returns
True
iffield
is a new field in the hash and value was set,False
iffield
already exists in the hash and the value was updated.
- Definition Classes
- HashOperations → HashApi
- Deprecated
return value semantics is inconsistent with effredis.HashOperations#hsetnx and effredis.HashOperations#hmset. Use effredis.HashOperations#hset1 instead
- See also
-
def
randkey[A](implicit parse: Parse[A]): F[Resp[Option[A]]]
- Definition Classes
- BaseOperations
- Annotations
- @deprecated
- Deprecated
(Since version 2.8) use randomkey
-
def
slaveOf(options: Any): F[Resp[Boolean]]
- Definition Classes
- NodeOperations
- Annotations
- @deprecated
- Deprecated
(Since version 1.2.0) use slaveof