redis
package redis
Members list
Packages
package redis.actors
package redis.api
package redis.commands
package redis.protocol
package redis.util
Type members
Classlikes
trait ActorRequest
Attributes
- Source
- ActorRequest.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
trait Transactionsclass RedisClientclass RedisClientMasterSlavesclass RedisClientActorLikeclass RedisBlockingClientclass SentinelClientShow all
trait BufferedRequest
Attributes
- Source
- BufferedRequest.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
class TransactionBuilder
object ByteStringDeserializer extends ByteStringDeserializerLowPriority
Attributes
- Companion
- trait
- Source
- ByteStringDeserializer.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Self type
Attributes
- Companion
- object
- Source
- ByteStringDeserializer.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
- Self type
Attributes
- Source
- ByteStringDeserializerDefault.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
Attributes
- Source
- ByteStringDeserializerLowPriority.scala
- Supertypes
- Known subtypes
-
object ByteStringDeserializer
object ByteStringFormatter extends ByteStringFormatterDefault
Attributes
- Companion
- trait
- Source
- ByteStringFormatter.scala
- Supertypes
- Self type
-
ByteStringFormatter.type
trait ByteStringFormatter[T] extends ByteStringSerializer[T], ByteStringDeserializer[T]
Attributes
- Companion
- object
- Source
- ByteStringFormatter.scala
- Supertypes
-
trait ByteStringDeserializer[T]trait ByteStringSerializer[T]class Objecttrait Matchableclass Any
Attributes
- Source
- ByteStringFormatterDefault.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
object ByteStringFormatter
object ByteStringSerializer extends ByteStringSerializerLowPriority
Attributes
- Companion
- trait
- Source
- ByteStringSerializer.scala
- Supertypes
- Self type
-
ByteStringSerializer.type
Attributes
- Companion
- object
- Source
- ByteStringSerializer.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
trait ByteStringFormatter[T]object ArrayByteConverterobject ByteConverterobject ByteStringConverterobject CharConverterobject DoubleConverterobject FloatConverterobject IntConverterobject LongConverterobject ShortConverterobject StringShow all
- Self type
Attributes
- Source
- ByteStringSerializerLowPriority.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
object ByteStringSerializer
trait ClusterKey
Attributes
- Source
- ClusterKey.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
class MultiClusterKey[K]class Del[K]class ExistsMany[K]class Unlink[K]class SimpleClusterKey[K]class GeoAdd[K]class GeoDist[K]class GeoHash[K]class GeoPos[K]class GeoRadius[K]class GeoRadiusByMember[K]class GeoRadiusByMemberWithOpt[K]class Hkeys[K]class Hlen[K]class Exists[K]class Expire[K]class Expireat[K]class Move[K]class ObjectEncoding[K]class ObjectIdletime[K]class ObjectRefcount[K]class Persist[K]class Pexpire[K]class Pexpireat[K]class Pttl[K]class Ttl[K]class Type[K]class Llen[K]class Ltrim[K]class Scard[K]class Zcard[K]class Zcount[K]class Zremrangebylex[K]class Zremrangebyrank[K]class Zremrangebyscore[K]class Bitcount[K]class BitcountRange[K]class Bitpos[K]class Decr[K]class Decrby[K]class Getbit[K]class Incr[K]class Incrby[K]class Incrbyfloat[K]class Setbit[K]class Strlen[K]Show all
Attributes
- Source
- Cursor.scala
- Supertypes
object MultiBulkConverter
Attributes
- Companion
- trait
- Source
- MultiBulkConverter.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Self type
-
MultiBulkConverter.type
Attributes
- Companion
- object
- Source
- MultiBulkConverter.scala
- Supertypes
-
class Objecttrait Matchableclass Any
abstract class MultiClusterKey[K](implicit redisKey: ByteStringSerializer[K]) extends ClusterKey
Attributes
- Companion
- object
- Source
- MultiClusterKey.scala
- Supertypes
- Known subtypes
object MultiClusterKey
Attributes
- Companion
- class
- Source
- MultiClusterKey.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Self type
-
MultiClusterKey.type
case class Operation[RedisReplyT <: RedisReply, T](redisCommand: RedisCommand[RedisReplyT, T], promise: Promise[T])
Attributes
- Source
- Operation.scala
- Supertypes
case class RedisBlockingClient(var host: String, var port: Int, username: Option[String], password: Option[String], db: Option[Int], name: String, connectTimeout: Option[FiniteDuration])(implicit _system: ActorSystem, redisDispatcher: RedisDispatcher) extends RedisClientActorLike, BLists
Attributes
- Source
- RedisBlockingClient.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait BListstrait Requestclass RedisClientActorLiketrait ActorRequestclass Objecttrait Matchableclass AnyShow all
case class RedisClient(var host: String, var port: Int, username: Option[String], password: Option[String], db: Option[Int], name: String, connectTimeout: Option[FiniteDuration])(implicit _system: ActorSystem, redisDispatcher: RedisDispatcher) extends RedisClientActorLike, RedisCommands, Transactions
Attributes
- Source
- RedisClient.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait Transactionstrait RedisCommandstrait Geotrait Clusterstrait HyperLogLogtrait Servertrait Connectiontrait Scriptingtrait Publishtrait SortedSetstrait Setstrait Liststrait Hashestrait Stringstrait Keystrait Requestclass RedisClientActorLiketrait ActorRequestclass Objecttrait Matchableclass AnyShow all
abstract class RedisClientActorLike(system: ActorSystem, redisDispatcher: RedisDispatcher, connectTimeout: Option[FiniteDuration]) extends ActorRequest
Attributes
- Source
- RedisClientActorLike.scala
- Supertypes
- Known subtypes
case class RedisClientMasterSlaves(master: RedisServer, slaves: Seq[RedisServer])(implicit _system: ActorSystem, redisDispatcher: RedisDispatcher) extends RedisCommands, Transactions
Attributes
- Source
- RedisClientMasterSlaves.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait Transactionstrait ActorRequesttrait RedisCommandstrait Geotrait Clusterstrait HyperLogLogtrait Servertrait Connectiontrait Scriptingtrait Publishtrait SortedSetstrait Setstrait Liststrait Hashestrait Stringstrait Keystrait Requestclass Objecttrait Matchableclass AnyShow all
case class RedisClientMutablePool(redisServers: Seq[RedisServer], name: String)(implicit system: ActorSystem, redisDispatcher: RedisDispatcher) extends RedisClientPoolLike, RoundRobinPoolRequest, RedisCommands
Attributes
- Source
- RedisClientMutablePool.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait RedisCommandstrait Geotrait Clusterstrait HyperLogLogtrait Servertrait Connectiontrait Scriptingtrait Publishtrait SortedSetstrait Setstrait Liststrait Hashestrait Stringstrait Keystrait Requesttrait RoundRobinPoolRequestclass RedisClientPoolLikeclass Objecttrait Matchableclass AnyShow all
case class RedisClientPool(redisServers: Seq[RedisServer], name: String)(implicit _system: ActorSystem, redisDispatcher: RedisDispatcher) extends RedisClientPoolLike, RoundRobinPoolRequest, RedisCommands
Attributes
- Source
- RedisClientPool.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait RedisCommandstrait Geotrait Clusterstrait HyperLogLogtrait Servertrait Connectiontrait Scriptingtrait Publishtrait SortedSetstrait Setstrait Liststrait Hashestrait Stringstrait Keystrait Requesttrait RoundRobinPoolRequestclass RedisClientPoolLikeclass Objecttrait Matchableclass AnyShow all
Attributes
- Source
- RedisClientPoolLike.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
case class RedisCluster(redisServers: Seq[RedisServer], name: String)(implicit _system: ActorSystem, redisDispatcher: RedisDispatcher) extends RedisClientPoolLike, RedisCommands
Attributes
- Source
- RedisCluster.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait RedisCommandstrait Geotrait Clusterstrait HyperLogLogtrait Servertrait Connectiontrait Scriptingtrait Publishtrait SortedSetstrait Setstrait Liststrait Hashestrait Stringstrait Keystrait Requestclass RedisClientPoolLikeclass Objecttrait Matchableclass AnyShow all
Attributes
- Source
- RedisCommand.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
class ClusterInfoclass ClusterNodesclass ClusterSlotstrait RedisCommandBulk[T]class ObjectEncoding[K]class ScriptLoadobject ClientListclass Infotrait RedisCommandBulkDoubleclass GeoDist[K]trait RedisCommandBulkOptionByteString[R]class Randomkey[R]object ClientGetnameclass Incrbyfloat[K]trait RedisCommandInteger[T]class Exists[K]class Expire[K]class Expireat[K]class Move[K]class Persist[K]class Pexpire[K]class Pexpireat[K]class Getbit[K]class Setbit[K]class SenResetMastertrait RedisCommandIntegerLongclass GeoAdd[K]class Hlen[K]class Pfcount[K]class Del[K]class ExistsMany[K]class Pttl[K]class Ttl[K]class Unlink[K]class Llen[K]class Publish[A]object Dbsizeobject Lastsaveclass Scard[K]class Zcard[K]class Zcount[K]class Zremrangebylex[K]class Zremrangebyrank[K]class Zremrangebyscore[K]class Bitcount[K]class BitcountRange[K]class Bitpos[K]class Decr[K]class Decrby[K]class Incr[K]class Incrby[K]class Strlen[K]trait RedisCommandMultiBulk[T]class GeoHash[K]class GeoPos[K]class GeoRadius[K]class GeoRadiusByMember[K]class GeoRadiusByMemberWithOpt[K]class Hkeys[K]class Keysclass ScriptExistsclass ConfigGetobject Timeobject Execclass SenGetMasterAddrclass SenMasterInfoclass SenMastersclass SenSlavestrait RedisCommandMultiBulkCursor[R]class Scan[C]trait RedisCommandMultiBulkSeqByteString[R]trait RedisCommandRedisReply[T]class ObjectIdletime[K]class ObjectRefcount[K]trait RedisCommandRedisReplyRedisReply[R]trait RedisCommandStatus[T]class Auth[V]object Quitclass Selectclass Swapdbclass Pfmerge[K]class Migrate[K]class Ltrim[K]object ScriptFlushobject ScriptKillclass ClientKillclass ClientSetnameobject ConfigResetstatclass ConfigSetclass Flushallclass Flushdbobject Saveclass Shutdownclass Slaveofobject SlaveofNoOneobject Multiclass Watchclass SenMasterFailovertrait RedisCommandStatusStringobject Pingclass Type[K]object Bgrewriteaofobject Bgsaveclass DebugObject[K]object DebugSegfaultShow all
trait RedisCommandBulk[T] extends RedisCommand[Bulk, T]
Attributes
- Source
- RedisCommandBulk.scala
- Supertypes
- Known subtypes
-
class ObjectEncoding[K]class ScriptLoadobject ClientListclass Infotrait RedisCommandBulkDoubleclass GeoDist[K]trait RedisCommandBulkOptionByteString[R]class Randomkey[R]object ClientGetnameclass Incrbyfloat[K]Show all
trait RedisCommandBulkDouble extends RedisCommandBulk[Double]
Attributes
- Source
- RedisCommandBulkDouble.scala
- Supertypes
- Known subtypes
trait RedisCommandBulkOptionByteString[R] extends RedisCommandBulk[Option[R]]
Attributes
- Source
- RedisCommandBulkOptionByteString.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
trait RedisCommandBulkOptionDouble extends RedisCommandBulk[Option[Double]]
Attributes
- Source
- RedisCommandBulkOptionDouble.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
class Incrbyfloat[K]
trait RedisCommandInteger[T] extends RedisCommand[Integer, T]
Attributes
- Source
- RedisCommandInteger.scala
- Supertypes
- Known subtypes
-
class Exists[K]class Expire[K]class Expireat[K]class Move[K]class Persist[K]class Pexpire[K]class Pexpireat[K]class Getbit[K]class Setbit[K]class SenResetMastertrait RedisCommandIntegerLongclass GeoAdd[K]class Hlen[K]class Pfcount[K]class Del[K]class ExistsMany[K]class Pttl[K]class Ttl[K]class Unlink[K]class Llen[K]class Publish[A]object Dbsizeobject Lastsaveclass Scard[K]class Zcard[K]class Zcount[K]class Zremrangebylex[K]class Zremrangebyrank[K]class Zremrangebyscore[K]class Bitcount[K]class BitcountRange[K]class Bitpos[K]class Decr[K]class Decrby[K]class Incr[K]class Incrby[K]class Strlen[K]Show all
trait RedisCommandIntegerBoolean extends RedisCommandInteger[Boolean]
Attributes
- Source
- RedisCommandIntegerBoolean.scala
- Supertypes
- Known subtypes
trait RedisCommandIntegerLong extends RedisCommandInteger[Long]
Attributes
- Source
- RedisCommandIntegerLong.scala
- Supertypes
- Known subtypes
-
class GeoAdd[K]class Hlen[K]class Pfcount[K]class Del[K]class ExistsMany[K]class Pttl[K]class Ttl[K]class Unlink[K]class Llen[K]class Publish[A]object Dbsizeobject Lastsaveclass Scard[K]class Zcard[K]class Zcount[K]class Zremrangebylex[K]class Zremrangebyrank[K]class Zremrangebyscore[K]class Bitcount[K]class BitcountRange[K]class Bitpos[K]class Decr[K]class Decrby[K]class Incr[K]class Incrby[K]class Strlen[K]Show all
trait RedisCommandMultiBulk[T] extends RedisCommand[MultiBulk, T]
Attributes
- Source
- RedisCommandMultiBulk.scala
- Supertypes
- Known subtypes
-
class GeoHash[K]class GeoPos[K]class GeoRadius[K]class GeoRadiusByMember[K]class GeoRadiusByMemberWithOpt[K]class Hkeys[K]class Keysclass ScriptExistsclass ConfigGetobject Timeobject Execclass SenGetMasterAddrclass SenMasterInfoclass SenMastersclass SenSlavestrait RedisCommandMultiBulkCursor[R]class Scan[C]trait RedisCommandMultiBulkSeqByteString[R]Show all
trait RedisCommandMultiBulkCursor[R] extends RedisCommandMultiBulk[Cursor[R]]
Attributes
- Source
- RedisCommandMultiBulkCursor.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
trait RedisCommandMultiBulkSeqByteString[R] extends RedisCommandMultiBulk[Seq[R]]
Attributes
- Source
- RedisCommandMultiBulkSeqByteString.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
Show all
trait RedisCommandMultiBulkSeqByteStringDouble[R] extends RedisCommandMultiBulk[Seq[(R, Double)]]
Attributes
- Source
- RedisCommandMultiBulkSeqByteStringDouble.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
trait RedisCommandRedisReply[T] extends RedisCommand[RedisReply, T]
Attributes
- Source
- RedisCommandRedisReply.scala
- Supertypes
- Known subtypes
trait RedisCommandRedisReplyOptionLong extends RedisCommandRedisReply[Option[Long]]
Attributes
- Source
- RedisCommandRedisReplyOptionLong.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
trait RedisCommandRedisReplyRedisReply[R] extends RedisCommandRedisReply[R]
Attributes
- Source
- RedisCommandRedisReplyRedisReply.scala
- Supertypes
- Known subtypes
trait RedisCommandStatus[T] extends RedisCommand[Status, T]
Attributes
- Source
- RedisCommandStatus.scala
- Supertypes
- Known subtypes
-
class Auth[V]object Quitclass Selectclass Swapdbclass Pfmerge[K]class Migrate[K]class Ltrim[K]object ScriptFlushobject ScriptKillclass ClientKillclass ClientSetnameobject ConfigResetstatclass ConfigSetclass Flushallclass Flushdbobject Saveclass Shutdownclass Slaveofobject SlaveofNoOneobject Multiclass Watchclass SenMasterFailovertrait RedisCommandStatusStringobject Pingclass Type[K]object Bgrewriteaofobject Bgsaveclass DebugObject[K]object DebugSegfaultShow all
trait RedisCommandStatusBoolean extends RedisCommandStatus[Boolean]
Attributes
- Source
- RedisCommandStatusBoolean.scala
- Supertypes
- Known subtypes
-
object Quitclass Selectclass Swapdbclass Pfmerge[K]class Migrate[K]class Ltrim[K]object ScriptFlushobject ScriptKillclass ClientKillclass ClientSetnameobject ConfigResetstatclass ConfigSetclass Flushallclass Flushdbobject Saveclass Shutdownclass Slaveofobject SlaveofNoOneobject Multiclass Watchclass SenMasterFailoverShow all
trait RedisCommandStatusString extends RedisCommandStatus[String]
Attributes
- Source
- RedisCommandStatusString.scala
- Supertypes
- Known subtypes
-
object Pingclass Type[K]object Bgrewriteaofobject Bgsaveclass DebugObject[K]object DebugSegfaultShow all
trait RedisCommands extends Keys, Strings, Hashes, Lists, Sets, SortedSets, Publish, Scripting, Connection, Server, HyperLogLog, Clusters, Geo
Attributes
- Source
- RedisCommands.scala
- Supertypes
-
trait Geotrait Clusterstrait HyperLogLogtrait Servertrait Connectiontrait Scriptingtrait Publishtrait SortedSetstrait Setstrait Liststrait Hashestrait Stringstrait Keystrait Requestclass Objecttrait Matchableclass AnyShow all
- Known subtypes
-
class TransactionBuilderclass RedisClientclass RedisClientMasterSlavesclass RedisClientMutablePoolclass RedisClientPoolclass RedisClusterShow all
object RedisComputeSlot
Attributes
- Source
- RedisComputeSlot.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Self type
-
RedisComputeSlot.type
Attributes
- Source
- RedisConnection.scala
- Supertypes
Attributes
- Source
- RedisDispatcher.scala
- Supertypes
Attributes
- Source
- RedisPubSub.scala
- Supertypes
object RedisReplyDeserializer extends RedisReplyDeserializerLowPriority
Attributes
- Companion
- trait
- Source
- RedisReplyDeserializer.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Self type
Attributes
- Companion
- object
- Source
- RedisReplyDeserializer.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
object RedisReplyobject String
Attributes
- Source
- RedisReplyDeserializerDefault.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
object RedisReplyDeserializer
Attributes
- Source
- RedisReplyDeserializerLowPriority.scala
- Supertypes
- Known subtypes
-
object RedisReplyDeserializer
Attributes
- Source
- RedisServer.scala
- Supertypes
trait Request
Attributes
- Source
- Request.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
trait BListsclass RedisBlockingClienttrait Clusterstrait RedisCommandsclass TransactionBuilderclass RedisClientclass RedisClientMasterSlavesclass RedisClientMutablePoolclass RedisClientPoolclass RedisClustertrait Connectiontrait Geotrait Hashestrait HyperLogLogtrait Keystrait Liststrait Publishtrait Scriptingtrait Sentineltrait SentinelCommandsclass SentinelClienttrait Servertrait Setstrait SortedSetstrait StringsShow all
trait RoundRobinPoolRequest
Attributes
- Source
- RoundRobinPoolRequest.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
-
class RedisClientMutablePoolclass RedisClientPool
case class SentinelClient(var host: String, var port: Int, onMasterChange: (String, String, Int) => Unit, onNewSentinel: (String, String, Int) => Unit, onSentinelDown: (String, String, Int) => Unit, onNewSlave: (String, String, Int) => Unit, onSlaveDown: (String, String, Int) => Unit, name: String)(implicit _system: ActorSystem, redisDispatcher: RedisDispatcher) extends RedisClientActorLike, SentinelCommands
Attributes
- Source
- SentinelClient.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait SentinelCommandstrait Sentineltrait Requestclass RedisClientActorLiketrait ActorRequestclass Objecttrait Matchableclass AnyShow all
trait SentinelCommands extends Sentinel
Attributes
- Source
- SentinelCommands.scala
- Supertypes
- Known subtypes
-
class SentinelClient
Attributes
- Source
- SentinelMonitored.scala
- Supertypes
-
class Objecttrait Matchableclass Any
- Known subtypes
case class SentinelMonitoredRedisBlockingClient(sentinels: Seq[(String, Int)], master: String, username: Option[String], password: Option[String], db: Option[Int], name: String)(implicit system: ActorSystem, redisDispatcher: RedisDispatcher) extends SentinelMonitoredRedisClientLike, BLists
Attributes
- Source
- SentinelMonitoredRedisBlockingClient.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait BListstrait Requesttrait ActorRequestclass SentinelMonitoredclass Objecttrait Matchableclass AnyShow all
abstract class SentinelMonitoredRedisBlockingClientLike(system: ActorSystem, redisDispatcher: RedisDispatcher) extends SentinelMonitored, ActorRequest
Attributes
- Source
- SentinelMonitoredRedisBlockingClientLike.scala
- Supertypes
case class SentinelMonitoredRedisClient(sentinels: Seq[(String, Int)], master: String, username: Option[String], password: Option[String], db: Option[Int], name: String)(implicit system: ActorSystem, redisDispatcher: RedisDispatcher) extends SentinelMonitoredRedisClientLike, RedisCommands, Transactions
Attributes
- Source
- SentinelMonitoredRedisClient.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait Transactionstrait RedisCommandstrait Geotrait Clusterstrait HyperLogLogtrait Servertrait Connectiontrait Scriptingtrait Publishtrait SortedSetstrait Setstrait Liststrait Hashestrait Stringstrait Keystrait Requesttrait ActorRequestclass SentinelMonitoredclass Objecttrait Matchableclass AnyShow all
abstract class SentinelMonitoredRedisClientLike(system: ActorSystem, redisDispatcher: RedisDispatcher) extends SentinelMonitored, ActorRequest
Attributes
- Source
- SentinelMonitoredRedisClientLike.scala
- Supertypes
- Known subtypes
case class SentinelMonitoredRedisClientMasterSlaves(sentinels: Seq[(String, Int)], master: String)(implicit _system: ActorSystem, redisDispatcher: RedisDispatcher) extends SentinelMonitored, ActorRequest, RedisCommands, Transactions
Attributes
- Source
- SentinelMonitoredRedisClientMasterSlaves.scala
- Supertypes
-
trait Serializabletrait Producttrait Equalstrait Transactionstrait RedisCommandstrait Geotrait Clusterstrait HyperLogLogtrait Servertrait Connectiontrait Scriptingtrait Publishtrait SortedSetstrait Setstrait Liststrait Hashestrait Stringstrait Keystrait Requesttrait ActorRequestclass SentinelMonitoredclass Objecttrait Matchableclass AnyShow all
abstract class SimpleClusterKey[K](implicit redisKey: ByteStringSerializer[K]) extends ClusterKey
Attributes
- Source
- SimpleClusterKey.scala
- Supertypes
- Known subtypes
-
class GeoAdd[K]class GeoDist[K]class GeoHash[K]class GeoPos[K]class GeoRadius[K]class GeoRadiusByMember[K]class GeoRadiusByMemberWithOpt[K]class Hkeys[K]class Hlen[K]class Exists[K]class Expire[K]class Expireat[K]class Move[K]class ObjectEncoding[K]class ObjectIdletime[K]class ObjectRefcount[K]class Persist[K]class Pexpire[K]class Pexpireat[K]class Pttl[K]class Ttl[K]class Type[K]class Llen[K]class Ltrim[K]class Scard[K]class Zcard[K]class Zcount[K]class Zremrangebylex[K]class Zremrangebyrank[K]class Zremrangebyscore[K]class Bitcount[K]class BitcountRange[K]class Bitpos[K]class Decr[K]class Decrby[K]class Getbit[K]class Incr[K]class Incrby[K]class Incrbyfloat[K]class Setbit[K]class Strlen[K]Show all
Attributes
- Source
- Transaction.scala
- Supertypes
In this article