| Safe Haskell | None | 
|---|---|
| Language | Haskell2010 | 
Database.Redis
Contents
Synopsis
- data Redis a
- runRedis :: Connection -> Redis a -> IO a
- unRedis :: Redis a -> ReaderT RedisEnv IO a
- reRedis :: ReaderT RedisEnv IO a -> Redis a
- class MonadRedis m => RedisCtx m f | m -> f where- returnDecode :: RedisResult a => Reply -> m (f a)
 
- class Monad m => MonadRedis m where
- data Connection
- data ConnectError
- connect :: ConnectInfo -> IO Connection
- checkedConnect :: ConnectInfo -> IO Connection
- disconnect :: Connection -> IO ()
- withConnect :: (MonadMask m, MonadIO m) => ConnectInfo -> (Connection -> m c) -> m c
- withCheckedConnect :: (MonadMask m, MonadIO m) => ConnectInfo -> (Connection -> m c) -> m c
- data ConnectInfo = ConnInfo {}
- defaultConnectInfo :: ConnectInfo
- parseConnectInfo :: String -> Either String ConnectInfo
- data PortID
- auth :: ByteString -> Redis (Either Reply Status)
- echo :: RedisCtx m f => ByteString -> m (f ByteString)
- ping :: RedisCtx m f => m (f Status)
- quit :: RedisCtx m f => m (f Status)
- select :: RedisCtx m f => Integer -> m (f Status)
- del :: RedisCtx m f => [ByteString] -> m (f Integer)
- dump :: RedisCtx m f => ByteString -> m (f ByteString)
- exists :: RedisCtx m f => ByteString -> m (f Bool)
- expire :: RedisCtx m f => ByteString -> Integer -> m (f Bool)
- expireat :: RedisCtx m f => ByteString -> Integer -> m (f Bool)
- keys :: RedisCtx m f => ByteString -> m (f [ByteString])
- data MigrateOpts = MigrateOpts {}
- defaultMigrateOpts :: MigrateOpts
- migrate :: RedisCtx m f => ByteString -> ByteString -> ByteString -> Integer -> Integer -> m (f Status)
- migrateMultiple :: RedisCtx m f => ByteString -> ByteString -> Integer -> Integer -> MigrateOpts -> [ByteString] -> m (f Status)
- move :: RedisCtx m f => ByteString -> Integer -> m (f Bool)
- objectRefcount :: RedisCtx m f => ByteString -> m (f Integer)
- objectEncoding :: RedisCtx m f => ByteString -> m (f ByteString)
- objectIdletime :: RedisCtx m f => ByteString -> m (f Integer)
- persist :: RedisCtx m f => ByteString -> m (f Bool)
- pexpire :: RedisCtx m f => ByteString -> Integer -> m (f Bool)
- pexpireat :: RedisCtx m f => ByteString -> Integer -> m (f Bool)
- pttl :: RedisCtx m f => ByteString -> m (f Integer)
- randomkey :: RedisCtx m f => m (f (Maybe ByteString))
- rename :: RedisCtx m f => ByteString -> ByteString -> m (f Status)
- renamenx :: RedisCtx m f => ByteString -> ByteString -> m (f Bool)
- restore :: RedisCtx m f => ByteString -> Integer -> ByteString -> m (f Status)
- restoreReplace :: RedisCtx m f => ByteString -> Integer -> ByteString -> m (f Status)
- data Cursor
- cursor0 :: Cursor
- data ScanOpts = ScanOpts {}
- defaultScanOpts :: ScanOpts
- scan :: RedisCtx m f => Cursor -> m (f (Cursor, [ByteString]))
- scanOpts :: RedisCtx m f => Cursor -> ScanOpts -> m (f (Cursor, [ByteString]))
- data SortOpts = SortOpts {}
- defaultSortOpts :: SortOpts
- data SortOrder
- sort :: RedisCtx m f => ByteString -> SortOpts -> m (f [ByteString])
- sortStore :: RedisCtx m f => ByteString -> ByteString -> SortOpts -> m (f Integer)
- ttl :: RedisCtx m f => ByteString -> m (f Integer)
- data RedisType
- getType :: RedisCtx m f => ByteString -> m (f RedisType)
- wait :: RedisCtx m f => Integer -> Integer -> m (f Integer)
- hdel :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- hexists :: RedisCtx m f => ByteString -> ByteString -> m (f Bool)
- hget :: RedisCtx m f => ByteString -> ByteString -> m (f (Maybe ByteString))
- hgetall :: RedisCtx m f => ByteString -> m (f [(ByteString, ByteString)])
- hincrby :: RedisCtx m f => ByteString -> ByteString -> Integer -> m (f Integer)
- hincrbyfloat :: RedisCtx m f => ByteString -> ByteString -> Double -> m (f Double)
- hkeys :: RedisCtx m f => ByteString -> m (f [ByteString])
- hlen :: RedisCtx m f => ByteString -> m (f Integer)
- hmget :: RedisCtx m f => ByteString -> [ByteString] -> m (f [Maybe ByteString])
- hmset :: RedisCtx m f => ByteString -> [(ByteString, ByteString)] -> m (f Status)
- hscan :: RedisCtx m f => ByteString -> Cursor -> m (f (Cursor, [(ByteString, ByteString)]))
- hscanOpts :: RedisCtx m f => ByteString -> Cursor -> ScanOpts -> m (f (Cursor, [(ByteString, ByteString)]))
- hset :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Bool)
- hsetnx :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Bool)
- hstrlen :: RedisCtx m f => ByteString -> ByteString -> m (f Integer)
- hvals :: RedisCtx m f => ByteString -> m (f [ByteString])
- pfadd :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- pfcount :: RedisCtx m f => [ByteString] -> m (f Integer)
- pfmerge :: RedisCtx m f => ByteString -> [ByteString] -> m (f ByteString)
- blpop :: RedisCtx m f => [ByteString] -> Integer -> m (f (Maybe (ByteString, ByteString)))
- brpop :: RedisCtx m f => [ByteString] -> Integer -> m (f (Maybe (ByteString, ByteString)))
- brpoplpush :: RedisCtx m f => ByteString -> ByteString -> Integer -> m (f (Maybe ByteString))
- lindex :: RedisCtx m f => ByteString -> Integer -> m (f (Maybe ByteString))
- linsertBefore :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Integer)
- linsertAfter :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Integer)
- llen :: RedisCtx m f => ByteString -> m (f Integer)
- lpop :: RedisCtx m f => ByteString -> m (f (Maybe ByteString))
- lpush :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- lpushx :: RedisCtx m f => ByteString -> ByteString -> m (f Integer)
- lrange :: RedisCtx m f => ByteString -> Integer -> Integer -> m (f [ByteString])
- lrem :: RedisCtx m f => ByteString -> Integer -> ByteString -> m (f Integer)
- lset :: RedisCtx m f => ByteString -> Integer -> ByteString -> m (f Status)
- ltrim :: RedisCtx m f => ByteString -> Integer -> Integer -> m (f Status)
- rpop :: RedisCtx m f => ByteString -> m (f (Maybe ByteString))
- rpoplpush :: RedisCtx m f => ByteString -> ByteString -> m (f (Maybe ByteString))
- rpush :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- rpushx :: RedisCtx m f => ByteString -> ByteString -> m (f Integer)
- eval :: (RedisCtx m f, RedisResult a) => ByteString -> [ByteString] -> [ByteString] -> m (f a)
- evalsha :: (RedisCtx m f, RedisResult a) => ByteString -> [ByteString] -> [ByteString] -> m (f a)
- data DebugMode
- scriptDebug :: RedisCtx m f => DebugMode -> m (f Bool)
- scriptExists :: RedisCtx m f => [ByteString] -> m (f [Bool])
- scriptFlush :: RedisCtx m f => m (f Status)
- scriptKill :: RedisCtx m f => m (f Status)
- scriptLoad :: RedisCtx m f => ByteString -> m (f ByteString)
- bgrewriteaof :: RedisCtx m f => m (f Status)
- bgsave :: RedisCtx m f => m (f Status)
- clientGetname :: RedisCtx m f => m (f Status)
- clientList :: RedisCtx m f => m (f [ByteString])
- clientPause :: RedisCtx m f => Integer -> m (f Status)
- data ReplyMode
- clientReply :: RedisCtx m f => ReplyMode -> m (f Bool)
- clientSetname :: RedisCtx m f => ByteString -> m (f ByteString)
- commandCount :: RedisCtx m f => m (f Integer)
- commandInfo :: RedisCtx m f => [ByteString] -> m (f [ByteString])
- configGet :: RedisCtx m f => ByteString -> m (f [(ByteString, ByteString)])
- configResetstat :: RedisCtx m f => m (f Status)
- configRewrite :: RedisCtx m f => m (f Status)
- configSet :: RedisCtx m f => ByteString -> ByteString -> m (f Status)
- dbsize :: RedisCtx m f => m (f Integer)
- debugObject :: RedisCtx m f => ByteString -> m (f ByteString)
- flushall :: RedisCtx m f => m (f Status)
- flushdb :: RedisCtx m f => m (f Status)
- info :: RedisCtx m f => m (f ByteString)
- infoSection :: RedisCtx m f => ByteString -> m (f ByteString)
- lastsave :: RedisCtx m f => m (f Integer)
- save :: RedisCtx m f => m (f Status)
- slaveof :: RedisCtx m f => ByteString -> ByteString -> m (f Status)
- data Slowlog = Slowlog {}
- slowlogGet :: RedisCtx m f => Integer -> m (f [Slowlog])
- slowlogLen :: RedisCtx m f => m (f Integer)
- slowlogReset :: RedisCtx m f => m (f Status)
- time :: RedisCtx m f => m (f (Integer, Integer))
- sadd :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- scard :: RedisCtx m f => ByteString -> m (f Integer)
- sdiff :: RedisCtx m f => [ByteString] -> m (f [ByteString])
- sdiffstore :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- sinter :: RedisCtx m f => [ByteString] -> m (f [ByteString])
- sinterstore :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- sismember :: RedisCtx m f => ByteString -> ByteString -> m (f Bool)
- smembers :: RedisCtx m f => ByteString -> m (f [ByteString])
- smove :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Bool)
- spop :: RedisCtx m f => ByteString -> m (f (Maybe ByteString))
- spopN :: RedisCtx m f => ByteString -> Integer -> m (f [ByteString])
- srandmember :: RedisCtx m f => ByteString -> m (f (Maybe ByteString))
- srandmemberN :: RedisCtx m f => ByteString -> Integer -> m (f [ByteString])
- srem :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- sscan :: RedisCtx m f => ByteString -> Cursor -> m (f (Cursor, [ByteString]))
- sscanOpts :: RedisCtx m f => ByteString -> Cursor -> ScanOpts -> m (f (Cursor, [ByteString]))
- sunion :: RedisCtx m f => [ByteString] -> m (f [ByteString])
- sunionstore :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- data ZaddOpts = ZaddOpts {}
- defaultZaddOpts :: ZaddOpts
- zadd :: RedisCtx m f => ByteString -> [(Double, ByteString)] -> m (f Integer)
- zaddOpts :: RedisCtx m f => ByteString -> [(Double, ByteString)] -> ZaddOpts -> m (f Integer)
- zcard :: RedisCtx m f => ByteString -> m (f Integer)
- zcount :: RedisCtx m f => ByteString -> Double -> Double -> m (f Integer)
- zincrby :: RedisCtx m f => ByteString -> Integer -> ByteString -> m (f Double)
- data Aggregate
- zinterstore :: RedisCtx m f => ByteString -> [ByteString] -> Aggregate -> m (f Integer)
- zinterstoreWeights :: RedisCtx m f => ByteString -> [(ByteString, Double)] -> Aggregate -> m (f Integer)
- zlexcount :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Integer)
- zrange :: RedisCtx m f => ByteString -> Integer -> Integer -> m (f [ByteString])
- zrangeWithscores :: RedisCtx m f => ByteString -> Integer -> Integer -> m (f [(ByteString, Double)])
- data RangeLex a
- zrangebylex :: RedisCtx m f => ByteString -> RangeLex ByteString -> RangeLex ByteString -> m (f [ByteString])
- zrangebylexLimit :: RedisCtx m f => ByteString -> RangeLex ByteString -> RangeLex ByteString -> Integer -> Integer -> m (f [ByteString])
- zrangebyscore :: RedisCtx m f => ByteString -> Double -> Double -> m (f [ByteString])
- zrangebyscoreWithscores :: RedisCtx m f => ByteString -> Double -> Double -> m (f [(ByteString, Double)])
- zrangebyscoreLimit :: RedisCtx m f => ByteString -> Double -> Double -> Integer -> Integer -> m (f [ByteString])
- zrangebyscoreWithscoresLimit :: RedisCtx m f => ByteString -> Double -> Double -> Integer -> Integer -> m (f [(ByteString, Double)])
- zrank :: RedisCtx m f => ByteString -> ByteString -> m (f (Maybe Integer))
- zrem :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- zremrangebylex :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Integer)
- zremrangebyrank :: RedisCtx m f => ByteString -> Integer -> Integer -> m (f Integer)
- zremrangebyscore :: RedisCtx m f => ByteString -> Double -> Double -> m (f Integer)
- zrevrange :: RedisCtx m f => ByteString -> Integer -> Integer -> m (f [ByteString])
- zrevrangeWithscores :: RedisCtx m f => ByteString -> Integer -> Integer -> m (f [(ByteString, Double)])
- zrevrangebyscore :: RedisCtx m f => ByteString -> Double -> Double -> m (f [ByteString])
- zrevrangebyscoreWithscores :: RedisCtx m f => ByteString -> Double -> Double -> m (f [(ByteString, Double)])
- zrevrangebyscoreLimit :: RedisCtx m f => ByteString -> Double -> Double -> Integer -> Integer -> m (f [ByteString])
- zrevrangebyscoreWithscoresLimit :: RedisCtx m f => ByteString -> Double -> Double -> Integer -> Integer -> m (f [(ByteString, Double)])
- zrevrank :: RedisCtx m f => ByteString -> ByteString -> m (f (Maybe Integer))
- zscan :: RedisCtx m f => ByteString -> Cursor -> m (f (Cursor, [(ByteString, Double)]))
- zscanOpts :: RedisCtx m f => ByteString -> Cursor -> ScanOpts -> m (f (Cursor, [(ByteString, Double)]))
- zscore :: RedisCtx m f => ByteString -> ByteString -> m (f (Maybe Double))
- zunionstore :: RedisCtx m f => ByteString -> [ByteString] -> Aggregate -> m (f Integer)
- zunionstoreWeights :: RedisCtx m f => ByteString -> [(ByteString, Double)] -> Aggregate -> m (f Integer)
- append :: RedisCtx m f => ByteString -> ByteString -> m (f Integer)
- bitcount :: RedisCtx m f => ByteString -> m (f Integer)
- bitcountRange :: RedisCtx m f => ByteString -> Integer -> Integer -> m (f Integer)
- bitopAnd :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- bitopOr :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- bitopXor :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- bitopNot :: RedisCtx m f => ByteString -> ByteString -> m (f Integer)
- bitpos :: RedisCtx m f => ByteString -> Integer -> Integer -> Integer -> m (f Integer)
- decr :: RedisCtx m f => ByteString -> m (f Integer)
- decrby :: RedisCtx m f => ByteString -> Integer -> m (f Integer)
- get :: RedisCtx m f => ByteString -> m (f (Maybe ByteString))
- getbit :: RedisCtx m f => ByteString -> Integer -> m (f Integer)
- getrange :: RedisCtx m f => ByteString -> Integer -> Integer -> m (f ByteString)
- getset :: RedisCtx m f => ByteString -> ByteString -> m (f (Maybe ByteString))
- incr :: RedisCtx m f => ByteString -> m (f Integer)
- incrby :: RedisCtx m f => ByteString -> Integer -> m (f Integer)
- incrbyfloat :: RedisCtx m f => ByteString -> Double -> m (f Double)
- mget :: RedisCtx m f => [ByteString] -> m (f [Maybe ByteString])
- mset :: RedisCtx m f => [(ByteString, ByteString)] -> m (f Status)
- msetnx :: RedisCtx m f => [(ByteString, ByteString)] -> m (f Bool)
- psetex :: RedisCtx m f => ByteString -> Integer -> ByteString -> m (f Status)
- data Condition
- data SetOpts = SetOpts {}
- set :: RedisCtx m f => ByteString -> ByteString -> m (f Status)
- setOpts :: RedisCtx m f => ByteString -> ByteString -> SetOpts -> m (f Status)
- setbit :: RedisCtx m f => ByteString -> Integer -> ByteString -> m (f Integer)
- setex :: RedisCtx m f => ByteString -> Integer -> ByteString -> m (f Status)
- setnx :: RedisCtx m f => ByteString -> ByteString -> m (f Bool)
- setrange :: RedisCtx m f => ByteString -> Integer -> ByteString -> m (f Integer)
- strlen :: RedisCtx m f => ByteString -> m (f Integer)
- data XReadOpts = XReadOpts {}
- defaultXreadOpts :: XReadOpts
- data XReadResponse = XReadResponse {- stream :: ByteString
- records :: [StreamsRecord]
 
- data StreamsRecord = StreamsRecord {- recordId :: ByteString
- keyValues :: [(ByteString, ByteString)]
 
- data TrimOpts
- xadd :: RedisCtx m f => ByteString -> ByteString -> [(ByteString, ByteString)] -> m (f ByteString)
- xaddOpts :: RedisCtx m f => ByteString -> ByteString -> [(ByteString, ByteString)] -> TrimOpts -> m (f ByteString)
- xread :: RedisCtx m f => [(ByteString, ByteString)] -> m (f (Maybe [XReadResponse]))
- xreadOpts :: RedisCtx m f => [(ByteString, ByteString)] -> XReadOpts -> m (f (Maybe [XReadResponse]))
- xreadGroup :: RedisCtx m f => ByteString -> ByteString -> [(ByteString, ByteString)] -> m (f (Maybe [XReadResponse]))
- xreadGroupOpts :: RedisCtx m f => ByteString -> ByteString -> [(ByteString, ByteString)] -> XReadOpts -> m (f (Maybe [XReadResponse]))
- xack :: RedisCtx m f => ByteString -> ByteString -> [ByteString] -> m (f Integer)
- xgroupCreate :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Status)
- xgroupSetId :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Status)
- xgroupDestroy :: RedisCtx m f => ByteString -> ByteString -> m (f Bool)
- xgroupDelConsumer :: RedisCtx m f => ByteString -> ByteString -> ByteString -> m (f Integer)
- xrange :: RedisCtx m f => ByteString -> ByteString -> ByteString -> Maybe Integer -> m (f [StreamsRecord])
- xrevRange :: RedisCtx m f => ByteString -> ByteString -> ByteString -> Maybe Integer -> m (f [StreamsRecord])
- xlen :: RedisCtx m f => ByteString -> m (f Integer)
- data XPendingSummaryResponse = XPendingSummaryResponse {}
- xpendingSummary :: RedisCtx m f => ByteString -> ByteString -> Maybe ByteString -> m (f XPendingSummaryResponse)
- data XPendingDetailRecord = XPendingDetailRecord {}
- xpendingDetail :: RedisCtx m f => ByteString -> ByteString -> ByteString -> ByteString -> Integer -> Maybe ByteString -> m (f [XPendingDetailRecord])
- data XClaimOpts = XClaimOpts {}
- defaultXClaimOpts :: XClaimOpts
- xclaim :: RedisCtx m f => ByteString -> ByteString -> ByteString -> Integer -> XClaimOpts -> [ByteString] -> m (f [StreamsRecord])
- xclaimJustIds :: RedisCtx m f => ByteString -> ByteString -> ByteString -> Integer -> XClaimOpts -> [ByteString] -> m (f [ByteString])
- data XInfoConsumersResponse = XInfoConsumersResponse {}
- xinfoConsumers :: RedisCtx m f => ByteString -> ByteString -> m (f [XInfoConsumersResponse])
- data XInfoGroupsResponse = XInfoGroupsResponse {}
- xinfoGroups :: RedisCtx m f => ByteString -> m (f [XInfoGroupsResponse])
- data XInfoStreamResponse = XInfoStreamResponse {}
- xinfoStream :: RedisCtx m f => ByteString -> m (f XInfoStreamResponse)
- xdel :: RedisCtx m f => ByteString -> [ByteString] -> m (f Integer)
- xtrim :: RedisCtx m f => ByteString -> TrimOpts -> m (f Integer)
- inf :: RealFloat a => a
- watch :: [ByteString] -> Redis (Either Reply Status)
- unwatch :: Redis (Either Reply Status)
- multiExec :: RedisTx (Queued a) -> Redis (TxResult a)
- data Queued a
- data TxResult a
- data RedisTx a
- publish :: RedisCtx m f => ByteString -> ByteString -> m (f Integer)
- pubSub :: PubSub -> (Message -> IO PubSub) -> Redis ()
- data Message
- data PubSub
- subscribe :: [ByteString] -> PubSub
- unsubscribe :: [ByteString] -> PubSub
- psubscribe :: [ByteString] -> PubSub
- punsubscribe :: [ByteString] -> PubSub
- pubSubForever :: Connection -> PubSubController -> IO () -> IO ()
- type RedisChannel = ByteString
- type RedisPChannel = ByteString
- type MessageCallback = ByteString -> IO ()
- type PMessageCallback = RedisChannel -> ByteString -> IO ()
- data PubSubController
- newPubSubController :: MonadIO m => [(RedisChannel, MessageCallback)] -> [(RedisPChannel, PMessageCallback)] -> m PubSubController
- currentChannels :: MonadIO m => PubSubController -> m [RedisChannel]
- currentPChannels :: MonadIO m => PubSubController -> m [RedisPChannel]
- addChannels :: MonadIO m => PubSubController -> [(RedisChannel, MessageCallback)] -> [(RedisPChannel, PMessageCallback)] -> m UnregisterCallbacksAction
- addChannelsAndWait :: MonadIO m => PubSubController -> [(RedisChannel, MessageCallback)] -> [(RedisPChannel, PMessageCallback)] -> m UnregisterCallbacksAction
- removeChannels :: MonadIO m => PubSubController -> [RedisChannel] -> [RedisPChannel] -> m ()
- removeChannelsAndWait :: MonadIO m => PubSubController -> [RedisChannel] -> [RedisPChannel] -> m ()
- type UnregisterCallbacksAction = IO ()
- sendRequest :: (RedisCtx m f, RedisResult a) => [ByteString] -> m (f a)
- data Reply- = SingleLine ByteString
- | Error ByteString
- | Integer Integer
- | Bulk (Maybe ByteString)
- | MultiBulk (Maybe [Reply])
 
