insredis

package
v0.10.4 Latest Latest
Warning

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

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

README

insredis

The insredis package provides a universal Golang Redis interface and a client for easy interaction with Redis databases.

Overview

This package offers a set of methods covering various functionalities for working with Redis, encapsulated within the RedisInterface. It includes methods for key-value operations, set operations, list operations, sorted set operations, geospatial operations, and more.

Installation

To use this package, install it using Go modules:

go get github.com/useinsider/go-pkg/insredis

Usage

Initialization

Initialize a Redis client instance by providing configuration settings using Init()

import (
"github.com/yourusername/insredis"
"time"
)

func main() {
// Configure Redis settings
cfg := insredis.Config{
RedisHost:     "localhost:6379",
RedisPoolSize: 10,
DialTimeout:   500 * time.Millisecond,
ReadTimeout:   500 * time.Millisecond,
MaxRetries:    3,
}

// Initialize the Redis client
client := insredis.Init(cfg)

// Use the client for Redis operations
// e.g., client.Set("key", "value", 0)
}




// Default configs in table format

Config Name Default Value Description
RedisHost localhost:6379 Redis host address
RedisPoolSize 10 Maximum number of connections allocated by the Redis client
DialTimeout 500ms Maximum amount of time to wait for a connection to be established
ReadTimeout 500ms Maximum amount of time to wait for a read operation to complete
MaxRetries 0 (no retry) Maximum number of retries before giving up on a request

Usage in Tests

package main

import (
	"github.com/go-redis/redis"
	"github.com/golang/mock/gomock"
	"github.com/stretchr/testify/assert"
	"go-pkg/insredis"
	"testing"
)

func TestUsingRedisMock(t *testing.T) {
	controller := gomock.NewController(t)
	redisClient := insredis.NewMockRedisInterface(controller)

	redisClient.
		EXPECT().
		Ping().
		Times(1).
		DoAndReturn(func() *redis.StatusCmd {
			return redis.NewStatusCmd("PONG")
		})

	err := ping(redisClient)
	assert.NoError(t, err)
}

func ping(redisClient insredis.RedisInterface) error {
	return redisClient.Ping().Err()
}

How to Update Mock File

mockgen -source=./insredis/redis.go -destination=./insredis/redis_mock.go -package=insredis

Contributing

Contributions to this package are welcome! Feel free to submit issues or pull requests.

Documentation

Overview

Package insredis is a generated GoMock package.

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

func GetClient

func GetClient() *redis.Client

func Init

func Init(cfg Config) *redis.Client

Init creates a client pool for redis connections.

Types

type Config

type Config struct {
	RedisHost     string
	RedisPoolSize int
	DialTimeout   time.Duration
	ReadTimeout   time.Duration
	MaxRetries    int
}

type MockRedisInterface

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

MockRedisInterface is a mock of RedisInterface interface.

func NewMockRedisInterface

func NewMockRedisInterface(ctrl *gomock.Controller) *MockRedisInterface

NewMockRedisInterface creates a new mock instance.

func (*MockRedisInterface) Append

func (m *MockRedisInterface) Append(key, value string) *redis.IntCmd

Append mocks base method.

func (*MockRedisInterface) BLPop

func (m *MockRedisInterface) BLPop(timeout time.Duration, keys ...string) *redis.StringSliceCmd

BLPop mocks base method.

func (*MockRedisInterface) BRPop

func (m *MockRedisInterface) BRPop(timeout time.Duration, keys ...string) *redis.StringSliceCmd

BRPop mocks base method.

func (*MockRedisInterface) BRPopLPush

func (m *MockRedisInterface) BRPopLPush(source, destination string, timeout time.Duration) *redis.StringCmd

BRPopLPush mocks base method.

func (*MockRedisInterface) BZPopMax

func (m *MockRedisInterface) BZPopMax(timeout time.Duration, keys ...string) *redis.ZWithKeyCmd

BZPopMax mocks base method.

func (*MockRedisInterface) BZPopMin

func (m *MockRedisInterface) BZPopMin(timeout time.Duration, keys ...string) *redis.ZWithKeyCmd

BZPopMin mocks base method.

func (*MockRedisInterface) BgRewriteAOF

func (m *MockRedisInterface) BgRewriteAOF() *redis.StatusCmd

BgRewriteAOF mocks base method.

func (*MockRedisInterface) BgSave

func (m *MockRedisInterface) BgSave() *redis.StatusCmd

BgSave mocks base method.

func (*MockRedisInterface) BitCount

func (m *MockRedisInterface) BitCount(key string, bitCount *redis.BitCount) *redis.IntCmd

BitCount mocks base method.

func (*MockRedisInterface) BitOpAnd

func (m *MockRedisInterface) BitOpAnd(destKey string, keys ...string) *redis.IntCmd

BitOpAnd mocks base method.

func (*MockRedisInterface) BitOpNot

func (m *MockRedisInterface) BitOpNot(destKey, key string) *redis.IntCmd

BitOpNot mocks base method.

func (*MockRedisInterface) BitOpOr

func (m *MockRedisInterface) BitOpOr(destKey string, keys ...string) *redis.IntCmd

BitOpOr mocks base method.

func (*MockRedisInterface) BitOpXor

func (m *MockRedisInterface) BitOpXor(destKey string, keys ...string) *redis.IntCmd

BitOpXor mocks base method.

func (*MockRedisInterface) BitPos

func (m *MockRedisInterface) BitPos(key string, bit int64, pos ...int64) *redis.IntCmd

BitPos mocks base method.

func (*MockRedisInterface) ClientGetName

func (m *MockRedisInterface) ClientGetName() *redis.StringCmd

ClientGetName mocks base method.

func (*MockRedisInterface) ClientID

func (m *MockRedisInterface) ClientID() *redis.IntCmd

ClientID mocks base method.

func (*MockRedisInterface) ClientKill

func (m *MockRedisInterface) ClientKill(ipPort string) *redis.StatusCmd

ClientKill mocks base method.

func (*MockRedisInterface) ClientKillByFilter

func (m *MockRedisInterface) ClientKillByFilter(keys ...string) *redis.IntCmd

ClientKillByFilter mocks base method.

func (*MockRedisInterface) ClientList

func (m *MockRedisInterface) ClientList() *redis.StringCmd

ClientList mocks base method.

func (*MockRedisInterface) ClientPause

func (m *MockRedisInterface) ClientPause(dur time.Duration) *redis.BoolCmd

ClientPause mocks base method.

func (*MockRedisInterface) Close

func (m *MockRedisInterface) Close() error

Close mocks base method.

func (*MockRedisInterface) ClusterAddSlots

func (m *MockRedisInterface) ClusterAddSlots(slots ...int) *redis.StatusCmd

ClusterAddSlots mocks base method.

func (*MockRedisInterface) ClusterAddSlotsRange

func (m *MockRedisInterface) ClusterAddSlotsRange(min, max int) *redis.StatusCmd

ClusterAddSlotsRange mocks base method.

func (*MockRedisInterface) ClusterCountFailureReports

func (m *MockRedisInterface) ClusterCountFailureReports(nodeID string) *redis.IntCmd

ClusterCountFailureReports mocks base method.

func (*MockRedisInterface) ClusterCountKeysInSlot

func (m *MockRedisInterface) ClusterCountKeysInSlot(slot int) *redis.IntCmd

ClusterCountKeysInSlot mocks base method.

func (*MockRedisInterface) ClusterDelSlots

func (m *MockRedisInterface) ClusterDelSlots(slots ...int) *redis.StatusCmd

ClusterDelSlots mocks base method.

func (*MockRedisInterface) ClusterDelSlotsRange

func (m *MockRedisInterface) ClusterDelSlotsRange(min, max int) *redis.StatusCmd

ClusterDelSlotsRange mocks base method.

func (*MockRedisInterface) ClusterFailover

func (m *MockRedisInterface) ClusterFailover() *redis.StatusCmd

ClusterFailover mocks base method.

func (*MockRedisInterface) ClusterForget

func (m *MockRedisInterface) ClusterForget(nodeID string) *redis.StatusCmd

ClusterForget mocks base method.

func (*MockRedisInterface) ClusterGetKeysInSlot

func (m *MockRedisInterface) ClusterGetKeysInSlot(slot, count int) *redis.StringSliceCmd

ClusterGetKeysInSlot mocks base method.

func (*MockRedisInterface) ClusterInfo

func (m *MockRedisInterface) ClusterInfo() *redis.StringCmd

ClusterInfo mocks base method.

func (*MockRedisInterface) ClusterKeySlot

func (m *MockRedisInterface) ClusterKeySlot(key string) *redis.IntCmd

ClusterKeySlot mocks base method.

func (*MockRedisInterface) ClusterMeet

func (m *MockRedisInterface) ClusterMeet(host, port string) *redis.StatusCmd

ClusterMeet mocks base method.

func (*MockRedisInterface) ClusterNodes

func (m *MockRedisInterface) ClusterNodes() *redis.StringCmd

ClusterNodes mocks base method.

func (*MockRedisInterface) ClusterReplicate

func (m *MockRedisInterface) ClusterReplicate(nodeID string) *redis.StatusCmd

ClusterReplicate mocks base method.

func (*MockRedisInterface) ClusterResetHard

func (m *MockRedisInterface) ClusterResetHard() *redis.StatusCmd

ClusterResetHard mocks base method.

func (*MockRedisInterface) ClusterResetSoft

func (m *MockRedisInterface) ClusterResetSoft() *redis.StatusCmd

ClusterResetSoft mocks base method.

func (*MockRedisInterface) ClusterSaveConfig

func (m *MockRedisInterface) ClusterSaveConfig() *redis.StatusCmd

ClusterSaveConfig mocks base method.

func (*MockRedisInterface) ClusterSlaves

func (m *MockRedisInterface) ClusterSlaves(nodeID string) *redis.StringSliceCmd

ClusterSlaves mocks base method.

func (*MockRedisInterface) ClusterSlots

func (m *MockRedisInterface) ClusterSlots() *redis.ClusterSlotsCmd

ClusterSlots mocks base method.

func (*MockRedisInterface) Command

Command mocks base method.

func (*MockRedisInterface) ConfigGet

func (m *MockRedisInterface) ConfigGet(parameter string) *redis.SliceCmd

ConfigGet mocks base method.

func (*MockRedisInterface) ConfigResetStat

func (m *MockRedisInterface) ConfigResetStat() *redis.StatusCmd

ConfigResetStat mocks base method.

func (*MockRedisInterface) ConfigRewrite

func (m *MockRedisInterface) ConfigRewrite() *redis.StatusCmd

ConfigRewrite mocks base method.

func (*MockRedisInterface) ConfigSet

func (m *MockRedisInterface) ConfigSet(parameter, value string) *redis.StatusCmd

ConfigSet mocks base method.

func (*MockRedisInterface) DBSize

func (m *MockRedisInterface) DBSize() *redis.IntCmd

DBSize mocks base method.

func (*MockRedisInterface) DebugObject

func (m *MockRedisInterface) DebugObject(key string) *redis.StringCmd

DebugObject mocks base method.

func (*MockRedisInterface) Decr

func (m *MockRedisInterface) Decr(key string) *redis.IntCmd

Decr mocks base method.

func (*MockRedisInterface) DecrBy

func (m *MockRedisInterface) DecrBy(key string, decrement int64) *redis.IntCmd

DecrBy mocks base method.

func (*MockRedisInterface) Del

func (m *MockRedisInterface) Del(keys ...string) *redis.IntCmd

Del mocks base method.

func (*MockRedisInterface) Dump

func (m *MockRedisInterface) Dump(key string) *redis.StringCmd

Dump mocks base method.

func (*MockRedisInterface) EXPECT

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockRedisInterface) Echo

func (m *MockRedisInterface) Echo(message interface{}) *redis.StringCmd

Echo mocks base method.

func (*MockRedisInterface) Eval

func (m *MockRedisInterface) Eval(script string, keys []string, args ...interface{}) *redis.Cmd

Eval mocks base method.

func (*MockRedisInterface) EvalSha

func (m *MockRedisInterface) EvalSha(sha1 string, keys []string, args ...interface{}) *redis.Cmd

EvalSha mocks base method.

func (*MockRedisInterface) Exists

func (m *MockRedisInterface) Exists(keys ...string) *redis.IntCmd

Exists mocks base method.

func (*MockRedisInterface) Expire

func (m *MockRedisInterface) Expire(key string, expiration time.Duration) *redis.BoolCmd

Expire mocks base method.

func (*MockRedisInterface) ExpireAt

func (m *MockRedisInterface) ExpireAt(key string, tm time.Time) *redis.BoolCmd

ExpireAt mocks base method.

func (*MockRedisInterface) FlushAll

func (m *MockRedisInterface) FlushAll() *redis.StatusCmd

FlushAll mocks base method.

func (*MockRedisInterface) FlushAllAsync

func (m *MockRedisInterface) FlushAllAsync() *redis.StatusCmd

FlushAllAsync mocks base method.

func (*MockRedisInterface) FlushDB

func (m *MockRedisInterface) FlushDB() *redis.StatusCmd

FlushDB mocks base method.

func (*MockRedisInterface) FlushDBAsync

func (m *MockRedisInterface) FlushDBAsync() *redis.StatusCmd

FlushDBAsync mocks base method.

func (*MockRedisInterface) GeoAdd

