redismock

package module
v8.0.5 Latest Latest
Warning

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

Go to latest
Published: Jan 29, 2021 License: BSD-2-Clause Imports: 9 Imported by: 11

README

Redis client Mock Build Status

Provide mock test for redis query, Compatible with github.com/go-redis/redis/v8

Install

Confirm that you are using redis.Client the version is github.com/go-redis/redis/v8

go get github.com/go-redis/redismock/v8

Example

More examples: https://github.com/go-redis/redismock/blob/v8/example/example.go


var ctx = context.TODO()

func NewsInfoForCache(redisDB *redis.Client, newsID int) (info string, err error) {
	cacheKey := fmt.Sprintf("news_redis_cache_%d", newsID)
	info, err = redisDB.Get(ctx, cacheKey).Result()
	if err == redis.Nil {
		// info, err = call api()
		info = "test"
		err = redisDB.Set(ctx, cacheKey, info, 30 * time.Minute).Err()
	}
	return
}

func TestNewsInfoForCache(t *testing.T) {
	db, mock := redismock.NewClientMock()

	newsID := 123456789
	key := fmt.Sprintf("news_redis_cache_%d", newsID)

	// mock ignoring `call api()`

	mock.ExpectGet(key).RedisNil()
	mock.Regexp().ExpectSet(key, `[a-z]+`, 30 * time.Minute).SetErr(errors.New("FAIL"))

	_, err := NewsInfoForCache(db, newsID)
	if err == nil || err.Error() != "FAIL" {
		t.Error("wrong error")
	}

	if err := mock.ExpectationsWereMet(); err != nil {
		t.Error(err)
	}
}

Documentation

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type ClientMock