- data Status- = Ok
- | Pong
- | Status ByteString
 
- class RedisResult a where
- data ConnectionLostException = ConnectionLost
- data ConnectTimeout = ConnectTimeout ConnectPhase
How To Use This Module
Connect to a Redis server:
-- connects to localhost:6379 conn <-checkedConnectdefaultConnectInfo
Connect to a Redis server using TLS:
-- connects to foobar.redis.cache.windows.net:6380
import Network.TLS
import Network.TLS.Extra.Cipher
import Data.X509.CertificateStore
import Data.Default.Class (def)
(Just certStore) <- readCertificateStore "azure-redis.crt"
let tlsParams = (defaultParamsClient "foobar.redis.cache.windows.net" "") { clientSupported = def { supportedCiphers = ciphersuite_strong }, clientShared = def { sharedCAStore = certStore } }
let redisConnInfo = defaultConnectInfo { connectHost = "foobar.redis.cache.windows.net", connectPort = PortNumber 6380, connectTLSParams = Just tlsParams, connectAuth = Just "Foobar!" }
conn <- checkedConnect redisConnInfo
Send commands to the server:
{-# LANGUAGE OverloadedStrings #-}
...
runRedis conn $ do
     set "hello" "hello"
     set "world" "world"
     hello <- get "hello"
     world <- get "world"
     liftIO $ print (hello,world)
disconnect all idle resources in the connection pool:
disconnectconn
Command Type Signatures
Redis commands behave differently when issued in- or outside of a transaction. To make them work in both contexts, most command functions have a type signature similar to the following:
echo:: (RedisCtxm f) => ByteString -> m (f ByteString)
Here is how to interpret this type signature:
- The argument types are independent of the execution context. echoalways takes aByteStringparameter, whether in- or outside of a transaction. This is true for all command functions.
- All Redis commands return their result wrapped in some "container".
    The type fof this container depends on the commands execution contextm. TheByteStringreturn type in the example is specific to theechocommand. For other commands, it will often be another type.
- In the "normal" context Redis, outside of any transactions, results are wrapped in anEitherReply
- Inside a transaction, in the RedisTxcontext, results are wrapped in aQueued.
In short, you can view any command with a RedisCtx constraint in the
  type signature, to "have two types". For example echo "has both
  types":
echo :: ByteString -> Redis (Either Reply ByteString) echo :: ByteString -> RedisTx (Queued ByteString)
Lua Scripting
Lua values returned from the eval and evalsha functions will be
  converted to Haskell values by the decode function from the
  RedisResult type class.
 Lua Type      | Haskell Type       | Conversion Example
 --------------|--------------------|-----------------------------
 Number        | Integer            | 1.23   => 1
 String        | ByteString, Double | "1.23" => "1.23" or 1.23
 Boolean       | Bool               | false  => False
 Table         | List               | {1,2}  => [1,2]
 Additionally, any of the Haskell types from the table above can be
  wrapped in a Maybe:
42 => Just 42 :: Maybe Integer nil => Nothing :: Maybe Integer
Note that Redis imposes some limitations on the possible conversions:
- Lua numbers can only be converted to Integers. Only Lua strings can be interpreted as Doubles.
- Associative Lua tables can not be converted at all. Returned tables must be "arrays", i.e. indexed only by integers.
The Redis Scripting website (http://redis.io/commands/eval) documents the exact semantics of the scripting commands and value conversion.
Automatic Pipelining
Commands are automatically pipelined as much as possible. For example, in the above "hello world" example, all four commands are pipelined. Automatic pipelining makes use of Haskell's laziness. As long as a previous reply is not evaluated, subsequent commands can be pipelined.
Automatic pipelining is limited to the scope of runRedis call and
  it is guaranteed that every reply expected as a part of runRedis
  execution gets received after runRedis invocation.
To keep memory usage low, the number of requests "in the pipeline" is limited (per connection) to 1000. After that number, the next command is sent only when at least one reply has been received. That means, command functions may block until there are less than 1000 outstanding replies.
Error Behavior
- Operations against keys holding the wrong kind of value:
- Outside of a
    transaction, if the Redis server returns an Error, command functions will returnLefttheReply. The library user can inspect the error message to gain information on what kind of error occured.
- Connection to the server lost:
- In case of a lost connection, command
    functions throw a ConnectionLostException. It can only be caught outside ofrunRedis.
- Trying to connect to an unreachable server:
- When trying to connect to
    a server that does not exist or can't be reached, the connection pool
    only starts the first connection when actually executing a call to
    the server. This can lead to discovering very late that the server is
    not available, for example when running a server that logs to Redis.
    To prevent this, run a pingcommand directly after connecting or use thecheckedConnectfunction which encapsulates this behavior.
- Exceptions:
- Any exceptions can only be caught outside of runRedis. This way the connection pool can properly close the connection, making sure it is not left in an unusable state, e.g. closed or inside a transaction.
The Redis Monad
Context for normal command execution, outside of transactions. Use
  runRedis to run actions of this type.
In this context, each result is wrapped in an Either to account for the
  possibility of Redis returning an Error reply.
Instances
| Monad Redis Source # | |
| Functor Redis Source # | |
| MonadFail Redis Source # | |
| Defined in Database.Redis.Core.Internal | |
| Applicative Redis Source # | |
| MonadIO Redis Source # | |
| Defined in Database.Redis.Core.Internal | |
| MonadRedis Redis Source # | |
| RedisCtx Redis (Either Reply) Source # | |
| Defined in Database.Redis.Core Methods returnDecode :: RedisResult a => Reply -> Redis (Either Reply a) Source # | |
runRedis :: Connection -> Redis a -> IO a Source #
Interact with a Redis datastore specified by the given Connection.
Each call of runRedis takes a network connection from the Connection
  pool and runs the given Redis action. Calls to runRedis may thus block
  while all connections from the pool are in use.
class MonadRedis m => RedisCtx m f | m -> f where Source #
This class captures the following behaviour: In a context m, a command
  will return its result wrapped in a "container" of type f.
Please refer to the Command Type Signatures section of this page for more information.
Methods
returnDecode :: RedisResult a => Reply -> m (f a) Source #
Instances
| RedisCtx RedisTx Queued Source # | |
| Defined in Database.Redis.Transactions Methods returnDecode :: RedisResult a => Reply -> RedisTx (Queued a) Source # | |
| RedisCtx Redis (Either Reply) Source # | |
| Defined in Database.Redis.Core Methods returnDecode :: RedisResult a => Reply -> Redis (Either Reply a) Source # | |
class Monad m => MonadRedis m where Source #
Instances
| MonadRedis Redis Source # | |
| MonadRedis RedisTx Source # | |
Connection
data Connection Source #
A threadsafe pool of network connections to a Redis server. Use the
  connect function to create one.
data ConnectError Source #
Constructors
| ConnectAuthError Reply | |
| ConnectSelectError Reply | 
Instances
| Eq ConnectError Source # | |
| Defined in Database.Redis.Core | |
| Show ConnectError Source # | |
| Defined in Database.Redis.Core Methods showsPrec :: Int -> ConnectError -> ShowS # show :: ConnectError -> String # showList :: [ConnectError] -> ShowS # | |
| Exception ConnectError Source # | |
| Defined in Database.Redis.Core Methods toException :: ConnectError -> SomeException # fromException :: SomeException -> Maybe ConnectError # displayException :: ConnectError -> String # | |
connect :: ConnectInfo -> IO Connection Source #
Constructs a Connection pool to a Redis server designated by the 
  given ConnectInfo. The first connection is not actually established
  until the first call to the server.
checkedConnect :: ConnectInfo -> IO Connection Source #
Constructs a Connection pool to a Redis server designated by the
  given ConnectInfo, then tests if the server is actually there. 
  Throws an exception if the connection to the Redis server can't be
  established.
disconnect :: Connection -> IO () Source #
Destroy all idle resources in the pool.
withConnect :: (MonadMask m, MonadIO m) => ConnectInfo -> (Connection -> m c) -> m c Source #
Memory bracket around connect and disconnect. 
withCheckedConnect :: (MonadMask m, MonadIO m) => ConnectInfo -> (Connection -> m c) -> m c Source #
Memory bracket around checkedConnect and disconnect
data ConnectInfo Source #
Information for connnecting to a Redis server.
It is recommended to not use the ConnInfo data constructor directly.
 Instead use defaultConnectInfo and update it with record syntax. For
 example to connect to a password protected Redis server running on localhost
 and listening to the default port:
myConnectInfo :: ConnectInfo
myConnectInfo = defaultConnectInfo {connectAuth = Just "secret"}
Constructors
| ConnInfo | |
| Fields 
 | |
Instances
| Show ConnectInfo Source # | |
| Defined in Database.Redis.Core Methods showsPrec :: Int -> ConnectInfo -> ShowS # show :: ConnectInfo -> String # showList :: [ConnectInfo] -> ShowS # | |
defaultConnectInfo :: ConnectInfo Source #
Default information for connecting:
connectHost = "localhost" connectPort = PortNumber 6379 -- Redis default port connectAuth = Nothing -- No password connectDatabase = 0 -- SELECT database 0 connectMaxConnections = 50 -- Up to 50 connections connectMaxIdleTime = 30 -- Keep open for 30 seconds connectTimeout = Nothing -- Don't add timeout logic connectTLSParams = Nothing -- Do not use TLS
parseConnectInfo :: String -> Either String ConnectInfo Source #
Parse a ConnectInfo
Username is ignored, path is used to specify the database:
>>>parseConnectInfo "redis://username:password@host:42/2"Right (ConnInfo {connectHost = "host", connectPort = PortNumber 42, connectAuth = Just "password", connectDatabase = 2, connectMaxConnections = 50, connectMaxIdleTime = 30s, connectTimeout = Nothing, connectTLSParams = Nothing})
>>>parseConnectInfo "redis://username:password@host:42/db"Left "Invalid port: db"
The scheme is validated, to prevent mixing up configurations:
>>>parseConnectInfo "postgres://"Left "Wrong scheme"
Beyond that, all values are optional. Omitted values are taken from
 defaultConnectInfo
>>>parseConnectInfo "redis://"Right (ConnInfo {connectHost = "localhost", connectPort = PortNumber 6379, connectAuth = Nothing, connectDatabase = 0, connectMaxConnections = 50, connectMaxIdleTime = 30s, connectTimeout = Nothing, connectTLSParams = Nothing})
Constructors
| PortNumber PortNumber | |
| UnixSocket String | 
Commands
Connection
Authenticate to the server (http://redis.io/commands/auth). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | message | 
| -> m (f ByteString) | 
Echo the given string (http://redis.io/commands/echo). Since Redis 1.0.0
Ping the server (http://redis.io/commands/ping). Since Redis 1.0.0
Close the connection (http://redis.io/commands/quit). Since Redis 1.0.0
Change the selected database for the current connection (http://redis.io/commands/select). Since Redis 1.0.0
Keys
Delete a key (http://redis.io/commands/del). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f ByteString) | 
Return a serialized version of the value stored at the specified key (http://redis.io/commands/dump). Since Redis 2.6.0
Determine if a key exists (http://redis.io/commands/exists). Since Redis 1.0.0
Set a key's time to live in seconds (http://redis.io/commands/expire). Since Redis 1.0.0
Set the expiration for a key as a UNIX timestamp (http://redis.io/commands/expireat). Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | pattern | 
| -> m (f [ByteString]) | 
Find all keys matching the given pattern (http://redis.io/commands/keys). Since Redis 1.0.0
data MigrateOpts Source #
Options for the migrate command.
Constructors
| MigrateOpts | |
| Fields 
 | |
Instances
| Eq MigrateOpts Source # | |
| Defined in Database.Redis.ManualCommands | |
| Show MigrateOpts Source # | |
| Defined in Database.Redis.ManualCommands Methods showsPrec :: Int -> MigrateOpts -> ShowS # show :: MigrateOpts -> String # showList :: [MigrateOpts] -> ShowS # | |
defaultMigrateOpts :: MigrateOpts Source #
Redis default MigrateOpts. Equivalent to omitting all optional parameters.
MigrateOpts
    { migrateCopy    = False -- remove the key from the local instance
    , migrateReplace = False -- don't replace existing key on the remote instance
    }
Arguments
| :: RedisCtx m f | |
| => ByteString | host | 
| -> ByteString | port | 
| -> ByteString | key | 
| -> Integer | destinationDb | 
| -> Integer | timeout | 
| -> m (f Status) | 
Atomically transfer a key from a Redis instance to another one (http://redis.io/commands/migrate). The Redis command MIGRATE is split up into migrate, migrateMultiple. Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | host | 
| -> ByteString | port | 
| -> Integer | destinationDb | 
| -> Integer | timeout | 
| -> MigrateOpts | |
| -> [ByteString] | keys | 
| -> m (f Status) | 
Atomically transfer a key from a Redis instance to another one (http://redis.io/commands/migrate). The Redis command MIGRATE is split up into migrate, migrateMultiple. Since Redis 2.6.0
Move a key to another database (http://redis.io/commands/move). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f Integer) | 
Inspect the internals of Redis objects (http://redis.io/commands/object). The Redis command OBJECT is split up into objectRefcount, objectEncoding, objectIdletime. Since Redis 2.2.3
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f ByteString) | 
Inspect the internals of Redis objects (http://redis.io/commands/object). The Redis command OBJECT is split up into objectRefcount, objectEncoding, objectIdletime. Since Redis 2.2.3
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f Integer) | 
Inspect the internals of Redis objects (http://redis.io/commands/object). The Redis command OBJECT is split up into objectRefcount, objectEncoding, objectIdletime. Since Redis 2.2.3
Remove the expiration from a key (http://redis.io/commands/persist). Since Redis 2.2.0
Set a key's time to live in milliseconds (http://redis.io/commands/pexpire). Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | millisecondsTimestamp | 
| -> m (f Bool) | 
Set the expiration for a key as a UNIX timestamp specified in milliseconds (http://redis.io/commands/pexpireat). Since Redis 2.6.0
Get the time to live for a key in milliseconds (http://redis.io/commands/pttl). Since Redis 2.6.0
Return a random key from the keyspace (http://redis.io/commands/randomkey). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | newkey | 
| -> m (f Status) | 
Rename a key (http://redis.io/commands/rename). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | newkey | 
| -> m (f Bool) | 
Rename a key, only if the new key does not exist (http://redis.io/commands/renamenx). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | timeToLive | 
| -> ByteString | serializedValue | 
| -> m (f Status) | 
Create a key using the provided serialized value, previously obtained using DUMP (http://redis.io/commands/restore). The Redis command RESTORE is split up into restore, restoreReplace. Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | timeToLive | 
| -> ByteString | serializedValue | 
| -> m (f Status) | 
Create a key using the provided serialized value, previously obtained using DUMP (http://redis.io/commands/restore). The Redis command RESTORE is split up into restore, restoreReplace. Since Redis 2.6.0
defaultScanOpts :: ScanOpts Source #
Redis default ScanOpts. Equivalent to omitting all optional parameters.
ScanOpts
    { scanMatch = Nothing -- don't match any pattern
    , scanCount = Nothing -- don't set any requirements on number elements returned (works like value COUNT 10)
    }
Arguments
| :: RedisCtx m f | |
| => Cursor | |
| -> m (f (Cursor, [ByteString])) | next cursor and values | 
Incrementally iterate the keys space (http://redis.io/commands/scan). The Redis command SCAN is split up into scan, scanOpts. Since Redis 2.8.0
Arguments
| :: RedisCtx m f | |
| => Cursor | |
| -> ScanOpts | |
| -> m (f (Cursor, [ByteString])) | next cursor and values | 
Incrementally iterate the keys space (http://redis.io/commands/scan). The Redis command SCAN is split up into scan, scanOpts. Since Redis 2.8.0
Options for the sort command.
Constructors
| SortOpts | |
defaultSortOpts :: SortOpts Source #
Redis default SortOpts. Equivalent to omitting all optional parameters.
SortOpts
    { sortBy    = Nothing -- omit the BY option
    , sortLimit = (0,-1)  -- return entire collection
    , sortGet   = []      -- omit the GET option
    , sortOrder = Asc     -- sort in ascending order
    , sortAlpha = False   -- sort numerically, not lexicographically
    }
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> SortOpts | |
| -> m (f [ByteString]) | 
Sort the elements in a list, set or sorted set (http://redis.io/commands/sort). The Redis command SORT is split up into sort, sortStore. Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | destination | 
| -> SortOpts | |
| -> m (f Integer) | 
Sort the elements in a list, set or sorted set (http://redis.io/commands/sort). The Redis command SORT is split up into sort, sortStore. Since Redis 1.0.0
Get the time to live for a key (http://redis.io/commands/ttl). Since Redis 1.0.0
Determine the type stored at key (http://redis.io/commands/type). Since Redis 1.0.0
Wait for the synchronous replication of all the write commands sent in the context of the current connection (http://redis.io/commands/wait). Since Redis 3.0.0
Hashes
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [ByteString] | field | 
| -> m (f Integer) | 
Delete one or more hash fields (http://redis.io/commands/hdel). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | field | 
| -> m (f Bool) | 
Determine if a hash field exists (http://redis.io/commands/hexists). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | field | 
| -> m (f (Maybe ByteString)) | 
Get the value of a hash field (http://redis.io/commands/hget). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f [(ByteString, ByteString)]) | 
Get all the fields and values in a hash (http://redis.io/commands/hgetall). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | field | 
| -> Integer | increment | 
| -> m (f Integer) | 
Increment the integer value of a hash field by the given number (http://redis.io/commands/hincrby). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | field | 
| -> Double | increment | 
| -> m (f Double) | 
Increment the float value of a hash field by the given amount (http://redis.io/commands/hincrbyfloat). Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f [ByteString]) | 
Get all the fields in a hash (http://redis.io/commands/hkeys). Since Redis 2.0.0
Get the number of fields in a hash (http://redis.io/commands/hlen). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [ByteString] | field | 
| -> m (f [Maybe ByteString]) | 
Get the values of all the given hash fields (http://redis.io/commands/hmget). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [(ByteString, ByteString)] | fieldValue | 
| -> m (f Status) | 
Set multiple hash fields to multiple values (http://redis.io/commands/hmset). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Cursor | |
| -> m (f (Cursor, [(ByteString, ByteString)])) | next cursor and values | 
Incrementally iterate hash fields and associated values (http://redis.io/commands/hscan). The Redis command HSCAN is split up into hscan, hscanOpts. Since Redis 2.8.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Cursor | |
| -> ScanOpts | |
| -> m (f (Cursor, [(ByteString, ByteString)])) | next cursor and values | 
Incrementally iterate hash fields and associated values (http://redis.io/commands/hscan). The Redis command HSCAN is split up into hscan, hscanOpts. Since Redis 2.8.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | field | 
| -> ByteString | value | 
| -> m (f Bool) | 
Set the string value of a hash field (http://redis.io/commands/hset). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | field | 
| -> ByteString | value | 
| -> m (f Bool) | 
Set the value of a hash field, only if the field does not exist (http://redis.io/commands/hsetnx). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | field | 
| -> m (f Integer) | 
Get the length of the value of a hash field (http://redis.io/commands/hstrlen). Since Redis 3.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f [ByteString]) | 
Get all the values in a hash (http://redis.io/commands/hvals). Since Redis 2.0.0
HyperLogLogs
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [ByteString] | value | 
| -> m (f Integer) | 
Adds all the elements arguments to the HyperLogLog data structure stored at the variable name specified as first argument (http://redis.io/commands/pfadd). Since Redis 2.8.9
Return the approximated cardinality of the set(s) observed by the HyperLogLog at key(s) (http://redis.io/commands/pfcount). Since Redis 2.8.9
Arguments
| :: RedisCtx m f | |
| => ByteString | destkey | 
| -> [ByteString] | sourcekey | 
| -> m (f ByteString) | 
Merge N different HyperLogLogs into a single one (http://redis.io/commands/pfmerge). Since Redis 2.8.9
Lists
Arguments
| :: RedisCtx m f | |
| => [ByteString] | key | 
| -> Integer | timeout | 
| -> m (f (Maybe (ByteString, ByteString))) | 
Remove and get the first element in a list, or block until one is available (http://redis.io/commands/blpop). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => [ByteString] | key | 
| -> Integer | timeout | 
| -> m (f (Maybe (ByteString, ByteString))) | 
Remove and get the last element in a list, or block until one is available (http://redis.io/commands/brpop). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | source | 
| -> ByteString | destination | 
| -> Integer | timeout | 
| -> m (f (Maybe ByteString)) | 
Pop a value from a list, push it to another list and return it; or block until one is available (http://redis.io/commands/brpoplpush). Since Redis 2.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | index | 
| -> m (f (Maybe ByteString)) | 
Get an element from a list by its index (http://redis.io/commands/lindex). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | pivot | 
| -> ByteString | value | 
| -> m (f Integer) | 
Insert an element before or after another element in a list (http://redis.io/commands/linsert). The Redis command LINSERT is split up into linsertBefore, linsertAfter. Since Redis 2.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | pivot | 
| -> ByteString | value | 
| -> m (f Integer) | 
Insert an element before or after another element in a list (http://redis.io/commands/linsert). The Redis command LINSERT is split up into linsertBefore, linsertAfter. Since Redis 2.2.0
Get the length of a list (http://redis.io/commands/llen). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f (Maybe ByteString)) | 
Remove and get the first element in a list (http://redis.io/commands/lpop). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [ByteString] | value | 
| -> m (f Integer) | 
Prepend one or multiple values to a list (http://redis.io/commands/lpush). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | value | 
| -> m (f Integer) | 
Prepend a value to a list, only if the list exists (http://redis.io/commands/lpushx). Since Redis 2.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | start | 
| -> Integer | stop | 
| -> m (f [ByteString]) | 
Get a range of elements from a list (http://redis.io/commands/lrange). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | count | 
| -> ByteString | value | 
| -> m (f Integer) | 
Remove elements from a list (http://redis.io/commands/lrem). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | index | 
| -> ByteString | value | 
| -> m (f Status) | 
Set the value of an element in a list by its index (http://redis.io/commands/lset). Since Redis 1.0.0
Trim a list to the specified range (http://redis.io/commands/ltrim). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f (Maybe ByteString)) | 
Remove and get the last element in a list (http://redis.io/commands/rpop). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | source | 
| -> ByteString | destination | 
| -> m (f (Maybe ByteString)) | 
Remove the last element in a list, prepend it to another list and return it (http://redis.io/commands/rpoplpush). Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [ByteString] | value | 
| -> m (f Integer) | 
Append one or multiple values to a list (http://redis.io/commands/rpush). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | value | 
| -> m (f Integer) | 
Append a value to a list, only if the list exists (http://redis.io/commands/rpushx). Since Redis 2.2.0
Scripting
Arguments
| :: (RedisCtx m f, RedisResult a) | |
| => ByteString | script | 
| -> [ByteString] | keys | 
| -> [ByteString] | args | 
| -> m (f a) | 
Execute a Lua script server side (http://redis.io/commands/eval). Since Redis 2.6.0
Arguments
| :: (RedisCtx m f, RedisResult a) | |
| => ByteString | script | 
| -> [ByteString] | keys | 
| -> [ByteString] | args | 
| -> m (f a) | 
Execute a Lua script server side (http://redis.io/commands/evalsha). Since Redis 2.6.0
Set the debug mode for executed scripts (http://redis.io/commands/script-debug). Since Redis 3.2.0
Arguments
| :: RedisCtx m f | |
| => [ByteString] | script | 
| -> m (f [Bool]) | 
Check existence of scripts in the script cache (http://redis.io/commands/script-exists). Since Redis 2.6.0
scriptFlush :: RedisCtx m f => m (f Status) Source #
Remove all the scripts from the script cache (http://redis.io/commands/script-flush). Since Redis 2.6.0
scriptKill :: RedisCtx m f => m (f Status) Source #
Kill the script currently in execution (http://redis.io/commands/script-kill). Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | script | 
| -> m (f ByteString) | 
Load the specified Lua script into the script cache (http://redis.io/commands/script-load). Since Redis 2.6.0
Server
bgrewriteaof :: RedisCtx m f => m (f Status) Source #
Asynchronously rewrite the append-only file (http://redis.io/commands/bgrewriteaof). Since Redis 1.0.0
Asynchronously save the dataset to disk (http://redis.io/commands/bgsave). Since Redis 1.0.0
clientGetname :: RedisCtx m f => m (f Status) Source #
Get the current connection name (http://redis.io/commands/client-getname). Since Redis 2.6.9
clientList :: RedisCtx m f => m (f [ByteString]) Source #
Get the list of client connections (http://redis.io/commands/client-list). Since Redis 2.4.0
Stop processing commands from clients for some time (http://redis.io/commands/client-pause). Since Redis 2.9.50
Instruct the server whether to reply to commands (http://redis.io/commands/client-reply). Since Redis 3.2
Arguments
| :: RedisCtx m f | |
| => ByteString | connectionName | 
| -> m (f ByteString) | 
Set the current connection name (http://redis.io/commands/client-setname). Since Redis 2.6.9
commandCount :: RedisCtx m f => m (f Integer) Source #
Get total number of Redis commands (http://redis.io/commands/command-count). Since Redis 2.8.13
Arguments
| :: RedisCtx m f | |
| => [ByteString] | commandName | 
| -> m (f [ByteString]) | 
Get array of specific Redis command details (http://redis.io/commands/command-info). Since Redis 2.8.13
Arguments
| :: RedisCtx m f | |
| => ByteString | parameter | 
| -> m (f [(ByteString, ByteString)]) | 
Get the value of a configuration parameter (http://redis.io/commands/config-get). Since Redis 2.0.0
configResetstat :: RedisCtx m f => m (f Status) Source #
Reset the stats returned by INFO (http://redis.io/commands/config-resetstat). Since Redis 2.0.0
configRewrite :: RedisCtx m f => m (f Status) Source #
Rewrite the configuration file with the in memory configuration (http://redis.io/commands/config-rewrite). Since Redis 2.8.0
Arguments
| :: RedisCtx m f | |
| => ByteString | parameter | 
| -> ByteString | value | 
| -> m (f Status) | 
Set a configuration parameter to the given value (http://redis.io/commands/config-set). Since Redis 2.0.0
Return the number of keys in the selected database (http://redis.io/commands/dbsize). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f ByteString) | 
Get debugging information about a key (http://redis.io/commands/debug-object). Since Redis 1.0.0
Remove all keys from all databases (http://redis.io/commands/flushall). Since Redis 1.0.0
Remove all keys from the current database (http://redis.io/commands/flushdb). Since Redis 1.0.0
info :: RedisCtx m f => m (f ByteString) Source #
Get information and statistics about the server (http://redis.io/commands/info). The Redis command INFO is split up into info, infoSection. Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | section | 
| -> m (f ByteString) | 
Get information and statistics about the server (http://redis.io/commands/info). The Redis command INFO is split up into info, infoSection. Since Redis 1.0.0
Get the UNIX time stamp of the last successful save to disk (http://redis.io/commands/lastsave). Since Redis 1.0.0
Synchronously save the dataset to disk (http://redis.io/commands/save). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | host | 
| -> ByteString | port | 
| -> m (f Status) | 
Make the server a slave of another instance, or promote it as master (http://redis.io/commands/slaveof). Since Redis 1.0.0
A single entry from the slowlog.
Constructors
| Slowlog | |
| Fields 
 | |
Manages the Redis slow queries log (http://redis.io/commands/slowlog). The Redis command SLOWLOG is split up into slowlogGet, slowlogLen, slowlogReset. Since Redis 2.2.12
slowlogLen :: RedisCtx m f => m (f Integer) Source #
Manages the Redis slow queries log (http://redis.io/commands/slowlog). The Redis command SLOWLOG is split up into slowlogGet, slowlogLen, slowlogReset. Since Redis 2.2.12
slowlogReset :: RedisCtx m f => m (f Status) Source #
Manages the Redis slow queries log (http://redis.io/commands/slowlog). The Redis command SLOWLOG is split up into slowlogGet, slowlogLen, slowlogReset. Since Redis 2.2.12
Return the current server time (http://redis.io/commands/time). Since Redis 2.6.0
Sets
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [ByteString] | member | 
| -> m (f Integer) | 
Add one or more members to a set (http://redis.io/commands/sadd). Since Redis 1.0.0
Get the number of members in a set (http://redis.io/commands/scard). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => [ByteString] | key | 
| -> m (f [ByteString]) | 
Subtract multiple sets (http://redis.io/commands/sdiff). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destination | 
| -> [ByteString] | key | 
| -> m (f Integer) | 
Subtract multiple sets and store the resulting set in a key (http://redis.io/commands/sdiffstore). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => [ByteString] | key | 
| -> m (f [ByteString]) | 
Intersect multiple sets (http://redis.io/commands/sinter). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destination | 
| -> [ByteString] | key | 
| -> m (f Integer) | 
Intersect multiple sets and store the resulting set in a key (http://redis.io/commands/sinterstore). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | member | 
| -> m (f Bool) | 
Determine if a given value is a member of a set (http://redis.io/commands/sismember). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f [ByteString]) | 
Get all the members in a set (http://redis.io/commands/smembers). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | source | 
| -> ByteString | destination | 
| -> ByteString | member | 
| -> m (f Bool) | 
Move a member from one set to another (http://redis.io/commands/smove). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f (Maybe ByteString)) | 
Remove and return one or multiple random members from a set (http://redis.io/commands/spop). The Redis command SPOP is split up into spop, spopN. Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | count | 
| -> m (f [ByteString]) | 
Remove and return one or multiple random members from a set (http://redis.io/commands/spop). The Redis command SPOP is split up into spop, spopN. Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f (Maybe ByteString)) | 
Get one or multiple random members from a set (http://redis.io/commands/srandmember). The Redis command SRANDMEMBER is split up into srandmember, srandmemberN. Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | count | 
| -> m (f [ByteString]) | 
Get one or multiple random members from a set (http://redis.io/commands/srandmember). The Redis command SRANDMEMBER is split up into srandmember, srandmemberN. Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [ByteString] | member | 
| -> m (f Integer) | 
Remove one or more members from a set (http://redis.io/commands/srem). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Cursor | |
| -> m (f (Cursor, [ByteString])) | next cursor and values | 
Incrementally iterate Set elements (http://redis.io/commands/sscan). The Redis command SSCAN is split up into sscan, sscanOpts. Since Redis 2.8.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Cursor | |
| -> ScanOpts | |
| -> m (f (Cursor, [ByteString])) | next cursor and values | 
Incrementally iterate Set elements (http://redis.io/commands/sscan). The Redis command SSCAN is split up into sscan, sscanOpts. Since Redis 2.8.0
Arguments
| :: RedisCtx m f | |
| => [ByteString] | key | 
| -> m (f [ByteString]) | 
Add multiple sets (http://redis.io/commands/sunion). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destination | 
| -> [ByteString] | key | 
| -> m (f Integer) | 
Add multiple sets and store the resulting set in a key (http://redis.io/commands/sunionstore). Since Redis 1.0.0
Sorted Sets
Constructors
| ZaddOpts | |
| Fields 
 | |
defaultZaddOpts :: ZaddOpts Source #
Redis default ZaddOpts. Equivalent to omitting all optional parameters.
ZaddOpts
    { zaddCondition = Nothing -- omit NX and XX options
    , zaddChange    = False   -- don't modify the return value from the number of new elements added, to the total number of elements changed
    , zaddIncrement = False   -- don't add like ZINCRBY
    }
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [(Double, ByteString)] | scoreMember | 
| -> m (f Integer) | 
Add one or more members to a sorted set, or update its score if it already exists (http://redis.io/commands/zadd). The Redis command ZADD is split up into zadd, zaddOpts. Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [(Double, ByteString)] | scoreMember | 
| -> ZaddOpts | options | 
| -> m (f Integer) | 
Add one or more members to a sorted set, or update its score if it already exists (http://redis.io/commands/zadd). The Redis command ZADD is split up into zadd, zaddOpts. Since Redis 1.2.0
Get the number of members in a sorted set (http://redis.io/commands/zcard). Since Redis 1.2.0
Count the members in a sorted set with scores within the given values (http://redis.io/commands/zcount). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | increment | 
| -> ByteString | member | 
| -> m (f Double) | 
Increment the score of a member in a sorted set (http://redis.io/commands/zincrby). Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destination | 
| -> [ByteString] | keys | 
| -> Aggregate | |
| -> m (f Integer) | 
Intersect multiple sorted sets and store the resulting sorted set in a new key (http://redis.io/commands/zinterstore). The Redis command ZINTERSTORE is split up into zinterstore, zinterstoreWeights. Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destination | 
| -> [(ByteString, Double)] | weighted keys | 
| -> Aggregate | |
| -> m (f Integer) | 
Intersect multiple sorted sets and store the resulting sorted set in a new key (http://redis.io/commands/zinterstore). The Redis command ZINTERSTORE is split up into zinterstore, zinterstoreWeights. Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | min | 
| -> ByteString | max | 
| -> m (f Integer) | 
Count the number of members in a sorted set between a given lexicographical range (http://redis.io/commands/zlexcount). Since Redis 2.8.9
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | start | 
| -> Integer | stop | 
| -> m (f [ByteString]) | 
Return a range of members in a sorted set, by index (http://redis.io/commands/zrange). The Redis command ZRANGE is split up into zrange, zrangeWithscores. Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | start | 
| -> Integer | stop | 
| -> m (f [(ByteString, Double)]) | 
Return a range of members in a sorted set, by index (http://redis.io/commands/zrange). The Redis command ZRANGE is split up into zrange, zrangeWithscores. Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> RangeLex ByteString | min | 
| -> RangeLex ByteString | max | 
| -> m (f [ByteString]) | 
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> RangeLex ByteString | min | 
| -> RangeLex ByteString | max | 
| -> Integer | offset | 
| -> Integer | count | 
| -> m (f [ByteString]) | 
Return a range of members in a sorted set, by lexicographical range (http://redis.io/commands/zrangebylex). Since Redis 2.8.9
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | min | 
| -> Double | max | 
| -> m (f [ByteString]) | 
Return a range of members in a sorted set, by score (http://redis.io/commands/zrangebyscore). The Redis command ZRANGEBYSCORE is split up into zrangebyscore, zrangebyscoreWithscores, zrangebyscoreLimit, zrangebyscoreWithscoresLimit. Since Redis 1.0.5
zrangebyscoreWithscores Source #
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | min | 
| -> Double | max | 
| -> m (f [(ByteString, Double)]) | 
Return a range of members in a sorted set, by score (http://redis.io/commands/zrangebyscore). The Redis command ZRANGEBYSCORE is split up into zrangebyscore, zrangebyscoreWithscores, zrangebyscoreLimit, zrangebyscoreWithscoresLimit. Since Redis 1.0.5
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | min | 
| -> Double | max | 
| -> Integer | offset | 
| -> Integer | count | 
| -> m (f [ByteString]) | 
Return a range of members in a sorted set, by score (http://redis.io/commands/zrangebyscore). The Redis command ZRANGEBYSCORE is split up into zrangebyscore, zrangebyscoreWithscores, zrangebyscoreLimit, zrangebyscoreWithscoresLimit. Since Redis 1.0.5
zrangebyscoreWithscoresLimit Source #
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | min | 
| -> Double | max | 
| -> Integer | offset | 
| -> Integer | count | 
| -> m (f [(ByteString, Double)]) | 
Return a range of members in a sorted set, by score (http://redis.io/commands/zrangebyscore). The Redis command ZRANGEBYSCORE is split up into zrangebyscore, zrangebyscoreWithscores, zrangebyscoreLimit, zrangebyscoreWithscoresLimit. Since Redis 1.0.5
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | member | 
| -> m (f (Maybe Integer)) | 
Determine the index of a member in a sorted set (http://redis.io/commands/zrank). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> [ByteString] | member | 
| -> m (f Integer) | 
Remove one or more members from a sorted set (http://redis.io/commands/zrem). Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | min | 
| -> ByteString | max | 
| -> m (f Integer) | 
Remove all members in a sorted set between the given lexicographical range (http://redis.io/commands/zremrangebylex). Since Redis 2.8.9
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | start | 
| -> Integer | stop | 
| -> m (f Integer) | 
Remove all members in a sorted set within the given indexes (http://redis.io/commands/zremrangebyrank). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | min | 
| -> Double | max | 
| -> m (f Integer) | 
Remove all members in a sorted set within the given scores (http://redis.io/commands/zremrangebyscore). Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | start | 
| -> Integer | stop | 
| -> m (f [ByteString]) | 
Return a range of members in a sorted set, by index, with scores ordered from high to low (http://redis.io/commands/zrevrange). The Redis command ZREVRANGE is split up into zrevrange, zrevrangeWithscores. Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | start | 
| -> Integer | stop | 
| -> m (f [(ByteString, Double)]) | 
Return a range of members in a sorted set, by index, with scores ordered from high to low (http://redis.io/commands/zrevrange). The Redis command ZREVRANGE is split up into zrevrange, zrevrangeWithscores. Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | max | 
| -> Double | min | 
| -> m (f [ByteString]) | 
Return a range of members in a sorted set, by score, with scores ordered from high to low (http://redis.io/commands/zrevrangebyscore). The Redis command ZREVRANGEBYSCORE is split up into zrevrangebyscore, zrevrangebyscoreWithscores, zrevrangebyscoreLimit, zrevrangebyscoreWithscoresLimit. Since Redis 2.2.0
zrevrangebyscoreWithscores Source #
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | max | 
| -> Double | min | 
| -> m (f [(ByteString, Double)]) | 
Return a range of members in a sorted set, by score, with scores ordered from high to low (http://redis.io/commands/zrevrangebyscore). The Redis command ZREVRANGEBYSCORE is split up into zrevrangebyscore, zrevrangebyscoreWithscores, zrevrangebyscoreLimit, zrevrangebyscoreWithscoresLimit. Since Redis 2.2.0
zrevrangebyscoreLimit Source #
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | max | 
| -> Double | min | 
| -> Integer | offset | 
| -> Integer | count | 
| -> m (f [ByteString]) | 
Return a range of members in a sorted set, by score, with scores ordered from high to low (http://redis.io/commands/zrevrangebyscore). The Redis command ZREVRANGEBYSCORE is split up into zrevrangebyscore, zrevrangebyscoreWithscores, zrevrangebyscoreLimit, zrevrangebyscoreWithscoresLimit. Since Redis 2.2.0
zrevrangebyscoreWithscoresLimit Source #
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | max | 
| -> Double | min | 
| -> Integer | offset | 
| -> Integer | count | 
| -> m (f [(ByteString, Double)]) | 
Return a range of members in a sorted set, by score, with scores ordered from high to low (http://redis.io/commands/zrevrangebyscore). The Redis command ZREVRANGEBYSCORE is split up into zrevrangebyscore, zrevrangebyscoreWithscores, zrevrangebyscoreLimit, zrevrangebyscoreWithscoresLimit. Since Redis 2.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | member | 
| -> m (f (Maybe Integer)) | 
Determine the index of a member in a sorted set, with scores ordered from high to low (http://redis.io/commands/zrevrank). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Cursor | |
| -> m (f (Cursor, [(ByteString, Double)])) | next cursor and values | 
Incrementally iterate sorted sets elements and associated scores (http://redis.io/commands/zscan). The Redis command ZSCAN is split up into zscan, zscanOpts. Since Redis 2.8.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Cursor | |
| -> ScanOpts | |
| -> m (f (Cursor, [(ByteString, Double)])) | next cursor and values | 
Incrementally iterate sorted sets elements and associated scores (http://redis.io/commands/zscan). The Redis command ZSCAN is split up into zscan, zscanOpts. Since Redis 2.8.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | member | 
| -> m (f (Maybe Double)) | 
Get the score associated with the given member in a sorted set (http://redis.io/commands/zscore). Since Redis 1.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destination | 
| -> [ByteString] | keys | 
| -> Aggregate | |
| -> m (f Integer) | 
Add multiple sorted sets and store the resulting sorted set in a new key (http://redis.io/commands/zunionstore). The Redis command ZUNIONSTORE is split up into zunionstore, zunionstoreWeights. Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destination | 
| -> [(ByteString, Double)] | weighted keys | 
| -> Aggregate | |
| -> m (f Integer) | 
Add multiple sorted sets and store the resulting sorted set in a new key (http://redis.io/commands/zunionstore). The Redis command ZUNIONSTORE is split up into zunionstore, zunionstoreWeights. Since Redis 2.0.0
Strings
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | value | 
| -> m (f Integer) | 
Append a value to a key (http://redis.io/commands/append). Since Redis 2.0.0
Count set bits in a string (http://redis.io/commands/bitcount). The Redis command BITCOUNT is split up into bitcount, bitcountRange. Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | start | 
| -> Integer | end | 
| -> m (f Integer) | 
Count set bits in a string (http://redis.io/commands/bitcount). The Redis command BITCOUNT is split up into bitcount, bitcountRange. Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destkey | 
| -> [ByteString] | srckeys | 
| -> m (f Integer) | 
Perform bitwise operations between strings (http://redis.io/commands/bitop). The Redis command BITOP is split up into bitopAnd, bitopOr, bitopXor, bitopNot. Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destkey | 
| -> [ByteString] | srckeys | 
| -> m (f Integer) | 
Perform bitwise operations between strings (http://redis.io/commands/bitop). The Redis command BITOP is split up into bitopAnd, bitopOr, bitopXor, bitopNot. Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destkey | 
| -> [ByteString] | srckeys | 
| -> m (f Integer) | 
Perform bitwise operations between strings (http://redis.io/commands/bitop). The Redis command BITOP is split up into bitopAnd, bitopOr, bitopXor, bitopNot. Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | destkey | 
| -> ByteString | srckey | 
| -> m (f Integer) | 
Perform bitwise operations between strings (http://redis.io/commands/bitop). The Redis command BITOP is split up into bitopAnd, bitopOr, bitopXor, bitopNot. Since Redis 2.6.0
Find first bit set or clear in a string (http://redis.io/commands/bitpos). Since Redis 2.8.7
Decrement the integer value of a key by one (http://redis.io/commands/decr). Since Redis 1.0.0
Decrement the integer value of a key by the given number (http://redis.io/commands/decrby). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> m (f (Maybe ByteString)) | 
Get the value of a key (http://redis.io/commands/get). Since Redis 1.0.0
Returns the bit value at offset in the string value stored at key (http://redis.io/commands/getbit). Since Redis 2.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | start | 
| -> Integer | end | 
| -> m (f ByteString) | 
Get a substring of the string stored at a key (http://redis.io/commands/getrange). Since Redis 2.4.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | value | 
| -> m (f (Maybe ByteString)) | 
Set the string value of a key and return its old value (http://redis.io/commands/getset). Since Redis 1.0.0
Increment the integer value of a key by one (http://redis.io/commands/incr). Since Redis 1.0.0
Increment the integer value of a key by the given amount (http://redis.io/commands/incrby). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Double | increment | 
| -> m (f Double) | 
Increment the float value of a key by the given amount (http://redis.io/commands/incrbyfloat). Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => [ByteString] | key | 
| -> m (f [Maybe ByteString]) | 
Get the values of all the given keys (http://redis.io/commands/mget). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => [(ByteString, ByteString)] | keyValue | 
| -> m (f Status) | 
Set multiple keys to multiple values (http://redis.io/commands/mset). Since Redis 1.0.1
Arguments
| :: RedisCtx m f | |
| => [(ByteString, ByteString)] | keyValue | 
| -> m (f Bool) | 
Set multiple keys to multiple values, only if none of the keys exist (http://redis.io/commands/msetnx). Since Redis 1.0.1
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | milliseconds | 
| -> ByteString | value | 
| -> m (f Status) | 
Set the value and expiration in milliseconds of a key (http://redis.io/commands/psetex). Since Redis 2.6.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | value | 
| -> m (f Status) | 
Set the string value of a key (http://redis.io/commands/set). The Redis command SET is split up into set, setOpts. Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | value | 
| -> SetOpts | |
| -> m (f Status) | 
Set the string value of a key (http://redis.io/commands/set). The Redis command SET is split up into set, setOpts. Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | offset | 
| -> ByteString | value | 
| -> m (f Integer) | 
Sets or clears the bit at offset in the string value stored at key (http://redis.io/commands/setbit). Since Redis 2.2.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | seconds | 
| -> ByteString | value | 
| -> m (f Status) | 
Set the value and expiration of a key (http://redis.io/commands/setex). Since Redis 2.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | value | 
| -> m (f Bool) | 
Set the value of a key, only if the key does not exist (http://redis.io/commands/setnx). Since Redis 1.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> Integer | offset | 
| -> ByteString | value | 
| -> m (f Integer) | 
Overwrite part of a string at key starting at the specified offset (http://redis.io/commands/setrange). Since Redis 2.2.0
Get the length of the value stored in a key (http://redis.io/commands/strlen). Since Redis 2.2.0
Streams
defaultXreadOpts :: XReadOpts Source #
Redis default XReadOpts. Equivalent to omitting all optional parameters.
XReadOpts
    { block = Nothing -- Don't block waiting for more records
    , recordCount    = Nothing   -- no record count
    }
data XReadResponse Source #
Constructors
| XReadResponse | |
| Fields 
 | |
Instances
| Eq XReadResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods (==) :: XReadResponse -> XReadResponse -> Bool # (/=) :: XReadResponse -> XReadResponse -> Bool # | |
| Show XReadResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods showsPrec :: Int -> XReadResponse -> ShowS # show :: XReadResponse -> String # showList :: [XReadResponse] -> ShowS # | |
| RedisResult XReadResponse Source # | |
| Defined in Database.Redis.ManualCommands | |
data StreamsRecord Source #
Constructors
| StreamsRecord | |
| Fields 
 | |
Instances
| Eq StreamsRecord Source # | |
| Defined in Database.Redis.ManualCommands Methods (==) :: StreamsRecord -> StreamsRecord -> Bool # (/=) :: StreamsRecord -> StreamsRecord -> Bool # | |
| Show StreamsRecord Source # | |
| Defined in Database.Redis.ManualCommands Methods showsPrec :: Int -> StreamsRecord -> ShowS # show :: StreamsRecord -> String # showList :: [StreamsRecord] -> ShowS # | |
| RedisResult StreamsRecord Source # | |
| Defined in Database.Redis.ManualCommands | |
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | id | 
| -> [(ByteString, ByteString)] | (field, value) | 
| -> m (f ByteString) | 
Add a value to a stream (https://redis.io/commands/xadd). Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | key | 
| -> ByteString | id | 
| -> [(ByteString, ByteString)] | (field, value) | 
| -> TrimOpts | |
| -> m (f ByteString) | 
Add a value to a stream (https://redis.io/commands/xadd). The Redis command XADD is split up into xadd, xaddOpts. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => [(ByteString, ByteString)] | (stream, id) pairs | 
| -> m (f (Maybe [XReadResponse])) | 
Read values from a stream (https://redis.io/commands/xread). The Redis command XREAD is split up into xread, xreadOpts. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => [(ByteString, ByteString)] | (stream, id) pairs | 
| -> XReadOpts | Options | 
| -> m (f (Maybe [XReadResponse])) | 
Read values from a stream (https://redis.io/commands/xread). The Redis command XREAD is split up into xread, xreadOpts. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | group name | 
| -> ByteString | consumer name | 
| -> [(ByteString, ByteString)] | (stream, id) pairs | 
| -> m (f (Maybe [XReadResponse])) | 
Read values from a stream as part of a consumer group (https:/redis.iocommands/xreadgroup). The redis command XREADGROUP is split up into xreadGroup and xreadGroupOpts. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | group name | 
| -> ByteString | consumer name | 
| -> [(ByteString, ByteString)] | (stream, id) pairs | 
| -> XReadOpts | Options | 
| -> m (f (Maybe [XReadResponse])) | 
Read values from a stream as part of a consumer group (https:/redis.iocommands/xreadgroup). The redis command XREADGROUP is split up into xreadGroup and xreadGroupOpts. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group name | 
| -> [ByteString] | message IDs | 
| -> m (f Integer) | 
Acknowledge receipt of a message as part of a consumer group. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group name | 
| -> ByteString | start ID | 
| -> m (f Status) | 
Create a consumer group. The redis command XGROUP is split up into xgroupCreate, xgroupSetId, xgroupDestroy, and xgroupDelConsumer. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group | 
| -> ByteString | id | 
| -> m (f Status) | 
Set the id for a consumer group. The redis command XGROUP is split up into xgroupCreate, xgroupSetId, xgroupDestroy, and xgroupDelConsumer. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group | 
| -> m (f Bool) | 
Destroy a consumer group. The redis command XGROUP is split up into xgroupCreate, xgroupSetId, xgroupDestroy, and xgroupDelConsumer. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group | 
| -> ByteString | consumer | 
| -> m (f Integer) | 
Delete a consumer. The redis command XGROUP is split up into xgroupCreate, xgroupSetId, xgroupDestroy, and xgroupDelConsumer. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | start | 
| -> ByteString | end | 
| -> Maybe Integer | COUNT | 
| -> m (f [StreamsRecord]) | 
Read values from a stream within a range (https:/redis.iocommands/xrange). Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | end | 
| -> ByteString | start | 
| -> Maybe Integer | COUNT | 
| -> m (f [StreamsRecord]) | 
Read values from a stream within a range in reverse order (https:/redis.iocommands/xrevrange). Since Redis 5.0.0
Get the number of entries in a stream (https:/redis.iocommands/xlen). Since Redis 5.0.0
data XPendingSummaryResponse Source #
Constructors
| XPendingSummaryResponse | |
Instances
| Eq XPendingSummaryResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods (==) :: XPendingSummaryResponse -> XPendingSummaryResponse -> Bool # (/=) :: XPendingSummaryResponse -> XPendingSummaryResponse -> Bool # | |
| Show XPendingSummaryResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods showsPrec :: Int -> XPendingSummaryResponse -> ShowS # show :: XPendingSummaryResponse -> String # showList :: [XPendingSummaryResponse] -> ShowS # | |
| RedisResult XPendingSummaryResponse Source # | |
| Defined in Database.Redis.ManualCommands | |
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group | 
| -> Maybe ByteString | consumer | 
| -> m (f XPendingSummaryResponse) | 
Get information about pending messages (https:/redis.iocommands/xpending). The Redis XPENDING command is split into xpendingSummary and xpendingDetail. Since Redis 5.0.0
data XPendingDetailRecord Source #
Constructors
| XPendingDetailRecord | |
| Fields | |
Instances
| Eq XPendingDetailRecord Source # | |
| Defined in Database.Redis.ManualCommands Methods (==) :: XPendingDetailRecord -> XPendingDetailRecord -> Bool # (/=) :: XPendingDetailRecord -> XPendingDetailRecord -> Bool # | |
| Show XPendingDetailRecord Source # | |
| Defined in Database.Redis.ManualCommands Methods showsPrec :: Int -> XPendingDetailRecord -> ShowS # show :: XPendingDetailRecord -> String # showList :: [XPendingDetailRecord] -> ShowS # | |
| RedisResult XPendingDetailRecord Source # | |
| Defined in Database.Redis.ManualCommands | |
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group | 
| -> ByteString | startId | 
| -> ByteString | endId | 
| -> Integer | count | 
| -> Maybe ByteString | consumer | 
| -> m (f [XPendingDetailRecord]) | 
Get detailed information about pending messages (https:/redis.iocommands/xpending). The Redis XPENDING command is split into xpendingSummary and xpendingDetail. Since Redis 5.0.0
data XClaimOpts Source #
Constructors
| XClaimOpts | |
| Fields 
 | |
Instances
| Eq XClaimOpts Source # | |
| Defined in Database.Redis.ManualCommands | |
| Show XClaimOpts Source # | |
| Defined in Database.Redis.ManualCommands Methods showsPrec :: Int -> XClaimOpts -> ShowS # show :: XClaimOpts -> String # showList :: [XClaimOpts] -> ShowS # | |
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group | 
| -> ByteString | consumer | 
| -> Integer | min idle time | 
| -> XClaimOpts | optional arguments | 
| -> [ByteString] | message IDs | 
| -> m (f [StreamsRecord]) | 
Change ownership of some messages to the given consumer, returning the updated messages. The Redis XCLAIM command is split into xclaim and xclaimJustIds. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group | 
| -> ByteString | consumer | 
| -> Integer | min idle time | 
| -> XClaimOpts | optional arguments | 
| -> [ByteString] | message IDs | 
| -> m (f [ByteString]) | 
Change ownership of some messages to the given consumer, returning only the changed message IDs. The Redis XCLAIM command is split into xclaim and xclaimJustIds. Since Redis 5.0.0
data XInfoConsumersResponse Source #
Constructors
| XInfoConsumersResponse | |
Instances
| Eq XInfoConsumersResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods (==) :: XInfoConsumersResponse -> XInfoConsumersResponse -> Bool # (/=) :: XInfoConsumersResponse -> XInfoConsumersResponse -> Bool # | |
| Show XInfoConsumersResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods showsPrec :: Int -> XInfoConsumersResponse -> ShowS # show :: XInfoConsumersResponse -> String # showList :: [XInfoConsumersResponse] -> ShowS # | |
| RedisResult XInfoConsumersResponse Source # | |
| Defined in Database.Redis.ManualCommands | |
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> ByteString | group | 
| -> m (f [XInfoConsumersResponse]) | 
Get info about consumers in a group. The Redis command XINFO is split into xinfoConsumers, xinfoGroups, and xinfoStream. Since Redis 5.0.0
data XInfoGroupsResponse Source #
Constructors
| XInfoGroupsResponse | |
Instances
| Eq XInfoGroupsResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods (==) :: XInfoGroupsResponse -> XInfoGroupsResponse -> Bool # (/=) :: XInfoGroupsResponse -> XInfoGroupsResponse -> Bool # | |
| Show XInfoGroupsResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods showsPrec :: Int -> XInfoGroupsResponse -> ShowS # show :: XInfoGroupsResponse -> String # showList :: [XInfoGroupsResponse] -> ShowS # | |
| RedisResult XInfoGroupsResponse Source # | |
| Defined in Database.Redis.ManualCommands | |
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> m (f [XInfoGroupsResponse]) | 
Get info about groups consuming from a stream. The Redis command XINFO is split into xinfoConsumers, xinfoGroups, and xinfoStream. Since Redis 5.0.0
data XInfoStreamResponse Source #
Constructors
| XInfoStreamResponse | |
Instances
| Eq XInfoStreamResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods (==) :: XInfoStreamResponse -> XInfoStreamResponse -> Bool # (/=) :: XInfoStreamResponse -> XInfoStreamResponse -> Bool # | |
| Show XInfoStreamResponse Source # | |
| Defined in Database.Redis.ManualCommands Methods showsPrec :: Int -> XInfoStreamResponse -> ShowS # show :: XInfoStreamResponse -> String # showList :: [XInfoStreamResponse] -> ShowS # | |
| RedisResult XInfoStreamResponse Source # | |
| Defined in Database.Redis.ManualCommands | |
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> m (f XInfoStreamResponse) | 
Get info about a stream. The Redis command XINFO is split into xinfoConsumers, xinfoGroups, and xinfoStream. Since Redis 5.0.0
Arguments
| :: RedisCtx m f | |
| => ByteString | stream | 
| -> [ByteString] | message IDs | 
| -> m (f Integer) | 
Delete messages from a stream. Since Redis 5.0.0
Set the upper bound for number of messages in a stream. Since Redis 5.0.0
Constructor for inf Redis argument values
Unimplemented Commands
These commands are not implemented, as of now. Library
  users can implement these or other commands from
  experimental Redis versions by using the sendRequest
  function.
- COMMAND (http://redis.io/commands/command)
- COMMAND GETKEYS (http://redis.io/commands/command-getkeys)
- ROLE (http://redis.io/commands/role)
- CLIENT KILL (http://redis.io/commands/client-kill)
- ZREVRANGEBYLEX (http://redis.io/commands/zrevrangebylex)
- ZRANGEBYSCORE (http://redis.io/commands/zrangebyscore)
- ZREVRANGEBYSCORE (http://redis.io/commands/zrevrangebyscore)
- MONITOR (http://redis.io/commands/monitor)
- SYNC (http://redis.io/commands/sync)
- SHUTDOWN (http://redis.io/commands/shutdown)
- DEBUG SEGFAULT (http://redis.io/commands/debug-segfault)
Transactions
Arguments
| :: [ByteString] | key | 
| -> Redis (Either Reply Status) | 
Watch the given keys to determine execution of the MULTI/EXEC block (http://redis.io/commands/watch).
unwatch :: Redis (Either Reply Status) Source #
Forget about all watched keys (http://redis.io/commands/unwatch).
multiExec :: RedisTx (Queued a) -> Redis (TxResult a) Source #
Run commands inside a transaction. For documentation on the semantics of Redis transaction see http://redis.io/topics/transactions.
Inside the transaction block, command functions return their result wrapped
  in a Queued. The Queued result is a proxy object for the actual
  command's result, which will only be available after EXECing the
  transaction.
Example usage (note how Queued 's Applicative instance is used to
  combine the two individual results):
 runRedis conn $ do
     set "hello" "hello"
     set "world" "world"
     helloworld <- multiExec $ do
         hello <- get "hello"
         world <- get "world"
         return $ (,) <$> hello <*> world
     liftIO (print helloworld)
 A Queued value represents the result of a command inside a transaction. It
  is a proxy object for the actual result, which will only be available
  after returning from a multiExec transaction.
Queued values are composable by utilizing the Functor, Applicative or
  Monad interfaces.
Result of a multiExec transaction.
Constructors
| TxSuccess a | Transaction completed successfully. The wrapped value corresponds to
   the  | 
| TxAborted | Transaction aborted due to an earlier  | 
| TxError String | At least one of the commands returned an  | 
Instances
| Eq a => Eq (TxResult a) Source # | |
| Show a => Show (TxResult a) Source # | |
| Generic (TxResult a) Source # | |
| NFData a => NFData (TxResult a) Source # | |
| Defined in Database.Redis.Transactions | |
| type Rep (TxResult a) Source # | |
| Defined in Database.Redis.Transactions type Rep (TxResult a) = D1 (MetaData "TxResult" "Database.Redis.Transactions" "hedis-0.12.14-Ffs9V6h6CgJ4apyzivQRa1" False) (C1 (MetaCons "TxSuccess" PrefixI False) (S1 (MetaSel (Nothing :: Maybe Symbol) NoSourceUnpackedness NoSourceStrictness DecidedLazy) (Rec0 a)) :+: (C1 (MetaCons "TxAborted" PrefixI False) (U1 :: Type -> Type) :+: C1 (MetaCons "TxError" PrefixI False) (S1 (MetaSel (Nothing :: Maybe Symbol) NoSourceUnpackedness NoSourceStrictness DecidedLazy) (Rec0 String)))) | |
Command-context inside of MULTI/EXEC transactions. Use multiExec to run
  actions of this type.
In the RedisTx context, all commands return a Queued value. It is a
  proxy object for the actual result, which will only be available after
  finishing the transaction.
Instances
| Monad RedisTx Source # | |
| Functor RedisTx Source # | |
| Applicative RedisTx Source # | |
| MonadIO RedisTx Source # | |
| Defined in Database.Redis.Transactions | |
| MonadRedis RedisTx Source # | |
| RedisCtx RedisTx Queued Source # | |
| Defined in Database.Redis.Transactions Methods returnDecode :: RedisResult a => Reply -> RedisTx (Queued a) Source # | |
Pub/Sub
Arguments
| :: RedisCtx m f | |
| => ByteString | channel | 
| -> ByteString | message | 
| -> m (f Integer) | 
Post a message to a channel (http://redis.io/commands/publish).
Subscribing to channels
There are two Pub/Sub implementations.  First, there is a single-threaded implementation pubSub
 which is simpler to use but has the restriction that subscription changes can only be made in
 response to a message.  Secondly, there is a more complicated Pub/Sub controller pubSubForever
 that uses concurrency to support changing subscriptions at any time but requires more setup.
 You should only use one or the other.  In addition, no types or utility functions (that are part
 of the public API) are shared, so functions or types in one of the following sections cannot
 be used for the other.  In particular, be aware that they use different utility functions to subscribe
 and unsubscribe to channels.
Single-thread Pub/Sub
Listens to published messages on subscribed channels and channels matching the subscribed patterns. For documentation on the semantics of Redis Pub/Sub see http://redis.io/topics/pubsub.
The given callback function is called for each received message. 
  Subscription changes are triggered by the returned PubSub. To keep
  subscriptions unchanged, the callback can return mempty.
Example: Subscribe to the "news" channel indefinitely.
 pubSub (subscribe ["news"]) $ \msg -> do
     putStrLn $ "Message from " ++ show (msgChannel msg)
     return mempty
 Example: Receive a single message from the "chat" channel.
 pubSub (subscribe ["chat"]) $ \msg -> do
     putStrLn $ "Message from " ++ show (msgChannel msg)
     return $ unsubscribe ["chat"]
 It should be noted that Redis Pub/Sub by its nature is asynchronous
 so returning unsubscribe does not mean that callback won't be able
 to receive any further messages. And to guarantee that you won't
 won't process messages after unsubscription and won't unsubscribe
 from the same channel more than once you need to use IORef or
 something similar
Encapsulates subscription changes. Use subscribe, unsubscribe,
  psubscribe, punsubscribe or mempty to construct a value. Combine
  values by using the Monoid interface, i.e. mappend and mconcat.
Arguments
| :: [ByteString] | channel | 
| -> PubSub | 
Listen for messages published to the given channels (http://redis.io/commands/subscribe).
Arguments
| :: [ByteString] | channel | 
| -> PubSub | 
Stop listening for messages posted to the given channels (http://redis.io/commands/unsubscribe).
Arguments
| :: [ByteString] | pattern | 
| -> PubSub | 
Listen for messages published to channels matching the given patterns (http://redis.io/commands/psubscribe).
Arguments
| :: [ByteString] | pattern | 
| -> PubSub | 
Stop listening for messages posted to channels matching the given patterns (http://redis.io/commands/punsubscribe).
Continuous Pub/Sub message controller
Arguments
| :: Connection | The connection pool | 
| -> PubSubController | The controller which keeps track of all subscriptions and handlers | 
| -> IO () | This action is executed once Redis acknowledges that all the subscriptions in
 the controller are now subscribed.  You can use this after an exception (such as
  | 
| -> IO () | 
Open a connection to the Redis server, register to all channels in the PubSubController,
 and process messages and subscription change requests forever.  The only way this will ever
 exit is if there is an exception from the network code or an unhandled exception
 in a MessageCallback or PMessageCallback. For example, if the network connection to Redis
 dies, pubSubForever will throw a ConnectionLost.  When such an exception is
 thrown, you can recall pubSubForever with the same PubSubController which will open a
 new connection and resubscribe to all the channels which are tracked in the PubSubController.
The general pattern is therefore during program startup create a PubSubController and fork
 a thread which calls pubSubForever in a loop (using an exponential backoff algorithm
 such as the retry package to not hammer the Redis
 server if it does die).  For example,
myhandler :: ByteString -> IO ()
myhandler msg = putStrLn $ unpack $ decodeUtf8 msg
onInitialComplete :: IO ()
onInitialComplete = putStrLn "Redis acknowledged that mychannel is now subscribed"
main :: IO ()
main = do
  conn <- connect defaultConnectInfo
  pubSubCtrl <- newPubSubController [("mychannel", myhandler)] []
  forkIO $ forever $
      pubSubForever conn pubSubCtrl onInitialComplete
        `catch` (\(e :: SomeException) -> do
          putStrLn $ "Got error: " ++ show e
          threadDelay $ 50*1000) -- TODO: use exponential backoff
  {- elsewhere in your program, use pubSubCtrl to change subscriptions -}
At most one active pubSubForever can be running against a single PubSubController at any time.  If
 two active calls to pubSubForever share a single PubSubController there will be deadlocks.  If
 you do want to process messages using multiple connections to Redis, you can create more than one
 PubSubController.  For example, create one PubSubController for each getNumCapabilities
 and then create a Haskell thread bound to each capability each calling pubSubForever in a loop.
 This will create one network connection per controller/capability and allow you to
 register separate channels and callbacks for each controller, spreading the load across the capabilities.
type RedisChannel = ByteString Source #
A Redis channel name
type RedisPChannel = ByteString Source #
A Redis pattern channel name
type MessageCallback = ByteString -> IO () Source #
A handler for a message from a subscribed channel. The callback is passed the message content.
Messages are processed synchronously in the receiving thread, so if the callback
 takes a long time it will block other callbacks and other messages from being
 received.  If you need to move long-running work to a different thread, we suggest
 you use TBQueue with a reasonable bound, so that if messages are arriving faster
 than you can process them, you do eventually block.
If the callback throws an exception, the exception will be thrown from pubSubForever
 which will cause the entire Redis connection for all subscriptions to be closed.
 As long as you call pubSubForever in a loop you will reconnect to your subscribed
 channels, but you should probably add an exception handler to each callback to
 prevent this.
type PMessageCallback = RedisChannel -> ByteString -> IO () Source #
A handler for a message from a psubscribed channel. The callback is passed the channel the message was sent on plus the message content.
Similar to MessageCallback, callbacks are executed synchronously and any exceptions
 are rethrown from pubSubForever.
data PubSubController Source #
A controller that stores a set of channels, pattern channels, and callbacks.
 It allows you to manage Pub/Sub subscriptions and pattern subscriptions and alter them at
 any time throughout the life of your program.
 You should typically create the controller at the start of your program and then store it
 through the life of your program, using addChannels and removeChannels to update the
 current subscriptions.
Arguments
| :: MonadIO m | |
| => [(RedisChannel, MessageCallback)] | the initial subscriptions | 
| -> [(RedisPChannel, PMessageCallback)] | the initial pattern subscriptions | 
| -> m PubSubController | 
Create a new PubSubController.  Note that this does not subscribe to any channels, it just
 creates the controller.  The subscriptions will happen once pubSubForever is called.
currentChannels :: MonadIO m => PubSubController -> m [RedisChannel] Source #
Get the list of current channels in the PubSubController.  WARNING! This might not
 exactly reflect the subscribed channels in the Redis server, because there is a delay
 between adding or removing a channel in the PubSubController and when Redis receives
 and processes the subscription change request.
currentPChannels :: MonadIO m => PubSubController -> m [RedisPChannel] Source #
Get the list of current pattern channels in the PubSubController.  WARNING! This might not
 exactly reflect the subscribed channels in the Redis server, because there is a delay
 between adding or removing a channel in the PubSubController and when Redis receives
 and processes the subscription change request.
Arguments
| :: MonadIO m | |
| => PubSubController | |
| -> [(RedisChannel, MessageCallback)] | the channels to subscribe to | 
| -> [(RedisPChannel, PMessageCallback)] | the channels to pattern subscribe to | 
| -> m UnregisterCallbacksAction | 
Add channels into the PubSubController, and if there is an active pubSubForever, send the subscribe
 and psubscribe commands to Redis.  The addChannels function is thread-safe.  This function
 does not wait for Redis to acknowledge that the channels have actually been subscribed; use
 addChannelsAndWait for that.
You can subscribe to the same channel or pattern channel multiple times; the PubSubController keeps
 a list of callbacks and executes each callback in response to a message.
The return value is an action UnregisterCallbacksAction which will unregister the callbacks,
 which should typically used with bracket.
Arguments
| :: MonadIO m | |
| => PubSubController | |
| -> [(RedisChannel, MessageCallback)] | the channels to subscribe to | 
| -> [(RedisPChannel, PMessageCallback)] | the channels to psubscribe to | 
| -> m UnregisterCallbacksAction | 
Call addChannels and then wait for Redis to acknowledge that the channels are actually subscribed.
Note that this function waits for all pending subscription change requests, so if you for example call
 addChannelsAndWait from multiple threads simultaneously, they all will wait for all pending
 subscription changes to be acknowledged by Redis (this is due to the fact that we just track the total
 number of pending change requests sent to Redis and just wait until that count reaches zero).
This also correctly waits if the network connection dies during the subscription change.  Say that the
 network connection dies right after we send a subscription change to Redis.  pubSubForever will throw
 ConnectionLost and addChannelsAndWait will continue to wait.  Once you recall pubSubForever
 with the same PubSubController, pubSubForever will open a new connection, send subscription commands
 for all channels in the PubSubController (which include the ones we are waiting for),
 and wait for the responses from Redis.  Only once we receive the response from Redis that it has subscribed
 to all channels in PubSubController will addChannelsAndWait unblock and return.
removeChannels :: MonadIO m => PubSubController -> [RedisChannel] -> [RedisPChannel] -> m () Source #
Remove channels from the PubSubController, and if there is an active pubSubForever, send the
 unsubscribe commands to Redis.  Note that as soon as this function returns, no more callbacks will be
 executed even if more messages arrive during the period when we request to unsubscribe from the channel
 and Redis actually processes the unsubscribe request.  This function is thread-safe.
If you remove all channels, the connection in pubSubForever to redis will stay open and waiting for
 any new channels from a call to addChannels.  If you really want to close the connection,
 use killThread or cancel to kill the thread running
 pubSubForever.
removeChannelsAndWait :: MonadIO m => PubSubController -> [RedisChannel] -> [RedisPChannel] -> m () Source #
Call removeChannels and then wait for all pending subscription change requests to be acknowledged
 by Redis.  This uses the same waiting logic as addChannelsAndWait.  Since removeChannels immediately
 notifies the PubSubController to start discarding messages, you likely don't need this function and
 can just use removeChannels.
type UnregisterCallbacksAction = IO () Source #
An action that when executed will unregister the callbacks.  It is returned from addChannels
 or addChannelsAndWait and typically you would use it in bracket to guarantee that you
 unsubscribe from channels.  For example, if you are using websockets to distribute messages to
 clients, you could use something such as:
websocketConn <- Network.WebSockets.acceptRequest pending
let mycallback msg = Network.WebSockets.sendTextData websocketConn msg
bracket (addChannelsAndWait ctrl [("hello", mycallback)] []) id $ const $ do
  {- loop here calling Network.WebSockets.receiveData -}Low-Level Command API
sendRequest :: (RedisCtx m f, RedisResult a) => [ByteString] -> m (f a) Source #
sendRequest can be used to implement commands from experimental
  versions of Redis. An example of how to implement a command is given
  below.
-- |Redis DEBUG OBJECT command debugObject :: ByteString ->Redis(EitherReplyByteString) debugObject key =sendRequest["DEBUG", "OBJECT", key]
Low-level representation of replies from the Redis server.
Constructors
| SingleLine ByteString | |
| Error ByteString | |
| Integer Integer | |
| Bulk (Maybe ByteString) | |
| MultiBulk (Maybe [Reply]) | 
Instances
Constructors
| Ok | |
| Pong | |
| Status ByteString | 
Instances
| Eq Status Source # | |
| Show Status Source # | |
| Generic Status Source # | |
| NFData Status Source # | |
| Defined in Database.Redis.Types | |
| RedisResult Status Source # | |
| type Rep Status Source # | |
| Defined in Database.Redis.Types type Rep Status = D1 (MetaData "Status" "Database.Redis.Types" "hedis-0.12.14-Ffs9V6h6CgJ4apyzivQRa1" False) (C1 (MetaCons "Ok" PrefixI False) (U1 :: Type -> Type) :+: (C1 (MetaCons "Pong" PrefixI False) (U1 :: Type -> Type) :+: C1 (MetaCons "Status" PrefixI False) (S1 (MetaSel (Nothing :: Maybe Symbol) NoSourceUnpackedness NoSourceStrictness DecidedLazy) (Rec0 ByteString)))) | |
class RedisResult a where Source #
Instances
data ConnectionLostException Source #
Constructors
| ConnectionLost | 
Instances
| Show ConnectionLostException Source # | |
| Defined in Database.Redis.ProtocolPipelining Methods showsPrec :: Int -> ConnectionLostException -> ShowS # show :: ConnectionLostException -> String # showList :: [ConnectionLostException] -> ShowS # | |
| Exception ConnectionLostException Source # | |
| Defined in Database.Redis.ProtocolPipelining | |
data ConnectTimeout Source #
Constructors
| ConnectTimeout ConnectPhase | 
Instances
| Show ConnectTimeout Source # | |
| Defined in Database.Redis.ProtocolPipelining Methods showsPrec :: Int -> ConnectTimeout -> ShowS # show :: ConnectTimeout -> String # showList :: [ConnectTimeout] -> ShowS # | |
| Exception ConnectTimeout Source # | |
| Defined in Database.Redis.ProtocolPipelining Methods toException :: ConnectTimeout -> SomeException # | |