redis

package
v1.0.4 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Dec 25, 2024 License: Apache-2.0 Imports: 10 Imported by: 0

README

devcloud-go/redis

Introduction

Currently, the Redis supports three modes.single-read-write,local-read-single-write and double-write

single-read-write

image

local-read-single-write

image

double-write

image

Quickstart:
  1. use yaml configuartion file
package main

import (
    "context"
    "time"

    "github.com/huaweicloud/devcloud-go/redis"
)

func main()  {
    ctx := context.Background()
    client := redis.NewDevsporeClientWithYaml("./config_with_password.yaml")
    client.Set(ctx, "test_key", "test_val", time.Hour)
    client.Get(ctx, "test_key")
}
  1. use code(recommend)
package main

import (
    "context"
    "time"

    goredis "github.com/go-redis/redis/v8"
    "github.com/huaweicloud/devcloud-go/redis"
    "github.com/huaweicloud/devcloud-go/redis/config"
)
func main() {
    servers := map[string]*config.ServerConfiguration{
        "server1": {
            Hosts:      "127.0.0.0:6379",
            Password:   "XXXX",
            Type:       config.ServerTypeNormal,
            Cloud:      "huawei cloud",
            Region:     "beijing",
            Azs:        "az0",
        },
    }
    configuration := &config.Configuration{
        RedisConfig: &config.RedisConfiguration{
            Servers: servers,
        },
        RouteAlgorithm: "single-read-write",
        Active:         "server1",  
    }

    client := redis.NewDevsporeClient(configuration)
    ctx := context.Background()
    client.Set(ctx, "test_key", "test_val", time.Hour)
    client.Get(ctx, "test_key")
}
Yaml configuration file
props:
  version: v1
  appId: xxx
  monitorId: sdk_test
  cloud: huaweicloud
  region: cn-north-4
  azs: az1 
etcd: # Optional
  address: 127.0.0.1:2379,127.0.0.2:2379,127.0.0.3:2379
  apiVersion: v3
  username: XXXX
  password: XXXX
  httpsEnable: false
redis:
  redisGroupName: xxx-redis-group
  username: xxx # for redis 6.0
  password: yyy
  nearest: dc1
  connectionPool:
    enable: true
  servers:
    dc1:
      hosts: 127.0.0.1:6379
      password: password
      type: normal  # cluster, sentinel, normal
      cloud: huaweicloud  # cloud
      region: cn-north-4  # region id
      azs: az1  # azs
      pool: # Optional
        maxTotal: 100
        maxIdle: 8
        minIdle: 0
        maxWaitMillis: 10000
        timeBetweenEvictionRunsMillis: 1000
    dc2:
      hosts: 127.0.0.1:6380
      password: password
      type: sentinel  # cluster, sentinel, normal
      cloud: huaweicloud  # cloud
      region: cn-north-4  # region id
      azs: az1  # azs
      pool: # Optional
        maxTotal: 100
        maxIdle: 8
        minIdle: 0
        maxWaitMillis: 10000
        timeBetweenEvictionRunsMillis: 1000
routeAlgorithm: single-read-write  # local-read-single-write, single-read-write, double-write
active: dc1
Double-write

Redis also supports double-write modes, including memory double-write and file double-write, depending on asyncRemotePool.persist. true: file double-write; false: memory double-write

redis:
  redisGroupName: xxx-redis-group
  username: xxx # for redis 6.0
  password: yyy
  nearest: dc1
  asyncRemoteWrite:
    retryTimes: 4
  connectionPool:
    enable: true
  asyncRemotePool:
    persist: true
    threadCoreSize: 10
    taskQueueSize: 5
    persistDir: dataDir/
  servers:
    dc1:
      hosts: 127.0.0.1:6379
      password:
      type: normal  # cluster, sentinel, normal
      cloud: huaweicloud  # cloud
      region: cn-north-4  # region id
      azs: az1  # azs
      pool: # Optional
        maxTotal: 100
        maxIdle: 8
        minIdle: 0
        maxWaitMillis: 10000
        timeBetweenEvictionRunsMillis: 1000
    dc2:
      hosts: 127.0.0.1:6380
      password:
      type: normal  # cluster, sentinel, normal
      cloud: huaweicloud  # cloud
      region: cn-north-4  # region id
      azs: az1  # azs
      pool: # Optional
        maxTotal: 100
        maxIdle: 8
        minIdle: 0
        maxWaitMillis: 10000
        timeBetweenEvictionRunsMillis: 1000
routeAlgorithm: double-write  # local-read-single-write, single-read-write, double-write
active: dc2
Fault injection

Redis also supports the creation of services with fault injection. The configuration is similar to that of MySQL.

func DCRedis(etcdAddrs, redisAddrs []string) *redisconfig.Configuration {
    servers := make(map[string]*redisconfig.ServerConfiguration)
    for i, addr := range redisAddrs {
        stri := strconv.Itoa(i + 1)
        servers["ds"+stri] = &redisconfig.ServerConfiguration{
            Hosts:    addr,
            Password: "XXXX",
            Type:     redisconfig.ServerTypeNormal,
            Cloud:    "huawei cloud",
            Region:   "beijing",
            Azs:      "az1",
        }
    }
    configuration := &redisconfig.Configuration{
        RedisConfig: &redisconfig.RedisConfiguration{
            Servers: servers,
        },
        RouteAlgorithm: "single-read-write",
        Active:         "ds1",
        Chaos: &mas.InjectionProperties{
            Active:     true,
            Duration:   50,
            Interval:   100,
            Percentage: 100,
            DelayInjection: &mas.DelayInjection{
                Active:     true,
                Percentage: 100,
                TimeMs:     1000,
                JitterMs:   500,
            },
            ErrorInjection: &mas.ErrorInjection{
                Active:     true,
                Percentage: 30,
            },
        },
    }
    return configuration
}

Alternatively, add the following configuration to the configuration file:

chaos:
  active: true
  duration: 50
  interval: 100
  percentage: 100
  delayInjection:
    active: true
    percentage: 100
    timeMs: 1000
    jitterMs: 500
  errorInjection:
    active: true
    percentage: 20
Testing

package commands_test needs redis 6.2.0+, so if your redis is redis 5.0+, you need to execute

ginkgo -skip="redis6" 

See more usages of ginkgo in https://github.com/onsi/ginkgo