type ClientMock interface {
	// ClearExpect clear whether all queued expectations were met in order
	ClearExpect()

	// Regexp using the regular match command
	Regexp() *mock

	// CustomMatch using custom matching functions
	CustomMatch(fn CustomMatch) *mock

	// ExpectationsWereMet checks whether all queued expectations
	// were met in order. If any of them was not met - an error is returned.
	ExpectationsWereMet() error

	// MatchExpectationsInOrder gives an option whether to match all expectations in the order they were set or not.
	MatchExpectationsInOrder(b bool)

	ExpectTxPipeline()
	ExpectTxPipelineExec() *ExpectedSlice

	ExpectWatch(keys ...string) *ExpectedError

	ExpectCommand() *ExpectedCommandsInfo
	ExpectClientGetName() *ExpectedString
	ExpectEcho(message interface{}) *ExpectedString
	ExpectPing() *ExpectedStatus
	ExpectQuit() *ExpectedStatus
	ExpectDel(keys ...string) *ExpectedInt
	ExpectUnlink(keys ...string) *ExpectedInt
	ExpectDump(key string) *ExpectedString
	ExpectExists(keys ...string) *ExpectedInt
	ExpectExpire(key string, expiration time.Duration) *ExpectedBool
	ExpectExpireAt(key string, tm time.Time) *ExpectedBool
	ExpectKeys(pattern string) *ExpectedStringSlice
	ExpectMigrate(host, port, key string, db int, timeout time.Duration) *ExpectedStatus
	ExpectMove(key string, db int) *ExpectedBool
	ExpectObjectRefCount(key string) *ExpectedInt
	ExpectObjectEncoding(key string) *ExpectedString
	ExpectObjectIdleTime(key string) *ExpectedDuration
	ExpectPersist(key string) *ExpectedBool
	ExpectPExpire(key string, expiration time.Duration) *ExpectedBool
	ExpectPExpireAt(key string, tm time.Time) *ExpectedBool
	ExpectPTTL(key string) *ExpectedDuration
	ExpectRandomKey() *ExpectedString
	ExpectRename(key, newkey string) *ExpectedStatus
	ExpectRenameNX(key, newkey string) *ExpectedBool
	ExpectRestore(key string, ttl time.Duration, value string) *ExpectedStatus
	ExpectRestoreReplace(key string, ttl time.Duration, value string) *ExpectedStatus
	ExpectSort(key string, sort *redis.Sort) *ExpectedStringSlice
	ExpectSortStore(key, store string, sort *redis.Sort) *ExpectedInt
	ExpectSortInterfaces(key string, sort *redis.Sort) *ExpectedSlice
	ExpectTouch(keys ...string) *ExpectedInt
	ExpectTTL(key string) *ExpectedDuration
	ExpectType(key string) *ExpectedStatus
	ExpectAppend(key, value string) *ExpectedInt
	ExpectDecr(key string) *ExpectedInt
	ExpectDecrBy(key string, decrement int64) *ExpectedInt
	ExpectGet(key string) *ExpectedString
	ExpectGetRange(key string, start, end int64) *ExpectedString
	ExpectGetSet(key string, value interface{}) *ExpectedString
	ExpectIncr(key string) *ExpectedInt
	ExpectIncrBy(key string, value int64) *ExpectedInt
	ExpectIncrByFloat(key string, value float64) *ExpectedFloat
	ExpectMGet(keys ...string) *ExpectedSlice
	ExpectMSet(values ...interface{}) *ExpectedStatus
	ExpectMSetNX(values ...interface{}) *ExpectedBool
	ExpectSet(key string, value interface{}, expiration time.Duration) *ExpectedStatus
	ExpectSetEX(key string, value interface{}, expiration time.Duration) *ExpectedStatus
	ExpectSetNX(key string, value interface{}, expiration time.Duration) *ExpectedBool
	ExpectSetXX(key string, value interface{}, expiration time.Duration) *ExpectedBool
	ExpectSetRange(key string, offset int64, value string) *ExpectedInt
	ExpectStrLen(key string) *ExpectedInt

	ExpectGetBit(key string, offset int64) *ExpectedInt
	ExpectSetBit(key string, offset int64, value int) *ExpectedInt
	ExpectBitCount(key string, bitCount *redis.BitCount) *ExpectedInt
	ExpectBitOpAnd(destKey string, keys ...string) *ExpectedInt
	ExpectBitOpOr(destKey string, keys ...string) *ExpectedInt
	ExpectBitOpXor(destKey string, keys ...string) *ExpectedInt
	ExpectBitOpNot(destKey string, key string) *ExpectedInt
	ExpectBitPos(key string, bit int64, pos ...int64) *ExpectedInt
	ExpectBitField(key string, args ...interface{}) *ExpectedIntSlice

	ExpectScan(cursor uint64, match string, count int64) *ExpectedScan
	ExpectSScan(key string, cursor uint64, match string, count int64) *ExpectedScan
	ExpectHScan(key string, cursor uint64, match string, count int64) *ExpectedScan
	ExpectZScan(key string, cursor uint64, match string, count int64) *ExpectedScan

	ExpectHDel(key string, fields ...string) *ExpectedInt
	ExpectHExists(key, field string) *ExpectedBool
	ExpectHGet(key, field string) *ExpectedString
	ExpectHGetAll(key string) *ExpectedStringStringMap
	ExpectHIncrBy(key, field string, incr int64) *ExpectedInt
	ExpectHIncrByFloat(key, field string, incr float64) *ExpectedFloat
	ExpectHKeys(key string) *ExpectedStringSlice
	ExpectHLen(key string) *ExpectedInt
	ExpectHMGet(key string, fields ...string) *ExpectedSlice
	ExpectHSet(key string, values ...interface{}) *ExpectedInt
	ExpectHMSet(key string, values ...interface{}) *ExpectedBool
	ExpectHSetNX(key, field string, value interface{}) *ExpectedBool
	ExpectHVals(key string) *ExpectedStringSlice

	ExpectBLPop(timeout time.Duration, keys ...string) *ExpectedStringSlice
	ExpectBRPop(timeout time.Duration, keys ...string) *ExpectedStringSlice
	ExpectBRPopLPush(source, destination string, timeout time.Duration) *ExpectedString
	ExpectLIndex(key string, index int64) *ExpectedString
	ExpectLInsert(key, op string, pivot, value interface{}) *ExpectedInt
	ExpectLInsertBefore(key string, pivot, value interface{}) *ExpectedInt
	ExpectLInsertAfter(key string, pivot, value interface{}) *ExpectedInt
	ExpectLLen(key string) *ExpectedInt
	ExpectLPop(key string) *ExpectedString
	ExpectLPos(key string, value string, args redis.LPosArgs) *ExpectedInt
	ExpectLPosCount(key string, value string, count int64, args redis.LPosArgs) *ExpectedIntSlice
	ExpectLPush(key string, values ...interface{}) *ExpectedInt
	ExpectLPushX(key string, values ...interface{}) *ExpectedInt
	ExpectLRange(key string, start, stop int64) *ExpectedStringSlice
	ExpectLRem(key string, count int64, value interface{}) *ExpectedInt
	ExpectLSet(key string, index int64, value interface{}) *ExpectedStatus
	ExpectLTrim(key string, start, stop int64) *ExpectedStatus
	ExpectRPop(key string) *ExpectedString
	ExpectRPopLPush(source, destination string) *ExpectedString
	ExpectRPush(key string, values ...interface{}) *ExpectedInt
	ExpectRPushX(key string, values ...interface{}) *ExpectedInt

	ExpectSAdd(key string, members ...interface{}) *ExpectedInt
	ExpectSCard(key string) *ExpectedInt
	ExpectSDiff(keys ...string) *ExpectedStringSlice
	ExpectSDiffStore(destination string, keys ...string) *ExpectedInt
	ExpectSInter(keys ...string) *ExpectedStringSlice
	ExpectSInterStore(destination string, keys ...string) *ExpectedInt
	ExpectSIsMember(key string, member interface{}) *ExpectedBool
	ExpectSMembers(key string) *ExpectedStringSlice
	ExpectSMembersMap(key string) *ExpectedStringStructMap
	ExpectSMove(source, destination string, member interface{}) *ExpectedBool
	ExpectSPop(key string) *ExpectedString
	ExpectSPopN(key string, count int64) *ExpectedStringSlice
	ExpectSRandMember(key string) *ExpectedString
	ExpectSRandMemberN(key string, count int64) *ExpectedStringSlice
	ExpectSRem(key string, members ...interface{}) *ExpectedInt
	ExpectSUnion(keys ...string) *ExpectedStringSlice
	ExpectSUnionStore(destination string, keys ...string) *ExpectedInt

	ExpectXAdd(a *redis.XAddArgs) *ExpectedString
	ExpectXDel(stream string, ids ...string) *ExpectedInt
	ExpectXLen(stream string) *ExpectedInt
	ExpectXRange(stream, start, stop string) *ExpectedXMessageSlice
	ExpectXRangeN(stream, start, stop string, count int64) *ExpectedXMessageSlice
	ExpectXRevRange(stream string, start, stop string) *ExpectedXMessageSlice
	ExpectXRevRangeN(stream string, start, stop string, count int64) *ExpectedXMessageSlice
	ExpectXRead(a *redis.XReadArgs) *ExpectedXStreamSlice
	ExpectXReadStreams(streams ...string) *ExpectedXStreamSlice
	ExpectXGroupCreate(stream, group, start string) *ExpectedStatus
	ExpectXGroupCreateMkStream(stream, group, start string) *ExpectedStatus
	ExpectXGroupSetID(stream, group, start string) *ExpectedStatus
	ExpectXGroupDestroy(stream, group string) *ExpectedInt
	ExpectXGroupDelConsumer(stream, group, consumer string) *ExpectedInt
	ExpectXReadGroup(a *redis.XReadGroupArgs) *ExpectedXStreamSlice
	ExpectXAck(stream, group string, ids ...string) *ExpectedInt
	ExpectXPending(stream, group string) *ExpectedXPending
	ExpectXPendingExt(a *redis.XPendingExtArgs) *ExpectedXPendingExt
	ExpectXClaim(a *redis.XClaimArgs) *ExpectedXMessageSlice
	ExpectXClaimJustID(a *redis.XClaimArgs) *ExpectedStringSlice
	ExpectXTrim(key string, maxLen int64) *ExpectedInt
	ExpectXTrimApprox(key string, maxLen int64) *ExpectedInt
	ExpectXInfoGroups(key string) *ExpectedXInfoGroups
	ExpectXInfoStream(key string) *ExpectedXInfoStream

	ExpectBZPopMax(timeout time.Duration, keys ...string) *ExpectedZWithKey
	ExpectBZPopMin(timeout time.Duration, keys ...string) *ExpectedZWithKey
	ExpectZAdd(key string, members ...*redis.Z) *ExpectedInt
	ExpectZAddNX(key string, members ...*redis.Z) *ExpectedInt
	ExpectZAddXX(key string, members ...*redis.Z) *ExpectedInt
	ExpectZAddCh(key string, members ...*redis.Z) *ExpectedInt
	ExpectZAddNXCh(key string, members ...*redis.Z) *ExpectedInt
	ExpectZAddXXCh(key string, members ...*redis.Z) *ExpectedInt
	ExpectZIncr(key string, member *redis.Z) *ExpectedFloat
	ExpectZIncrNX(key string, member *redis.Z) *ExpectedFloat
	ExpectZIncrXX(key string, member *redis.Z) *ExpectedFloat
	ExpectZCard(key string) *ExpectedInt
	ExpectZCount(key, min, max string) *ExpectedInt
	ExpectZLexCount(key, min, max string) *ExpectedInt
	ExpectZIncrBy(key string, increment float64, member string) *ExpectedFloat
	ExpectZInterStore(destination string, store *redis.ZStore) *ExpectedInt
	ExpectZPopMax(key string, count ...int64) *ExpectedZSlice
	ExpectZPopMin(key string, count ...int64) *ExpectedZSlice
	ExpectZRange(key string, start, stop int64) *ExpectedStringSlice
	ExpectZRangeWithScores(key string, start, stop int64) *ExpectedZSlice
	ExpectZRangeByScore(key string, opt *redis.ZRangeBy) *ExpectedStringSlice
	ExpectZRangeByLex(key string, opt *redis.ZRangeBy) *ExpectedStringSlice
	ExpectZRangeByScoreWithScores(key string, opt *redis.ZRangeBy) *ExpectedZSlice
	ExpectZRank(key, member string) *ExpectedInt
	ExpectZRem(key string, members ...interface{}) *ExpectedInt
	ExpectZRemRangeByRank(key string, start, stop int64) *ExpectedInt
	ExpectZRemRangeByScore(key, min, max string) *ExpectedInt
	ExpectZRemRangeByLex(key, min, max string) *ExpectedInt
	ExpectZRevRange(key string, start, stop int64) *ExpectedStringSlice
	ExpectZRevRangeWithScores(key string, start, stop int64) *ExpectedZSlice
	ExpectZRevRangeByScore(key string, opt *redis.ZRangeBy) *ExpectedStringSlice
	ExpectZRevRangeByLex(key string, opt *redis.ZRangeBy) *ExpectedStringSlice
	ExpectZRevRangeByScoreWithScores(key string, opt *redis.ZRangeBy) *ExpectedZSlice
	ExpectZRevRank(key, member string) *ExpectedInt
	ExpectZScore(key, member string) *ExpectedFloat
	ExpectZUnionStore(dest string, store *redis.ZStore) *ExpectedInt

	ExpectPFAdd(key string, els ...interface{}) *ExpectedInt
	ExpectPFCount(keys ...string) *ExpectedInt
	ExpectPFMerge(dest string, keys ...string) *ExpectedStatus

	ExpectBgRewriteAOF() *ExpectedStatus
	ExpectBgSave() *ExpectedStatus
	ExpectClientKill(ipPort string) *ExpectedStatus
	ExpectClientKillByFilter(keys ...string) *ExpectedInt
	ExpectClientList() *ExpectedString
	ExpectClientPause(dur time.Duration) *ExpectedBool
	ExpectClientID() *ExpectedInt
	ExpectConfigGet(parameter string) *ExpectedSlice
	ExpectConfigResetStat() *ExpectedStatus
	ExpectConfigSet(parameter, value string) *ExpectedStatus
	ExpectConfigRewrite() *ExpectedStatus
	ExpectDBSize() *ExpectedInt
	ExpectFlushAll() *ExpectedStatus
	ExpectFlushAllAsync() *ExpectedStatus
	ExpectFlushDB() *ExpectedStatus
	ExpectFlushDBAsync() *ExpectedStatus
	ExpectInfo(section ...string) *ExpectedString
	ExpectLastSave() *ExpectedInt
	ExpectSave() *ExpectedStatus
	ExpectShutdown() *ExpectedStatus
	ExpectShutdownSave() *ExpectedStatus
	ExpectShutdownNoSave() *ExpectedStatus
	ExpectSlaveOf(host, port string) *ExpectedStatus
	ExpectTime() *ExpectedTime
	ExpectDebugObject(key string) *ExpectedString
	ExpectReadOnly() *ExpectedStatus
	ExpectReadWrite() *ExpectedStatus
	ExpectMemoryUsage(key string, samples ...int) *ExpectedInt

	ExpectEval(script string, keys []string, args ...interface{}) *ExpectedCmd
	ExpectEvalSha(sha1 string, keys []string, args ...interface{}) *ExpectedCmd
	ExpectScriptExists(hashes ...string) *ExpectedBoolSlice
	ExpectScriptFlush() *ExpectedStatus
	ExpectScriptKill() *ExpectedStatus
	ExpectScriptLoad(script string) *ExpectedString

	ExpectPublish(channel string, message interface{}) *ExpectedInt
	ExpectPubSubChannels(pattern string) *ExpectedStringSlice
	ExpectPubSubNumSub(channels ...string) *ExpectedStringIntMap
	ExpectPubSubNumPat() *ExpectedInt

	ExpectClusterSlots() *ExpectedClusterSlots
	ExpectClusterNodes() *ExpectedString
	ExpectClusterMeet(host, port string) *ExpectedStatus
	ExpectClusterForget(nodeID string) *ExpectedStatus
	ExpectClusterReplicate(nodeID string) *ExpectedStatus
	ExpectClusterResetSoft() *ExpectedStatus
	ExpectClusterResetHard() *ExpectedStatus
	ExpectClusterInfo() *ExpectedString
	ExpectClusterKeySlot(key string) *ExpectedInt
	ExpectClusterGetKeysInSlot(slot int, count int) *ExpectedStringSlice
	ExpectClusterCountFailureReports(nodeID string) *ExpectedInt
	ExpectClusterCountKeysInSlot(slot int) *ExpectedInt
	ExpectClusterDelSlots(slots ...int) *ExpectedStatus
	ExpectClusterDelSlotsRange(min, max int) *ExpectedStatus
	ExpectClusterSaveConfig() *ExpectedStatus
	ExpectClusterSlaves(nodeID string) *ExpectedStringSlice
	ExpectClusterFailover() *ExpectedStatus
	ExpectClusterAddSlots(slots ...int) *ExpectedStatus
	ExpectClusterAddSlotsRange(min, max int) *ExpectedStatus

	ExpectGeoAdd(key string, geoLocation ...*redis.GeoLocation) *ExpectedInt
	ExpectGeoPos(key string, members ...string) *ExpectedGeoPos
	ExpectGeoRadius(key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *ExpectedGeoLocation
	ExpectGeoRadiusStore(key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *ExpectedInt
	ExpectGeoRadiusByMember(key, member string, query *redis.GeoRadiusQuery) *ExpectedGeoLocation
	ExpectGeoRadiusByMemberStore(key, member string, query *redis.GeoRadiusQuery) *ExpectedInt
	ExpectGeoDist(key string, member1, member2, unit string) *ExpectedFloat
	ExpectGeoHash(key string, members ...string) *ExpectedStringSlice
}

func NewClientMock

func NewClientMock() (*redis.Client, ClientMock)

type CustomMatch

type CustomMatch func(expected, actual []interface{}) error

type ExpectedBool

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

func (*ExpectedBool) RedisNil

func (base *ExpectedBool) RedisNil()

func (*ExpectedBool) SetErr

func (base *ExpectedBool) SetErr(err error)

func (*ExpectedBool) SetVal

func (cmd *ExpectedBool) SetVal(val bool)

type ExpectedBoolSlice

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

func (*ExpectedBoolSlice) RedisNil

func (base *ExpectedBoolSlice) RedisNil()

func (*ExpectedBoolSlice) SetErr

func (base *ExpectedBoolSlice) SetErr(err error)

func (*ExpectedBoolSlice) SetVal

func (cmd *ExpectedBoolSlice) SetVal(val []bool)

type ExpectedClusterSlots

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

func (*ExpectedClusterSlots) RedisNil

func (base *ExpectedClusterSlots) RedisNil()

func (*ExpectedClusterSlots) SetErr

func (base *ExpectedClusterSlots) SetErr(err error)

func (*ExpectedClusterSlots) SetVal

func (cmd *ExpectedClusterSlots) SetVal(val []redis.ClusterSlot)

type ExpectedCmd

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

func (*ExpectedCmd) RedisNil

func (base *ExpectedCmd) RedisNil()

func (*ExpectedCmd) SetErr

func (base *ExpectedCmd) SetErr(err error)

func (*ExpectedCmd) SetVal

func (cmd *ExpectedCmd) SetVal(val interface{})

type ExpectedCommandsInfo

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

func (*ExpectedCommandsInfo) RedisNil

func (base *ExpectedCommandsInfo) RedisNil()

func (*ExpectedCommandsInfo) SetErr

func (base *ExpectedCommandsInfo) SetErr(err error)

func (*ExpectedCommandsInfo) SetVal

func (cmd *ExpectedCommandsInfo) SetVal(val []*redis.CommandInfo)

type ExpectedDuration

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

func (*ExpectedDuration) RedisNil

func (base *ExpectedDuration) RedisNil()

func (*ExpectedDuration) SetErr

func (base *ExpectedDuration) SetErr(err error)

func (*ExpectedDuration) SetVal

func (cmd *ExpectedDuration) SetVal(val time.Duration)

type ExpectedError

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

func (*ExpectedError) RedisNil

func (base *ExpectedError) RedisNil()

func (*ExpectedError) SetErr

func (base *ExpectedError) SetErr(err error)

type ExpectedFloat

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

func (*ExpectedFloat) RedisNil

func (base *ExpectedFloat) RedisNil()

func (*ExpectedFloat) SetErr

func (base *ExpectedFloat) SetErr(err error)

func (*ExpectedFloat) SetVal

func (cmd *ExpectedFloat) SetVal(val float64)

type ExpectedGeoLocation

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

func (*ExpectedGeoLocation) RedisNil

func (base *ExpectedGeoLocation) RedisNil()

func (*ExpectedGeoLocation) SetErr

func (base *ExpectedGeoLocation) SetErr(err error)

func (*ExpectedGeoLocation) SetVal

func (cmd *ExpectedGeoLocation) SetVal(val []redis.GeoLocation)

type ExpectedGeoPos

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

func (*ExpectedGeoPos) RedisNil

func (base *ExpectedGeoPos) RedisNil()

func (*ExpectedGeoPos) SetErr

func (base *ExpectedGeoPos) SetErr(err error)

func (*ExpectedGeoPos) SetVal

func (cmd *ExpectedGeoPos) SetVal(val []*redis.GeoPos)

type ExpectedInt

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

func (*ExpectedInt) RedisNil

func (base *ExpectedInt) RedisNil()

func (*ExpectedInt) SetErr

func (base *ExpectedInt) SetErr(err error)

func (*ExpectedInt) SetVal

func (cmd *ExpectedInt) SetVal(val int64)

type ExpectedIntSlice

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

func (*ExpectedIntSlice) RedisNil

func (base *ExpectedIntSlice) RedisNil()

func (*ExpectedIntSlice) SetErr

func (base *ExpectedIntSlice) SetErr(err error)

func (*ExpectedIntSlice) SetVal

func (cmd *ExpectedIntSlice) SetVal(val []int64)

type ExpectedScan

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

func (*ExpectedScan) RedisNil

func (base *ExpectedScan) RedisNil()

func (*ExpectedScan) SetErr

func (base *ExpectedScan) SetErr(err error)

func (*ExpectedScan) SetVal

func (cmd *ExpectedScan) SetVal(page []string, cursor uint64)

type ExpectedSlice

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

func (*ExpectedSlice) RedisNil

func (base *ExpectedSlice) RedisNil()

func (*ExpectedSlice) SetErr

func (base *ExpectedSlice) SetErr(err error)

func (*ExpectedSlice) SetVal

func (cmd *ExpectedSlice) SetVal(val []interface{})

type ExpectedStatus

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

func (*ExpectedStatus) RedisNil

func (base *ExpectedStatus) RedisNil()

func (*ExpectedStatus) SetErr

func (base *ExpectedStatus) SetErr(err error)

func (*ExpectedStatus) SetVal

func (cmd *ExpectedStatus) SetVal(val string)

type ExpectedString

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

func (*ExpectedString) RedisNil

func (base *ExpectedString) RedisNil()

func (*ExpectedString) SetErr

func (base *ExpectedString) SetErr(err error)

func (*ExpectedString) SetVal

func (cmd *ExpectedString) SetVal(val string)

type ExpectedStringIntMap

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

func (*ExpectedStringIntMap) RedisNil

func (base *ExpectedStringIntMap) RedisNil()

func (*ExpectedStringIntMap) SetErr

func (base *ExpectedStringIntMap) SetErr(err error)

func (*ExpectedStringIntMap) SetVal

func (cmd *ExpectedStringIntMap) SetVal(val map[string]int64)

type ExpectedStringSlice

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

func (*ExpectedStringSlice) RedisNil

func (base *ExpectedStringSlice) RedisNil()

func (*ExpectedStringSlice) SetErr

func (base *ExpectedStringSlice) SetErr(err error)

func (*ExpectedStringSlice) SetVal

func (cmd *ExpectedStringSlice) SetVal(val []string)

type ExpectedStringStringMap

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

func (*ExpectedStringStringMap) RedisNil

func (base *ExpectedStringStringMap) RedisNil()

func (*ExpectedStringStringMap) SetErr

func (base *ExpectedStringStringMap) SetErr(err error)

func (*ExpectedStringStringMap) SetVal

func (cmd *ExpectedStringStringMap) SetVal(val map[string]string)

type ExpectedStringStructMap

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

func (*ExpectedStringStructMap) RedisNil

func (base *ExpectedStringStructMap) RedisNil()

func (*ExpectedStringStructMap) SetErr

func (base *ExpectedStringStructMap) SetErr(err error)

func (*ExpectedStringStructMap) SetVal

func (cmd *ExpectedStringStructMap) SetVal(val []string)

type ExpectedTime

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

func (*ExpectedTime) RedisNil

func (base *ExpectedTime) RedisNil()

func (*ExpectedTime) SetErr

func (base *ExpectedTime) SetErr(err error)

func (*ExpectedTime) SetVal

func (cmd *ExpectedTime) SetVal(val time.Time)

type ExpectedXInfoGroups

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

func (*ExpectedXInfoGroups) RedisNil

func (base *ExpectedXInfoGroups) RedisNil()

func (*ExpectedXInfoGroups) SetErr

func (base *ExpectedXInfoGroups) SetErr(err error)

func (*ExpectedXInfoGroups) SetVal

func (cmd *ExpectedXInfoGroups) SetVal(val []redis.XInfoGroup)

type ExpectedXInfoStream

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

func (*ExpectedXInfoStream) RedisNil

func (base *ExpectedXInfoStream) RedisNil()

func (*ExpectedXInfoStream) SetErr

func (base *ExpectedXInfoStream) SetErr(err error)

func (*ExpectedXInfoStream) SetVal

func (cmd *ExpectedXInfoStream) SetVal(val *redis.XInfoStream)

type ExpectedXMessageSlice

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

func (*ExpectedXMessageSlice) RedisNil

func (base *ExpectedXMessageSlice) RedisNil()

func (*ExpectedXMessageSlice) SetErr

func (base *ExpectedXMessageSlice) SetErr(err error)

func (*ExpectedXMessageSlice) SetVal

func (cmd *ExpectedXMessageSlice) SetVal(val []redis.XMessage)

type ExpectedXPending

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

func (*ExpectedXPending) RedisNil

func (base *ExpectedXPending) RedisNil()

func (*ExpectedXPending) SetErr

func (base *ExpectedXPending) SetErr(err error)

func (*ExpectedXPending) SetVal

func (cmd *ExpectedXPending) SetVal(val *redis.XPending)

type ExpectedXPendingExt

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

func (*ExpectedXPendingExt) RedisNil

func (base *ExpectedXPendingExt) RedisNil()

func (*ExpectedXPendingExt) SetErr

func (base *ExpectedXPendingExt) SetErr(err error)

func (*ExpectedXPendingExt) SetVal

func (cmd *ExpectedXPendingExt) SetVal(val []redis.XPendingExt)

type ExpectedXStreamSlice

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

func (*ExpectedXStreamSlice) RedisNil

func (base *ExpectedXStreamSlice) RedisNil()

func (*ExpectedXStreamSlice) SetErr

func (base *ExpectedXStreamSlice) SetErr(err error)

func (*ExpectedXStreamSlice) SetVal

func (cmd *ExpectedXStreamSlice) SetVal(val []redis.XStream)

type ExpectedZSlice

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

func (*ExpectedZSlice) RedisNil

func (base *ExpectedZSlice) RedisNil()

func (*ExpectedZSlice) SetErr

func (base *ExpectedZSlice) SetErr(err error)

func (*ExpectedZSlice) SetVal

func (cmd *ExpectedZSlice) SetVal(val []redis.Z)

type ExpectedZWithKey

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

func (*ExpectedZWithKey) RedisNil

func (base *ExpectedZWithKey) RedisNil()

func (*ExpectedZWithKey) SetErr

func (base *ExpectedZWithKey) SetErr(err error)

func (*ExpectedZWithKey) SetVal

func (cmd *ExpectedZWithKey) SetVal(val *redis.ZWithKey)

Directories

Path Synopsis

Jump to

Keyboard shortcuts

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