Documentation ¶
Overview ¶
Package rueidis is a fast Golang Redis RESP3 client that does auto pipelining and supports client side caching.
Index ¶
- Constants
- Variables
- func BinaryString(bs []byte) string
- func IsRedisNil(err error) bool
- func JSON(in any) string
- func JsonMGetCache(client Client, ctx context.Context, ttl time.Duration, keys []string, ...) (ret map[string]RedisMessage, err error)
- func MGetCache(client Client, ctx context.Context, ttl time.Duration, keys []string) (ret map[string]RedisMessage, err error)
- type CacheableTTL
- type Client
- type ClientOption
- type Commands
- type DedicatedClient
- type Lua
- type LuaExec
- type PubSubHooks
- type PubSubMessage
- type PubSubSubscription
- type RedirectMode
- type RedisError
- type RedisMessage
- func (m *RedisMessage) AsBool() (val bool, err error)
- func (m *RedisMessage) AsFloat64() (val float64, err error)
- func (m *RedisMessage) AsFloatSlice() ([]float64, error)
- func (m *RedisMessage) AsInt64() (val int64, err error)
- func (m *RedisMessage) AsIntMap() (map[string]int64, error)
- func (m *RedisMessage) AsIntSlice() ([]int64, error)
- func (m *RedisMessage) AsMap() (map[string]RedisMessage, error)
- func (m *RedisMessage) AsReader() (reader io.Reader, err error)
- func (m *RedisMessage) AsStrMap() (map[string]string, error)
- func (m *RedisMessage) AsStrSlice() ([]string, error)
- func (m *RedisMessage) AsXRange() ([]XRangeEntry, error)
- func (m *RedisMessage) AsXRangeEntry() (XRangeEntry, error)
- func (m *RedisMessage) AsXRead() (ret map[string][]XRangeEntry, err error)
- func (m *RedisMessage) AsZScore() (s ZScore, err error)
- func (m *RedisMessage) AsZScores() ([]ZScore, error)
- func (m *RedisMessage) DecodeJSON(v interface{}) (err error)
- func (m *RedisMessage) Error() error
- func (m *RedisMessage) IsArray() bool
- func (m *RedisMessage) IsBool() bool
- func (m *RedisMessage) IsCacheHit() bool
- func (m *RedisMessage) IsFloat64() bool
- func (m *RedisMessage) IsInt64() bool
- func (m *RedisMessage) IsMap() bool
- func (m *RedisMessage) IsNil() bool
- func (m *RedisMessage) IsString() bool
- func (m *RedisMessage) ToAny() (interface{}, error)
- func (m *RedisMessage) ToArray() ([]RedisMessage, error)
- func (m *RedisMessage) ToBool() (val bool, err error)
- func (m *RedisMessage) ToFloat64() (val float64, err error)
- func (m *RedisMessage) ToInt64() (val int64, err error)
- func (m *RedisMessage) ToMap() (map[string]RedisMessage, error)
- func (m *RedisMessage) ToString() (val string, err error)
- type RedisResult
- func (r RedisResult) AsBool() (bool, error)
- func (r RedisResult) AsFloat64() (float64, error)
- func (r RedisResult) AsFloatSlice() ([]float64, error)
- func (r RedisResult) AsInt64() (int64, error)
- func (r RedisResult) AsIntMap() (map[string]int64, error)
- func (r RedisResult) AsIntSlice() ([]int64, error)
- func (r RedisResult) AsMap() (map[string]RedisMessage, error)
- func (r RedisResult) AsReader() (reader io.Reader, err error)
- func (r RedisResult) AsStrMap() (map[string]string, error)
- func (r RedisResult) AsStrSlice() ([]string, error)
- func (r RedisResult) AsXRange() ([]XRangeEntry, error)
- func (r RedisResult) AsXRangeEntry() (XRangeEntry, error)
- func (r RedisResult) AsXRead() (map[string][]XRangeEntry, error)
- func (r RedisResult) AsZScore() (ZScore, error)
- func (r RedisResult) AsZScores() ([]ZScore, error)
- func (r RedisResult) DecodeJSON(v interface{}) error
- func (r RedisResult) Error() error
- func (r RedisResult) IsCacheHit() bool
- func (r RedisResult) NonRedisError() error
- func (r RedisResult) RedisError() *RedisError
- func (r RedisResult) ToAny() (interface{}, error)
- func (r RedisResult) ToArray() ([]RedisMessage, error)
- func (r RedisResult) ToBool() (bool, error)
- func (r RedisResult) ToFloat64() (float64, error)
- func (r RedisResult) ToInt64() (int64, error)
- func (r RedisResult) ToMap() (map[string]RedisMessage, error)
- func (r RedisResult) ToMessage() (RedisMessage, error)
- func (r RedisResult) ToString() (string, error)
- type SentinelOption
- type XRangeEntry
- type ZScore
Examples ¶
Constants ¶
const ( // DefaultCacheBytes is the default value of ClientOption.CacheSizeEachConn, which is 128 MiB DefaultCacheBytes = 128 * (1 << 20) // DefaultRingScale is the default value of ClientOption.RingScaleEachConn, which results into having a ring of size 2^10 for each connection DefaultRingScale = 10 // DefaultPoolSize is the default value of ClientOption.BlockingPoolSize DefaultPoolSize = 1000 // DefaultDialTimeout is the default value of ClientOption.Dialer.Timeout DefaultDialTimeout = 5 * time.Second // DefaultTCPKeepAlive is the default value of ClientOption.Dialer.KeepAlive DefaultTCPKeepAlive = 1 * time.Second // DefaultReadBuffer is the default value of bufio.NewReaderSize for each connection, which is 0.5MiB DefaultReadBuffer = 1 << 19 // DefaultWriteBuffer is the default value of bufio.NewWriterSize for each connection, which is 0.5MiB DefaultWriteBuffer = 1 << 19 )
Variables ¶
var ( // ErrClosing means the Client.Close had been called ErrClosing = errors.New("rueidis client is closing or unable to connect redis") // ErrNoAddr means the ClientOption.InitAddress is empty ErrNoAddr = errors.New("no alive address in InitAddress") // ErrNoCache means your redis does not support client-side caching and must set ClientOption.DisableCache to true ErrNoCache = errors.New("ClientOption.DisableCache must be true for redis not supporting client-side caching or not supporting RESP3") // ErrRESP2PubSubMixed means your redis does not support RESP3 and rueidis can't handle SUBSCRIBE/PSUBSCRIBE/SSUBSCRIBE in mixed case ErrRESP2PubSubMixed = errors.New("rueidis does not support SUBSCRIBE/PSUBSCRIBE/SSUBSCRIBE mixed with other commands in RESP2") )
var ErrNoSlot = errors.New("the slot has no redis node")
ErrNoSlot indicates that there is no redis node owns the key slot.
Functions ¶
func BinaryString ¶
BinaryString convert the provided []byte into a string without copy. It does what strings.Builder.String() does. Redis Strings are binary safe, this means that it is safe to store any []byte into Redis directly. Users can use this BinaryString helper to insert a []byte as the part of redis command. For example:
client.B().Set().Key(rueidis.BinaryString([]byte{0})).Value(rueidis.BinaryString([]byte{0})).Build()
To read back the []byte of the string returned from the Redis, it is recommended to use the RedisMessage.AsReader.
func IsRedisNil ¶
IsRedisNil is a handy method to check if error is redis nil response. All redis nil response returns as an error.
Example ¶
client, err := NewClient(ClientOption{InitAddress: []string{"127.0.0.1:6379"}}) if err != nil { panic(err) } defer client.Close() _, err = client.Do(context.Background(), client.B().Get().Key("not_exists").Build()).ToString() if err != nil && IsRedisNil(err) { fmt.Printf("it is a nil response") }
Output:
func JSON ¶
JSON convert the provided parameter into a JSON string. Users can use this JSON helper to work with RedisJSON commands. For example:
client.B().JsonSet().Key("a").Path("$.myField").Value(rueidis.JSON("str")).Build()
Types ¶
type CacheableTTL ¶
CacheableTTL is parameter container of DoMultiCache
type Client ¶
type Client interface { // B is the getter function to the command builder for the client // If the client is a cluster client, the command builder also prohibits cross key slots in one command. B() cmds.Builder // Do is the method sending user's redis command building from the B() to a redis node. // client.Do(ctx, client.B().Get().Key("k").Build()).ToString() // All concurrent non-blocking commands will be pipelined automatically and have better throughput. // Blocking commands will use another separated connection pool. // The cmd parameter is recycled after passing into Do() and should not be reused. Do(ctx context.Context, cmd cmds.Completed) (resp RedisResult) // DoMulti takes multiple redis commands and sends them together, reducing RTT from the user code. // The multi parameters are recycled after passing into DoMulti() and should not be reused. DoMulti(ctx context.Context, multi ...cmds.Completed) (resp []RedisResult) // DoCache is similar to Do, but it uses opt-in client side caching and requires a client side TTL. // The explicit client side TTL specifies the maximum TTL on the client side. // If the key's TTL on the server is smaller than the client side TTL, the client side TTL will be capped. // client.Do(ctx, client.B().Get().Key("k").Cache(), time.Minute).ToString() // The above example will send the following command to redis if cache miss: // CLIENT CACHING YES // PTTL k // GET k // The in-memory cache size is configured by ClientOption.CacheSizeEachConn. // The cmd parameter is recycled after passing into DoCache() and should not be reused. DoCache(ctx context.Context, cmd cmds.Cacheable, ttl time.Duration) (resp RedisResult) // DoMultiCache is similar to DoCache, but works with multiple cacheable commands across different slots. // It will first group commands by slots and will send only cache missed commands to redis. DoMultiCache(ctx context.Context, multi ...CacheableTTL) (resp []RedisResult) // Receive accepts SUBSCRIBE, SSUBSCRIBE, PSUBSCRIBE command and a message handler. // Receive will block and then return value only when the following cases: // 1. return nil when received any unsubscribe/punsubscribe message related to the provided `subscribe` command. // 2. return ErrClosing when the client is closed manually. // 3. return ctx.Err() when the `ctx` is done. // 4. return non-nil err when the provided `subscribe` command failed. Receive(ctx context.Context, subscribe cmds.Completed, fn func(msg PubSubMessage)) error // Dedicated acquire a connection from the blocking connection pool, no one else can use the connection // during Dedicated. The main usage of Dedicated is CAS operation, which is WATCH + MULTI + EXEC. // However, one should try to avoid CAS operation but use Lua script instead, because occupying a connection // is not good for performance. Dedicated(fn func(DedicatedClient) error) (err error) // Dedicate does the same as Dedicated, but it exposes DedicatedClient directly // and requires user to invoke cancel() manually to put connection back to the pool. Dedicate() (client DedicatedClient, cancel func()) // Nodes returns each redis node this client known as rueidis.Client. This is useful if you want to // send commands to some specific redis nodes in the cluster. Nodes() map[string]Client // Close will make further calls to the client be rejected with ErrClosing, // and Close will wait until all pending calls finished. Close() }
Client is the redis client interface for both single redis instance and redis cluster. It should be created from the NewClient()
Example (DedicateCAS) ¶
client, err := NewClient(ClientOption{InitAddress: []string{"127.0.0.1:6379"}}) if err != nil { panic(err) } defer client.Close() c, cancel := client.Dedicate() defer cancel() ctx := context.Background() // watch keys first if err := c.Do(ctx, c.B().Watch().Key("k1", "k2").Build()).Error(); err != nil { panic(err) } // perform read here values, err := c.Do(ctx, c.B().Mget().Key("k1", "k2").Build()).ToArray() if err != nil { panic(err) } v1, _ := values[0].ToString() v2, _ := values[1].ToString() // perform write with MULTI EXEC for _, resp := range c.DoMulti( ctx, c.B().Multi().Build(), c.B().Set().Key("k1").Value(v1+"1").Build(), c.B().Set().Key("k2").Value(v2+"2").Build(), c.B().Exec().Build(), ) { if err := resp.Error(); err != nil { panic(err) } }
Output:
Example (DedicatedCAS) ¶
client, err := NewClient(ClientOption{InitAddress: []string{"127.0.0.1:6379"}}) if err != nil { panic(err) } defer client.Close() ctx := context.Background() client.Dedicated(func(client DedicatedClient) error { // watch keys first if err := client.Do(ctx, client.B().Watch().Key("k1", "k2").Build()).Error(); err != nil { return err } // perform read here values, err := client.Do(ctx, client.B().Mget().Key("k1", "k2").Build()).ToArray() if err != nil { return err } v1, _ := values[0].ToString() v2, _ := values[1].ToString() // perform write with MULTI EXEC for _, resp := range client.DoMulti( ctx, client.B().Multi().Build(), client.B().Set().Key("k1").Value(v1+"1").Build(), client.B().Set().Key("k2").Value(v2+"2").Build(), client.B().Exec().Build(), ) { if err := resp.Error(); err != nil { return err } } return nil })
Output:
Example (Do) ¶
client, err := NewClient(ClientOption{InitAddress: []string{"127.0.0.1:6379"}}) if err != nil { panic(err) } defer client.Close() ctx := context.Background() client.Do(ctx, client.B().Set().Key("k").Value("1").Build()).Error() client.Do(ctx, client.B().Get().Key("k").Build()).ToString() client.Do(ctx, client.B().Get().Key("k").Build()).AsInt64() client.Do(ctx, client.B().Hmget().Key("h").Field("a", "b").Build()).ToArray() client.Do(ctx, client.B().Scard().Key("s").Build()).ToInt64() client.Do(ctx, client.B().Smembers().Key("s").Build()).AsStrSlice()
Output:
Example (DoCache) ¶
client, err := NewClient(ClientOption{InitAddress: []string{"127.0.0.1:6379"}}) if err != nil { panic(err) } defer client.Close() ctx := context.Background() client.DoCache(ctx, client.B().Get().Key("k").Cache(), time.Minute).ToString() client.DoCache(ctx, client.B().Get().Key("k").Cache(), time.Minute).AsInt64() client.DoCache(ctx, client.B().Hmget().Key("h").Field("a", "b").Cache(), time.Minute).ToArray() client.DoCache(ctx, client.B().Scard().Key("s").Cache(), time.Minute).ToInt64() client.DoCache(ctx, client.B().Smembers().Key("s").Cache(), time.Minute).AsStrSlice()
Output:
func NewClient ¶
func NewClient(option ClientOption) (client Client, err error)
NewClient uses ClientOption to initialize the Client for both cluster client and single client. It will first try to connect as cluster client. If the len(ClientOption.InitAddress) == 1 and the address does not enable cluster mode, the NewClient() will use single client instead.
Example (Cluster) ¶
client, _ := NewClient(ClientOption{ InitAddress: []string{"127.0.0.1:7001", "127.0.0.1:7002", "127.0.0.1:7003"}, ShuffleInit: true, }) defer client.Close()
Output:
Example (Sentinel) ¶
client, _ := NewClient(ClientOption{ InitAddress: []string{"127.0.0.1:26379", "127.0.0.1:26380", "127.0.0.1:26381"}, Sentinel: SentinelOption{ MasterSet: "my_master", }, }) defer client.Close()
Output:
Example (Single) ¶
client, _ := NewClient(ClientOption{ InitAddress: []string{"127.0.0.1:6379"}, }) defer client.Close()
Output:
type ClientOption ¶
type ClientOption struct { // TCP & TLS // Dialer can be used to customized how rueidis connect to a redis instance via TCP, including: // - Timeout, the default is DefaultDialTimeout // - KeepAlive, the default is DefaultTCPKeepAlive // The Dialer.KeepAlive interval is used to detect an unresponsive idle tcp connection. // OS takes at least (tcp_keepalive_probes+1)*Dialer.KeepAlive time to conclude an idle connection to be unresponsive. // For example: DefaultTCPKeepAlive = 1s and the default of tcp_keepalive_probes on Linux is 9. // Therefore, it takes at least 10s to kill an idle and unresponsive tcp connection on Linux by default. Dialer net.Dialer TLSConfig *tls.Config // Sentinel options, including MasterSet and Auth options Sentinel SentinelOption // Redis AUTH parameters Username string Password string ClientName string // InitAddress point to redis nodes. // Rueidis will connect to them one by one and issue CLUSTER SLOT command to initialize the cluster client until success. // If len(InitAddress) == 1 and the address is not running in cluster mode, rueidis will fall back to the single client mode. // If ClientOption.Sentinel.MasterSet is set, then InitAddress will be used to connect sentinels InitAddress []string SelectDB int // CacheSizeEachConn is redis client side cache size that bind to each TCP connection to a single redis instance. // The default is DefaultCacheBytes. CacheSizeEachConn int // RingScaleEachConn sets the size of the ring buffer in each connection to (2 ^ RingScaleEachConn). // The default is RingScaleEachConn, which results into having a ring of size 2^10 for each connection. // Reduce this value can reduce the memory consumption of each connection at the cost of potential throughput degradation. // Values smaller than 8 is typically not recommended. RingScaleEachConn int // ReadBufferEachConn is the size of the bufio.NewReaderSize for each connection, default to DefaultReadBuffer (0.5 MiB). ReadBufferEachConn int // WriteBufferEachConn is the size of the bufio.NewWriterSize for each connection, default to DefaultWriteBuffer (0.5 MiB). WriteBufferEachConn int // BlockingPoolSize is the size of the connection pool shared by blocking commands (ex BLPOP, XREAD with BLOCK). // The default is DefaultPoolSize. BlockingPoolSize int // PipelineMultiplex determines how many tcp connections used to pipeline commands to one redis instance. // The default for single and sentinel clients is 2, which means 4 connections (2^2). // The default for cluster client is 0, which means 1 connection (2^0). PipelineMultiplex int // ConnWriteTimeout is applied net.Conn.SetWriteDeadline and periodic PING to redis // Since the Dialer.KeepAlive will not be triggered if there is data in the outgoing buffer, // ConnWriteTimeout should be set in order to detect local congestion or unresponsive redis server. // This default is ClientOption.Dialer.KeepAlive * (9+1), where 9 is the default of tcp_keepalive_probes on Linux. ConnWriteTimeout time.Duration // ShuffleInit is a handy flag that shuffles the InitAddress after passing to the NewClient() if it is true ShuffleInit bool // DisableRetry disables retrying read-only commands under network errors DisableRetry bool // DisableCache falls back Client.DoCache/Client.DoMultiCache to Client.Do/Client.DoMulti DisableCache bool // OnInvalidations is a callback function in case of client-side caching invalidation received. // Note that this function must be fast, otherwise other redis messages will be blocked. OnInvalidations func([]RedisMessage) // ClientTrackingOptions will be appended to CLIENT TRACKING ON command when the connection is established. // The default is []string{"OPTIN"} ClientTrackingOptions []string }
ClientOption should be passed to NewClient to construct a Client
type Commands ¶
Commands is an exported alias to []cmds.Completed. This allows users to store commands for later usage, for example:
c, release := client.Dedicate() defer release() cmds := make(rueidis.Commands, 0, 10) for i := 0; i < 10; i++ { cmds = append(cmds, c.B().Set().Key(strconv.Itoa(i)).Value(strconv.Itoa(i)).Build()) } for _, resp := range c.DoMulti(ctx, cmds...) { if err := resp.Error(); err != nil { panic(err) }
However, please know that once commands are processed by the Do() or DoMulti(), they are recycled and should not be reused.
type DedicatedClient ¶
type DedicatedClient interface { // B is inherited from the Client B() cmds.Builder // Do is the same as Client's // The cmd parameter is recycled after passing into Do() and should not be reused. Do(ctx context.Context, cmd cmds.Completed) (resp RedisResult) // DoMulti takes multiple redis commands and sends them together, reducing RTT from the user code. // The multi parameters are recycled after passing into DoMulti() and should not be reused. DoMulti(ctx context.Context, multi ...cmds.Completed) (resp []RedisResult) // Receive is the same as Client's Receive(ctx context.Context, subscribe cmds.Completed, fn func(msg PubSubMessage)) error // SetPubSubHooks is an alternative way to processing Pub/Sub messages instead of using Receive. // SetPubSubHooks is non-blocking and allows users to subscribe/unsubscribe channels later. // Note that the hooks will be called sequentially but in another goroutine. // The return value will be either: // 1. an error channel, if the hooks passed in is not zero, or // 2. nil, if the hooks passed in is zero. (used for reset hooks) // In the former case, the error channel is guaranteed to be close when the hooks will not be called anymore, // and has at most one error describing the reason why the hooks will not be called anymore. // Users can use the error channel to detect disconnection. SetPubSubHooks(hooks PubSubHooks) <-chan error // Close closes the dedicated connection and prevent the connection be put back into the pool. Close() }
DedicatedClient is obtained from Client.Dedicated() and it will be bound to single redis connection and no other commands can be pipelined in to this connection during Client.Dedicated(). If the DedicatedClient is obtained from cluster client, the first command to it must have a Key() to identify the redis node.
type Lua ¶
type Lua struct {
// contains filtered or unexported fields
}
Lua represents a redis lua script. It should be created from the NewLuaScript() or NewLuaScriptReadOnly()
Example (Exec) ¶
client, err := NewClient(ClientOption{InitAddress: []string{"127.0.0.1:6379"}}) if err != nil { panic(err) } defer client.Close() ctx := context.Background() script := NewLuaScript("return {KEYS[1],KEYS[2],ARGV[1],ARGV[2]}") script.Exec(ctx, client, []string{"k1", "k2"}, []string{"a1", "a2"}).ToArray()
Output:
func NewLuaScript ¶
NewLuaScript creates a Lua instance whose Lua.Exec uses EVALSHA and EVAL.
func NewLuaScriptReadOnly ¶
NewLuaScriptReadOnly creates a Lua instance whose Lua.Exec uses EVALSHA_RO and EVAL_RO.
func (*Lua) Exec ¶
Exec the script to the given Client. It will first try with the EVALSHA/EVALSHA_RO and then EVAL/EVAL_RO if first try failed. Cross slot keys are prohibited if the Client is a cluster client.
func (*Lua) ExecMulti ¶
ExecMulti exec the script multiple times by the provided LuaExec to the given Client. It will first try SCRIPT LOAD the script to all redis nodes and then exec it with the EVALSHA/EVALSHA_RO. Cross slot keys within single LuaExec are prohibited if the Client is a cluster client.
type PubSubHooks ¶
type PubSubHooks struct { // OnMessage will be called when receiving "message" and "pmessage" event. OnMessage func(m PubSubMessage) // OnSubscription will be called when receiving "subscribe", "unsubscribe", "psubscribe" and "punsubscribe" event. OnSubscription func(s PubSubSubscription) }
PubSubHooks can be registered into DedicatedClient to process pubsub messages without using Client.Receive
type PubSubMessage ¶
type PubSubMessage struct { // Pattern is only available with pmessage. Pattern string // Channel is the channel the message belongs to Channel string // Message is the message content Message string }
PubSubMessage represent a pubsub message from redis
type PubSubSubscription ¶
type PubSubSubscription struct { // Kind is "subscribe", "unsubscribe", "psubscribe" or "punsubscribe" Kind string // Channel is the event subject. Channel string // Count is the current number of subscriptions for connection. Count int64 }
PubSubSubscription represent a pubsub "subscribe", "unsubscribe", "psubscribe" or "punsubscribe" event.
type RedirectMode ¶
type RedirectMode int
const ( RedirectNone RedirectMode = iota RedirectMove RedirectAsk RedirectRetry )
type RedisError ¶
type RedisError RedisMessage
RedisError is an error response or a nil message from redis instance
func (*RedisError) Error ¶
func (r *RedisError) Error() string
func (*RedisError) IsAsk ¶
func (r *RedisError) IsAsk() (addr string, ok bool)
IsAsk checks if it is a redis ASK message and returns ask address.
func (*RedisError) IsClusterDown ¶
func (r *RedisError) IsClusterDown() bool
IsClusterDown checks if it is a redis CLUSTERDOWN message and returns ask address.
func (*RedisError) IsMoved ¶
func (r *RedisError) IsMoved() (addr string, ok bool)
IsMoved checks if it is a redis MOVED message and returns moved address.
func (*RedisError) IsNil ¶
func (r *RedisError) IsNil() bool
IsNil checks if it is a redis nil message.
func (*RedisError) IsNoScript ¶
func (r *RedisError) IsNoScript() bool
IsNoScript checks if it is a redis NOSCRIPT message.
func (*RedisError) IsTryAgain ¶
func (r *RedisError) IsTryAgain() bool
IsTryAgain checks if it is a redis TRYAGAIN message and returns ask address.
type RedisMessage ¶
type RedisMessage struct {
// contains filtered or unexported fields
}
RedisMessage is a redis response message, it may be a nil response
func (*RedisMessage) AsBool ¶
func (m *RedisMessage) AsBool() (val bool, err error)
AsBool checks if message is non-nil redis response, and parses it as bool
func (*RedisMessage) AsFloat64 ¶
func (m *RedisMessage) AsFloat64() (val float64, err error)
AsFloat64 check if message is a redis string response, and parse it as float64
func (*RedisMessage) AsFloatSlice ¶
func (m *RedisMessage) AsFloatSlice() ([]float64, error)
AsFloatSlice check if message is a redis array/set response, and convert to []float64. redis nil element and other non float element will be present as zero.
func (*RedisMessage) AsInt64 ¶
func (m *RedisMessage) AsInt64() (val int64, err error)
AsInt64 check if message is a redis string response, and parse it as int64
func (*RedisMessage) AsIntMap ¶
func (m *RedisMessage) AsIntMap() (map[string]int64, error)
AsIntMap check if message is a redis map/array/set response, and convert to map[string]int64. redis nil element and other non integer element will be present as zero.
func (*RedisMessage) AsIntSlice ¶
func (m *RedisMessage) AsIntSlice() ([]int64, error)
AsIntSlice check if message is a redis array/set response, and convert to []int64. redis nil element and other non integer element will be present as zero.
func (*RedisMessage) AsMap ¶
func (m *RedisMessage) AsMap() (map[string]RedisMessage, error)
AsMap check if message is a redis array/set response, and convert to map[string]RedisMessage
func (*RedisMessage) AsReader ¶
func (m *RedisMessage) AsReader() (reader io.Reader, err error)
AsReader check if message is a redis string response and wrap it with the strings.NewReader
func (*RedisMessage) AsStrMap ¶
func (m *RedisMessage) AsStrMap() (map[string]string, error)
AsStrMap check if message is a redis map/array/set response, and convert to map[string]string. redis nil element and other non string element will be present as zero.
func (*RedisMessage) AsStrSlice ¶
func (m *RedisMessage) AsStrSlice() ([]string, error)
AsStrSlice check if message is a redis array/set response, and convert to []string. redis nil element and other non string element will be present as zero.
func (*RedisMessage) AsXRange ¶
func (m *RedisMessage) AsXRange() ([]XRangeEntry, error)
AsXRange check if message is a redis array/set response, and convert to []XRangeEntry
func (*RedisMessage) AsXRangeEntry ¶
func (m *RedisMessage) AsXRangeEntry() (XRangeEntry, error)
AsXRangeEntry check if message is a redis array/set response of length 2, and convert to XRangeEntry
func (*RedisMessage) AsXRead ¶
func (m *RedisMessage) AsXRead() (ret map[string][]XRangeEntry, err error)
AsXRead converts XREAD/XREADGRUOP response to map[string][]XRangeEntry
func (*RedisMessage) AsZScore ¶
func (m *RedisMessage) AsZScore() (s ZScore, err error)
AsZScore converts ZPOPMAX and ZPOPMIN command with count 1 response to a single ZScore
func (*RedisMessage) AsZScores ¶
func (m *RedisMessage) AsZScores() ([]ZScore, error)
AsZScores converts ZRANGE WITHSCROES, ZDIFF WITHSCROES and ZPOPMAX/ZPOPMIN command with count > 1 responses to []ZScore
func (*RedisMessage) DecodeJSON ¶
func (m *RedisMessage) DecodeJSON(v interface{}) (err error)
DecodeJSON check if message is a redis string response and treat it as json, then unmarshal it into provided value
func (*RedisMessage) Error ¶
func (m *RedisMessage) Error() error
Error check if message is a redis error response, including nil response
func (*RedisMessage) IsArray ¶
func (m *RedisMessage) IsArray() bool
IsArray check if message is a redis array response
func (*RedisMessage) IsBool ¶
func (m *RedisMessage) IsBool() bool
IsBool check if message is a redis RESP3 bool response
func (*RedisMessage) IsCacheHit ¶
func (m *RedisMessage) IsCacheHit() bool
IsCacheHit check if message is from client side cache
func (*RedisMessage) IsFloat64 ¶
func (m *RedisMessage) IsFloat64() bool
IsFloat64 check if message is a redis RESP3 double response
func (*RedisMessage) IsInt64 ¶
func (m *RedisMessage) IsInt64() bool
IsInt64 check if message is a redis RESP3 int response
func (*RedisMessage) IsMap ¶
func (m *RedisMessage) IsMap() bool
IsMap check if message is a redis RESP3 map response
func (*RedisMessage) IsNil ¶
func (m *RedisMessage) IsNil() bool
IsNil check if message is a redis nil response
func (*RedisMessage) IsString ¶
func (m *RedisMessage) IsString() bool
IsString check if message is a redis string response
func (*RedisMessage) ToAny ¶
func (m *RedisMessage) ToAny() (interface{}, error)
ToAny turns message into go interface{} value
func (*RedisMessage) ToArray ¶
func (m *RedisMessage) ToArray() ([]RedisMessage, error)
ToArray check if message is a redis array/set response, and return it
func (*RedisMessage) ToBool ¶
func (m *RedisMessage) ToBool() (val bool, err error)
ToBool check if message is a redis RESP3 bool response, and return it
func (*RedisMessage) ToFloat64 ¶
func (m *RedisMessage) ToFloat64() (val float64, err error)
ToFloat64 check if message is a redis RESP3 double response, and return it
func (*RedisMessage) ToInt64 ¶
func (m *RedisMessage) ToInt64() (val int64, err error)
ToInt64 check if message is a redis RESP3 int response, and return it
func (*RedisMessage) ToMap ¶
func (m *RedisMessage) ToMap() (map[string]RedisMessage, error)
ToMap check if message is a redis RESP3 map response, and return it
func (*RedisMessage) ToString ¶
func (m *RedisMessage) ToString() (val string, err error)
ToString check if message is a redis string response, and return it
type RedisResult ¶
type RedisResult struct {
// contains filtered or unexported fields
}
RedisResult is the return struct from Client.Do or Client.DoCache it contains either a redis response or an underlying error (ex. network timeout).
func (RedisResult) AsBool ¶
func (r RedisResult) AsBool() (bool, error)
AsBool delegates to RedisMessage.AsBool
func (RedisResult) AsFloat64 ¶
func (r RedisResult) AsFloat64() (float64, error)
AsFloat64 delegates to RedisMessage.AsFloat64
func (RedisResult) AsFloatSlice ¶
func (r RedisResult) AsFloatSlice() ([]float64, error)
AsFloatSlice delegates to RedisMessage.AsFloatSlice
func (RedisResult) AsInt64 ¶
func (r RedisResult) AsInt64() (int64, error)
AsInt64 delegates to RedisMessage.AsInt64
func (RedisResult) AsIntMap ¶
func (r RedisResult) AsIntMap() (map[string]int64, error)
AsIntMap delegates to RedisMessage.AsIntMap
func (RedisResult) AsIntSlice ¶
func (r RedisResult) AsIntSlice() ([]int64, error)
AsIntSlice delegates to RedisMessage.AsIntSlice
func (RedisResult) AsMap ¶
func (r RedisResult) AsMap() (map[string]RedisMessage, error)
AsMap delegates to RedisMessage.AsMap
func (RedisResult) AsReader ¶
func (r RedisResult) AsReader() (reader io.Reader, err error)
AsReader delegates to RedisMessage.AsReader
func (RedisResult) AsStrMap ¶
func (r RedisResult) AsStrMap() (map[string]string, error)
AsStrMap delegates to RedisMessage.AsStrMap
func (RedisResult) AsStrSlice ¶
func (r RedisResult) AsStrSlice() ([]string, error)
AsStrSlice delegates to RedisMessage.AsStrSlice
func (RedisResult) AsXRange ¶
func (r RedisResult) AsXRange() ([]XRangeEntry, error)
AsXRange delegates to RedisMessage.AsXRange
func (RedisResult) AsXRangeEntry ¶
func (r RedisResult) AsXRangeEntry() (XRangeEntry, error)
AsXRangeEntry delegates to RedisMessage.AsXRangeEntry
func (RedisResult) AsXRead ¶
func (r RedisResult) AsXRead() (map[string][]XRangeEntry, error)
AsXRead delegates to RedisMessage.AsXRead
func (RedisResult) AsZScore ¶
func (r RedisResult) AsZScore() (ZScore, error)
AsZScore delegates to RedisMessage.AsZScore
func (RedisResult) AsZScores ¶
func (r RedisResult) AsZScores() ([]ZScore, error)
AsZScores delegates to RedisMessage.AsZScores
func (RedisResult) DecodeJSON ¶
func (r RedisResult) DecodeJSON(v interface{}) error
DecodeJSON delegates to RedisMessage.DecodeJSON
func (RedisResult) Error ¶
func (r RedisResult) Error() error
Error returns either underlying error or redis error or nil
func (RedisResult) IsCacheHit ¶
func (r RedisResult) IsCacheHit() bool
IsCacheHit delegates to RedisMessage.IsCacheHit
func (RedisResult) NonRedisError ¶
func (r RedisResult) NonRedisError() error
NonRedisError can be used to check if there is an underlying error (ex. network timeout).
func (RedisResult) RedisError ¶
func (r RedisResult) RedisError() *RedisError
RedisError can be used to check if the redis response is an error message.
func (RedisResult) ToAny ¶
func (r RedisResult) ToAny() (interface{}, error)
ToAny delegates to RedisMessage.ToAny
func (RedisResult) ToArray ¶
func (r RedisResult) ToArray() ([]RedisMessage, error)
ToArray delegates to RedisMessage.ToArray
func (RedisResult) ToBool ¶
func (r RedisResult) ToBool() (bool, error)
ToBool delegates to RedisMessage.ToBool
func (RedisResult) ToFloat64 ¶
func (r RedisResult) ToFloat64() (float64, error)
ToFloat64 delegates to RedisMessage.ToFloat64
func (RedisResult) ToInt64 ¶
func (r RedisResult) ToInt64() (int64, error)
ToInt64 delegates to RedisMessage.ToInt64
func (RedisResult) ToMap ¶
func (r RedisResult) ToMap() (map[string]RedisMessage, error)
ToMap delegates to RedisMessage.ToMap
func (RedisResult) ToMessage ¶
func (r RedisResult) ToMessage() (RedisMessage, error)
ToMessage retrieves the RedisMessage
func (RedisResult) ToString ¶
func (r RedisResult) ToString() (string, error)
ToString delegates to RedisMessage.ToString
type SentinelOption ¶
type SentinelOption struct { // TCP & TLS, same as ClientOption but for connecting sentinel Dialer net.Dialer TLSConfig *tls.Config // MasterSet is the redis master set name monitored by sentinel cluster. // If this field is set, then ClientOption.InitAddress will be used to connect to sentinel cluster. MasterSet string // Redis AUTH parameters for sentinel Username string Password string ClientName string }
SentinelOption contains MasterSet,
type XRangeEntry ¶
XRangeEntry is the element type of both XRANGE and XREVRANGE command response array