Description of Configuration Parameters
Configuration
Parameter NameParameter TypeValue rangeDescription
propsPropertiesConfigurationFor details,see the description of the data structure of PropertiesConfigurationMas monitoring configuration,which is used together with etcd
etcdEtcdConfigurationFor details,see the description of the data structure of EtcdConfigurationEtcd configuration.If it is configured, it will be pulled from the remote end
redisRedisConfigurationFor details,see the description of the data structure of RedisConfigurationRedisServer configuration
routeAlgorithmstringsingle-read-write,local-read-single-write,double-writeRouting algorithm
activestringThe value can only be dc1 or dc2Activated Redis
chaosInjectionPropertiesFor details,see the description of the data structure of InjectionPropertiesFault Injection Configuration
PropertiesConfiguration
Parameter NameParameter TypeValue rangeDescription
versionstring-Project version number
appIdstring-Project name
monitorIdstring-Monitoring group name
cloudstring-Project deployment cloud group
regionstring-Project deployment region
azsstring-Project deployment AZ
EtcdConfiguration
Parameter NameParameter TypeValue rangeDescription
addressstring-Etcd address
apiVersionstring-Etcd interface Version
usernamestring-Etcd username
passwordstring-Etcd password
httpEnablebool-Specifies whether HTTPS is enabled for Etcd
RedisConfiguration
Parameter NameParameter TypeValue rangeDescription
neareststringThe value can only be dc1 or dc2Indicates the local Redis
asyncRemoteWrite.retryTimesint-Number of retries of asynchronous remote write operations
connectionPool.enablebooltrue/falseIndicates whether to enable the connection pool
asyncRemotePoolAsyncRemotePoolConfigurationFor details,see the description of the data structure of AsyncRemotePoolConfigurationConfigure the asynchronous write thread pool
serversmap[string]ServerConfigurationThe key is dc1/dc2.for details about a single dimension,see the description of the data structure of ServerConfigurationRedisServer connection configuration of dc1 and dc2
AsyncRemotePoolConfiguration
Parameter NameParameter TypeValue rangeDescription
threadCoreSizeint-Basic size of the thread pool
persistbooltrue/falseIndicates whether the command is persistent.No:The command is fast.Yes:The speed is lower than that of non-persistent
taskQueueSizeint-Number of buffer queues
persistDirstringDefault root directory "/"Redis persistent file directory
ServerConfiguration
Parameter NameParameter TypeValue rangeDescription
hostsstring-RedisServer IP address
passwordstring-RedisServer password
typestringcluster,sentinel,normalRedisServer Type
cloudstring-RedisServer cloud
regionstring-Region to which the RedisServer belongs
azsstring-AZ to which RedisServer belongs
poolServerConnectionPoolConfigurationFor details,see the description of the data structure of ServerConnectionPoolConfigurationConnection pool configuration
ServerConnectionPoolConfiguration
Parameter NameParameter TypeValue rangeDescription
maxTotalint-Maximum number of active objects
maxIdleint-Maximum number of objects that can remain in the idle state
minIdleint-Minimum number of objects that can remain in the idle state
maxWaitMillisint-Maximum wait time when no object is returned in the pool
timeBetweenEvictionRunsMillisint-Idle link detection thread,detection interval,in milliseconds.A negative value indicates that the detection thread is not running
InjectionProperties
Parameter NameParameter TypeValue rangeDescription
activebooltrue/falseWhether the fault injection function is enabled
durationint-Fault injection duration,in seconds
intervalint-Fault injection interval,in seconds
percentageint0-100Injection failure probability
delayInjection.activebooltrue/falseDelay injection switch
delayInjection.percentageint0-100Delayed Fault Effective Probability
delayInjection.timeMsint-Indicates the delay base,in milliseconds
delayInjection.jitterMsint-Indicates the jitter amplitude of the delay, in milliseconds
errorInjection.activebooltrue/falseAbnormal injection switch
errorInjection.percentageint0-100Abnormal Fault Effective Probability

Documentation

Overview

Package redis defines DevsporeClient which implements all redis commands in https://github.com/go-redis/redis/blob/master/commands.go and it provides read-write separation and etcd multi-data source disaster tolerance switching capabilities, user can create a DevsporeClient by yaml configuration file or by code, see details in README.md.

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type DevsporeClient

type DevsporeClient struct {
	// contains filtered or unexported fields
}

DevsporeClient implements go-redis/UniversalClient interface which defines all redis commands, DevsporeClient includes configuration and a client pool, the pool will store redis client or cluster client.

func NewDevsporeClient

func NewDevsporeClient(configuration *config.Configuration) *DevsporeClient

NewDevsporeClient create a devsporeClient with Configuration which will assign etcd remote configuration.

func NewDevsporeClientWithYaml

func NewDevsporeClientWithYaml(yamlFilePath string) *DevsporeClient

NewDevsporeClientWithYaml create a devsporeClient with yaml configuration.

func (*DevsporeClient) AddHook

func (c *DevsporeClient) AddHook(hook redis.Hook)

func (*DevsporeClient) Append

func (c *DevsporeClient) Append(ctx context.Context, key, value string) *redis.IntCmd

func (*DevsporeClient) BLPop