func (m *MockRedisInterface) GeoAdd(key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd

GeoAdd mocks base method.

func (*MockRedisInterface) GeoDist

func (m *MockRedisInterface) GeoDist(key, member1, member2, unit string) *redis.FloatCmd

GeoDist mocks base method.

func (*MockRedisInterface) GeoHash

func (m *MockRedisInterface) GeoHash(key string, members ...string) *redis.StringSliceCmd

GeoHash mocks base method.

func (*MockRedisInterface) GeoPos

func (m *MockRedisInterface) GeoPos(key string, members ...string) *redis.GeoPosCmd

GeoPos mocks base method.

func (*MockRedisInterface) GeoRadius

func (m *MockRedisInterface) GeoRadius(key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd

GeoRadius mocks base method.

func (*MockRedisInterface) GeoRadiusByMember

func (m *MockRedisInterface) GeoRadiusByMember(key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd

GeoRadiusByMember mocks base method.

func (*MockRedisInterface) GeoRadiusByMemberRO

func (m *MockRedisInterface) GeoRadiusByMemberRO(key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd

GeoRadiusByMemberRO mocks base method.

func (*MockRedisInterface) GeoRadiusRO

func (m *MockRedisInterface) GeoRadiusRO(key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd

GeoRadiusRO mocks base method.

func (*MockRedisInterface) Get

Get mocks base method.

func (*MockRedisInterface) GetBit

func (m *MockRedisInterface) GetBit(key string, offset int64) *redis.IntCmd

GetBit mocks base method.

func (*MockRedisInterface) GetRange

func (m *MockRedisInterface) GetRange(key string, start, end int64) *redis.StringCmd

GetRange mocks base method.

func (*MockRedisInterface) GetSet

func (m *MockRedisInterface) GetSet(key string, value interface{}) *redis.StringCmd

GetSet mocks base method.

func (*MockRedisInterface) HDel

func (m *MockRedisInterface) HDel(key string, fields ...string) *redis.IntCmd

HDel mocks base method.

func (*MockRedisInterface) HExists

func (m *MockRedisInterface) HExists(key, field string) *redis.BoolCmd

HExists mocks base method.

func (*MockRedisInterface) HGet

func (m *MockRedisInterface) HGet(key, field string) *redis.StringCmd

HGet mocks base method.

func (*MockRedisInterface) HGetAll

HGetAll mocks base method.

func (*MockRedisInterface) HIncrBy

func (m *MockRedisInterface) HIncrBy(key, field string, incr int64) *redis.IntCmd

HIncrBy mocks base method.

func (*MockRedisInterface) HIncrByFloat

func (m *MockRedisInterface) HIncrByFloat(key, field string, incr float64) *redis.FloatCmd

HIncrByFloat mocks base method.

func (*MockRedisInterface) HKeys

HKeys mocks base method.

func (*MockRedisInterface) HLen

func (m *MockRedisInterface) HLen(key string) *redis.IntCmd

HLen mocks base method.

func (*MockRedisInterface) HMGet

func (m *MockRedisInterface) HMGet(key string, fields ...string) *redis.SliceCmd

HMGet mocks base method.

func (*MockRedisInterface) HMSet

func (m *MockRedisInterface) HMSet(key string, fields map[string]interface{}) *redis.StatusCmd

HMSet mocks base method.

func (*MockRedisInterface) HScan

func (m *MockRedisInterface) HScan(key string, cursor uint64, match string, count int64) *redis.ScanCmd

HScan mocks base method.

func (*MockRedisInterface) HSet

func (m *MockRedisInterface) HSet(key, field string, value interface{}) *redis.BoolCmd

HSet mocks base method.

func (*MockRedisInterface) HSetNX

func (m *MockRedisInterface) HSetNX(key, field string, value interface{}) *redis.BoolCmd

HSetNX mocks base method.

func (*MockRedisInterface) HVals

HVals mocks base method.

func (*MockRedisInterface) Incr

func (m *MockRedisInterface) Incr(key string) *redis.IntCmd

Incr mocks base method.

func (*MockRedisInterface) IncrBy

func (m *MockRedisInterface) IncrBy(key string, value int64) *redis.IntCmd

IncrBy mocks base method.

func (*MockRedisInterface) IncrByFloat

func (m *MockRedisInterface) IncrByFloat(key string, value float64) *redis.FloatCmd

IncrByFloat mocks base method.

func (*MockRedisInterface) Info

func (m *MockRedisInterface) Info(section ...string) *redis.StringCmd

Info mocks base method.

func (*MockRedisInterface) Keys

func (m *MockRedisInterface) Keys(pattern string) *redis.StringSliceCmd

Keys mocks base method.

func (*MockRedisInterface) LIndex

func (m *MockRedisInterface) LIndex(key string, index int64) *redis.StringCmd

LIndex mocks base method.

func (*MockRedisInterface) LInsert

func (m *MockRedisInterface) LInsert(key, op string, pivot, value interface{}) *redis.IntCmd

LInsert mocks base method.

func (*MockRedisInterface) LInsertAfter

func (m *MockRedisInterface) LInsertAfter(key string, pivot, value interface{}) *redis.IntCmd

LInsertAfter mocks base method.

func (*MockRedisInterface) LInsertBefore

func (m *MockRedisInterface) LInsertBefore(key string, pivot, value interface{}) *redis.IntCmd

LInsertBefore mocks base method.

func (*MockRedisInterface) LLen

func (m *MockRedisInterface) LLen(key string) *redis.IntCmd

LLen mocks base method.

func (*MockRedisInterface) LPop

func (m *MockRedisInterface) LPop(key string) *redis.StringCmd

LPop mocks base method.

func (*MockRedisInterface) LPush

func (m *MockRedisInterface) LPush(key string, values ...interface{}) *redis.IntCmd

LPush mocks base method.

func (*MockRedisInterface) LPushX

func (m *MockRedisInterface) LPushX(key string, value interface{}) *redis.IntCmd

LPushX mocks base method.

func (*MockRedisInterface) LRange

func (m *MockRedisInterface) LRange(key string, start, stop int64) *redis.StringSliceCmd

LRange mocks base method.

func (*MockRedisInterface) LRem

func (m *MockRedisInterface) LRem(key string, count int64, value interface{}) *redis.IntCmd

LRem mocks base method.

func (*MockRedisInterface) LSet

func (m *MockRedisInterface) LSet(key string, index int64, value interface{}) *redis.StatusCmd

LSet mocks base method.

func (*MockRedisInterface) LTrim

func (m *MockRedisInterface) LTrim(key string, start, stop int64) *redis.StatusCmd

LTrim mocks base method.

func (*MockRedisInterface) LastSave

func (m *MockRedisInterface) LastSave() *redis.IntCmd

LastSave mocks base method.

func (*MockRedisInterface) MGet

func (m *MockRedisInterface) MGet(keys ...string) *redis.SliceCmd

MGet mocks base method.

func (*MockRedisInterface) MSet

func (m *MockRedisInterface) MSet(pairs ...interface{}) *redis.StatusCmd

MSet mocks base method.

func (*MockRedisInterface) MSetNX

func (m *MockRedisInterface) MSetNX(pairs ...interface{}) *redis.BoolCmd

MSetNX mocks base method.

func (*MockRedisInterface) MemoryUsage

func (m *MockRedisInterface) MemoryUsage(key string, samples ...int) *redis.IntCmd

MemoryUsage mocks base method.

func (*MockRedisInterface) Migrate

func (m *MockRedisInterface) Migrate(host, port, key string, db int64, timeout time.Duration) *redis.StatusCmd

Migrate mocks base method.

func (*MockRedisInterface) Move

func (m *MockRedisInterface) Move(key string, db int64) *redis.BoolCmd

Move mocks base method.

func (*MockRedisInterface) ObjectEncoding

func (m *MockRedisInterface) ObjectEncoding(key string) *redis.StringCmd

ObjectEncoding mocks base method.

func (*MockRedisInterface) ObjectIdleTime

func (m *MockRedisInterface) ObjectIdleTime(key string) *redis.DurationCmd

ObjectIdleTime mocks base method.

func (*MockRedisInterface) ObjectRefCount

func (m *MockRedisInterface) ObjectRefCount(key string) *redis.IntCmd

ObjectRefCount mocks base method.

func (*MockRedisInterface) PExpire

func (m *MockRedisInterface) PExpire(key string, expiration time.Duration) *redis.BoolCmd

PExpire mocks base method.

func (*MockRedisInterface) PExpireAt

func (m *MockRedisInterface) PExpireAt(key string, tm time.Time) *redis.BoolCmd

PExpireAt mocks base method.

func (*MockRedisInterface) PFAdd

func (m *MockRedisInterface) PFAdd(key string, els ...interface{}) *redis.IntCmd

PFAdd mocks base method.

func (*MockRedisInterface) PFCount

func (m *MockRedisInterface) PFCount(keys ...string) *redis.IntCmd

PFCount mocks base method.

func (*MockRedisInterface) PFMerge

func (m *MockRedisInterface) PFMerge(dest string, keys ...string) *redis.StatusCmd

PFMerge mocks base method.

func (*MockRedisInterface) PSubscribe

func (m *MockRedisInterface) PSubscribe(channels ...string) *redis.PubSub

PSubscribe mocks base method.

func (*MockRedisInterface) PTTL

PTTL mocks base method.

func (*MockRedisInterface) Persist

func (m *MockRedisInterface) Persist(key string) *redis.BoolCmd

Persist mocks base method.

func (*MockRedisInterface) Ping

func (m *MockRedisInterface) Ping() *redis.StatusCmd

Ping mocks base method.

func (*MockRedisInterface) Pipeline

func (m *MockRedisInterface) Pipeline() redis.Pipeliner

Pipeline mocks base method.

func (*MockRedisInterface) Pipelined

func (m *MockRedisInterface) Pipelined(fn func(redis.Pipeliner) error) ([]redis.Cmder, error)

Pipelined mocks base method.

func (*MockRedisInterface) Process

func (m *MockRedisInterface) Process(cmd redis.Cmder) error

Process mocks base method.

func (*MockRedisInterface) PubSubChannels

func (m *MockRedisInterface) PubSubChannels(pattern string) *redis.StringSliceCmd

PubSubChannels mocks base method.

func (*MockRedisInterface) PubSubNumPat

func (m *MockRedisInterface) PubSubNumPat() *redis.IntCmd

PubSubNumPat mocks base method.

func (*MockRedisInterface) PubSubNumSub

func (m *MockRedisInterface) PubSubNumSub(channels ...string) *redis.StringIntMapCmd

PubSubNumSub mocks base method.

func (*MockRedisInterface) Publish

func (m *MockRedisInterface) Publish(channel string, message interface{}) *redis.IntCmd

Publish mocks base method.

func (*MockRedisInterface) Quit

func (m *MockRedisInterface) Quit() *redis.StatusCmd

Quit mocks base method.

func (*MockRedisInterface) RPop

func (m *MockRedisInterface) RPop(key string) *redis.StringCmd

RPop mocks base method.

func (*MockRedisInterface) RPopLPush

func (m *MockRedisInterface) RPopLPush(source, destination string) *redis.StringCmd

RPopLPush mocks base method.

func (*MockRedisInterface) RPush

func (m *MockRedisInterface) RPush(key string, values ...interface{}) *redis.IntCmd

RPush mocks base method.

func (*MockRedisInterface) RPushX

func (m *MockRedisInterface) RPushX(key string, value interface{}) *redis.IntCmd

RPushX mocks base method.

func (*MockRedisInterface) RandomKey

func (m *MockRedisInterface) RandomKey() *redis.StringCmd

RandomKey mocks base method.

func (*MockRedisInterface) ReadOnly

func (m *MockRedisInterface) ReadOnly() *redis.StatusCmd

ReadOnly mocks base method.

func (*MockRedisInterface) ReadWrite

func (m *MockRedisInterface) ReadWrite() *redis.StatusCmd

ReadWrite mocks base method.

func (*MockRedisInterface) Rename

func (m *MockRedisInterface) Rename(key, newkey string) *redis.StatusCmd

Rename mocks base method.

func (*MockRedisInterface) RenameNX

func (m *MockRedisInterface) RenameNX(key, newkey string) *redis.BoolCmd

RenameNX mocks base method.

func (*MockRedisInterface) Restore

func (m *MockRedisInterface) Restore(key string, ttl time.Duration, value string) *redis.StatusCmd

Restore mocks base method.

func (*MockRedisInterface) RestoreReplace

func (m *MockRedisInterface) RestoreReplace(key string, ttl time.Duration, value string) *redis.StatusCmd

RestoreReplace mocks base method.

func (*MockRedisInterface) SAdd

func (m *MockRedisInterface) SAdd(key string, members ...interface{}) *redis.IntCmd

SAdd mocks base method.

func (*MockRedisInterface) SCard

func (m *MockRedisInterface) SCard(key string) *redis.IntCmd

SCard mocks base method.

func (*MockRedisInterface) SDiff

func (m *MockRedisInterface) SDiff(keys ...string) *redis.StringSliceCmd

SDiff mocks base method.

func (*MockRedisInterface) SDiffStore

func (m *MockRedisInterface) SDiffStore(destination string, keys ...string) *redis.IntCmd

SDiffStore mocks base method.

func (*MockRedisInterface) SInter

func (m *MockRedisInterface) SInter(keys ...string) *redis.StringSliceCmd

SInter mocks base method.

func (*MockRedisInterface) SInterStore

func (m *MockRedisInterface) SInterStore(destination string, keys ...string) *redis.IntCmd

SInterStore mocks base method.

func (*MockRedisInterface) SIsMember

func (m *MockRedisInterface) SIsMember(key string, member interface{}) *redis.BoolCmd

SIsMember mocks base method.

func (*MockRedisInterface) SMembers

func (m *MockRedisInterface) SMembers(key string) *redis.StringSliceCmd

SMembers mocks base method.

func (*MockRedisInterface) SMembersMap

func (m *MockRedisInterface) SMembersMap(key string) *redis.StringStructMapCmd

SMembersMap mocks base method.

func (*MockRedisInterface) SMove

func (m *MockRedisInterface) SMove(source, destination string, member interface{}) *redis.BoolCmd

SMove mocks base method.

func (*MockRedisInterface) SPop

func (m *MockRedisInterface) SPop(key string) *redis.StringCmd

SPop mocks base method.

func (*MockRedisInterface) SPopN

func (m *MockRedisInterface) SPopN(key string, count int64) *redis.StringSliceCmd

SPopN mocks base method.

func (*MockRedisInterface) SRandMember

func (m *MockRedisInterface) SRandMember(key string) *redis.StringCmd

SRandMember mocks base method.

func (*MockRedisInterface) SRandMemberN

func (m *MockRedisInterface) SRandMemberN(key string, count int64) *redis.StringSliceCmd

SRandMemberN mocks base method.

func (*MockRedisInterface) SRem

func (m *MockRedisInterface) SRem(key string, members ...interface{}) *redis.IntCmd

SRem mocks base method.

func (*MockRedisInterface) SScan

func (m *MockRedisInterface) SScan(key string, cursor uint64, match string, count int64) *redis.ScanCmd

SScan mocks base method.

func (*MockRedisInterface) SUnion

func (m *MockRedisInterface) SUnion(keys ...string) *redis.StringSliceCmd

SUnion mocks base method.

func (*MockRedisInterface) SUnionStore

func (m *MockRedisInterface) SUnionStore(destination string, keys ...string) *redis.IntCmd

SUnionStore mocks base method.

func (*MockRedisInterface) Save

func (m *MockRedisInterface) Save() *redis.StatusCmd

Save mocks base method.

func (*MockRedisInterface) Scan

func (m *MockRedisInterface) Scan(cursor uint64, match string, count int64) *redis.ScanCmd

Scan mocks base method.

func (*MockRedisInterface) ScriptExists

func (m *MockRedisInterface) ScriptExists(hashes ...string) *redis.BoolSliceCmd

ScriptExists mocks base method.

func (*MockRedisInterface) ScriptFlush

func (m *MockRedisInterface) ScriptFlush() *redis.StatusCmd

ScriptFlush mocks base method.

func (*MockRedisInterface) ScriptKill

func (m *MockRedisInterface) ScriptKill() *redis.StatusCmd

ScriptKill mocks base method.

func (*MockRedisInterface) ScriptLoad

func (m *MockRedisInterface) ScriptLoad(script string) *redis.StringCmd

ScriptLoad mocks base method.

func (*MockRedisInterface) Set

func (m *MockRedisInterface) Set(key string, value interface{}, expiration time.Duration) *redis.StatusCmd

Set mocks base method.

func (*MockRedisInterface) SetBit

func (m *MockRedisInterface) SetBit(key string, offset int64, value int) *redis.IntCmd

SetBit mocks base method.

func (*MockRedisInterface) SetNX

func (m *MockRedisInterface) SetNX(key string, value interface{}, expiration time.Duration) *redis.BoolCmd

SetNX mocks base method.

func (*MockRedisInterface) SetRange

func (m *MockRedisInterface) SetRange(key string, offset int64, value string) *redis.IntCmd

SetRange mocks base method.

func (*MockRedisInterface) SetXX

func (m *MockRedisInterface) SetXX(key string, value interface{}, expiration time.Duration) *redis.BoolCmd

SetXX mocks base method.

func (*MockRedisInterface) Shutdown

func (m *MockRedisInterface) Shutdown() *redis.StatusCmd

Shutdown mocks base method.

func (*MockRedisInterface) ShutdownNoSave

func (m *MockRedisInterface) ShutdownNoSave() *redis.StatusCmd

ShutdownNoSave mocks base method.

func (*MockRedisInterface) ShutdownSave

func (m *MockRedisInterface) ShutdownSave() *redis.StatusCmd

ShutdownSave mocks base method.

func (*MockRedisInterface) SlaveOf

func (m *MockRedisInterface) SlaveOf(host, port string) *redis.StatusCmd

SlaveOf mocks base method.

func (*MockRedisInterface) Sort

func (m *MockRedisInterface) Sort(key string, sort *redis.Sort) *redis.StringSliceCmd

Sort mocks base method.

func (*MockRedisInterface) SortInterfaces

func (m *MockRedisInterface) SortInterfaces(key string, sort *redis.Sort) *redis.SliceCmd

SortInterfaces mocks base method.

func (*MockRedisInterface) SortStore

func (m *MockRedisInterface) SortStore(key, store string, sort *redis.Sort) *redis.IntCmd

SortStore mocks base method.

func (*MockRedisInterface) StrLen

func (m *MockRedisInterface) StrLen(key string) *redis.IntCmd

StrLen mocks base method.

func (*MockRedisInterface) Subscribe

func (m *MockRedisInterface) Subscribe(channels ...string) *redis.PubSub

Subscribe mocks base method.

func (*MockRedisInterface) TTL

TTL mocks base method.

func (*MockRedisInterface) Time

func (m *MockRedisInterface) Time() *redis.TimeCmd

Time mocks base method.

func (*MockRedisInterface) Touch

func (m *MockRedisInterface) Touch(keys ...string) *redis.IntCmd

Touch mocks base method.

func (*MockRedisInterface) TxPipeline

func (m *MockRedisInterface) TxPipeline() redis.Pipeliner

TxPipeline mocks base method.

func (*MockRedisInterface) TxPipelined

func (m *MockRedisInterface) TxPipelined(fn func(redis.Pipeliner) error) ([]redis.Cmder, error)

TxPipelined mocks base method.

func (*MockRedisInterface) Type

func (m *MockRedisInterface) Type(key string) *redis.StatusCmd

Type mocks base method.

func (m *MockRedisInterface) Unlink(keys ...string) *redis.IntCmd

Unlink mocks base method.

func (*MockRedisInterface) Watch

func (m *MockRedisInterface) Watch(fn func(*redis.Tx) error, keys ...string) error

Watch mocks base method.

func (*MockRedisInterface) WrapProcess

func (m *MockRedisInterface) WrapProcess(fn func(func(redis.Cmder) error) func(redis.Cmder) error)

WrapProcess mocks base method.

func (*MockRedisInterface) WrapProcessPipeline

func (m *MockRedisInterface) WrapProcessPipeline(fn func(func([]redis.Cmder) error) func([]redis.Cmder) error)

WrapProcessPipeline mocks base method.

func (*MockRedisInterface) XAck

func (m *MockRedisInterface) XAck(stream, group string, ids ...string) *redis.IntCmd

XAck mocks base method.

func (*MockRedisInterface) XAdd

XAdd mocks base method.

func (*MockRedisInterface) XClaim

XClaim mocks base method.

func (*MockRedisInterface) XClaimJustID

XClaimJustID mocks base method.

func (*MockRedisInterface) XDel

func (m *MockRedisInterface) XDel(stream string, ids ...string) *redis.IntCmd

XDel mocks base method.

func (*MockRedisInterface) XGroupCreate

func (m *MockRedisInterface) XGroupCreate(stream, group, start string) *redis.StatusCmd

XGroupCreate mocks base method.

func (*MockRedisInterface) XGroupCreateMkStream

func (m *MockRedisInterface) XGroupCreateMkStream(stream, group, start string) *redis.StatusCmd

XGroupCreateMkStream mocks base method.

func (*MockRedisInterface) XGroupDelConsumer

func (m *MockRedisInterface) XGroupDelConsumer(stream, group, consumer string) *redis.IntCmd

XGroupDelConsumer mocks base method.

func (*MockRedisInterface) XGroupDestroy

func (m *MockRedisInterface) XGroupDestroy(stream, group string) *redis.IntCmd

XGroupDestroy mocks base method.

func (*MockRedisInterface) XGroupSetID

func (m *MockRedisInterface) XGroupSetID(stream, group, start string) *redis.StatusCmd

XGroupSetID mocks base method.

func (*MockRedisInterface) XLen

func (m *MockRedisInterface) XLen(stream string) *redis.IntCmd

XLen mocks base method.

func (*MockRedisInterface) XPending

func (m *MockRedisInterface) XPending(stream, group string) *redis.XPendingCmd

XPending mocks base method.

func (*MockRedisInterface) XPendingExt

XPendingExt mocks base method.

func (*MockRedisInterface) XRange

func (m *MockRedisInterface) XRange(stream, start, stop string) *redis.XMessageSliceCmd

XRange mocks base method.

func (*MockRedisInterface) XRangeN

func (m *MockRedisInterface) XRangeN(stream, start, stop string, count int64) *redis.XMessageSliceCmd

XRangeN mocks base method.

func (*MockRedisInterface) XRead

XRead mocks base method.

func (*MockRedisInterface) XReadGroup

XReadGroup mocks base method.

func (*MockRedisInterface) XReadStreams

func (m *MockRedisInterface) XReadStreams(streams ...string) *redis.XStreamSliceCmd

XReadStreams mocks base method.

func (*MockRedisInterface) XRevRange

func (m *MockRedisInterface) XRevRange(stream, start, stop string) *redis.XMessageSliceCmd

XRevRange mocks base method.

func (*MockRedisInterface) XRevRangeN

func (m *MockRedisInterface) XRevRangeN(stream, start, stop string, count int64) *redis.XMessageSliceCmd

XRevRangeN mocks base method.

func (*MockRedisInterface) XTrim

func (m *MockRedisInterface) XTrim(key string, maxLen int64) *redis.IntCmd

XTrim mocks base method.

func (*MockRedisInterface) XTrimApprox

func (m *MockRedisInterface) XTrimApprox(key string, maxLen int64) *redis.IntCmd

XTrimApprox mocks base method.

func (*MockRedisInterface) ZAdd

func (m *MockRedisInterface) ZAdd(key string, members ...redis.Z) *redis.IntCmd

ZAdd mocks base method.

func (*MockRedisInterface) ZAddCh

func (m *MockRedisInterface) ZAddCh(key string, members ...redis.Z) *redis.IntCmd

ZAddCh mocks base method.

func (*MockRedisInterface) ZAddNX

func (m *MockRedisInterface) ZAddNX(key string, members ...redis.Z) *redis.IntCmd

ZAddNX mocks base method.

func (*MockRedisInterface) ZAddNXCh

func (m *MockRedisInterface) ZAddNXCh(key string, members ...redis.Z) *redis.IntCmd

ZAddNXCh mocks base method.

func (*MockRedisInterface) ZAddXX

func (m *MockRedisInterface) ZAddXX(key string, members ...redis.Z) *redis.IntCmd

ZAddXX mocks base method.

func (*MockRedisInterface) ZAddXXCh

func (m *MockRedisInterface) ZAddXXCh(key string, members ...redis.Z) *redis.IntCmd

ZAddXXCh mocks base method.

func (*MockRedisInterface) ZCard

func (m *MockRedisInterface) ZCard(key string) *redis.IntCmd

ZCard mocks base method.

func (*MockRedisInterface) ZCount

func (m *MockRedisInterface) ZCount(key, min, max string) *redis.IntCmd

ZCount mocks base method.

func (*MockRedisInterface) ZIncr

func (m *MockRedisInterface) ZIncr(key string, member redis.Z) *redis.FloatCmd

ZIncr mocks base method.

func (*MockRedisInterface) ZIncrBy

func (m *MockRedisInterface) ZIncrBy(key string, increment float64, member string) *redis.FloatCmd

ZIncrBy mocks base method.

func (*MockRedisInterface) ZIncrNX

func (m *MockRedisInterface) ZIncrNX(key string, member redis.Z) *redis.FloatCmd

ZIncrNX mocks base method.

func (*MockRedisInterface) ZIncrXX

func (m *MockRedisInterface) ZIncrXX(key string, member redis.Z) *redis.FloatCmd

ZIncrXX mocks base method.

func (*MockRedisInterface) ZInterStore

func (m *MockRedisInterface) ZInterStore(destination string, store redis.ZStore, keys ...string) *redis.IntCmd

ZInterStore mocks base method.

func (*MockRedisInterface) ZLexCount

func (m *MockRedisInterface) ZLexCount(key, min, max string) *redis.IntCmd

ZLexCount mocks base method.

func (*MockRedisInterface) ZPopMax

func (m *MockRedisInterface) ZPopMax(key string, count ...int64) *redis.ZSliceCmd

ZPopMax mocks base method.

func (*MockRedisInterface) ZPopMin

func (m *MockRedisInterface) ZPopMin(key string, count ...int64) *redis.ZSliceCmd

ZPopMin mocks base method.

func (*MockRedisInterface) ZRange

func (m *MockRedisInterface) ZRange(key string, start, stop int64) *redis.StringSliceCmd

ZRange mocks base method.

func (*MockRedisInterface) ZRangeByLex

func (m *MockRedisInterface) ZRangeByLex(key string, opt redis.ZRangeBy) *redis.StringSliceCmd

ZRangeByLex mocks base method.

func (*MockRedisInterface) ZRangeByScore

func (m *MockRedisInterface) ZRangeByScore(key string, opt redis.ZRangeBy) *redis.StringSliceCmd

ZRangeByScore mocks base method.

func (*MockRedisInterface) ZRangeByScoreWithScores

func (m *MockRedisInterface) ZRangeByScoreWithScores(key string, opt redis.ZRangeBy) *redis.ZSliceCmd

ZRangeByScoreWithScores mocks base method.

func (*MockRedisInterface) ZRangeWithScores

func (m *MockRedisInterface) ZRangeWithScores(key string, start, stop int64) *redis.ZSliceCmd

ZRangeWithScores mocks base method.

func (*MockRedisInterface) ZRank

func (m *MockRedisInterface) ZRank(key, member string) *redis.IntCmd

ZRank mocks base method.

func (*MockRedisInterface) ZRem

func (m *MockRedisInterface) ZRem(key string, members ...interface{}) *redis.IntCmd

ZRem mocks base method.

func (*MockRedisInterface) ZRemRangeByLex

func (m *MockRedisInterface) ZRemRangeByLex(key, min, max string) *redis.IntCmd

ZRemRangeByLex mocks base method.

func (*MockRedisInterface) ZRemRangeByRank

func (m *MockRedisInterface) ZRemRangeByRank(key string, start, stop int64) *redis.IntCmd

ZRemRangeByRank mocks base method.

func (*MockRedisInterface) ZRemRangeByScore

func (m *MockRedisInterface) ZRemRangeByScore(key, min, max string) *redis.IntCmd

ZRemRangeByScore mocks base method.

func (*MockRedisInterface) ZRevRange

func (m *MockRedisInterface) ZRevRange(key string, start, stop int64) *redis.StringSliceCmd

ZRevRange mocks base method.

func (*MockRedisInterface) ZRevRangeByLex

func (m *MockRedisInterface) ZRevRangeByLex(key string, opt redis.ZRangeBy) *redis.StringSliceCmd

ZRevRangeByLex mocks base method.

func (*MockRedisInterface) ZRevRangeByScore

func (m *MockRedisInterface) ZRevRangeByScore(key string, opt redis.ZRangeBy) *redis.StringSliceCmd

ZRevRangeByScore mocks base method.

func (*MockRedisInterface) ZRevRangeByScoreWithScores

func (m *MockRedisInterface) ZRevRangeByScoreWithScores(key string, opt redis.ZRangeBy) *redis.ZSliceCmd

ZRevRangeByScoreWithScores mocks base method.

func (*MockRedisInterface) ZRevRangeWithScores

func (m *MockRedisInterface) ZRevRangeWithScores(key string, start, stop int64) *redis.ZSliceCmd

ZRevRangeWithScores mocks base method.

func (*MockRedisInterface) ZRevRank

func (m *MockRedisInterface) ZRevRank(key, member string) *redis.IntCmd

ZRevRank mocks base method.

func (*MockRedisInterface) ZScan

func (m *MockRedisInterface) ZScan(key string, cursor uint64, match string, count int64) *redis.ScanCmd

ZScan mocks base method.

func (*MockRedisInterface) ZScore

func (m *MockRedisInterface) ZScore(key, member string) *redis.FloatCmd

ZScore mocks base method.

func (*MockRedisInterface) ZUnionStore

func (m *MockRedisInterface) ZUnionStore(dest string, store redis.ZStore, keys ...string) *redis.IntCmd

ZUnionStore mocks base method.

type MockRedisInterfaceMockRecorder

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

MockRedisInterfaceMockRecorder is the mock recorder for MockRedisInterface.

func (*MockRedisInterfaceMockRecorder) Append

func (mr *MockRedisInterfaceMockRecorder) Append(key, value interface{}) *gomock.Call

Append indicates an expected call of Append.

func (*MockRedisInterfaceMockRecorder) BLPop

func (mr *MockRedisInterfaceMockRecorder) BLPop(timeout interface{}, keys ...interface{}) *gomock.Call

BLPop indicates an expected call of BLPop.

func (*MockRedisInterfaceMockRecorder) BRPop

func (mr *MockRedisInterfaceMockRecorder) BRPop(timeout interface{}, keys ...interface{}) *gomock.Call

BRPop indicates an expected call of BRPop.

func (*MockRedisInterfaceMockRecorder) BRPopLPush

func (mr *MockRedisInterfaceMockRecorder) BRPopLPush(source, destination, timeout interface{}) *gomock.Call

BRPopLPush indicates an expected call of BRPopLPush.

func (*MockRedisInterfaceMockRecorder) BZPopMax

func (mr *MockRedisInterfaceMockRecorder) BZPopMax(timeout interface{}, keys ...interface{}) *gomock.Call

BZPopMax indicates an expected call of BZPopMax.

func (*MockRedisInterfaceMockRecorder) BZPopMin

func (mr *MockRedisInterfaceMockRecorder) BZPopMin(timeout interface{}, keys ...interface{}) *gomock.Call

BZPopMin indicates an expected call of BZPopMin.

func (*MockRedisInterfaceMockRecorder) BgRewriteAOF

func (mr *MockRedisInterfaceMockRecorder) BgRewriteAOF() *gomock.Call

BgRewriteAOF indicates an expected call of BgRewriteAOF.

func (*MockRedisInterfaceMockRecorder) BgSave

BgSave indicates an expected call of BgSave.

func (*MockRedisInterfaceMockRecorder) BitCount

func (mr *MockRedisInterfaceMockRecorder) BitCount(key, bitCount interface{}) *gomock.Call

BitCount indicates an expected call of BitCount.

func (*MockRedisInterfaceMockRecorder) BitOpAnd

func (mr *MockRedisInterfaceMockRecorder) BitOpAnd(destKey interface{}, keys ...interface{}) *gomock.Call

BitOpAnd indicates an expected call of BitOpAnd.

func (*MockRedisInterfaceMockRecorder) BitOpNot

func (mr *MockRedisInterfaceMockRecorder) BitOpNot(destKey, key interface{}) *gomock.Call

BitOpNot indicates an expected call of BitOpNot.

func (*MockRedisInterfaceMockRecorder) BitOpOr

func (mr *MockRedisInterfaceMockRecorder) BitOpOr(destKey interface{}, keys ...interface{}) *gomock.Call

BitOpOr indicates an expected call of BitOpOr.

func (*MockRedisInterfaceMockRecorder) BitOpXor

func (mr *MockRedisInterfaceMockRecorder) BitOpXor(destKey interface{}, keys ...interface{}) *gomock.Call

BitOpXor indicates an expected call of BitOpXor.

func (*MockRedisInterfaceMockRecorder) BitPos

func (mr *MockRedisInterfaceMockRecorder) BitPos(key, bit interface{}, pos ...interface{}) *gomock.Call

BitPos indicates an expected call of BitPos.

func (*MockRedisInterfaceMockRecorder) ClientGetName

func (mr *MockRedisInterfaceMockRecorder) ClientGetName() *gomock.Call

ClientGetName indicates an expected call of ClientGetName.

func (*MockRedisInterfaceMockRecorder) ClientID

func (mr *MockRedisInterfaceMockRecorder) ClientID() *gomock.Call

ClientID indicates an expected call of ClientID.

func (*MockRedisInterfaceMockRecorder) ClientKill

func (mr *MockRedisInterfaceMockRecorder) ClientKill(ipPort interface{}) *gomock.Call

ClientKill indicates an expected call of ClientKill.

func (*MockRedisInterfaceMockRecorder) ClientKillByFilter

func (mr *MockRedisInterfaceMockRecorder) ClientKillByFilter(keys ...interface{}) *gomock.Call

ClientKillByFilter indicates an expected call of ClientKillByFilter.

func (*MockRedisInterfaceMockRecorder) ClientList

func (mr *MockRedisInterfaceMockRecorder) ClientList() *gomock.Call

ClientList indicates an expected call of ClientList.

func (*MockRedisInterfaceMockRecorder) ClientPause

func (mr *MockRedisInterfaceMockRecorder) ClientPause(dur interface{}) *gomock.Call

ClientPause indicates an expected call of ClientPause.

func (*MockRedisInterfaceMockRecorder) Close

Close indicates an expected call of Close.

func (*MockRedisInterfaceMockRecorder) ClusterAddSlots

func (mr *MockRedisInterfaceMockRecorder) ClusterAddSlots(slots ...interface{}) *gomock.Call

ClusterAddSlots indicates an expected call of ClusterAddSlots.

func (*MockRedisInterfaceMockRecorder) ClusterAddSlotsRange

func (mr *MockRedisInterfaceMockRecorder) ClusterAddSlotsRange(min, max interface{}) *gomock.Call

ClusterAddSlotsRange indicates an expected call of ClusterAddSlotsRange.

func (*MockRedisInterfaceMockRecorder) ClusterCountFailureReports

func (mr *MockRedisInterfaceMockRecorder) ClusterCountFailureReports(nodeID interface{}) *gomock.Call

ClusterCountFailureReports indicates an expected call of ClusterCountFailureReports.

func (*MockRedisInterfaceMockRecorder) ClusterCountKeysInSlot

func (mr *MockRedisInterfaceMockRecorder) ClusterCountKeysInSlot(slot interface{}) *gomock.Call

ClusterCountKeysInSlot indicates an expected call of ClusterCountKeysInSlot.

func (*MockRedisInterfaceMockRecorder) ClusterDelSlots

func (mr *MockRedisInterfaceMockRecorder) ClusterDelSlots(slots ...interface{}) *gomock.Call

ClusterDelSlots indicates an expected call of ClusterDelSlots.

func (*MockRedisInterfaceMockRecorder) ClusterDelSlotsRange

func (mr *MockRedisInterfaceMockRecorder) ClusterDelSlotsRange(min, max interface{}) *gomock.Call

ClusterDelSlotsRange indicates an expected call of ClusterDelSlotsRange.

func (*MockRedisInterfaceMockRecorder) ClusterFailover

func (mr *MockRedisInterfaceMockRecorder) ClusterFailover() *gomock.Call

ClusterFailover indicates an expected call of ClusterFailover.

func (*MockRedisInterfaceMockRecorder) ClusterForget

func (mr *MockRedisInterfaceMockRecorder) ClusterForget(nodeID interface{}) *gomock.Call

ClusterForget indicates an expected call of ClusterForget.

func (*MockRedisInterfaceMockRecorder) ClusterGetKeysInSlot

func (mr *MockRedisInterfaceMockRecorder) ClusterGetKeysInSlot(slot, count interface{}) *gomock.Call

ClusterGetKeysInSlot indicates an expected call of ClusterGetKeysInSlot.

func (*MockRedisInterfaceMockRecorder) ClusterInfo

func (mr *MockRedisInterfaceMockRecorder) ClusterInfo() *gomock.Call

ClusterInfo indicates an expected call of ClusterInfo.

func (*MockRedisInterfaceMockRecorder) ClusterKeySlot

func (mr *MockRedisInterfaceMockRecorder) ClusterKeySlot(key interface{}) *gomock.Call

ClusterKeySlot indicates an expected call of ClusterKeySlot.

func (*MockRedisInterfaceMockRecorder) ClusterMeet

func (mr *MockRedisInterfaceMockRecorder) ClusterMeet(host, port interface{}) *gomock.Call

ClusterMeet indicates an expected call of ClusterMeet.

func (*MockRedisInterfaceMockRecorder) ClusterNodes

func (mr *MockRedisInterfaceMockRecorder) ClusterNodes() *gomock.Call

ClusterNodes indicates an expected call of ClusterNodes.

func (*MockRedisInterfaceMockRecorder) ClusterReplicate

func (mr *MockRedisInterfaceMockRecorder) ClusterReplicate(nodeID interface{}) *gomock.Call

ClusterReplicate indicates an expected call of ClusterReplicate.

func (*MockRedisInterfaceMockRecorder) ClusterResetHard

func (mr *MockRedisInterfaceMockRecorder) ClusterResetHard() *gomock.Call

ClusterResetHard indicates an expected call of ClusterResetHard.

func (*MockRedisInterfaceMockRecorder) ClusterResetSoft

func (mr *MockRedisInterfaceMockRecorder) ClusterResetSoft() *gomock.Call

ClusterResetSoft indicates an expected call of ClusterResetSoft.

func (*MockRedisInterfaceMockRecorder) ClusterSaveConfig

func (mr *MockRedisInterfaceMockRecorder) ClusterSaveConfig() *gomock.Call

ClusterSaveConfig indicates an expected call of ClusterSaveConfig.

func (*MockRedisInterfaceMockRecorder) ClusterSlaves

func (mr *MockRedisInterfaceMockRecorder) ClusterSlaves(nodeID interface{}) *gomock.Call

ClusterSlaves indicates an expected call of ClusterSlaves.

func (*MockRedisInterfaceMockRecorder) ClusterSlots

func (mr *MockRedisInterfaceMockRecorder) ClusterSlots() *gomock.Call

ClusterSlots indicates an expected call of ClusterSlots.

func (*MockRedisInterfaceMockRecorder) Command

Command indicates an expected call of Command.

func (*MockRedisInterfaceMockRecorder) ConfigGet

func (mr *MockRedisInterfaceMockRecorder) ConfigGet(parameter interface{}) *gomock.Call

ConfigGet indicates an expected call of ConfigGet.

func (*MockRedisInterfaceMockRecorder) ConfigResetStat

func (mr *MockRedisInterfaceMockRecorder) ConfigResetStat() *gomock.Call

ConfigResetStat indicates an expected call of ConfigResetStat.

func (*MockRedisInterfaceMockRecorder) ConfigRewrite

func (mr *MockRedisInterfaceMockRecorder) ConfigRewrite() *gomock.Call

ConfigRewrite indicates an expected call of ConfigRewrite.

func (*MockRedisInterfaceMockRecorder) ConfigSet

func (mr *MockRedisInterfaceMockRecorder) ConfigSet(parameter, value interface{}) *gomock.Call

ConfigSet indicates an expected call of ConfigSet.

func (*MockRedisInterfaceMockRecorder) DBSize

DBSize indicates an expected call of DBSize.

func (*MockRedisInterfaceMockRecorder) DebugObject

func (mr *MockRedisInterfaceMockRecorder) DebugObject(key interface{}) *gomock.Call

DebugObject indicates an expected call of DebugObject.

func (*MockRedisInterfaceMockRecorder) Decr

func (mr *MockRedisInterfaceMockRecorder) Decr(key interface{}) *gomock.Call

Decr indicates an expected call of Decr.

func (*MockRedisInterfaceMockRecorder) DecrBy

func (mr *MockRedisInterfaceMockRecorder) DecrBy(key, decrement interface{}) *gomock.Call

DecrBy indicates an expected call of DecrBy.

func (*MockRedisInterfaceMockRecorder) Del

func (mr *MockRedisInterfaceMockRecorder) Del(keys ...interface{}) *gomock.Call

Del indicates an expected call of Del.

func (*MockRedisInterfaceMockRecorder) Dump

func (mr *MockRedisInterfaceMockRecorder) Dump(key interface{}) *gomock.Call

Dump indicates an expected call of Dump.

func (*MockRedisInterfaceMockRecorder) Echo

func (mr *MockRedisInterfaceMockRecorder) Echo(message interface{}) *gomock.Call

Echo indicates an expected call of Echo.

func (*MockRedisInterfaceMockRecorder) Eval

func (mr *MockRedisInterfaceMockRecorder) Eval(script, keys interface{}, args ...interface{}) *gomock.Call

Eval indicates an expected call of Eval.

func (*MockRedisInterfaceMockRecorder) EvalSha

func (mr *MockRedisInterfaceMockRecorder) EvalSha(sha1, keys interface{}, args ...interface{}) *gomock.Call

EvalSha indicates an expected call of EvalSha.

func (*MockRedisInterfaceMockRecorder) Exists

func (mr *MockRedisInterfaceMockRecorder) Exists(keys ...interface{}) *gomock.Call

Exists indicates an expected call of Exists.

func (*MockRedisInterfaceMockRecorder) Expire

func (mr *MockRedisInterfaceMockRecorder) Expire(key, expiration interface{}) *gomock.Call

Expire indicates an expected call of Expire.

func (*MockRedisInterfaceMockRecorder) ExpireAt

func (mr *MockRedisInterfaceMockRecorder) ExpireAt(key, tm interface{}) *gomock.Call

ExpireAt indicates an expected call of ExpireAt.

func (*MockRedisInterfaceMockRecorder) FlushAll

func (mr *MockRedisInterfaceMockRecorder) FlushAll() *gomock.Call

FlushAll indicates an expected call of FlushAll.

func (*MockRedisInterfaceMockRecorder) FlushAllAsync

func (mr *MockRedisInterfaceMockRecorder) FlushAllAsync() *gomock.Call

FlushAllAsync indicates an expected call of FlushAllAsync.

func (*MockRedisInterfaceMockRecorder) FlushDB

FlushDB indicates an expected call of FlushDB.

func (*MockRedisInterfaceMockRecorder) FlushDBAsync

func (mr *MockRedisInterfaceMockRecorder) FlushDBAsync() *gomock.Call

FlushDBAsync indicates an expected call of FlushDBAsync.

func (*MockRedisInterfaceMockRecorder) GeoAdd

func (mr *MockRedisInterfaceMockRecorder) GeoAdd(key interface{}, geoLocation ...interface{}) *gomock.Call

GeoAdd indicates an expected call of GeoAdd.

func (*MockRedisInterfaceMockRecorder) GeoDist

func (mr *MockRedisInterfaceMockRecorder) GeoDist(key, member1, member2, unit interface{}) *gomock.Call

GeoDist indicates an expected call of GeoDist.

func (*MockRedisInterfaceMockRecorder) GeoHash

func (mr *MockRedisInterfaceMockRecorder) GeoHash(key interface{}, members ...interface{}) *gomock.Call

GeoHash indicates an expected call of GeoHash.

func (*MockRedisInterfaceMockRecorder) GeoPos

func (mr *MockRedisInterfaceMockRecorder) GeoPos(key interface{}, members ...interface{}) *gomock.Call

GeoPos indicates an expected call of GeoPos.

func (*MockRedisInterfaceMockRecorder) GeoRadius

func (mr *MockRedisInterfaceMockRecorder) GeoRadius(key, longitude, latitude, query interface{}) *gomock.Call

GeoRadius indicates an expected call of GeoRadius.

func (*MockRedisInterfaceMockRecorder) GeoRadiusByMember

func (mr *MockRedisInterfaceMockRecorder) GeoRadiusByMember(key, member, query interface{}) *gomock.Call

GeoRadiusByMember indicates an expected call of GeoRadiusByMember.

func (*MockRedisInterfaceMockRecorder) GeoRadiusByMemberRO

func (mr *MockRedisInterfaceMockRecorder) GeoRadiusByMemberRO(key, member, query interface{}) *gomock.Call

GeoRadiusByMemberRO indicates an expected call of GeoRadiusByMemberRO.

func (*MockRedisInterfaceMockRecorder) GeoRadiusRO

func (mr *MockRedisInterfaceMockRecorder) GeoRadiusRO(key, longitude, latitude, query interface{}) *gomock.Call

GeoRadiusRO indicates an expected call of GeoRadiusRO.

func (*MockRedisInterfaceMockRecorder) Get

func (mr *MockRedisInterfaceMockRecorder) Get(key interface{}) *gomock.Call

Get indicates an expected call of Get.

func (*MockRedisInterfaceMockRecorder) GetBit

func (mr *MockRedisInterfaceMockRecorder) GetBit(key, offset interface{}) *gomock.Call

GetBit indicates an expected call of GetBit.

func (*MockRedisInterfaceMockRecorder) GetRange

func (mr *MockRedisInterfaceMockRecorder) GetRange(key, start, end interface{}) *gomock.Call

GetRange indicates an expected call of GetRange.

func (*MockRedisInterfaceMockRecorder) GetSet

func (mr *MockRedisInterfaceMockRecorder) GetSet(key, value interface{}) *gomock.Call

GetSet indicates an expected call of GetSet.

func (*MockRedisInterfaceMockRecorder) HDel

func (mr *MockRedisInterfaceMockRecorder) HDel(key interface{}, fields ...interface{}) *gomock.Call

HDel indicates an expected call of HDel.

func (*MockRedisInterfaceMockRecorder) HExists

func (mr *MockRedisInterfaceMockRecorder) HExists(key, field interface{}) *gomock.Call

HExists indicates an expected call of HExists.

func (*MockRedisInterfaceMockRecorder) HGet

func (mr *MockRedisInterfaceMockRecorder) HGet(key, field interface{}) *gomock.Call

HGet indicates an expected call of HGet.

func (*MockRedisInterfaceMockRecorder) HGetAll

func (mr *MockRedisInterfaceMockRecorder) HGetAll(key interface{}) *gomock.Call

HGetAll indicates an expected call of HGetAll.

func (*MockRedisInterfaceMockRecorder) HIncrBy

func (mr *MockRedisInterfaceMockRecorder) HIncrBy(key, field, incr interface{}) *gomock.Call

HIncrBy indicates an expected call of HIncrBy.

func (*MockRedisInterfaceMockRecorder) HIncrByFloat

func (mr *MockRedisInterfaceMockRecorder) HIncrByFloat(key, field, incr interface{}) *gomock.Call

HIncrByFloat indicates an expected call of HIncrByFloat.

func (*MockRedisInterfaceMockRecorder) HKeys

func (mr *MockRedisInterfaceMockRecorder) HKeys(key interface{}) *gomock.Call

HKeys indicates an expected call of HKeys.

func (*MockRedisInterfaceMockRecorder) HLen

func (mr *MockRedisInterfaceMockRecorder) HLen(key interface{}) *gomock.Call

HLen indicates an expected call of HLen.

func (*MockRedisInterfaceMockRecorder) HMGet

func (mr *MockRedisInterfaceMockRecorder) HMGet(key interface{}, fields ...interface{}) *gomock.Call

HMGet indicates an expected call of HMGet.

func (*MockRedisInterfaceMockRecorder) HMSet

func (mr *MockRedisInterfaceMockRecorder) HMSet(key, fields interface{}) *gomock.Call

HMSet indicates an expected call of HMSet.

func (*MockRedisInterfaceMockRecorder) HScan

func (mr *MockRedisInterfaceMockRecorder) HScan(key, cursor, match, count interface{}) *gomock.Call

HScan indicates an expected call of HScan.

func (*MockRedisInterfaceMockRecorder) HSet

func (mr *MockRedisInterfaceMockRecorder) HSet(key, field, value interface{}) *gomock.Call

HSet indicates an expected call of HSet.

func (*MockRedisInterfaceMockRecorder) HSetNX

func (mr *MockRedisInterfaceMockRecorder) HSetNX(key, field, value interface{}) *gomock.Call

HSetNX indicates an expected call of HSetNX.

func (*MockRedisInterfaceMockRecorder) HVals

func (mr *MockRedisInterfaceMockRecorder) HVals(key interface{}) *gomock.Call

HVals indicates an expected call of HVals.

func (*MockRedisInterfaceMockRecorder) Incr

func (mr *MockRedisInterfaceMockRecorder) Incr(key interface{}) *gomock.Call

Incr indicates an expected call of Incr.

func (*MockRedisInterfaceMockRecorder) IncrBy

func (mr *MockRedisInterfaceMockRecorder) IncrBy(key, value interface{}) *gomock.Call

IncrBy indicates an expected call of IncrBy.

func (*MockRedisInterfaceMockRecorder) IncrByFloat

func (mr *MockRedisInterfaceMockRecorder) IncrByFloat(key, value interface{}) *gomock.Call

IncrByFloat indicates an expected call of IncrByFloat.

func (*MockRedisInterfaceMockRecorder) Info

func (mr *MockRedisInterfaceMockRecorder) Info(section ...interface{}) *gomock.Call

Info indicates an expected call of Info.

func (*MockRedisInterfaceMockRecorder) Keys

func (mr *MockRedisInterfaceMockRecorder) Keys(pattern interface{}) *gomock.Call

Keys indicates an expected call of Keys.

func (*MockRedisInterfaceMockRecorder) LIndex

func (mr *MockRedisInterfaceMockRecorder) LIndex(key, index interface{}) *gomock.Call

LIndex indicates an expected call of LIndex.

func (*MockRedisInterfaceMockRecorder) LInsert

func (mr *MockRedisInterfaceMockRecorder) LInsert(key, op, pivot, value interface{}) *gomock.Call

LInsert indicates an expected call of LInsert.

func (*MockRedisInterfaceMockRecorder) LInsertAfter

func (mr *MockRedisInterfaceMockRecorder) LInsertAfter(key, pivot, value interface{}) *gomock.Call

LInsertAfter indicates an expected call of LInsertAfter.

func (*MockRedisInterfaceMockRecorder) LInsertBefore

func (mr *MockRedisInterfaceMockRecorder) LInsertBefore(key, pivot, value interface{}) *gomock.Call

LInsertBefore indicates an expected call of LInsertBefore.

func (*MockRedisInterfaceMockRecorder) LLen

func (mr *MockRedisInterfaceMockRecorder) LLen(key interface{}) *gomock.Call

LLen indicates an expected call of LLen.

func (*MockRedisInterfaceMockRecorder) LPop

func (mr *MockRedisInterfaceMockRecorder) LPop(key interface{}) *gomock.Call

LPop indicates an expected call of LPop.

func (*MockRedisInterfaceMockRecorder) LPush

func (mr *MockRedisInterfaceMockRecorder) LPush(key interface{}, values ...interface{}) *gomock.Call

LPush indicates an expected call of LPush.

func (*MockRedisInterfaceMockRecorder) LPushX

func (mr *MockRedisInterfaceMockRecorder) LPushX(key, value interface{}) *gomock.Call

LPushX indicates an expected call of LPushX.

func (*MockRedisInterfaceMockRecorder) LRange

func (mr *MockRedisInterfaceMockRecorder) LRange(key, start, stop interface{}) *gomock.Call

LRange indicates an expected call of LRange.

func (*MockRedisInterfaceMockRecorder) LRem

func (mr *MockRedisInterfaceMockRecorder) LRem(key, count, value interface{}) *gomock.Call

LRem indicates an expected call of LRem.

func (*MockRedisInterfaceMockRecorder) LSet

func (mr *MockRedisInterfaceMockRecorder) LSet(key, index, value interface{}) *gomock.Call

LSet indicates an expected call of LSet.

func (*MockRedisInterfaceMockRecorder) LTrim

func (mr *MockRedisInterfaceMockRecorder) LTrim(key, start, stop interface{}) *gomock.Call

LTrim indicates an expected call of LTrim.

func (*MockRedisInterfaceMockRecorder) LastSave

func (mr *MockRedisInterfaceMockRecorder) LastSave() *gomock.Call

LastSave indicates an expected call of LastSave.

func (*MockRedisInterfaceMockRecorder) MGet

func (mr *MockRedisInterfaceMockRecorder) MGet(keys ...interface{}) *gomock.Call

MGet indicates an expected call of MGet.

func (*MockRedisInterfaceMockRecorder) MSet

func (mr *MockRedisInterfaceMockRecorder) MSet(pairs ...interface{}) *gomock.Call

MSet indicates an expected call of MSet.

func (*MockRedisInterfaceMockRecorder) MSetNX

func (mr *MockRedisInterfaceMockRecorder) MSetNX(pairs ...interface{}) *gomock.Call

MSetNX indicates an expected call of MSetNX.

func (*MockRedisInterfaceMockRecorder) MemoryUsage

func (mr *MockRedisInterfaceMockRecorder) MemoryUsage(key interface{}, samples ...interface{}) *gomock.Call

MemoryUsage indicates an expected call of MemoryUsage.

func (*MockRedisInterfaceMockRecorder) Migrate

func (mr *MockRedisInterfaceMockRecorder) Migrate(host, port, key, db, timeout interface{}) *gomock.Call

Migrate indicates an expected call of Migrate.

func (*MockRedisInterfaceMockRecorder) Move

func (mr *MockRedisInterfaceMockRecorder) Move(key, db interface{}) *gomock.Call

Move indicates an expected call of Move.

func (*MockRedisInterfaceMockRecorder) ObjectEncoding

func (mr *MockRedisInterfaceMockRecorder) ObjectEncoding(key interface{}) *gomock.Call

ObjectEncoding indicates an expected call of ObjectEncoding.

func (*MockRedisInterfaceMockRecorder) ObjectIdleTime

func (mr *MockRedisInterfaceMockRecorder) ObjectIdleTime(key interface{}) *gomock.Call

ObjectIdleTime indicates an expected call of ObjectIdleTime.

func (*MockRedisInterfaceMockRecorder) ObjectRefCount

func (mr *MockRedisInterfaceMockRecorder) ObjectRefCount(key interface{}) *gomock.Call

ObjectRefCount indicates an expected call of ObjectRefCount.

func (*MockRedisInterfaceMockRecorder) PExpire

func (mr *MockRedisInterfaceMockRecorder) PExpire(key, expiration interface{}) *gomock.Call

PExpire indicates an expected call of PExpire.

func (*MockRedisInterfaceMockRecorder) PExpireAt

func (mr *MockRedisInterfaceMockRecorder) PExpireAt(key, tm interface{}) *gomock.Call

PExpireAt indicates an expected call of PExpireAt.

func (*MockRedisInterfaceMockRecorder) PFAdd

func (mr *MockRedisInterfaceMockRecorder) PFAdd(key interface{}, els ...interface{}) *gomock.Call

PFAdd indicates an expected call of PFAdd.

func (*MockRedisInterfaceMockRecorder) PFCount

func (mr *MockRedisInterfaceMockRecorder) PFCount(keys ...interface{}) *gomock.Call

PFCount indicates an expected call of PFCount.

func (*MockRedisInterfaceMockRecorder) PFMerge

func (mr *MockRedisInterfaceMockRecorder) PFMerge(dest interface{}, keys ...interface{}) *gomock.Call

PFMerge indicates an expected call of PFMerge.

func (*MockRedisInterfaceMockRecorder) PSubscribe

func (mr *MockRedisInterfaceMockRecorder) PSubscribe(channels ...interface{}) *gomock.Call

PSubscribe indicates an expected call of PSubscribe.

func (*MockRedisInterfaceMockRecorder) PTTL

func (mr *MockRedisInterfaceMockRecorder) PTTL(key interface{}) *gomock.Call

PTTL indicates an expected call of PTTL.

func (*MockRedisInterfaceMockRecorder) Persist

func (mr *MockRedisInterfaceMockRecorder) Persist(key interface{}) *gomock.Call

Persist indicates an expected call of Persist.

func (*MockRedisInterfaceMockRecorder) Ping

Ping indicates an expected call of Ping.

func (*MockRedisInterfaceMockRecorder) Pipeline

func (mr *MockRedisInterfaceMockRecorder) Pipeline() *gomock.Call

Pipeline indicates an expected call of Pipeline.

func (*MockRedisInterfaceMockRecorder) Pipelined

func (mr *MockRedisInterfaceMockRecorder) Pipelined(fn interface{}) *gomock.Call

Pipelined indicates an expected call of Pipelined.

func (*MockRedisInterfaceMockRecorder) Process

func (mr *MockRedisInterfaceMockRecorder) Process(cmd interface{}) *gomock.Call

Process indicates an expected call of Process.

func (*MockRedisInterfaceMockRecorder) PubSubChannels

func (mr *MockRedisInterfaceMockRecorder) PubSubChannels(pattern interface{}) *gomock.Call

PubSubChannels indicates an expected call of PubSubChannels.

func (*MockRedisInterfaceMockRecorder) PubSubNumPat

func (mr *MockRedisInterfaceMockRecorder) PubSubNumPat() *gomock.Call

PubSubNumPat indicates an expected call of PubSubNumPat.

func (*MockRedisInterfaceMockRecorder) PubSubNumSub

func (mr *MockRedisInterfaceMockRecorder) PubSubNumSub(channels ...interface{}) *gomock.Call

PubSubNumSub indicates an expected call of PubSubNumSub.

func (*MockRedisInterfaceMockRecorder) Publish

func (mr *MockRedisInterfaceMockRecorder) Publish(channel, message interface{}) *gomock.Call

Publish indicates an expected call of Publish.

func (*MockRedisInterfaceMockRecorder) Quit

Quit indicates an expected call of Quit.

func (*MockRedisInterfaceMockRecorder) RPop

func (mr *MockRedisInterfaceMockRecorder) RPop(key interface{}) *gomock.Call

RPop indicates an expected call of RPop.

func (*MockRedisInterfaceMockRecorder) RPopLPush

func (mr *MockRedisInterfaceMockRecorder) RPopLPush(source, destination interface{}) *gomock.Call

RPopLPush indicates an expected call of RPopLPush.

func (*MockRedisInterfaceMockRecorder) RPush

func (mr *MockRedisInterfaceMockRecorder) RPush(key interface{}, values ...interface{}) *gomock.Call

RPush indicates an expected call of RPush.

func (*MockRedisInterfaceMockRecorder) RPushX

func (mr *MockRedisInterfaceMockRecorder) RPushX(key, value interface{}) *gomock.Call

RPushX indicates an expected call of RPushX.

func (*MockRedisInterfaceMockRecorder) RandomKey

func (mr *MockRedisInterfaceMockRecorder) RandomKey() *gomock.Call

RandomKey indicates an expected call of RandomKey.

func (*MockRedisInterfaceMockRecorder) ReadOnly

func (mr *MockRedisInterfaceMockRecorder) ReadOnly() *gomock.Call

ReadOnly indicates an expected call of ReadOnly.

func (*MockRedisInterfaceMockRecorder) ReadWrite

func (mr *MockRedisInterfaceMockRecorder) ReadWrite() *gomock.Call

ReadWrite indicates an expected call of ReadWrite.

func (*MockRedisInterfaceMockRecorder) Rename

func (mr *MockRedisInterfaceMockRecorder) Rename(key, newkey interface{}) *gomock.Call

Rename indicates an expected call of Rename.

func (*MockRedisInterfaceMockRecorder) RenameNX

func (mr *MockRedisInterfaceMockRecorder) RenameNX(key, newkey interface{}) *gomock.Call

RenameNX indicates an expected call of RenameNX.

func (*MockRedisInterfaceMockRecorder) Restore

func (mr *MockRedisInterfaceMockRecorder) Restore(key, ttl, value interface{}) *gomock.Call

Restore indicates an expected call of Restore.

func (*MockRedisInterfaceMockRecorder) RestoreReplace

func (mr *MockRedisInterfaceMockRecorder) RestoreReplace(key, ttl, value interface{}) *gomock.Call

RestoreReplace indicates an expected call of RestoreReplace.

func (*MockRedisInterfaceMockRecorder) SAdd

func (mr *MockRedisInterfaceMockRecorder) SAdd(key interface{}, members ...interface{}) *gomock.Call

SAdd indicates an expected call of SAdd.

func (*MockRedisInterfaceMockRecorder) SCard

func (mr *MockRedisInterfaceMockRecorder) SCard(key interface{}) *gomock.Call

SCard indicates an expected call of SCard.

func (*MockRedisInterfaceMockRecorder) SDiff

func (mr *MockRedisInterfaceMockRecorder) SDiff(keys ...interface{}) *gomock.Call

SDiff indicates an expected call of SDiff.

func (*MockRedisInterfaceMockRecorder) SDiffStore

func (mr *MockRedisInterfaceMockRecorder) SDiffStore(destination interface{}, keys ...interface{}) *gomock.Call

SDiffStore indicates an expected call of SDiffStore.

func (*MockRedisInterfaceMockRecorder) SInter

func (mr *MockRedisInterfaceMockRecorder) SInter(keys ...interface{}) *gomock.Call

SInter indicates an expected call of SInter.

func (*MockRedisInterfaceMockRecorder) SInterStore

func (mr *MockRedisInterfaceMockRecorder) SInterStore(destination interface{}, keys ...interface{}) *gomock.Call

SInterStore indicates an expected call of SInterStore.

func (*MockRedisInterfaceMockRecorder) SIsMember

func (mr *MockRedisInterfaceMockRecorder) SIsMember(key, member interface{}) *gomock.Call

SIsMember indicates an expected call of SIsMember.

func (*MockRedisInterfaceMockRecorder) SMembers

func (mr *MockRedisInterfaceMockRecorder) SMembers(key interface{}) *gomock.Call

SMembers indicates an expected call of SMembers.

func (*MockRedisInterfaceMockRecorder) SMembersMap

func (mr *MockRedisInterfaceMockRecorder) SMembersMap(key interface{}) *gomock.Call

SMembersMap indicates an expected call of SMembersMap.

func (*MockRedisInterfaceMockRecorder) SMove

func (mr *MockRedisInterfaceMockRecorder) SMove(source, destination, member interface{}) *gomock.Call

SMove indicates an expected call of SMove.

func (*MockRedisInterfaceMockRecorder) SPop

func (mr *MockRedisInterfaceMockRecorder) SPop(key interface{}) *gomock.Call

SPop indicates an expected call of SPop.

func (*MockRedisInterfaceMockRecorder) SPopN

func (mr *MockRedisInterfaceMockRecorder) SPopN(key, count interface{}) *gomock.Call

SPopN indicates an expected call of SPopN.

func (*MockRedisInterfaceMockRecorder) SRandMember

func (mr *MockRedisInterfaceMockRecorder) SRandMember(key interface{}) *gomock.Call

SRandMember indicates an expected call of SRandMember.

func (*MockRedisInterfaceMockRecorder) SRandMemberN

func (mr *MockRedisInterfaceMockRecorder) SRandMemberN(key, count interface{}) *gomock.Call

SRandMemberN indicates an expected call of SRandMemberN.

func (*MockRedisInterfaceMockRecorder) SRem

func (mr *MockRedisInterfaceMockRecorder) SRem(key interface{}, members ...interface{}) *gomock.Call

SRem indicates an expected call of SRem.

func (*MockRedisInterfaceMockRecorder) SScan

func (mr *MockRedisInterfaceMockRecorder) SScan(key, cursor, match, count interface{}) *gomock.Call

SScan indicates an expected call of SScan.

func (*MockRedisInterfaceMockRecorder) SUnion

func (mr *MockRedisInterfaceMockRecorder) SUnion(keys ...interface{}) *gomock.Call

SUnion indicates an expected call of SUnion.

func (*MockRedisInterfaceMockRecorder) SUnionStore

func (mr *MockRedisInterfaceMockRecorder) SUnionStore(destination interface{}, keys ...interface{}) *gomock.Call

SUnionStore indicates an expected call of SUnionStore.

func (*MockRedisInterfaceMockRecorder) Save

Save indicates an expected call of Save.

func (*MockRedisInterfaceMockRecorder) Scan

func (mr *MockRedisInterfaceMockRecorder) Scan(cursor, match, count interface{}) *gomock.Call

Scan indicates an expected call of Scan.

func (*MockRedisInterfaceMockRecorder) ScriptExists

func (mr *MockRedisInterfaceMockRecorder) ScriptExists(hashes ...interface{}) *gomock.Call

ScriptExists indicates an expected call of ScriptExists.

func (*MockRedisInterfaceMockRecorder) ScriptFlush

func (mr *MockRedisInterfaceMockRecorder) ScriptFlush() *gomock.Call

ScriptFlush indicates an expected call of ScriptFlush.

func (*MockRedisInterfaceMockRecorder) ScriptKill

func (mr *MockRedisInterfaceMockRecorder) ScriptKill() *gomock.Call

ScriptKill indicates an expected call of ScriptKill.

func (*MockRedisInterfaceMockRecorder) ScriptLoad

func (mr *MockRedisInterfaceMockRecorder) ScriptLoad(script interface{}) *gomock.Call

ScriptLoad indicates an expected call of ScriptLoad.

func (*MockRedisInterfaceMockRecorder) Set

func (mr *MockRedisInterfaceMockRecorder) Set(key, value, expiration interface{}) *gomock.Call

Set indicates an expected call of Set.

func (*MockRedisInterfaceMockRecorder) SetBit

func (mr *MockRedisInterfaceMockRecorder) SetBit(key, offset, value interface{}) *gomock.Call

SetBit indicates an expected call of SetBit.

func (*MockRedisInterfaceMockRecorder) SetNX

func (mr *MockRedisInterfaceMockRecorder) SetNX(key, value, expiration interface{}) *gomock.Call

SetNX indicates an expected call of SetNX.

func (*MockRedisInterfaceMockRecorder) SetRange

func (mr *MockRedisInterfaceMockRecorder) SetRange(key, offset, value interface{}) *gomock.Call

SetRange indicates an expected call of SetRange.

func (*MockRedisInterfaceMockRecorder) SetXX

func (mr *MockRedisInterfaceMockRecorder) SetXX(key, value, expiration interface{}) *gomock.Call

SetXX indicates an expected call of SetXX.

func (*MockRedisInterfaceMockRecorder) Shutdown

func (mr *MockRedisInterfaceMockRecorder) Shutdown() *gomock.Call

Shutdown indicates an expected call of Shutdown.

func (*MockRedisInterfaceMockRecorder) ShutdownNoSave

func (mr *MockRedisInterfaceMockRecorder) ShutdownNoSave() *gomock.Call

ShutdownNoSave indicates an expected call of ShutdownNoSave.

func (*MockRedisInterfaceMockRecorder) ShutdownSave

func (mr *MockRedisInterfaceMockRecorder) ShutdownSave() *gomock.Call

ShutdownSave indicates an expected call of ShutdownSave.

func (*MockRedisInterfaceMockRecorder) SlaveOf

func (mr *MockRedisInterfaceMockRecorder) SlaveOf(host, port interface{}) *gomock.Call

SlaveOf indicates an expected call of SlaveOf.

func (*MockRedisInterfaceMockRecorder) Sort

func (mr *MockRedisInterfaceMockRecorder) Sort(key, sort interface{}) *gomock.Call

Sort indicates an expected call of Sort.

func (*MockRedisInterfaceMockRecorder) SortInterfaces

func (mr *MockRedisInterfaceMockRecorder) SortInterfaces(key, sort interface{}) *gomock.Call

SortInterfaces indicates an expected call of SortInterfaces.

func (*MockRedisInterfaceMockRecorder) SortStore

func (mr *MockRedisInterfaceMockRecorder) SortStore(key, store, sort interface{}) *gomock.Call

SortStore indicates an expected call of SortStore.

func (*MockRedisInterfaceMockRecorder) StrLen

func (mr *MockRedisInterfaceMockRecorder) StrLen(key interface{}) *gomock.Call

StrLen indicates an expected call of StrLen.

func (*MockRedisInterfaceMockRecorder) Subscribe

func (mr *MockRedisInterfaceMockRecorder) Subscribe(channels ...interface{}) *gomock.Call

Subscribe indicates an expected call of Subscribe.

func (*MockRedisInterfaceMockRecorder) TTL

func (mr *MockRedisInterfaceMockRecorder) TTL(key interface{}) *gomock.Call

TTL indicates an expected call of TTL.

func (*MockRedisInterfaceMockRecorder) Time

Time indicates an expected call of Time.

func (*MockRedisInterfaceMockRecorder) Touch

func (mr *MockRedisInterfaceMockRecorder) Touch(keys ...interface{}) *gomock.Call

Touch indicates an expected call of Touch.

func (*MockRedisInterfaceMockRecorder) TxPipeline

func (mr *MockRedisInterfaceMockRecorder) TxPipeline() *gomock.Call

TxPipeline indicates an expected call of TxPipeline.

func (*MockRedisInterfaceMockRecorder) TxPipelined

func (mr *MockRedisInterfaceMockRecorder) TxPipelined(fn interface{}) *gomock.Call

TxPipelined indicates an expected call of TxPipelined.

func (*MockRedisInterfaceMockRecorder) Type

func (mr *MockRedisInterfaceMockRecorder) Type(key interface{}) *gomock.Call

Type indicates an expected call of Type.

func (mr *MockRedisInterfaceMockRecorder) Unlink(keys ...interface{}) *gomock.Call

Unlink indicates an expected call of Unlink.

func (*MockRedisInterfaceMockRecorder) Watch

func (mr *MockRedisInterfaceMockRecorder) Watch(fn interface{}, keys ...interface{}) *gomock.Call

Watch indicates an expected call of Watch.

func (*MockRedisInterfaceMockRecorder) WrapProcess

func (mr *MockRedisInterfaceMockRecorder) WrapProcess(fn interface{}) *gomock.Call

WrapProcess indicates an expected call of WrapProcess.

func (*MockRedisInterfaceMockRecorder) WrapProcessPipeline

func (mr *MockRedisInterfaceMockRecorder) WrapProcessPipeline(fn interface{}) *gomock.Call

WrapProcessPipeline indicates an expected call of WrapProcessPipeline.

func (*MockRedisInterfaceMockRecorder) XAck

func (mr *MockRedisInterfaceMockRecorder) XAck(stream, group interface{}, ids ...interface{}) *gomock.Call

XAck indicates an expected call of XAck.

func (*MockRedisInterfaceMockRecorder) XAdd

func (mr *MockRedisInterfaceMockRecorder) XAdd(a interface{}) *gomock.Call

XAdd indicates an expected call of XAdd.

func (*MockRedisInterfaceMockRecorder) XClaim

func (mr *MockRedisInterfaceMockRecorder) XClaim(a interface{}) *gomock.Call

XClaim indicates an expected call of XClaim.

func (*MockRedisInterfaceMockRecorder) XClaimJustID

func (mr *MockRedisInterfaceMockRecorder) XClaimJustID(a interface{}) *gomock.Call

XClaimJustID indicates an expected call of XClaimJustID.

func (*MockRedisInterfaceMockRecorder) XDel

func (mr *MockRedisInterfaceMockRecorder) XDel(stream interface{}, ids ...interface{}) *gomock.Call

XDel indicates an expected call of XDel.

func (*MockRedisInterfaceMockRecorder) XGroupCreate

func (mr *MockRedisInterfaceMockRecorder) XGroupCreate(stream, group, start interface{}) *gomock.Call

XGroupCreate indicates an expected call of XGroupCreate.

func (*MockRedisInterfaceMockRecorder) XGroupCreateMkStream

func (mr *MockRedisInterfaceMockRecorder) XGroupCreateMkStream(stream, group, start interface{}) *gomock.Call

XGroupCreateMkStream indicates an expected call of XGroupCreateMkStream.

func (*MockRedisInterfaceMockRecorder) XGroupDelConsumer

func (mr *MockRedisInterfaceMockRecorder) XGroupDelConsumer(stream, group, consumer interface{}) *gomock.Call

XGroupDelConsumer indicates an expected call of XGroupDelConsumer.

func (*MockRedisInterfaceMockRecorder) XGroupDestroy

func (mr *MockRedisInterfaceMockRecorder) XGroupDestroy(stream, group interface{}) *gomock.Call

XGroupDestroy indicates an expected call of XGroupDestroy.

func (*MockRedisInterfaceMockRecorder) XGroupSetID

func (mr *MockRedisInterfaceMockRecorder) XGroupSetID(stream, group, start interface{}) *gomock.Call

XGroupSetID indicates an expected call of XGroupSetID.

func (*MockRedisInterfaceMockRecorder) XLen

func (mr *MockRedisInterfaceMockRecorder) XLen(stream interface{}) *gomock.Call

XLen indicates an expected call of XLen.

func (*MockRedisInterfaceMockRecorder) XPending

func (mr *MockRedisInterfaceMockRecorder) XPending(stream, group interface{}) *gomock.Call

XPending indicates an expected call of XPending.

func (*MockRedisInterfaceMockRecorder) XPendingExt

func (mr *MockRedisInterfaceMockRecorder) XPendingExt(a interface{}) *gomock.Call

XPendingExt indicates an expected call of XPendingExt.

func (*MockRedisInterfaceMockRecorder) XRange

func (mr *MockRedisInterfaceMockRecorder) XRange(stream, start, stop interface{}) *gomock.Call

XRange indicates an expected call of XRange.

func (*MockRedisInterfaceMockRecorder) XRangeN

func (mr *MockRedisInterfaceMockRecorder) XRangeN(stream, start, stop, count interface{}) *gomock.Call

XRangeN indicates an expected call of XRangeN.

func (*MockRedisInterfaceMockRecorder) XRead

func (mr *MockRedisInterfaceMockRecorder) XRead(a interface{}) *gomock.Call

XRead indicates an expected call of XRead.

func (*MockRedisInterfaceMockRecorder) XReadGroup

func (mr *MockRedisInterfaceMockRecorder) XReadGroup(a interface{}) *gomock.Call

XReadGroup indicates an expected call of XReadGroup.

func (*MockRedisInterfaceMockRecorder) XReadStreams

func (mr *MockRedisInterfaceMockRecorder) XReadStreams(streams ...interface{}) *gomock.Call

XReadStreams indicates an expected call of XReadStreams.

func (*MockRedisInterfaceMockRecorder) XRevRange

func (mr *MockRedisInterfaceMockRecorder) XRevRange(stream, start, stop interface{}) *gomock.Call

XRevRange indicates an expected call of XRevRange.

func (*MockRedisInterfaceMockRecorder) XRevRangeN

func (mr *MockRedisInterfaceMockRecorder) XRevRangeN(stream, start, stop, count interface{}) *gomock.Call

XRevRangeN indicates an expected call of XRevRangeN.

func (*MockRedisInterfaceMockRecorder) XTrim

func (mr *MockRedisInterfaceMockRecorder) XTrim(key, maxLen interface{}) *gomock.Call

XTrim indicates an expected call of XTrim.

func (*MockRedisInterfaceMockRecorder) XTrimApprox

func (mr *MockRedisInterfaceMockRecorder) XTrimApprox(key, maxLen interface{}) *gomock.Call

XTrimApprox indicates an expected call of XTrimApprox.

func (*MockRedisInterfaceMockRecorder) ZAdd

func (mr *MockRedisInterfaceMockRecorder) ZAdd(key interface{}, members ...interface{}) *gomock.Call

ZAdd indicates an expected call of ZAdd.

func (*MockRedisInterfaceMockRecorder) ZAddCh

func (mr *MockRedisInterfaceMockRecorder) ZAddCh(key interface{}, members ...interface{}) *gomock.Call

ZAddCh indicates an expected call of ZAddCh.

func (*MockRedisInterfaceMockRecorder) ZAddNX

func (mr *MockRedisInterfaceMockRecorder) ZAddNX(key interface{}, members ...interface{}) *gomock.Call

ZAddNX indicates an expected call of ZAddNX.

func (*MockRedisInterfaceMockRecorder) ZAddNXCh

func (mr *MockRedisInterfaceMockRecorder) ZAddNXCh(key interface{}, members ...interface{}) *gomock.Call

ZAddNXCh indicates an expected call of ZAddNXCh.

func (*MockRedisInterfaceMockRecorder) ZAddXX

func (mr *MockRedisInterfaceMockRecorder) ZAddXX(key interface{}, members ...interface{}) *gomock.Call

ZAddXX indicates an expected call of ZAddXX.

func (*MockRedisInterfaceMockRecorder) ZAddXXCh

func (mr *MockRedisInterfaceMockRecorder) ZAddXXCh(key interface{}, members ...interface{}) *gomock.Call

ZAddXXCh indicates an expected call of ZAddXXCh.

func (*MockRedisInterfaceMockRecorder) ZCard

func (mr *MockRedisInterfaceMockRecorder) ZCard(key interface{}) *gomock.Call

ZCard indicates an expected call of ZCard.

func (*MockRedisInterfaceMockRecorder) ZCount

func (mr *MockRedisInterfaceMockRecorder) ZCount(key, min, max interface{}) *gomock.Call

ZCount indicates an expected call of ZCount.

func (*MockRedisInterfaceMockRecorder) ZIncr

func (mr *MockRedisInterfaceMockRecorder) ZIncr(key, member interface{}) *gomock.Call

ZIncr indicates an expected call of ZIncr.

func (*MockRedisInterfaceMockRecorder) ZIncrBy

func (mr *MockRedisInterfaceMockRecorder) ZIncrBy(key, increment, member interface{}) *gomock.Call

ZIncrBy indicates an expected call of ZIncrBy.

func (*MockRedisInterfaceMockRecorder) ZIncrNX

func (mr *MockRedisInterfaceMockRecorder) ZIncrNX(key, member interface{}) *gomock.Call

ZIncrNX indicates an expected call of ZIncrNX.

func (*MockRedisInterfaceMockRecorder) ZIncrXX

func (mr *MockRedisInterfaceMockRecorder) ZIncrXX(key, member interface{}) *gomock.Call

ZIncrXX indicates an expected call of ZIncrXX.

func (*MockRedisInterfaceMockRecorder) ZInterStore

func (mr *MockRedisInterfaceMockRecorder) ZInterStore(destination, store interface{}, keys ...interface{}) *gomock.Call

ZInterStore indicates an expected call of ZInterStore.

func (*MockRedisInterfaceMockRecorder) ZLexCount

func (mr *MockRedisInterfaceMockRecorder) ZLexCount(key, min, max interface{}) *gomock.Call

ZLexCount indicates an expected call of ZLexCount.

func (*MockRedisInterfaceMockRecorder) ZPopMax

func (mr *MockRedisInterfaceMockRecorder) ZPopMax(key interface{}, count ...interface{}) *gomock.Call

ZPopMax indicates an expected call of ZPopMax.

func (*MockRedisInterfaceMockRecorder) ZPopMin

func (mr *MockRedisInterfaceMockRecorder) ZPopMin(key interface{}, count ...interface{}) *gomock.Call

ZPopMin indicates an expected call of ZPopMin.

func (*MockRedisInterfaceMockRecorder) ZRange

func (mr *MockRedisInterfaceMockRecorder) ZRange(key, start, stop interface{}) *gomock.Call

ZRange indicates an expected call of ZRange.

func (*MockRedisInterfaceMockRecorder) ZRangeByLex

func (mr *MockRedisInterfaceMockRecorder) ZRangeByLex(key, opt interface{}) *gomock.Call

ZRangeByLex indicates an expected call of ZRangeByLex.

func (*MockRedisInterfaceMockRecorder) ZRangeByScore

func (mr *MockRedisInterfaceMockRecorder) ZRangeByScore(key, opt interface{}) *gomock.Call

ZRangeByScore indicates an expected call of ZRangeByScore.

func (*MockRedisInterfaceMockRecorder) ZRangeByScoreWithScores

func (mr *MockRedisInterfaceMockRecorder) ZRangeByScoreWithScores(key, opt interface{}) *gomock.Call

ZRangeByScoreWithScores indicates an expected call of ZRangeByScoreWithScores.

func (*MockRedisInterfaceMockRecorder) ZRangeWithScores

func (mr *MockRedisInterfaceMockRecorder) ZRangeWithScores(key, start, stop interface{}) *gomock.Call

ZRangeWithScores indicates an expected call of ZRangeWithScores.

func (*MockRedisInterfaceMockRecorder) ZRank

func (mr *MockRedisInterfaceMockRecorder) ZRank(key, member interface{}) *gomock.Call

ZRank indicates an expected call of ZRank.

func (*MockRedisInterfaceMockRecorder) ZRem

func (mr *MockRedisInterfaceMockRecorder) ZRem(key interface{}, members ...interface{}) *gomock.Call

ZRem indicates an expected call of ZRem.

func (*MockRedisInterfaceMockRecorder) ZRemRangeByLex

func (mr *MockRedisInterfaceMockRecorder) ZRemRangeByLex(key, min, max interface{}) *gomock.Call

ZRemRangeByLex indicates an expected call of ZRemRangeByLex.

func (*MockRedisInterfaceMockRecorder) ZRemRangeByRank

func (mr *MockRedisInterfaceMockRecorder) ZRemRangeByRank(key, start, stop interface{}) *gomock.Call

ZRemRangeByRank indicates an expected call of ZRemRangeByRank.

func (*MockRedisInterfaceMockRecorder) ZRemRangeByScore

func (mr *MockRedisInterfaceMockRecorder) ZRemRangeByScore(key, min, max interface{}) *gomock.Call

ZRemRangeByScore indicates an expected call of ZRemRangeByScore.

func (*MockRedisInterfaceMockRecorder) ZRevRange

func (mr *MockRedisInterfaceMockRecorder) ZRevRange(key, start, stop interface{}) *gomock.Call

ZRevRange indicates an expected call of ZRevRange.

func (*MockRedisInterfaceMockRecorder) ZRevRangeByLex

func (mr *MockRedisInterfaceMockRecorder) ZRevRangeByLex(key, opt interface{}) *gomock.Call

ZRevRangeByLex indicates an expected call of ZRevRangeByLex.

func (*MockRedisInterfaceMockRecorder) ZRevRangeByScore

func (mr *MockRedisInterfaceMockRecorder) ZRevRangeByScore(key, opt interface{}) *gomock.Call

ZRevRangeByScore indicates an expected call of ZRevRangeByScore.

func (*MockRedisInterfaceMockRecorder) ZRevRangeByScoreWithScores

func (mr *MockRedisInterfaceMockRecorder) ZRevRangeByScoreWithScores(key, opt interface{}) *gomock.Call

ZRevRangeByScoreWithScores indicates an expected call of ZRevRangeByScoreWithScores.

func (*MockRedisInterfaceMockRecorder) ZRevRangeWithScores

func (mr *MockRedisInterfaceMockRecorder) ZRevRangeWithScores(key, start, stop interface{}) *gomock.Call

ZRevRangeWithScores indicates an expected call of ZRevRangeWithScores.

func (*MockRedisInterfaceMockRecorder) ZRevRank

func (mr *MockRedisInterfaceMockRecorder) ZRevRank(key, member interface{}) *gomock.Call

ZRevRank indicates an expected call of ZRevRank.

func (*MockRedisInterfaceMockRecorder) ZScan

func (mr *MockRedisInterfaceMockRecorder) ZScan(key, cursor, match, count interface{}) *gomock.Call

ZScan indicates an expected call of ZScan.

func (*MockRedisInterfaceMockRecorder) ZScore

func (mr *MockRedisInterfaceMockRecorder) ZScore(key, member interface{}) *gomock.Call

ZScore indicates an expected call of ZScore.

func (*MockRedisInterfaceMockRecorder) ZUnionStore

func (mr *MockRedisInterfaceMockRecorder) ZUnionStore(dest, store interface{}, keys ...interface{}) *gomock.Call

ZUnionStore indicates an expected call of ZUnionStore.

type RedisInterface

type RedisInterface interface {
	Watch(fn func(*redis.Tx) error, keys ...string) error
	Process(cmd redis.Cmder) error
	WrapProcess(fn func(oldProcess func(cmd redis.Cmder) error) func(cmd redis.Cmder) error)
	WrapProcessPipeline(fn func(oldProcess func([]redis.Cmder) error) func([]redis.Cmder) error)
	Subscribe(channels ...string) *redis.PubSub
	PSubscribe(channels ...string) *redis.PubSub
	Pipeline() redis.Pipeliner
	Pipelined(fn func(redis.Pipeliner) error) ([]redis.Cmder, error)
	TxPipelined(fn func(redis.Pipeliner) error) ([]redis.Cmder, error)
	TxPipeline() redis.Pipeliner
	Command() *redis.CommandsInfoCmd
	ClientGetName() *redis.StringCmd
	Echo(message interface{}) *redis.StringCmd
	Ping() *redis.StatusCmd
	Quit() *redis.StatusCmd
	Del(keys ...string) *redis.IntCmd
	Unlink(keys ...string) *redis.IntCmd
	Dump(key string) *redis.StringCmd
	Exists(keys ...string) *redis.IntCmd
	Expire(key string, expiration time.Duration) *redis.BoolCmd
	ExpireAt(key string, tm time.Time) *redis.BoolCmd
	Keys(pattern string) *redis.StringSliceCmd
	Migrate(host, port, key string, db int64, timeout time.Duration) *redis.StatusCmd
	Move(key string, db int64) *redis.BoolCmd
	ObjectRefCount(key string) *redis.IntCmd
	ObjectEncoding(key string) *redis.StringCmd
	ObjectIdleTime(key string) *redis.DurationCmd
	Persist(key string) *redis.BoolCmd
	PExpire(key string, expiration time.Duration) *redis.BoolCmd
	PExpireAt(key string, tm time.Time) *redis.BoolCmd
	PTTL(key string) *redis.DurationCmd
	RandomKey() *redis.StringCmd
	Rename(key, newkey string) *redis.StatusCmd
	RenameNX(key, newkey string) *redis.BoolCmd
	Restore(key string, ttl time.Duration, value string) *redis.StatusCmd
	RestoreReplace(key string, ttl time.Duration, value string) *redis.StatusCmd
	Sort(key string, sort *redis.Sort) *redis.StringSliceCmd
	SortStore(key, store string, sort *redis.Sort) *redis.IntCmd
	SortInterfaces(key string, sort *redis.Sort) *redis.SliceCmd
	Touch(keys ...string) *redis.IntCmd
	TTL(key string) *redis.DurationCmd
	Type(key string) *redis.StatusCmd
	Scan(cursor uint64, match string, count int64) *redis.ScanCmd
	SScan(key string, cursor uint64, match string, count int64) *redis.ScanCmd
	HScan(key string, cursor uint64, match string, count int64) *redis.ScanCmd
	ZScan(key string, cursor uint64, match string, count int64) *redis.ScanCmd
	Append(key, value string) *redis.IntCmd
	BitCount(key string, bitCount *redis.BitCount) *redis.IntCmd
	BitOpAnd(destKey string, keys ...string) *redis.IntCmd
	BitOpOr(destKey string, keys ...string) *redis.IntCmd
	BitOpXor(destKey string, keys ...string) *redis.IntCmd
	BitOpNot(destKey string, key string) *redis.IntCmd
	BitPos(key string, bit int64, pos ...int64) *redis.IntCmd
	Decr(key string) *redis.IntCmd
	DecrBy(key string, decrement int64) *redis.IntCmd
	Get(key string) *redis.StringCmd
	GetBit(key string, offset int64) *redis.IntCmd
	GetRange(key string, start, end int64) *redis.StringCmd
	GetSet(key string, value interface{}) *redis.StringCmd
	Incr(key string) *redis.IntCmd
	IncrBy(key string, value int64) *redis.IntCmd
	IncrByFloat(key string, value float64) *redis.FloatCmd
	MGet(keys ...string) *redis.SliceCmd
	MSet(pairs ...interface{}) *redis.StatusCmd
	MSetNX(pairs ...interface{}) *redis.BoolCmd
	Set(key string, value interface{}, expiration time.Duration) *redis.StatusCmd
	SetBit(key string, offset int64, value int) *redis.IntCmd
	SetNX(key string, value interface{}, expiration time.Duration) *redis.BoolCmd
	SetXX(key string, value interface{}, expiration time.Duration) *redis.BoolCmd
	SetRange(key string, offset int64, value string) *redis.IntCmd
	StrLen(key string) *redis.IntCmd
	HDel(key string, fields ...string) *redis.IntCmd
	HExists(key, field string) *redis.BoolCmd
	HGet(key, field string) *redis.StringCmd
	HGetAll(key string) *redis.StringStringMapCmd
	HIncrBy(key, field string, incr int64) *redis.IntCmd
	HIncrByFloat(key, field string, incr float64) *redis.FloatCmd
	HKeys(key string) *redis.StringSliceCmd
	HLen(key string) *redis.IntCmd
	HMGet(key string, fields ...string) *redis.SliceCmd
	HMSet(key string, fields map[string]interface{}) *redis.StatusCmd
	HSet(key, field string, value interface{}) *redis.BoolCmd
	HSetNX(key, field string, value interface{}) *redis.BoolCmd
	HVals(key string) *redis.StringSliceCmd
	BLPop(timeout time.Duration, keys ...string) *redis.StringSliceCmd
	BRPop(timeout time.Duration, keys ...string) *redis.StringSliceCmd
	BRPopLPush(source, destination string, timeout time.Duration) *redis.StringCmd
	LIndex(key string, index int64) *redis.StringCmd
	LInsert(key, op string, pivot, value interface{}) *redis.IntCmd
	LInsertBefore(key string, pivot, value interface{}) *redis.IntCmd
	LInsertAfter(key string, pivot, value interface{}) *redis.IntCmd
	LLen(key string) *redis.IntCmd
	LPop(key string) *redis.StringCmd
	LPush(key string, values ...interface{}) *redis.IntCmd
	LPushX(key string, value interface{}) *redis.IntCmd
	LRange(key string, start, stop int64) *redis.StringSliceCmd
	LRem(key string, count int64, value interface{}) *redis.IntCmd
	LSet(key string, index int64, value interface{}) *redis.StatusCmd
	LTrim(key string, start, stop int64) *redis.StatusCmd
	RPop(key string) *redis.StringCmd
	RPopLPush(source, destination string) *redis.StringCmd
	RPush(key string, values ...interface{}) *redis.IntCmd
	RPushX(key string, value interface{}) *redis.IntCmd
	SAdd(key string, members ...interface{}) *redis.IntCmd
	SCard(key string) *redis.IntCmd
	SDiff(keys ...string) *redis.StringSliceCmd
	SDiffStore(destination string, keys ...string) *redis.IntCmd
	SInter(keys ...string) *redis.StringSliceCmd
	SInterStore(destination string, keys ...string) *redis.IntCmd
	SIsMember(key string, member interface{}) *redis.BoolCmd
	SMembers(key string) *redis.StringSliceCmd
	SMembersMap(key string) *redis.StringStructMapCmd
	SMove(source, destination string, member interface{}) *redis.BoolCmd
	SPop(key string) *redis.StringCmd
	SPopN(key string, count int64) *redis.StringSliceCmd
	SRandMember(key string) *redis.StringCmd
	SRandMemberN(key string, count int64) *redis.StringSliceCmd
	SRem(key string, members ...interface{}) *redis.IntCmd
	SUnion(keys ...string) *redis.StringSliceCmd
	SUnionStore(destination string, keys ...string) *redis.IntCmd
	XAdd(a *redis.XAddArgs) *redis.StringCmd
	XDel(stream string, ids ...string) *redis.IntCmd
	XLen(stream string) *redis.IntCmd
	XRange(stream, start, stop string) *redis.XMessageSliceCmd
	XRangeN(stream, start, stop string, count int64) *redis.XMessageSliceCmd
	XRevRange(stream string, start, stop string) *redis.XMessageSliceCmd
	XRevRangeN(stream string, start, stop string, count int64) *redis.XMessageSliceCmd
	XRead(a *redis.XReadArgs) *redis.XStreamSliceCmd
	XReadStreams(streams ...string) *redis.XStreamSliceCmd
	XGroupCreate(stream, group, start string) *redis.StatusCmd
	XGroupCreateMkStream(stream, group, start string) *redis.StatusCmd
	XGroupSetID(stream, group, start string) *redis.StatusCmd
	XGroupDestroy(stream, group string) *redis.IntCmd
	XGroupDelConsumer(stream, group, consumer string) *redis.IntCmd
	XReadGroup(a *redis.XReadGroupArgs) *redis.XStreamSliceCmd
	XAck(stream, group string, ids ...string) *redis.IntCmd
	XPending(stream, group string) *redis.XPendingCmd
	XPendingExt(a *redis.XPendingExtArgs) *redis.XPendingExtCmd
	XClaim(a *redis.XClaimArgs) *redis.XMessageSliceCmd
	XClaimJustID(a *redis.XClaimArgs) *redis.StringSliceCmd
	XTrim(key string, maxLen int64) *redis.IntCmd
	XTrimApprox(key string, maxLen int64) *redis.IntCmd
	BZPopMax(timeout time.Duration, keys ...string) *redis.ZWithKeyCmd
	BZPopMin(timeout time.Duration, keys ...string) *redis.ZWithKeyCmd
	ZAdd(key string, members ...redis.Z) *redis.IntCmd
	ZAddNX(key string, members ...redis.Z) *redis.IntCmd
	ZAddXX(key string, members ...redis.Z) *redis.IntCmd
	ZAddCh(key string, members ...redis.Z) *redis.IntCmd
	ZAddNXCh(key string, members ...redis.Z) *redis.IntCmd
	ZAddXXCh(key string, members ...redis.Z) *redis.IntCmd
	ZIncr(key string, member redis.Z) *redis.FloatCmd
	ZIncrNX(key string, member redis.Z) *redis.FloatCmd
	ZIncrXX(key string, member redis.Z) *redis.FloatCmd
	ZCard(key string) *redis.IntCmd
	ZCount(key, min, max string) *redis.IntCmd
	ZLexCount(key, min, max string) *redis.IntCmd
	ZIncrBy(key string, increment float64, member string) *redis.FloatCmd
	ZInterStore(destination string, store redis.ZStore, keys ...string) *redis.IntCmd
	ZPopMax(key string, count ...int64) *redis.ZSliceCmd
	ZPopMin(key string, count ...int64) *redis.ZSliceCmd
	ZRange(key string, start, stop int64) *redis.StringSliceCmd
	ZRangeWithScores(key string, start, stop int64) *redis.ZSliceCmd
	ZRangeByScore(key string, opt redis.ZRangeBy) *redis.StringSliceCmd
	ZRangeByLex(key string, opt redis.ZRangeBy) *redis.StringSliceCmd
	ZRangeByScoreWithScores(key string, opt redis.ZRangeBy) *redis.ZSliceCmd
	ZRank(key, member string) *redis.IntCmd
	ZRem(key string, members ...interface{}) *redis.IntCmd
	ZRemRangeByRank(key string, start, stop int64) *redis.IntCmd
	ZRemRangeByScore(key, min, max string) *redis.IntCmd
	ZRemRangeByLex(key, min, max string) *redis.IntCmd
	ZRevRange(key string, start, stop int64) *redis.StringSliceCmd
	ZRevRangeWithScores(key string, start, stop int64) *redis.ZSliceCmd
	ZRevRangeByScore(key string, opt redis.ZRangeBy) *redis.StringSliceCmd
	ZRevRangeByLex(key string, opt redis.ZRangeBy) *redis.StringSliceCmd
	ZRevRangeByScoreWithScores(key string, opt redis.ZRangeBy) *redis.ZSliceCmd
	ZRevRank(key, member string) *redis.IntCmd
	ZScore(key, member string) *redis.FloatCmd
	ZUnionStore(dest string, store redis.ZStore, keys ...string) *redis.IntCmd
	PFAdd(key string, els ...interface{}) *redis.IntCmd
	PFCount(keys ...string) *redis.IntCmd
	PFMerge(dest string, keys ...string) *redis.StatusCmd
	BgRewriteAOF() *redis.StatusCmd
	BgSave() *redis.StatusCmd
	ClientKill(ipPort string) *redis.StatusCmd
	ClientKillByFilter(keys ...string) *redis.IntCmd
	ClientList() *redis.StringCmd
	ClientPause(dur time.Duration) *redis.BoolCmd
	ClientID() *redis.IntCmd
	ConfigGet(parameter string) *redis.SliceCmd
	ConfigResetStat() *redis.StatusCmd
	ConfigSet(parameter, value string) *redis.StatusCmd
	ConfigRewrite() *redis.StatusCmd
	DBSize() *redis.IntCmd
	FlushAll() *redis.StatusCmd
	FlushAllAsync() *redis.StatusCmd
	FlushDB() *redis.StatusCmd
	FlushDBAsync() *redis.StatusCmd
	Info(section ...string) *redis.StringCmd
	LastSave() *redis.IntCmd
	Save() *redis.StatusCmd
	Shutdown() *redis.StatusCmd
	ShutdownSave() *redis.StatusCmd
	ShutdownNoSave() *redis.StatusCmd
	SlaveOf(host, port string) *redis.StatusCmd
	Time() *redis.TimeCmd
	Eval(script string, keys []string, args ...interface{}) *redis.Cmd
	EvalSha(sha1 string, keys []string, args ...interface{}) *redis.Cmd
	ScriptExists(hashes ...string) *redis.BoolSliceCmd
	ScriptFlush() *redis.StatusCmd
	ScriptKill() *redis.StatusCmd
	ScriptLoad(script string) *redis.StringCmd
	DebugObject(key string) *redis.StringCmd
	Publish(channel string, message interface{}) *redis.IntCmd
	PubSubChannels(pattern string) *redis.StringSliceCmd
	PubSubNumSub(channels ...string) *redis.StringIntMapCmd
	PubSubNumPat() *redis.IntCmd
	ClusterSlots() *redis.ClusterSlotsCmd
	ClusterNodes() *redis.StringCmd
	ClusterMeet(host, port string) *redis.StatusCmd
	ClusterForget(nodeID string) *redis.StatusCmd
	ClusterReplicate(nodeID string) *redis.StatusCmd
	ClusterResetSoft() *redis.StatusCmd
	ClusterResetHard() *redis.StatusCmd
	ClusterInfo() *redis.StringCmd
	ClusterKeySlot(key string) *redis.IntCmd
	ClusterGetKeysInSlot(slot int, count int) *redis.StringSliceCmd
	ClusterCountFailureReports(nodeID string) *redis.IntCmd
	ClusterCountKeysInSlot(slot int) *redis.IntCmd
	ClusterDelSlots(slots ...int) *redis.StatusCmd
	ClusterDelSlotsRange(min, max int) *redis.StatusCmd
	ClusterSaveConfig() *redis.StatusCmd
	ClusterSlaves(nodeID string) *redis.StringSliceCmd
	ClusterFailover() *redis.StatusCmd
	ClusterAddSlots(slots ...int) *redis.StatusCmd
	ClusterAddSlotsRange(min, max int) *redis.StatusCmd
	GeoAdd(key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd
	GeoPos(key string, members ...string) *redis.GeoPosCmd
	GeoRadius(key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd
	GeoRadiusRO(key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd
	GeoRadiusByMember(key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd
	GeoRadiusByMemberRO(key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd
	GeoDist(key string, member1, member2, unit string) *redis.FloatCmd
	GeoHash(key string, members ...string) *redis.StringSliceCmd
	ReadOnly() *redis.StatusCmd
	ReadWrite() *redis.StatusCmd
	MemoryUsage(key string, samples ...int) *redis.IntCmd
	Close() error
}

RedisInterface is a universal golang redis interface.

Jump to

Keyboard shortcuts

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