func (c *DevsporeClient) BLPop(ctx context.Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd

func (*DevsporeClient) BRPop

func (c *DevsporeClient) BRPop(ctx context.Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd

func (*DevsporeClient) BRPopLPush

func (c *DevsporeClient) BRPopLPush(ctx context.Context, source, destination string, timeout time.Duration) *redis.StringCmd

func (*DevsporeClient) BZPopMax

func (c *DevsporeClient) BZPopMax(ctx context.Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd

func (*DevsporeClient) BZPopMin

func (c *DevsporeClient) BZPopMin(ctx context.Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd

func (*DevsporeClient) BgRewriteAOF

func (c *DevsporeClient) BgRewriteAOF(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) BgSave

func (c *DevsporeClient) BgSave(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) BitCount

func (c *DevsporeClient) BitCount(ctx context.Context, key string, bitCount *redis.BitCount) *redis.IntCmd

func (*DevsporeClient) BitField

func (c *DevsporeClient) BitField(ctx context.Context, key string, args ...interface{}) *redis.IntSliceCmd

func (*DevsporeClient) BitOpAnd

func (c *DevsporeClient) BitOpAnd(ctx context.Context, destKey string, keys ...string) *redis.IntCmd

func (*DevsporeClient) BitOpNot

func (c *DevsporeClient) BitOpNot(ctx context.Context, destKey string, key string) *redis.IntCmd

func (*DevsporeClient) BitOpOr

func (c *DevsporeClient) BitOpOr(ctx context.Context, destKey string, keys ...string) *redis.IntCmd

func (*DevsporeClient) BitOpXor

func (c *DevsporeClient) BitOpXor(ctx context.Context, destKey string, keys ...string) *redis.IntCmd

func (*DevsporeClient) BitPos

func (c *DevsporeClient) BitPos(ctx context.Context, key string, bit int64, pos ...int64) *redis.IntCmd

func (*DevsporeClient) ClientGetName

func (c *DevsporeClient) ClientGetName(ctx context.Context) *redis.StringCmd

func (*DevsporeClient) ClientID

func (c *DevsporeClient) ClientID(ctx context.Context) *redis.IntCmd

func (*DevsporeClient) ClientKill

func (c *DevsporeClient) ClientKill(ctx context.Context, ipPort string) *redis.StatusCmd

func (*DevsporeClient) ClientKillByFilter

func (c *DevsporeClient) ClientKillByFilter(ctx context.Context, keys ...string) *redis.IntCmd

func (*DevsporeClient) ClientList

func (c *DevsporeClient) ClientList(ctx context.Context) *redis.StringCmd

func (*DevsporeClient) ClientPause

func (c *DevsporeClient) ClientPause(ctx context.Context, dur time.Duration) *redis.BoolCmd

func (*DevsporeClient) ClientUnblock

func (c *DevsporeClient) ClientUnblock(ctx context.Context, id int64) *redis.IntCmd

func (*DevsporeClient) ClientUnblockWithError

func (c *DevsporeClient) ClientUnblockWithError(ctx context.Context, id int64) *redis.IntCmd

func (*DevsporeClient) Close

func (c *DevsporeClient) Close() error

Close closes all clients in clientPool

func (*DevsporeClient) ClusterAddSlots

func (c *DevsporeClient) ClusterAddSlots(ctx context.Context, slots ...int) *redis.StatusCmd

func (*DevsporeClient) ClusterAddSlotsRange

func (c *DevsporeClient) ClusterAddSlotsRange(ctx context.Context, min, max int) *redis.StatusCmd

func (*DevsporeClient) ClusterCountFailureReports

func (c *DevsporeClient) ClusterCountFailureReports(ctx context.Context, nodeID string) *redis.IntCmd

func (*DevsporeClient) ClusterCountKeysInSlot

func (c *DevsporeClient) ClusterCountKeysInSlot(ctx context.Context, slot int) *redis.IntCmd

func (*DevsporeClient) ClusterDelSlots

func (c *DevsporeClient) ClusterDelSlots(ctx context.Context, slots ...int) *redis.StatusCmd

func (*DevsporeClient) ClusterDelSlotsRange

func (c *DevsporeClient) ClusterDelSlotsRange(ctx context.Context, min, max int) *redis.StatusCmd

func (*DevsporeClient) ClusterFailover

func (c *DevsporeClient) ClusterFailover(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ClusterForget

func (c *DevsporeClient) ClusterForget(ctx context.Context, nodeID string) *redis.StatusCmd

func (*DevsporeClient) ClusterGetKeysInSlot

func (c *DevsporeClient) ClusterGetKeysInSlot(ctx context.Context, slot int, count int) *redis.StringSliceCmd

func (*DevsporeClient) ClusterInfo

func (c *DevsporeClient) ClusterInfo(ctx context.Context) *redis.StringCmd

func (*DevsporeClient) ClusterKeySlot

func (c *DevsporeClient) ClusterKeySlot(ctx context.Context, key string) *redis.IntCmd

func (*DevsporeClient) ClusterMeet

func (c *DevsporeClient) ClusterMeet(ctx context.Context, host, port string) *redis.StatusCmd

func (*DevsporeClient) ClusterNodes

func (c *DevsporeClient) ClusterNodes(ctx context.Context) *redis.StringCmd

func (*DevsporeClient) ClusterReplicate

func (c *DevsporeClient) ClusterReplicate(ctx context.Context, nodeID string) *redis.StatusCmd

func (*DevsporeClient) ClusterResetHard

func (c *DevsporeClient) ClusterResetHard(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ClusterResetSoft

func (c *DevsporeClient) ClusterResetSoft(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ClusterSaveConfig

func (c *DevsporeClient) ClusterSaveConfig(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ClusterSlaves

func (c *DevsporeClient) ClusterSlaves(ctx context.Context, nodeID string) *redis.StringSliceCmd

func (*DevsporeClient) ClusterSlots

func (c *DevsporeClient) ClusterSlots(ctx context.Context) *redis.ClusterSlotsCmd

func (*DevsporeClient) Command

func (c *DevsporeClient) Command(ctx context.Context) *redis.CommandsInfoCmd

func (*DevsporeClient) ConfigGet

func (c *DevsporeClient) ConfigGet(ctx context.Context, parameter string) *redis.SliceCmd

func (*DevsporeClient) ConfigResetStat

func (c *DevsporeClient) ConfigResetStat(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ConfigRewrite

func (c *DevsporeClient) ConfigRewrite(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ConfigSet

func (c *DevsporeClient) ConfigSet(ctx context.Context, parameter, value string) *redis.StatusCmd

func (*DevsporeClient) Context

func (c *DevsporeClient) Context() context.Context

func (*DevsporeClient) DBSize

func (c *DevsporeClient) DBSize(ctx context.Context) *redis.IntCmd

func (*DevsporeClient) DebugObject

func (c *DevsporeClient) DebugObject(ctx context.Context, key string) *redis.StringCmd

func (*DevsporeClient) Decr

func (c *DevsporeClient) Decr(ctx context.Context, key string) *redis.IntCmd

func (*DevsporeClient) DecrBy

func (c *DevsporeClient) DecrBy(ctx context.Context, key string, decrement int64) *redis.IntCmd

func (*DevsporeClient) Del

func (c *DevsporeClient) Del(ctx context.Context, keys ...string) *redis.IntCmd

func (*DevsporeClient) Do

func (c *DevsporeClient) Do(ctx context.Context, args ...interface{}) *redis.Cmd

func (*DevsporeClient) Dump

func (c *DevsporeClient) Dump(ctx context.Context, key string) *redis.StringCmd

func (*DevsporeClient) Echo

func (c *DevsporeClient) Echo(ctx context.Context, message interface{}) *redis.StringCmd

func (*DevsporeClient) Eval

func (c *DevsporeClient) Eval(ctx context.Context, script string, keys []string, args ...interface{}) *redis.Cmd

func (*DevsporeClient) EvalSha

func (c *DevsporeClient) EvalSha(ctx context.Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd

func (*DevsporeClient) Exists

func (c *DevsporeClient) Exists(ctx context.Context, keys ...string) *redis.IntCmd

func (*DevsporeClient) Expire

func (c *DevsporeClient) Expire(ctx context.Context, key string, expiration time.Duration) *redis.BoolCmd

func (*DevsporeClient) ExpireAt

func (c *DevsporeClient) ExpireAt(ctx context.Context, key string, tm time.Time) *redis.BoolCmd

func (*DevsporeClient) FlushAll

func (c *DevsporeClient) FlushAll(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) FlushAllAsync

func (c *DevsporeClient) FlushAllAsync(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) FlushDB

func (c *DevsporeClient) FlushDB(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) FlushDBAsync

func (c *DevsporeClient) FlushDBAsync(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) GeoAdd

func (c *DevsporeClient) GeoAdd(ctx context.Context, key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd

func (*DevsporeClient) GeoDist

func (c *DevsporeClient) GeoDist(ctx context.Context, key string, member1, member2, unit string) *redis.FloatCmd

func (*DevsporeClient) GeoHash

func (c *DevsporeClient) GeoHash(ctx context.Context, key string, members ...string) *redis.StringSliceCmd

func (*DevsporeClient) GeoPos

func (c *DevsporeClient) GeoPos(ctx context.Context, key string, members ...string) *redis.GeoPosCmd

func (*DevsporeClient) GeoRadius

func (c *DevsporeClient) GeoRadius(ctx context.Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd

func (*DevsporeClient) GeoRadiusByMember

func (c *DevsporeClient) GeoRadiusByMember(ctx context.Context, key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd

func (*DevsporeClient) GeoRadiusByMemberStore

func (c *DevsporeClient) GeoRadiusByMemberStore(ctx context.Context, key, member string, query *redis.GeoRadiusQuery) *redis.IntCmd

func (*DevsporeClient) GeoRadiusStore

func (c *DevsporeClient) GeoRadiusStore(ctx context.Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.IntCmd

func (*DevsporeClient) GeoSearch

func (c *DevsporeClient) GeoSearch(ctx context.Context, key string, q *redis.GeoSearchQuery) *redis.StringSliceCmd

func (*DevsporeClient) GeoSearchLocation

func (c *DevsporeClient) GeoSearchLocation(ctx context.Context, key string, q *redis.GeoSearchLocationQuery) *redis.GeoSearchLocationCmd

func (*DevsporeClient) GeoSearchStore

func (c *DevsporeClient) GeoSearchStore(ctx context.Context, key, store string, q *redis.GeoSearchStoreQuery) *redis.IntCmd

func (*DevsporeClient) Get

func (c *DevsporeClient) Get(ctx context.Context, key string) *redis.StringCmd

func (*DevsporeClient) GetBit

func (c *DevsporeClient) GetBit(ctx context.Context, key string, offset int64) *redis.IntCmd

func (*DevsporeClient) GetDel

func (c *DevsporeClient) GetDel(ctx context.Context, key string) *redis.StringCmd

func (*DevsporeClient) GetEx

func (c *DevsporeClient) GetEx(ctx context.Context, key string, expiration time.Duration) *redis.StringCmd

func (*DevsporeClient) GetRange

func (c *DevsporeClient) GetRange(ctx context.Context, key string, start, end int64) *redis.StringCmd

func (*DevsporeClient) GetSet

func (c *DevsporeClient) GetSet(ctx context.Context, key string, value interface{}) *redis.StringCmd

func (*DevsporeClient) HDel

func (c *DevsporeClient) HDel(ctx context.Context, key string, fields ...string) *redis.IntCmd

func (*DevsporeClient) HExists

func (c *DevsporeClient) HExists(ctx context.Context, key, field string) *redis.BoolCmd

func (*DevsporeClient) HGet

func (c *DevsporeClient) HGet(ctx context.Context, key, field string) *redis.StringCmd

func (*DevsporeClient) HGetAll

func (c *DevsporeClient) HGetAll(ctx context.Context, key string) *redis.StringStringMapCmd

func (*DevsporeClient) HIncrBy

func (c *DevsporeClient) HIncrBy(ctx context.Context, key, field string, incr int64) *redis.IntCmd

func (*DevsporeClient) HIncrByFloat

func (c *DevsporeClient) HIncrByFloat(ctx context.Context, key, field string, incr float64) *redis.FloatCmd

func (*DevsporeClient) HKeys

func (c *DevsporeClient) HKeys(ctx context.Context, key string) *redis.StringSliceCmd

func (*DevsporeClient) HLen

func (c *DevsporeClient) HLen(ctx context.Context, key string) *redis.IntCmd

func (*DevsporeClient) HMGet

func (c *DevsporeClient) HMGet(ctx context.Context, key string, fields ...string) *redis.SliceCmd

func (*DevsporeClient) HMSet

func (c *DevsporeClient) HMSet(ctx context.Context, key string, values ...interface{}) *redis.BoolCmd

func (*DevsporeClient) HRandField

func (c *DevsporeClient) HRandField(ctx context.Context, key string, count int, withValues bool) *redis.StringSliceCmd

func (*DevsporeClient) HScan

func (c *DevsporeClient) HScan(ctx context.Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd

func (*DevsporeClient) HSet

func (c *DevsporeClient) HSet(ctx context.Context, key string, values ...interface{}) *redis.IntCmd

func (*DevsporeClient) HSetNX

func (c *DevsporeClient) HSetNX(ctx context.Context, key, field string, value interface{}) *redis.BoolCmd

func (*DevsporeClient) HVals

func (c *DevsporeClient) HVals(ctx context.Context, key string) *redis.StringSliceCmd

func (*DevsporeClient) Incr

func (c *DevsporeClient) Incr(ctx context.Context, key string) *redis.IntCmd

func (*DevsporeClient) IncrBy

func (c *DevsporeClient) IncrBy(ctx context.Context, key string, value int64) *redis.IntCmd

func (*DevsporeClient) IncrByFloat

func (c *DevsporeClient) IncrByFloat(ctx context.Context, key string, value float64) *redis.FloatCmd

func (*DevsporeClient) Info

func (c *DevsporeClient) Info(ctx context.Context, section ...string) *redis.StringCmd

func (*DevsporeClient) Keys

func (c *DevsporeClient) Keys(ctx context.Context, pattern string) *redis.StringSliceCmd

func (*DevsporeClient) LIndex

func (c *DevsporeClient) LIndex(ctx context.Context, key string, index int64) *redis.StringCmd

func (*DevsporeClient) LInsert

func (c *DevsporeClient) LInsert(ctx context.Context, key, op string, pivot, value interface{}) *redis.IntCmd

func (*DevsporeClient) LInsertAfter

func (c *DevsporeClient) LInsertAfter(ctx context.Context, key string, pivot, value interface{}) *redis.IntCmd

func (*DevsporeClient) LInsertBefore

func (c *DevsporeClient) LInsertBefore(ctx context.Context, key string, pivot, value interface{}) *redis.IntCmd

func (*DevsporeClient) LLen

func (c *DevsporeClient) LLen(ctx context.Context, key string) *redis.IntCmd

func (*DevsporeClient) LMove

func (c *DevsporeClient) LMove(ctx context.Context, source, destination, srcpos, destpos string) *redis.StringCmd

func (*DevsporeClient) LPop

func (c *DevsporeClient) LPop(ctx context.Context, key string) *redis.StringCmd

func (*DevsporeClient) LPopCount

func (c *DevsporeClient) LPopCount(ctx context.Context, key string, count int) *redis.StringSliceCmd

func (*DevsporeClient) LPos

func (c *DevsporeClient) LPos(ctx context.Context, key string, value string, args redis.LPosArgs) *redis.IntCmd

func (*DevsporeClient) LPosCount

func (c *DevsporeClient) LPosCount(ctx context.Context, key string, value string, count int64, args redis.LPosArgs) *redis.IntSliceCmd

func (*DevsporeClient) LPush

func (c *DevsporeClient) LPush(ctx context.Context, key string, values ...interface{}) *redis.IntCmd

func (*DevsporeClient) LPushX

func (c *DevsporeClient) LPushX(ctx context.Context, key string, values ...interface{}) *redis.IntCmd

func (*DevsporeClient) LRange

func (c *DevsporeClient) LRange(ctx context.Context, key string, start, stop int64) *redis.StringSliceCmd

func (*DevsporeClient) LRem

func (c *DevsporeClient) LRem(ctx context.Context, key string, count int64, value interface{}) *redis.IntCmd

func (*DevsporeClient) LSet

func (c *DevsporeClient) LSet(ctx context.Context, key string, index int64, value interface{}) *redis.StatusCmd

func (*DevsporeClient) LTrim

func (c *DevsporeClient) LTrim(ctx context.Context, key string, start, stop int64) *redis.StatusCmd

func (*DevsporeClient) LastSave

func (c *DevsporeClient) LastSave(ctx context.Context) *redis.IntCmd

func (*DevsporeClient) MGet

func (c *DevsporeClient) MGet(ctx context.Context, keys ...string) *redis.SliceCmd

func (*DevsporeClient) MSet

func (c *DevsporeClient) MSet(ctx context.Context, values ...interface{}) *redis.StatusCmd

func (*DevsporeClient) MSetNX

func (c *DevsporeClient) MSetNX(ctx context.Context, values ...interface{}) *redis.BoolCmd

func (*DevsporeClient) MemoryUsage

func (c *DevsporeClient) MemoryUsage(ctx context.Context, key string, samples ...int) *redis.IntCmd

func (*DevsporeClient) Migrate

func (c *DevsporeClient) Migrate(ctx context.Context, host, port, key string, db int, timeout time.Duration) *redis.StatusCmd

func (*DevsporeClient) Move

func (c *DevsporeClient) Move(ctx context.Context, key string, db int) *redis.BoolCmd

func (*DevsporeClient) ObjectEncoding

func (c *DevsporeClient) ObjectEncoding(ctx context.Context, key string) *redis.StringCmd

func (*DevsporeClient) ObjectIdleTime

func (c *DevsporeClient) ObjectIdleTime(ctx context.Context, key string) *redis.DurationCmd

func (*DevsporeClient) ObjectRefCount

func (c *DevsporeClient) ObjectRefCount(ctx context.Context, key string) *redis.IntCmd

func (*DevsporeClient) PExpire

func (c *DevsporeClient) PExpire(ctx context.Context, key string, expiration time.Duration) *redis.BoolCmd

func (*DevsporeClient) PExpireAt

func (c *DevsporeClient) PExpireAt(ctx context.Context, key string, tm time.Time) *redis.BoolCmd

func (*DevsporeClient) PFAdd

func (c *DevsporeClient) PFAdd(ctx context.Context, key string, els ...interface{}) *redis.IntCmd

func (*DevsporeClient) PFCount

func (c *DevsporeClient) PFCount(ctx context.Context, keys ...string) *redis.IntCmd

func (*DevsporeClient) PFMerge

func (c *DevsporeClient) PFMerge(ctx context.Context, dest string, keys ...string) *redis.StatusCmd

func (*DevsporeClient) PSubscribe

func (c *DevsporeClient) PSubscribe(ctx context.Context, channels ...string) *redis.PubSub

func (*DevsporeClient) PTTL

func (c *DevsporeClient) PTTL(ctx context.Context, key string) *redis.DurationCmd

func (*DevsporeClient) Persist

func (c *DevsporeClient) Persist(ctx context.Context, key string) *redis.BoolCmd

func (*DevsporeClient) Ping

func (c *DevsporeClient) Ping(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) Pipeline

func (c *DevsporeClient) Pipeline() redis.Pipeliner

func (*DevsporeClient) Pipelined

func (c *DevsporeClient) Pipelined(ctx context.Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error)

func (*DevsporeClient) PoolStats

func (c *DevsporeClient) PoolStats() *redis.PoolStats

func (*DevsporeClient) Process

func (c *DevsporeClient) Process(ctx context.Context, cmd redis.Cmder) error

func (*DevsporeClient) PubSubChannels

func (c *DevsporeClient) PubSubChannels(ctx context.Context, pattern string) *redis.StringSliceCmd

func (*DevsporeClient) PubSubNumPat

func (c *DevsporeClient) PubSubNumPat(ctx context.Context) *redis.IntCmd

func (*DevsporeClient) PubSubNumSub

func (c *DevsporeClient) PubSubNumSub(ctx context.Context, channels ...string) *redis.StringIntMapCmd

func (*DevsporeClient) Publish

func (c *DevsporeClient) Publish(ctx context.Context, channel string, message interface{}) *redis.IntCmd

func (*DevsporeClient) Quit

func (c *DevsporeClient) Quit(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) RPop

func (c *DevsporeClient) RPop(ctx context.Context, key string) *redis.StringCmd

func (*DevsporeClient) RPopCount

func (c *DevsporeClient) RPopCount(ctx context.Context, key string, count int) *redis.StringSliceCmd

func (*DevsporeClient) RPopLPush

func (c *DevsporeClient) RPopLPush(ctx context.Context, source, destination string) *redis.StringCmd

func (*DevsporeClient) RPush

func (c *DevsporeClient) RPush(ctx context.Context, key string, values ...interface{}) *redis.IntCmd

func (*DevsporeClient) RPushX

func (c *DevsporeClient) RPushX(ctx context.Context, key string, values ...interface{}) *redis.IntCmd

func (*DevsporeClient) RandomKey

func (c *DevsporeClient) RandomKey(ctx context.Context) *redis.StringCmd

func (*DevsporeClient) ReadOnly

func (c *DevsporeClient) ReadOnly(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ReadWrite

func (c *DevsporeClient) ReadWrite(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) Rename

func (c *DevsporeClient) Rename(ctx context.Context, key, newkey string) *redis.StatusCmd

func (*DevsporeClient) RenameNX

func (c *DevsporeClient) RenameNX(ctx context.Context, key, newkey string) *redis.BoolCmd

func (*DevsporeClient) Restore

func (c *DevsporeClient) Restore(ctx context.Context, key string, ttl time.Duration, value string) *redis.StatusCmd

func (*DevsporeClient) RestoreReplace

func (c *DevsporeClient) RestoreReplace(ctx context.Context, key string, ttl time.Duration, value string) *redis.StatusCmd

func (*DevsporeClient) SAdd

func (c *DevsporeClient) SAdd(ctx context.Context, key string, members ...interface{}) *redis.IntCmd

func (*DevsporeClient) SCard

func (c *DevsporeClient) SCard(ctx context.Context, key string) *redis.IntCmd

func (*DevsporeClient) SDiff

func (c *DevsporeClient) SDiff(ctx context.Context, key ...string) *redis.StringSliceCmd

func (*DevsporeClient) SDiffStore

func (c *DevsporeClient) SDiffStore(ctx context.Context, destination string, key ...string) *redis.IntCmd

func (*DevsporeClient) SInter

func (c *DevsporeClient) SInter(ctx context.Context, key ...string) *redis.StringSliceCmd

func (*DevsporeClient) SInterStore

func (c *DevsporeClient) SInterStore(ctx context.Context, destination string, key ...string) *redis.IntCmd

func (*DevsporeClient) SIsMember

func (c *DevsporeClient) SIsMember(ctx context.Context, key string, member interface{}) *redis.BoolCmd

func (*DevsporeClient) SMIsMember

func (c *DevsporeClient) SMIsMember(ctx context.Context, key string, members ...interface{}) *redis.BoolSliceCmd

func (*DevsporeClient) SMembers

func (c *DevsporeClient) SMembers(ctx context.Context, key string) *redis.StringSliceCmd

func (*DevsporeClient) SMembersMap

func (c *DevsporeClient) SMembersMap(ctx context.Context, key string) *redis.StringStructMapCmd

func (*DevsporeClient) SMove

func (c *DevsporeClient) SMove(ctx context.Context, source, destination string, member interface{}) *redis.BoolCmd

func (*DevsporeClient) SPop

func (c *DevsporeClient) SPop(ctx context.Context, key string) *redis.StringCmd

func (*DevsporeClient) SPopN

func (c *DevsporeClient) SPopN(ctx context.Context, key string, count int64) *redis.StringSliceCmd

func (*DevsporeClient) SRandMember

func (c *DevsporeClient) SRandMember(ctx context.Context, key string) *redis.StringCmd

func (*DevsporeClient) SRandMemberN

func (c *DevsporeClient) SRandMemberN(ctx context.Context, key string, count int64) *redis.StringSliceCmd

func (*DevsporeClient) SRem

func (c *DevsporeClient) SRem(ctx context.Context, key string, members ...interface{}) *redis.IntCmd

func (*DevsporeClient) SScan

func (c *DevsporeClient) SScan(ctx context.Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd

func (*DevsporeClient) SUnion

func (c *DevsporeClient) SUnion(ctx context.Context, key ...string) *redis.StringSliceCmd

func (*DevsporeClient) SUnionStore

func (c *DevsporeClient) SUnionStore(ctx context.Context, destination string, key ...string) *redis.IntCmd

func (*DevsporeClient) Save

func (c *DevsporeClient) Save(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) Scan

func (c *DevsporeClient) Scan(ctx context.Context, cursor uint64, match string, count int64) *redis.ScanCmd

func (*DevsporeClient) ScanType

func (c *DevsporeClient) ScanType(ctx context.Context, cursor uint64, match string, count int64, keyType string) *redis.ScanCmd

func (*DevsporeClient) ScriptExists

func (c *DevsporeClient) ScriptExists(ctx context.Context, hashes ...string) *redis.BoolSliceCmd

func (*DevsporeClient) ScriptFlush

func (c *DevsporeClient) ScriptFlush(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ScriptKill

func (c *DevsporeClient) ScriptKill(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ScriptLoad

func (c *DevsporeClient) ScriptLoad(ctx context.Context, script string) *redis.StringCmd

func (*DevsporeClient) Set

func (c *DevsporeClient) Set(ctx context.Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd

func (*DevsporeClient) SetArgs

func (c *DevsporeClient) SetArgs(ctx context.Context, key string, value interface{}, a redis.SetArgs) *redis.StatusCmd

func (*DevsporeClient) SetBit

func (c *DevsporeClient) SetBit(ctx context.Context, key string, offset int64, value int) *redis.IntCmd

func (*DevsporeClient) SetEX

func (c *DevsporeClient) SetEX(ctx context.Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd

func (*DevsporeClient) SetNX

func (c *DevsporeClient) SetNX(ctx context.Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd

func (*DevsporeClient) SetRange

func (c *DevsporeClient) SetRange(ctx context.Context, key string, offset int64, value string) *redis.IntCmd

func (*DevsporeClient) SetXX

func (c *DevsporeClient) SetXX(ctx context.Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd

func (*DevsporeClient) Shutdown

func (c *DevsporeClient) Shutdown(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ShutdownNoSave

func (c *DevsporeClient) ShutdownNoSave(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) ShutdownSave

func (c *DevsporeClient) ShutdownSave(ctx context.Context) *redis.StatusCmd

func (*DevsporeClient) SlaveOf

func (c *DevsporeClient) SlaveOf(ctx context.Context, host, port string) *redis.StatusCmd

func (*DevsporeClient) SlowLogGet

func (c *DevsporeClient) SlowLogGet(ctx context.Context, num int64) *redis.SlowLogCmd

func (*DevsporeClient) Sort

func (c *DevsporeClient) Sort(ctx context.Context, key string, sort *redis.Sort) *redis.StringSliceCmd

func (*DevsporeClient) SortInterfaces

func (c *DevsporeClient) SortInterfaces(ctx context.Context, key string, sort *redis.Sort) *redis.SliceCmd

func (*DevsporeClient) SortStore

func (c *DevsporeClient) SortStore(ctx context.Context, key, store string, sort *redis.Sort) *redis.IntCmd

func (*DevsporeClient) StrLen

func (c *DevsporeClient) StrLen(ctx context.Context, key string) *redis.IntCmd

func (*DevsporeClient) Subscribe

func (c *DevsporeClient) Subscribe(ctx context.Context, channels ...string) *redis.PubSub

func (*DevsporeClient) TTL

func (c *DevsporeClient) TTL(ctx context.Context, key string) *redis.DurationCmd

func (*DevsporeClient) Time

func (c *DevsporeClient) Time(ctx context.Context) *redis.TimeCmd

func (*DevsporeClient) Touch

func (c *DevsporeClient) Touch(ctx context.Context, keys ...string) *redis.IntCmd

func (*DevsporeClient) TxPipeline

func (c *DevsporeClient) TxPipeline() redis.Pipeliner

func (*DevsporeClient) TxPipelined

func (c *DevsporeClient) TxPipelined(ctx context.Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error)

func (*DevsporeClient) Type

func (c *DevsporeClient) Type(ctx context.Context, key string) *redis.StatusCmd
func (c *DevsporeClient) Unlink(ctx context.Context, keys ...string) *redis.IntCmd

func (*DevsporeClient) Wait

func (c *DevsporeClient) Wait(ctx context.Context, numSlaves int, timeout time.Duration) *redis.IntCmd

func (*DevsporeClient) Watch

func (c *DevsporeClient) Watch(ctx context.Context, fn func(*redis.Tx) error, keys ...string) error

func (*DevsporeClient) XAck

func (c *DevsporeClient) XAck(ctx context.Context, stream, group string, ids ...string) *redis.IntCmd

func (*DevsporeClient) XAdd

func (c *DevsporeClient) XAdd(ctx context.Context, a *redis.XAddArgs) *redis.StringCmd

func (*DevsporeClient) XAutoClaim

func (c *DevsporeClient) XAutoClaim(ctx context.Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimCmd

func (*DevsporeClient) XAutoClaimJustID

func (c *DevsporeClient) XAutoClaimJustID(ctx context.Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimJustIDCmd

func (*DevsporeClient) XClaim

func (c *DevsporeClient) XClaim(ctx context.Context, a *redis.XClaimArgs) *redis.XMessageSliceCmd

func (*DevsporeClient) XClaimJustID

func (c *DevsporeClient) XClaimJustID(ctx context.Context, a *redis.XClaimArgs) *redis.StringSliceCmd

func (*DevsporeClient) XDel

func (c *DevsporeClient) XDel(ctx context.Context, stream string, ids ...string) *redis.IntCmd

func (*DevsporeClient) XGroupCreate

func (c *DevsporeClient) XGroupCreate(ctx context.Context, stream, group, start string) *redis.StatusCmd

func (*DevsporeClient) XGroupCreateConsumer

func (c *DevsporeClient) XGroupCreateConsumer(ctx context.Context, stream, group, consumer string) *redis.IntCmd

func (*DevsporeClient) XGroupCreateMkStream

func (c *DevsporeClient) XGroupCreateMkStream(ctx context.Context, stream, group, start string) *redis.StatusCmd

func (*DevsporeClient) XGroupDelConsumer

func (c *DevsporeClient) XGroupDelConsumer(ctx context.Context, stream, group, consumer string) *redis.IntCmd

func (*DevsporeClient) XGroupDestroy

func (c *DevsporeClient) XGroupDestroy(ctx context.Context, stream, group string) *redis.IntCmd

func (*DevsporeClient) XGroupSetID

func (c *DevsporeClient) XGroupSetID(ctx context.Context, stream, group, start string) *redis.StatusCmd

func (*DevsporeClient) XInfoConsumers

func (c *DevsporeClient) XInfoConsumers(ctx context.Context, key string, group string) *redis.XInfoConsumersCmd

func (*DevsporeClient) XInfoGroups

func (c *DevsporeClient) XInfoGroups(ctx context.Context, key string) *redis.XInfoGroupsCmd

func (*DevsporeClient) XInfoStream

func (c *DevsporeClient) XInfoStream(ctx context.Context, key string) *redis.XInfoStreamCmd

func (*DevsporeClient) XInfoStreamFull

func (c *DevsporeClient) XInfoStreamFull(ctx context.Context, key string, count int) *redis.XInfoStreamFullCmd

func (*DevsporeClient) XLen

func (c *DevsporeClient) XLen(ctx context.Context, stream string) *redis.IntCmd

func (*DevsporeClient) XPending

func (c *DevsporeClient) XPending(ctx context.Context, stream, group string) *redis.XPendingCmd

func (*DevsporeClient) XPendingExt

func (c *DevsporeClient) XPendingExt(ctx context.Context, a *redis.XPendingExtArgs) *redis.XPendingExtCmd

func (*DevsporeClient) XRange

func (c *DevsporeClient) XRange(ctx context.Context, stream, start, stop string) *redis.XMessageSliceCmd

func (*DevsporeClient) XRangeN

func (c *DevsporeClient) XRangeN(ctx context.Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd

func (*DevsporeClient) XRead

func (c *DevsporeClient) XRead(ctx context.Context, a *redis.XReadArgs) *redis.XStreamSliceCmd

func (*DevsporeClient) XReadGroup

func (c *DevsporeClient) XReadGroup(ctx context.Context, a *redis.XReadGroupArgs) *redis.XStreamSliceCmd

func (*DevsporeClient) XReadStreams

func (c *DevsporeClient) XReadStreams(ctx context.Context, streams ...string) *redis.XStreamSliceCmd

func (*DevsporeClient) XRevRange

func (c *DevsporeClient) XRevRange(ctx context.Context, stream, start, stop string) *redis.XMessageSliceCmd

func (*DevsporeClient) XRevRangeN

func (c *DevsporeClient) XRevRangeN(ctx context.Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd

func (*DevsporeClient) XTrim

func (c *DevsporeClient) XTrim(ctx context.Context, key string, maxLen int64) *redis.IntCmd

func (*DevsporeClient) XTrimApprox

func (c *DevsporeClient) XTrimApprox(ctx context.Context, key string, maxLen int64) *redis.IntCmd

func (*DevsporeClient) XTrimMaxLen

func (c *DevsporeClient) XTrimMaxLen(ctx context.Context, key string, maxLen int64) *redis.IntCmd

func (*DevsporeClient) XTrimMaxLenApprox

func (c *DevsporeClient) XTrimMaxLenApprox(ctx context.Context, key string, maxLen, limit int64) *redis.IntCmd

func (*DevsporeClient) XTrimMinID

func (c *DevsporeClient) XTrimMinID(ctx context.Context, key string, minID string) *redis.IntCmd

func (*DevsporeClient) XTrimMinIDApprox

func (c *DevsporeClient) XTrimMinIDApprox(ctx context.Context, key string, minID string, limit int64) *redis.IntCmd

func (*DevsporeClient) ZAdd

func (c *DevsporeClient) ZAdd(ctx context.Context, key string, members ...*redis.Z) *redis.IntCmd

func (*DevsporeClient) ZAddArgs

func (c *DevsporeClient) ZAddArgs(ctx context.Context, key string, args redis.ZAddArgs) *redis.IntCmd

func (*DevsporeClient) ZAddArgsIncr

func (c *DevsporeClient) ZAddArgsIncr(ctx context.Context, key string, args redis.ZAddArgs) *redis.FloatCmd

func (*DevsporeClient) ZAddCh

func (c *DevsporeClient) ZAddCh(ctx context.Context, key string, members ...*redis.Z) *redis.IntCmd

func (*DevsporeClient) ZAddNX

func (c *DevsporeClient) ZAddNX(ctx context.Context, key string, members ...*redis.Z) *redis.IntCmd

func (*DevsporeClient) ZAddNXCh

func (c *DevsporeClient) ZAddNXCh(ctx context.Context, key string, members ...*redis.Z) *redis.IntCmd

func (*DevsporeClient) ZAddXX

func (c *DevsporeClient) ZAddXX(ctx context.Context, key string, members ...*redis.Z) *redis.IntCmd

func (*DevsporeClient) ZAddXXCh

func (c *DevsporeClient) ZAddXXCh(ctx context.Context, key string, members ...*redis.Z) *redis.IntCmd

func (*DevsporeClient) ZCard

func (c *DevsporeClient) ZCard(ctx context.Context, key string) *redis.IntCmd

func (*DevsporeClient) ZCount

func (c *DevsporeClient) ZCount(ctx context.Context, key, min, max string) *redis.IntCmd

func (*DevsporeClient) ZDiff

func (c *DevsporeClient) ZDiff(ctx context.Context, keys ...string) *redis.StringSliceCmd

func (*DevsporeClient) ZDiffStore

func (c *DevsporeClient) ZDiffStore(ctx context.Context, destination string, keys ...string) *redis.IntCmd

func (*DevsporeClient) ZDiffWithScores

func (c *DevsporeClient) ZDiffWithScores(ctx context.Context, keys ...string) *redis.ZSliceCmd

func (*DevsporeClient) ZIncr

func (c *DevsporeClient) ZIncr(ctx context.Context, key string, member *redis.Z) *redis.FloatCmd

func (*DevsporeClient) ZIncrBy

func (c *DevsporeClient) ZIncrBy(ctx context.Context, key string, increment float64, member string) *redis.FloatCmd

func (*DevsporeClient) ZIncrNX

func (c *DevsporeClient) ZIncrNX(ctx context.Context, key string, member *redis.Z) *redis.FloatCmd

func (*DevsporeClient) ZIncrXX

func (c *DevsporeClient) ZIncrXX(ctx context.Context, key string, member *redis.Z) *redis.FloatCmd

func (*DevsporeClient) ZInter

func (c *DevsporeClient) ZInter(ctx context.Context, store *redis.ZStore) *redis.StringSliceCmd

func (*DevsporeClient) ZInterStore

func (c *DevsporeClient) ZInterStore(ctx context.Context, destination string, store *redis.ZStore) *redis.IntCmd

func (*DevsporeClient) ZInterWithScores

func (c *DevsporeClient) ZInterWithScores(ctx context.Context, store *redis.ZStore) *redis.ZSliceCmd

func (*DevsporeClient) ZLexCount

func (c *DevsporeClient) ZLexCount(ctx context.Context, key, min, max string) *redis.IntCmd

func (*DevsporeClient) ZMScore

func (c *DevsporeClient) ZMScore(ctx context.Context, key string, members ...string) *redis.FloatSliceCmd

func (*DevsporeClient) ZPopMax

func (c *DevsporeClient) ZPopMax(ctx context.Context, key string, count ...int64) *redis.ZSliceCmd

func (*DevsporeClient) ZPopMin

func (c *DevsporeClient) ZPopMin(ctx context.Context, key string, count ...int64) *redis.ZSliceCmd

func (*DevsporeClient) ZRandMember

func (c *DevsporeClient) ZRandMember(ctx context.Context, key string, count int, withScores bool) *redis.StringSliceCmd

func (*DevsporeClient) ZRange

func (c *DevsporeClient) ZRange(ctx context.Context, key string, start, stop int64) *redis.StringSliceCmd

func (*DevsporeClient) ZRangeArgs

func (c *DevsporeClient) ZRangeArgs(ctx context.Context, z redis.ZRangeArgs) *redis.StringSliceCmd

func (*DevsporeClient) ZRangeArgsWithScores

func (c *DevsporeClient) ZRangeArgsWithScores(ctx context.Context, z redis.ZRangeArgs) *redis.ZSliceCmd

func (*DevsporeClient) ZRangeByLex

func (c *DevsporeClient) ZRangeByLex(ctx context.Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd

func (*DevsporeClient) ZRangeByScore

func (c *DevsporeClient) ZRangeByScore(ctx context.Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd

func (*DevsporeClient) ZRangeByScoreWithScores

func (c *DevsporeClient) ZRangeByScoreWithScores(ctx context.Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd

func (*DevsporeClient) ZRangeStore

func (c *DevsporeClient) ZRangeStore(ctx context.Context, dst string, z redis.ZRangeArgs) *redis.IntCmd

func (*DevsporeClient) ZRangeWithScores

func (c *DevsporeClient) ZRangeWithScores(ctx context.Context, key string, start, stop int64) *redis.ZSliceCmd

func (*DevsporeClient) ZRank

func (c *DevsporeClient) ZRank(ctx context.Context, key, member string) *redis.IntCmd

func (*DevsporeClient) ZRem

func (c *DevsporeClient) ZRem(ctx context.Context, key string, members ...interface{}) *redis.IntCmd

func (*DevsporeClient) ZRemRangeByLex

func (c *DevsporeClient) ZRemRangeByLex(ctx context.Context, key, min, max string) *redis.IntCmd

func (*DevsporeClient) ZRemRangeByRank

func (c *DevsporeClient) ZRemRangeByRank(ctx context.Context, key string, start, stop int64) *redis.IntCmd

func (*DevsporeClient) ZRemRangeByScore

func (c *DevsporeClient) ZRemRangeByScore(ctx context.Context, key, min, max string) *redis.IntCmd

func (*DevsporeClient) ZRevRange

func (c *DevsporeClient) ZRevRange(ctx context.Context, key string, start, stop int64) *redis.StringSliceCmd

func (*DevsporeClient) ZRevRangeByLex

func (c *DevsporeClient) ZRevRangeByLex(ctx context.Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd

func (*DevsporeClient) ZRevRangeByScore

func (c *DevsporeClient) ZRevRangeByScore(ctx context.Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd

func (*DevsporeClient) ZRevRangeByScoreWithScores

func (c *DevsporeClient) ZRevRangeByScoreWithScores(ctx context.Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd

func (*DevsporeClient) ZRevRangeWithScores

func (c *DevsporeClient) ZRevRangeWithScores(ctx context.Context, key string, start, stop int64) *redis.ZSliceCmd

func (*DevsporeClient) ZRevRank

func (c *DevsporeClient) ZRevRank(ctx context.Context, key, member string) *redis.IntCmd

func (*DevsporeClient) ZScan

func (c *DevsporeClient) ZScan(ctx context.Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd

func (*DevsporeClient) ZScore

func (c *DevsporeClient) ZScore(ctx context.Context, key, member string) *redis.FloatCmd

func (*DevsporeClient) ZUnion

func (c *DevsporeClient) ZUnion(ctx context.Context, store redis.ZStore) *redis.StringSliceCmd

func (*DevsporeClient) ZUnionStore

func (c *DevsporeClient) ZUnionStore(ctx context.Context, dest string, store *redis.ZStore) *redis.IntCmd

func (*DevsporeClient) ZUnionWithScores

func (c *DevsporeClient) ZUnionWithScores(ctx context.Context, store redis.ZStore) *redis.ZSliceCmd

type DevsporeRedigoClient added in v1.0.4

type DevsporeRedigoClient struct {
	// contains filtered or unexported fields
}

func NewDevsporeRedigoClient added in v1.0.4

func NewDevsporeRedigoClient(configuration *config.Configuration) *DevsporeRedigoClient

NewDevsporeClient create a devsporeClient with Configuration which will assign etcd remote configuration.

func NewDevsporeRedigoClientWithYaml added in v1.0.4

func NewDevsporeRedigoClientWithYaml(yamlFilePath string) *DevsporeRedigoClient

NewDevsporeClientWithYaml create a devsporeClient with yaml configuration.

func (*DevsporeRedigoClient) Dial added in v1.0.4

func (c *DevsporeRedigoClient) Dial() redigo.Conn

get current conn ,not support dobule write & need defer close

func (*DevsporeRedigoClient) Do added in v1.0.4

func (c *DevsporeRedigoClient) Do(commandName string, args ...interface{}) (reply interface{}, err error)

redigoclient

func (*DevsporeRedigoClient) DoContext added in v1.0.4

func (c *DevsporeRedigoClient) DoContext(ctx context.Context, commandName string, args ...interface{}) (reply interface{}, err error)

func (*DevsporeRedigoClient) ExcuteRead added in v1.0.4

func (c *DevsporeRedigoClient) ExcuteRead(commandName string, args ...interface{}) (reply interface{}, err error)

func (*DevsporeRedigoClient) ExcuteWrite added in v1.0.4

func (c *DevsporeRedigoClient) ExcuteWrite(commandName string, args ...interface{}) (reply interface{}, err error)

func (*DevsporeRedigoClient) GetSubscribeTool added in v1.0.4

func (c *DevsporeRedigoClient) GetSubscribeTool() *redigostrategy.SubcribeTool

persistent subscribe tool

func (*DevsporeRedigoClient) Pipeline added in v1.0.4

func (c *DevsporeRedigoClient) Pipeline(cmds interface{}) (reply interface{}, err error)

cmds is [][]string or []*redigostrategy.RedigoCommandArgs

func (*DevsporeRedigoClient) Publish added in v1.0.4

func (c *DevsporeRedigoClient) Publish(channel string, message interface{}) error

func (*DevsporeRedigoClient) Subscribe added in v1.0.4

func (c *DevsporeRedigoClient) Subscribe(ctx context.Context, duration time.Duration, channel string) (interface{}, error)

single subscribe

func (*DevsporeRedigoClient) Transactions added in v1.0.4

func (c *DevsporeRedigoClient) Transactions(cmds interface{}) (reply interface{}, err error)

cmds is [][]string or []*redigostrategy.RedigoCommandArgs

Directories

Path Synopsis
Package config defines a series of devspore redis configuration, include configuration from yaml and remote etcd.
Package config defines a series of devspore redis configuration, include configuration from yaml and remote etcd.
Package file Double-write of files
Package file Double-write of files
Package strategy defines different route redigoStrategy mode.
Package strategy defines different route redigoStrategy mode.
Package strategy defines different route strategy mode.
Package strategy defines different route strategy mode.

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL