Documentation
¶
Overview ¶
Package mock_adapter is a generated GoMock package.
Index ¶
- type MockIDb
- func (m *MockIDb) Begin(opts ...*sql.TxOptions) adapter.ITx
- func (m *MockIDb) BeginContext(ctx context.Context, opts *sql.TxOptions) adapter.ITx
- func (m *MockIDb) EXPECT() *MockIDbMockRecorder
- func (m *MockIDb) Exec(query string, args ...interface{}) sql.Result
- func (m *MockIDb) ExecContext(ctx context.Context, query string, args ...interface{}) sql.Result
- func (m *MockIDb) GetDb(master bool) *sql.DB
- func (m *MockIDb) Prepare(query string) adapter.IStmt
- func (m *MockIDb) PrepareContext(ctx context.Context, query string) adapter.IStmt
- func (m *MockIDb) Query(query string, args ...interface{}) *sql.Rows
- func (m *MockIDb) QueryContext(ctx context.Context, query string, args ...interface{}) *sql.Rows
- func (m *MockIDb) QueryOne(query string, args ...interface{}) adapter.IRow
- func (m *MockIDb) QueryOneContext(ctx context.Context, query string, args ...interface{}) adapter.IRow
- func (m *MockIDb) SetMaster(v bool)
- type MockIDbMockRecorder
- func (mr *MockIDbMockRecorder) Begin(opts ...interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) BeginContext(ctx, opts interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) Exec(query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) ExecContext(ctx, query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) GetDb(master interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) Prepare(query interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) PrepareContext(ctx, query interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) Query(query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) QueryContext(ctx, query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) QueryOne(query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) QueryOneContext(ctx, query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIDbMockRecorder) SetMaster(v interface{}) *gomock.Call
- type MockIHttp
- func (m *MockIHttp) Do(req *http.Request, option ...*phttp.Option) *http.Response
- func (m *MockIHttp) DoMulti(requests []*http.Request, option ...*phttp.Option) []*http.Response
- func (m *MockIHttp) EXPECT() *MockIHttpMockRecorder
- func (m *MockIHttp) Get(addr string, data interface{}, option ...*phttp.Option) *http.Response
- func (m *MockIHttp) Post(addr string, data interface{}, option ...*phttp.Option) *http.Response
- func (m *MockIHttp) SetPanicRecover(v bool)
- type MockIHttpMockRecorder
- func (mr *MockIHttpMockRecorder) Do(req interface{}, option ...interface{}) *gomock.Call
- func (mr *MockIHttpMockRecorder) DoMulti(requests interface{}, option ...interface{}) *gomock.Call
- func (mr *MockIHttpMockRecorder) Get(addr, data interface{}, option ...interface{}) *gomock.Call
- func (mr *MockIHttpMockRecorder) Post(addr, data interface{}, option ...interface{}) *gomock.Call
- func (mr *MockIHttpMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
- type MockIMaxMind
- type MockIMaxMindMockRecorder
- type MockIMemCache
- func (m *MockIMemCache) Add(key string, value interface{}, expire ...time.Duration) bool
- func (m *MockIMemCache) Del(key string) bool
- func (m *MockIMemCache) EXPECT() *MockIMemCacheMockRecorder
- func (m *MockIMemCache) Exists(key string) bool
- func (m *MockIMemCache) Get(key string) *value.Value
- func (m *MockIMemCache) Incr(key string, delta int) int
- func (m *MockIMemCache) MAdd(items map[string]interface{}, expire ...time.Duration) bool
- func (m *MockIMemCache) MDel(keys []string) bool
- func (m *MockIMemCache) MGet(keys []string) map[string]*value.Value
- func (m *MockIMemCache) MSet(items map[string]interface{}, expire ...time.Duration) bool
- func (m *MockIMemCache) MultiRetrieve(cmd string, keys []string) []*memcache.Item
- func (m *MockIMemCache) MultiStore(cmd string, items []*memcache.Item, expire ...time.Duration) bool
- func (m *MockIMemCache) Retrieve(cmd, key string) *memcache.Item
- func (m *MockIMemCache) Set(key string, value interface{}, expire ...time.Duration) bool
- func (m *MockIMemCache) SetPanicRecover(v bool)
- func (m *MockIMemCache) Store(cmd string, item *memcache.Item, expire ...time.Duration) bool
- type MockIMemCacheMockRecorder
- func (mr *MockIMemCacheMockRecorder) Add(key, value interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) Del(key interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) Exists(key interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) Get(key interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) Incr(key, delta interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) MAdd(items interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) MDel(keys interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) MGet(keys interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) MSet(items interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) MultiRetrieve(cmd, keys interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) MultiStore(cmd, items interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) Retrieve(cmd, key interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) Set(key, value interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
- func (mr *MockIMemCacheMockRecorder) Store(cmd, item interface{}, expire ...interface{}) *gomock.Call
- type MockIMemory
- func (m *MockIMemory) Add(key string, value interface{}, expire ...time.Duration) bool
- func (m *MockIMemory) Del(key string) bool
- func (m *MockIMemory) EXPECT() *MockIMemoryMockRecorder
- func (m *MockIMemory) Exists(key string) bool
- func (m *MockIMemory) Get(key string) *value.Value
- func (m *MockIMemory) Incr(key string, delta int) int
- func (m *MockIMemory) MAdd(items map[string]interface{}, expire ...time.Duration) bool
- func (m *MockIMemory) MDel(keys []string) bool
- func (m *MockIMemory) MGet(keys []string) map[string]*value.Value
- func (m *MockIMemory) MSet(items map[string]interface{}, expire ...time.Duration) bool
- func (m *MockIMemory) Set(key string, value interface{}, expire ...time.Duration) bool
- func (m *MockIMemory) SetPanicRecover(v bool)
- type MockIMemoryMockRecorder
- func (mr *MockIMemoryMockRecorder) Add(key, value interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) Del(key interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) Exists(key interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) Get(key interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) Incr(key, delta interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) MAdd(items interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) MDel(keys interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) MGet(keys interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) MSet(items interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) Set(key, value interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIMemoryMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
- type MockIMongo
- func (m *MockIMongo) Count(query interface{}, options ...bson.M) (int, error)
- func (m *MockIMongo) DeleteAll(query interface{}) error
- func (m *MockIMongo) DeleteOne(query interface{}) error
- func (m *MockIMongo) EXPECT() *MockIMongoMockRecorder
- func (m *MockIMongo) FindAll(query, result interface{}, options ...bson.M) error
- func (m *MockIMongo) FindAndModify(query interface{}, change mgo.Change, result interface{}, options ...bson.M) error
- func (m *MockIMongo) FindDistinct(query interface{}, key string, result interface{}, options ...bson.M) error
- func (m *MockIMongo) FindOne(query, result interface{}, options ...bson.M) error
- func (m *MockIMongo) InsertAll(docs []interface{}) error
- func (m *MockIMongo) InsertOne(doc interface{}) error
- func (m *MockIMongo) MapReduce(query interface{}, job *mgo.MapReduce, result interface{}, options ...bson.M) error
- func (m *MockIMongo) PipeAll(pipeline, result interface{}) error
- func (m *MockIMongo) PipeOne(pipeline, result interface{}) error
- func (m *MockIMongo) UpdateAll(query, update interface{}) error
- func (m *MockIMongo) UpdateOne(query, update interface{}) error
- func (m *MockIMongo) UpdateOrInsert(query, update interface{}) error
- type MockIMongoMockRecorder
- func (mr *MockIMongoMockRecorder) Count(query interface{}, options ...interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) DeleteAll(query interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) DeleteOne(query interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) FindAll(query, result interface{}, options ...interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) FindAndModify(query, change, result interface{}, options ...interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) FindDistinct(query, key, result interface{}, options ...interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) FindOne(query, result interface{}, options ...interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) InsertAll(docs interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) InsertOne(doc interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) MapReduce(query, job, result interface{}, options ...interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) PipeAll(pipeline, result interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) PipeOne(pipeline, result interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) UpdateAll(query, update interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) UpdateOne(query, update interface{}) *gomock.Call
- func (mr *MockIMongoMockRecorder) UpdateOrInsert(query, update interface{}) *gomock.Call
- type MockIRabbitMq
- func (m *MockIRabbitMq) Consume(queueName string, opCodes []string, limit int, autoAck, noWait, exclusive bool) <-chan amqp.Delivery
- func (m *MockIRabbitMq) DecodeBody(d amqp.Delivery, ret interface{}) error
- func (m *MockIRabbitMq) DecodeHeaders(d amqp.Delivery) *rabbitmq.RabbitHeaders
- func (m *MockIRabbitMq) EXPECT() *MockIRabbitMqMockRecorder
- func (m *MockIRabbitMq) ExchangeDeclare()
- func (m *MockIRabbitMq) GetConsumeChannelBox(queueName string, opCodes []string) *rabbitmq.ChannelBox
- func (m *MockIRabbitMq) Publish(opCode string, data interface{}, dftOpUid ...string) bool
- func (m *MockIRabbitMq) SetPanicRecover(v bool)
- type MockIRabbitMqMockRecorder
- func (mr *MockIRabbitMqMockRecorder) Consume(queueName, opCodes, limit, autoAck, noWait, exclusive interface{}) *gomock.Call
- func (mr *MockIRabbitMqMockRecorder) DecodeBody(d, ret interface{}) *gomock.Call
- func (mr *MockIRabbitMqMockRecorder) DecodeHeaders(d interface{}) *gomock.Call
- func (mr *MockIRabbitMqMockRecorder) ExchangeDeclare() *gomock.Call
- func (mr *MockIRabbitMqMockRecorder) GetConsumeChannelBox(queueName, opCodes interface{}) *gomock.Call
- func (mr *MockIRabbitMqMockRecorder) Publish(opCode, data interface{}, dftOpUid ...interface{}) *gomock.Call
- func (mr *MockIRabbitMqMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
- type MockIRedis
- func (m *MockIRedis) Add(key string, value interface{}, expire ...time.Duration) bool
- func (m *MockIRedis) Del(key string) bool
- func (m *MockIRedis) Do(cmd string, args ...interface{}) interface{}
- func (m *MockIRedis) EXPECT() *MockIRedisMockRecorder
- func (m *MockIRedis) Exists(key string) bool
- func (m *MockIRedis) Get(key string) *value.Value
- func (m *MockIRedis) Incr(key string, delta int) int
- func (m *MockIRedis) MAdd(items map[string]interface{}, expire ...time.Duration) bool
- func (m *MockIRedis) MDel(keys []string) bool
- func (m *MockIRedis) MGet(keys []string) map[string]*value.Value
- func (m *MockIRedis) MSet(items map[string]interface{}, expire ...time.Duration) bool
- func (m *MockIRedis) Set(key string, value interface{}, expire ...time.Duration) bool
- func (m *MockIRedis) SetPanicRecover(v bool)
- type MockIRedisMockRecorder
- func (mr *MockIRedisMockRecorder) Add(key, value interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) Del(key interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) Do(cmd interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) Exists(key interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) Get(key interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) Incr(key, delta interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) MAdd(items interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) MDel(keys interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) MGet(keys interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) MSet(items interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) Set(key, value interface{}, expire ...interface{}) *gomock.Call
- func (mr *MockIRedisMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
- type MockIRow
- func (m *MockIRow) Context() iface.IContext
- func (m *MockIRow) EXPECT() *MockIRowMockRecorder
- func (m *MockIRow) GetObj(obj iface.IObject) iface.IObject
- func (m *MockIRow) GetObjCtx(ctx iface.IContext, obj iface.IObject) iface.IObject
- func (m *MockIRow) GetObjPool(funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
- func (m *MockIRow) GetObjPoolCtx(ctr iface.IContext, funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
- func (m *MockIRow) GetObjSingle(name string, funcName iface.IObjSingleFunc, params ...interface{}) iface.IObject
- func (m *MockIRow) GetObjSingleCtx(ctx iface.IContext, name string, funcName iface.IObjSingleFunc, ...) iface.IObject
- func (m *MockIRow) Scan(dest ...interface{}) error
- func (m *MockIRow) SetContext(ctx iface.IContext)
- type MockIRowMockRecorder
- func (mr *MockIRowMockRecorder) Context() *gomock.Call
- func (mr *MockIRowMockRecorder) GetObj(obj interface{}) *gomock.Call
- func (mr *MockIRowMockRecorder) GetObjCtx(ctx, obj interface{}) *gomock.Call
- func (mr *MockIRowMockRecorder) GetObjPool(funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockIRowMockRecorder) GetObjPoolCtx(ctr, funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockIRowMockRecorder) GetObjSingle(name, funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockIRowMockRecorder) GetObjSingleCtx(ctx, name, funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockIRowMockRecorder) Scan(dest ...interface{}) *gomock.Call
- func (mr *MockIRowMockRecorder) SetContext(ctx interface{}) *gomock.Call
- type MockIStmt
- func (m *MockIStmt) Close()
- func (m *MockIStmt) Context() iface.IContext
- func (m *MockIStmt) EXPECT() *MockIStmtMockRecorder
- func (m *MockIStmt) Exec(args ...interface{}) sql.Result
- func (m *MockIStmt) ExecContext(ctx context.Context, args ...interface{}) sql.Result
- func (m *MockIStmt) GetObj(obj iface.IObject) iface.IObject
- func (m *MockIStmt) GetObjCtx(ctx iface.IContext, obj iface.IObject) iface.IObject
- func (m *MockIStmt) GetObjPool(funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
- func (m *MockIStmt) GetObjPoolCtx(ctr iface.IContext, funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
- func (m *MockIStmt) GetObjSingle(name string, funcName iface.IObjSingleFunc, params ...interface{}) iface.IObject
- func (m *MockIStmt) GetObjSingleCtx(ctx iface.IContext, name string, funcName iface.IObjSingleFunc, ...) iface.IObject
- func (m *MockIStmt) Query(args ...interface{}) *sql.Rows
- func (m *MockIStmt) QueryContext(ctx context.Context, args ...interface{}) *sql.Rows
- func (m *MockIStmt) QueryOne(args ...interface{}) adapter.IRow
- func (m *MockIStmt) QueryOneContext(ctx context.Context, args ...interface{}) adapter.IRow
- func (m *MockIStmt) SetContext(ctx iface.IContext)
- type MockIStmtMockRecorder
- func (mr *MockIStmtMockRecorder) Close() *gomock.Call
- func (mr *MockIStmtMockRecorder) Context() *gomock.Call
- func (mr *MockIStmtMockRecorder) Exec(args ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) ExecContext(ctx interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) GetObj(obj interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) GetObjCtx(ctx, obj interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) GetObjPool(funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) GetObjPoolCtx(ctr, funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) GetObjSingle(name, funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) GetObjSingleCtx(ctx, name, funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) Query(args ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) QueryContext(ctx interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) QueryOne(args ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) QueryOneContext(ctx interface{}, args ...interface{}) *gomock.Call
- func (mr *MockIStmtMockRecorder) SetContext(ctx interface{}) *gomock.Call
- type MockITx
- func (m *MockITx) Commit() bool
- func (m *MockITx) Context() iface.IContext
- func (m *MockITx) EXPECT() *MockITxMockRecorder
- func (m *MockITx) Exec(query string, args ...interface{}) sql.Result
- func (m *MockITx) ExecContext(ctx context.Context, query string, args ...interface{}) sql.Result
- func (m *MockITx) GetObj(obj iface.IObject) iface.IObject
- func (m *MockITx) GetObjCtx(ctx iface.IContext, obj iface.IObject) iface.IObject
- func (m *MockITx) GetObjPool(funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
- func (m *MockITx) GetObjPoolCtx(ctr iface.IContext, funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
- func (m *MockITx) GetObjSingle(name string, funcName iface.IObjSingleFunc, params ...interface{}) iface.IObject
- func (m *MockITx) GetObjSingleCtx(ctx iface.IContext, name string, funcName iface.IObjSingleFunc, ...) iface.IObject
- func (m *MockITx) Prepare(query string) adapter.IStmt
- func (m *MockITx) PrepareContext(ctx context.Context, query string) adapter.IStmt
- func (m *MockITx) Query(query string, args ...interface{}) *sql.Rows
- func (m *MockITx) QueryContext(ctx context.Context, query string, args ...interface{}) *sql.Rows
- func (m *MockITx) QueryOne(query string, args ...interface{}) adapter.IRow
- func (m *MockITx) QueryOneContext(ctx context.Context, query string, args ...interface{}) adapter.IRow
- func (m *MockITx) Rollback() bool
- func (m *MockITx) SetContext(ctx iface.IContext)
- type MockITxMockRecorder
- func (mr *MockITxMockRecorder) Commit() *gomock.Call
- func (mr *MockITxMockRecorder) Context() *gomock.Call
- func (mr *MockITxMockRecorder) Exec(query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) ExecContext(ctx, query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) GetObj(obj interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) GetObjCtx(ctx, obj interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) GetObjPool(funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) GetObjPoolCtx(ctr, funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) GetObjSingle(name, funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) GetObjSingleCtx(ctx, name, funcName interface{}, params ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) Prepare(query interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) PrepareContext(ctx, query interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) Query(query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) QueryContext(ctx, query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) QueryOne(query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) QueryOneContext(ctx, query interface{}, args ...interface{}) *gomock.Call
- func (mr *MockITxMockRecorder) Rollback() *gomock.Call
- func (mr *MockITxMockRecorder) SetContext(ctx interface{}) *gomock.Call
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
This section is empty.
Types ¶
type MockIDb ¶
type MockIDb struct {
// contains filtered or unexported fields
}
MockIDb is a mock of IDb interface
func NewMockIDb ¶
func NewMockIDb(ctrl *gomock.Controller) *MockIDb
NewMockIDb creates a new mock instance
func (*MockIDb) BeginContext ¶
BeginContext mocks base method
func (*MockIDb) EXPECT ¶
func (m *MockIDb) EXPECT() *MockIDbMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockIDb) ExecContext ¶
ExecContext mocks base method
func (*MockIDb) PrepareContext ¶
PrepareContext mocks base method
func (*MockIDb) QueryContext ¶
QueryContext mocks base method
type MockIDbMockRecorder ¶
type MockIDbMockRecorder struct {
// contains filtered or unexported fields
}
MockIDbMockRecorder is the mock recorder for MockIDb
func (*MockIDbMockRecorder) Begin ¶
func (mr *MockIDbMockRecorder) Begin(opts ...interface{}) *gomock.Call
Begin indicates an expected call of Begin
func (*MockIDbMockRecorder) BeginContext ¶
func (mr *MockIDbMockRecorder) BeginContext(ctx, opts interface{}) *gomock.Call
BeginContext indicates an expected call of BeginContext
func (*MockIDbMockRecorder) Exec ¶
func (mr *MockIDbMockRecorder) Exec(query interface{}, args ...interface{}) *gomock.Call
Exec indicates an expected call of Exec
func (*MockIDbMockRecorder) ExecContext ¶
func (mr *MockIDbMockRecorder) ExecContext(ctx, query interface{}, args ...interface{}) *gomock.Call
ExecContext indicates an expected call of ExecContext
func (*MockIDbMockRecorder) GetDb ¶
func (mr *MockIDbMockRecorder) GetDb(master interface{}) *gomock.Call
GetDb indicates an expected call of GetDb
func (*MockIDbMockRecorder) Prepare ¶
func (mr *MockIDbMockRecorder) Prepare(query interface{}) *gomock.Call
Prepare indicates an expected call of Prepare
func (*MockIDbMockRecorder) PrepareContext ¶
func (mr *MockIDbMockRecorder) PrepareContext(ctx, query interface{}) *gomock.Call
PrepareContext indicates an expected call of PrepareContext
func (*MockIDbMockRecorder) Query ¶
func (mr *MockIDbMockRecorder) Query(query interface{}, args ...interface{}) *gomock.Call
Query indicates an expected call of Query
func (*MockIDbMockRecorder) QueryContext ¶
func (mr *MockIDbMockRecorder) QueryContext(ctx, query interface{}, args ...interface{}) *gomock.Call
QueryContext indicates an expected call of QueryContext
func (*MockIDbMockRecorder) QueryOne ¶
func (mr *MockIDbMockRecorder) QueryOne(query interface{}, args ...interface{}) *gomock.Call
QueryOne indicates an expected call of QueryOne
func (*MockIDbMockRecorder) QueryOneContext ¶
func (mr *MockIDbMockRecorder) QueryOneContext(ctx, query interface{}, args ...interface{}) *gomock.Call
QueryOneContext indicates an expected call of QueryOneContext
func (*MockIDbMockRecorder) SetMaster ¶
func (mr *MockIDbMockRecorder) SetMaster(v interface{}) *gomock.Call
SetMaster indicates an expected call of SetMaster
type MockIHttp ¶
type MockIHttp struct {
// contains filtered or unexported fields
}
MockIHttp is a mock of IHttp interface
func NewMockIHttp ¶
func NewMockIHttp(ctrl *gomock.Controller) *MockIHttp
NewMockIHttp creates a new mock instance
func (*MockIHttp) EXPECT ¶
func (m *MockIHttp) EXPECT() *MockIHttpMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockIHttp) SetPanicRecover ¶
SetPanicRecover mocks base method
type MockIHttpMockRecorder ¶
type MockIHttpMockRecorder struct {
// contains filtered or unexported fields
}
MockIHttpMockRecorder is the mock recorder for MockIHttp
func (*MockIHttpMockRecorder) Do ¶
func (mr *MockIHttpMockRecorder) Do(req interface{}, option ...interface{}) *gomock.Call
Do indicates an expected call of Do
func (*MockIHttpMockRecorder) DoMulti ¶
func (mr *MockIHttpMockRecorder) DoMulti(requests interface{}, option ...interface{}) *gomock.Call
DoMulti indicates an expected call of DoMulti
func (*MockIHttpMockRecorder) Get ¶
func (mr *MockIHttpMockRecorder) Get(addr, data interface{}, option ...interface{}) *gomock.Call
Get indicates an expected call of Get
func (*MockIHttpMockRecorder) Post ¶
func (mr *MockIHttpMockRecorder) Post(addr, data interface{}, option ...interface{}) *gomock.Call
Post indicates an expected call of Post
func (*MockIHttpMockRecorder) SetPanicRecover ¶
func (mr *MockIHttpMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
SetPanicRecover indicates an expected call of SetPanicRecover
type MockIMaxMind ¶
type MockIMaxMind struct {
// contains filtered or unexported fields
}
MockIMaxMind is a mock of IMaxMind interface
func NewMockIMaxMind ¶
func NewMockIMaxMind(ctrl *gomock.Controller) *MockIMaxMind
NewMockIMaxMind creates a new mock instance
func (*MockIMaxMind) EXPECT ¶
func (m *MockIMaxMind) EXPECT() *MockIMaxMindMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockIMaxMindMockRecorder ¶
type MockIMaxMindMockRecorder struct {
// contains filtered or unexported fields
}
MockIMaxMindMockRecorder is the mock recorder for MockIMaxMind
func (*MockIMaxMindMockRecorder) GeoByIp ¶
func (mr *MockIMaxMindMockRecorder) GeoByIp(ip interface{}, args ...interface{}) *gomock.Call
GeoByIp indicates an expected call of GeoByIp
type MockIMemCache ¶
type MockIMemCache struct {
// contains filtered or unexported fields
}
MockIMemCache is a mock of IMemCache interface
func NewMockIMemCache ¶
func NewMockIMemCache(ctrl *gomock.Controller) *MockIMemCache
NewMockIMemCache creates a new mock instance
func (*MockIMemCache) Add ¶
func (m *MockIMemCache) Add(key string, value interface{}, expire ...time.Duration) bool
Add mocks base method
func (*MockIMemCache) EXPECT ¶
func (m *MockIMemCache) EXPECT() *MockIMemCacheMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockIMemCache) Exists ¶
func (m *MockIMemCache) Exists(key string) bool
Exists mocks base method
func (*MockIMemCache) Get ¶
func (m *MockIMemCache) Get(key string) *value.Value
Get mocks base method
func (*MockIMemCache) Incr ¶
func (m *MockIMemCache) Incr(key string, delta int) int
Incr mocks base method
func (*MockIMemCache) MAdd ¶
func (m *MockIMemCache) MAdd(items map[string]interface{}, expire ...time.Duration) bool
MAdd mocks base method
func (*MockIMemCache) MDel ¶
func (m *MockIMemCache) MDel(keys []string) bool
MDel mocks base method
func (*MockIMemCache) MGet ¶
func (m *MockIMemCache) MGet(keys []string) map[string]*value.Value
MGet mocks base method
func (*MockIMemCache) MSet ¶
func (m *MockIMemCache) MSet(items map[string]interface{}, expire ...time.Duration) bool
MSet mocks base method
func (*MockIMemCache) MultiRetrieve ¶
func (m *MockIMemCache) MultiRetrieve(cmd string, keys []string) []*memcache.Item
MultiRetrieve mocks base method
func (*MockIMemCache) MultiStore ¶
func (m *MockIMemCache) MultiStore(cmd string, items []*memcache.Item, expire ...time.Duration) bool
MultiStore mocks base method
func (*MockIMemCache) Retrieve ¶
func (m *MockIMemCache) Retrieve(cmd, key string) *memcache.Item
Retrieve mocks base method
func (*MockIMemCache) Set ¶
func (m *MockIMemCache) Set(key string, value interface{}, expire ...time.Duration) bool
Set mocks base method
func (*MockIMemCache) SetPanicRecover ¶
func (m *MockIMemCache) SetPanicRecover(v bool)
SetPanicRecover mocks base method
type MockIMemCacheMockRecorder ¶
type MockIMemCacheMockRecorder struct {
// contains filtered or unexported fields
}
MockIMemCacheMockRecorder is the mock recorder for MockIMemCache
func (*MockIMemCacheMockRecorder) Add ¶
func (mr *MockIMemCacheMockRecorder) Add(key, value interface{}, expire ...interface{}) *gomock.Call
Add indicates an expected call of Add
func (*MockIMemCacheMockRecorder) Del ¶
func (mr *MockIMemCacheMockRecorder) Del(key interface{}) *gomock.Call
Del indicates an expected call of Del
func (*MockIMemCacheMockRecorder) Exists ¶
func (mr *MockIMemCacheMockRecorder) Exists(key interface{}) *gomock.Call
Exists indicates an expected call of Exists
func (*MockIMemCacheMockRecorder) Get ¶
func (mr *MockIMemCacheMockRecorder) Get(key interface{}) *gomock.Call
Get indicates an expected call of Get
func (*MockIMemCacheMockRecorder) Incr ¶
func (mr *MockIMemCacheMockRecorder) Incr(key, delta interface{}) *gomock.Call
Incr indicates an expected call of Incr
func (*MockIMemCacheMockRecorder) MAdd ¶
func (mr *MockIMemCacheMockRecorder) MAdd(items interface{}, expire ...interface{}) *gomock.Call
MAdd indicates an expected call of MAdd
func (*MockIMemCacheMockRecorder) MDel ¶
func (mr *MockIMemCacheMockRecorder) MDel(keys interface{}) *gomock.Call
MDel indicates an expected call of MDel
func (*MockIMemCacheMockRecorder) MGet ¶
func (mr *MockIMemCacheMockRecorder) MGet(keys interface{}) *gomock.Call
MGet indicates an expected call of MGet
func (*MockIMemCacheMockRecorder) MSet ¶
func (mr *MockIMemCacheMockRecorder) MSet(items interface{}, expire ...interface{}) *gomock.Call
MSet indicates an expected call of MSet
func (*MockIMemCacheMockRecorder) MultiRetrieve ¶
func (mr *MockIMemCacheMockRecorder) MultiRetrieve(cmd, keys interface{}) *gomock.Call
MultiRetrieve indicates an expected call of MultiRetrieve
func (*MockIMemCacheMockRecorder) MultiStore ¶
func (mr *MockIMemCacheMockRecorder) MultiStore(cmd, items interface{}, expire ...interface{}) *gomock.Call
MultiStore indicates an expected call of MultiStore
func (*MockIMemCacheMockRecorder) Retrieve ¶
func (mr *MockIMemCacheMockRecorder) Retrieve(cmd, key interface{}) *gomock.Call
Retrieve indicates an expected call of Retrieve
func (*MockIMemCacheMockRecorder) Set ¶
func (mr *MockIMemCacheMockRecorder) Set(key, value interface{}, expire ...interface{}) *gomock.Call
Set indicates an expected call of Set
func (*MockIMemCacheMockRecorder) SetPanicRecover ¶
func (mr *MockIMemCacheMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
SetPanicRecover indicates an expected call of SetPanicRecover
func (*MockIMemCacheMockRecorder) Store ¶
func (mr *MockIMemCacheMockRecorder) Store(cmd, item interface{}, expire ...interface{}) *gomock.Call
Store indicates an expected call of Store
type MockIMemory ¶
type MockIMemory struct {
// contains filtered or unexported fields
}
MockIMemory is a mock of IMemory interface
func NewMockIMemory ¶
func NewMockIMemory(ctrl *gomock.Controller) *MockIMemory
NewMockIMemory creates a new mock instance
func (*MockIMemory) Add ¶
func (m *MockIMemory) Add(key string, value interface{}, expire ...time.Duration) bool
Add mocks base method
func (*MockIMemory) EXPECT ¶
func (m *MockIMemory) EXPECT() *MockIMemoryMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockIMemory) Incr ¶
func (m *MockIMemory) Incr(key string, delta int) int
Incr mocks base method
func (*MockIMemory) MAdd ¶
func (m *MockIMemory) MAdd(items map[string]interface{}, expire ...time.Duration) bool
MAdd mocks base method
func (*MockIMemory) MGet ¶
func (m *MockIMemory) MGet(keys []string) map[string]*value.Value
MGet mocks base method
func (*MockIMemory) MSet ¶
func (m *MockIMemory) MSet(items map[string]interface{}, expire ...time.Duration) bool
MSet mocks base method
func (*MockIMemory) Set ¶
func (m *MockIMemory) Set(key string, value interface{}, expire ...time.Duration) bool
Set mocks base method
func (*MockIMemory) SetPanicRecover ¶
func (m *MockIMemory) SetPanicRecover(v bool)
SetPanicRecover mocks base method
type MockIMemoryMockRecorder ¶
type MockIMemoryMockRecorder struct {
// contains filtered or unexported fields
}
MockIMemoryMockRecorder is the mock recorder for MockIMemory
func (*MockIMemoryMockRecorder) Add ¶
func (mr *MockIMemoryMockRecorder) Add(key, value interface{}, expire ...interface{}) *gomock.Call
Add indicates an expected call of Add
func (*MockIMemoryMockRecorder) Del ¶
func (mr *MockIMemoryMockRecorder) Del(key interface{}) *gomock.Call
Del indicates an expected call of Del
func (*MockIMemoryMockRecorder) Exists ¶
func (mr *MockIMemoryMockRecorder) Exists(key interface{}) *gomock.Call
Exists indicates an expected call of Exists
func (*MockIMemoryMockRecorder) Get ¶
func (mr *MockIMemoryMockRecorder) Get(key interface{}) *gomock.Call
Get indicates an expected call of Get
func (*MockIMemoryMockRecorder) Incr ¶
func (mr *MockIMemoryMockRecorder) Incr(key, delta interface{}) *gomock.Call
Incr indicates an expected call of Incr
func (*MockIMemoryMockRecorder) MAdd ¶
func (mr *MockIMemoryMockRecorder) MAdd(items interface{}, expire ...interface{}) *gomock.Call
MAdd indicates an expected call of MAdd
func (*MockIMemoryMockRecorder) MDel ¶
func (mr *MockIMemoryMockRecorder) MDel(keys interface{}) *gomock.Call
MDel indicates an expected call of MDel
func (*MockIMemoryMockRecorder) MGet ¶
func (mr *MockIMemoryMockRecorder) MGet(keys interface{}) *gomock.Call
MGet indicates an expected call of MGet
func (*MockIMemoryMockRecorder) MSet ¶
func (mr *MockIMemoryMockRecorder) MSet(items interface{}, expire ...interface{}) *gomock.Call
MSet indicates an expected call of MSet
func (*MockIMemoryMockRecorder) Set ¶
func (mr *MockIMemoryMockRecorder) Set(key, value interface{}, expire ...interface{}) *gomock.Call
Set indicates an expected call of Set
func (*MockIMemoryMockRecorder) SetPanicRecover ¶
func (mr *MockIMemoryMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
SetPanicRecover indicates an expected call of SetPanicRecover
type MockIMongo ¶
type MockIMongo struct {
// contains filtered or unexported fields
}
MockIMongo is a mock of IMongo interface
func NewMockIMongo ¶
func NewMockIMongo(ctrl *gomock.Controller) *MockIMongo
NewMockIMongo creates a new mock instance
func (*MockIMongo) Count ¶
func (m *MockIMongo) Count(query interface{}, options ...bson.M) (int, error)
Count mocks base method
func (*MockIMongo) DeleteAll ¶
func (m *MockIMongo) DeleteAll(query interface{}) error
DeleteAll mocks base method
func (*MockIMongo) DeleteOne ¶
func (m *MockIMongo) DeleteOne(query interface{}) error
DeleteOne mocks base method
func (*MockIMongo) EXPECT ¶
func (m *MockIMongo) EXPECT() *MockIMongoMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockIMongo) FindAll ¶
func (m *MockIMongo) FindAll(query, result interface{}, options ...bson.M) error
FindAll mocks base method
func (*MockIMongo) FindAndModify ¶
func (m *MockIMongo) FindAndModify(query interface{}, change mgo.Change, result interface{}, options ...bson.M) error
FindAndModify mocks base method
func (*MockIMongo) FindDistinct ¶
func (m *MockIMongo) FindDistinct(query interface{}, key string, result interface{}, options ...bson.M) error
FindDistinct mocks base method
func (*MockIMongo) FindOne ¶
func (m *MockIMongo) FindOne(query, result interface{}, options ...bson.M) error
FindOne mocks base method
func (*MockIMongo) InsertAll ¶
func (m *MockIMongo) InsertAll(docs []interface{}) error
InsertAll mocks base method
func (*MockIMongo) InsertOne ¶
func (m *MockIMongo) InsertOne(doc interface{}) error
InsertOne mocks base method
func (*MockIMongo) MapReduce ¶
func (m *MockIMongo) MapReduce(query interface{}, job *mgo.MapReduce, result interface{}, options ...bson.M) error
MapReduce mocks base method
func (*MockIMongo) PipeAll ¶
func (m *MockIMongo) PipeAll(pipeline, result interface{}) error
PipeAll mocks base method
func (*MockIMongo) PipeOne ¶
func (m *MockIMongo) PipeOne(pipeline, result interface{}) error
PipeOne mocks base method
func (*MockIMongo) UpdateAll ¶
func (m *MockIMongo) UpdateAll(query, update interface{}) error
UpdateAll mocks base method
func (*MockIMongo) UpdateOne ¶
func (m *MockIMongo) UpdateOne(query, update interface{}) error
UpdateOne mocks base method
func (*MockIMongo) UpdateOrInsert ¶
func (m *MockIMongo) UpdateOrInsert(query, update interface{}) error
UpdateOrInsert mocks base method
type MockIMongoMockRecorder ¶
type MockIMongoMockRecorder struct {
// contains filtered or unexported fields
}
MockIMongoMockRecorder is the mock recorder for MockIMongo
func (*MockIMongoMockRecorder) Count ¶
func (mr *MockIMongoMockRecorder) Count(query interface{}, options ...interface{}) *gomock.Call
Count indicates an expected call of Count
func (*MockIMongoMockRecorder) DeleteAll ¶
func (mr *MockIMongoMockRecorder) DeleteAll(query interface{}) *gomock.Call
DeleteAll indicates an expected call of DeleteAll
func (*MockIMongoMockRecorder) DeleteOne ¶
func (mr *MockIMongoMockRecorder) DeleteOne(query interface{}) *gomock.Call
DeleteOne indicates an expected call of DeleteOne
func (*MockIMongoMockRecorder) FindAll ¶
func (mr *MockIMongoMockRecorder) FindAll(query, result interface{}, options ...interface{}) *gomock.Call
FindAll indicates an expected call of FindAll
func (*MockIMongoMockRecorder) FindAndModify ¶
func (mr *MockIMongoMockRecorder) FindAndModify(query, change, result interface{}, options ...interface{}) *gomock.Call
FindAndModify indicates an expected call of FindAndModify
func (*MockIMongoMockRecorder) FindDistinct ¶
func (mr *MockIMongoMockRecorder) FindDistinct(query, key, result interface{}, options ...interface{}) *gomock.Call
FindDistinct indicates an expected call of FindDistinct
func (*MockIMongoMockRecorder) FindOne ¶
func (mr *MockIMongoMockRecorder) FindOne(query, result interface{}, options ...interface{}) *gomock.Call
FindOne indicates an expected call of FindOne
func (*MockIMongoMockRecorder) InsertAll ¶
func (mr *MockIMongoMockRecorder) InsertAll(docs interface{}) *gomock.Call
InsertAll indicates an expected call of InsertAll
func (*MockIMongoMockRecorder) InsertOne ¶
func (mr *MockIMongoMockRecorder) InsertOne(doc interface{}) *gomock.Call
InsertOne indicates an expected call of InsertOne
func (*MockIMongoMockRecorder) MapReduce ¶
func (mr *MockIMongoMockRecorder) MapReduce(query, job, result interface{}, options ...interface{}) *gomock.Call
MapReduce indicates an expected call of MapReduce
func (*MockIMongoMockRecorder) PipeAll ¶
func (mr *MockIMongoMockRecorder) PipeAll(pipeline, result interface{}) *gomock.Call
PipeAll indicates an expected call of PipeAll
func (*MockIMongoMockRecorder) PipeOne ¶
func (mr *MockIMongoMockRecorder) PipeOne(pipeline, result interface{}) *gomock.Call
PipeOne indicates an expected call of PipeOne
func (*MockIMongoMockRecorder) UpdateAll ¶
func (mr *MockIMongoMockRecorder) UpdateAll(query, update interface{}) *gomock.Call
UpdateAll indicates an expected call of UpdateAll
func (*MockIMongoMockRecorder) UpdateOne ¶
func (mr *MockIMongoMockRecorder) UpdateOne(query, update interface{}) *gomock.Call
UpdateOne indicates an expected call of UpdateOne
func (*MockIMongoMockRecorder) UpdateOrInsert ¶
func (mr *MockIMongoMockRecorder) UpdateOrInsert(query, update interface{}) *gomock.Call
UpdateOrInsert indicates an expected call of UpdateOrInsert
type MockIRabbitMq ¶
type MockIRabbitMq struct {
// contains filtered or unexported fields
}
MockIRabbitMq is a mock of IRabbitMq interface
func NewMockIRabbitMq ¶
func NewMockIRabbitMq(ctrl *gomock.Controller) *MockIRabbitMq
NewMockIRabbitMq creates a new mock instance
func (*MockIRabbitMq) Consume ¶
func (m *MockIRabbitMq) Consume(queueName string, opCodes []string, limit int, autoAck, noWait, exclusive bool) <-chan amqp.Delivery
Consume mocks base method
func (*MockIRabbitMq) DecodeBody ¶
func (m *MockIRabbitMq) DecodeBody(d amqp.Delivery, ret interface{}) error
DecodeBody mocks base method
func (*MockIRabbitMq) DecodeHeaders ¶
func (m *MockIRabbitMq) DecodeHeaders(d amqp.Delivery) *rabbitmq.RabbitHeaders
DecodeHeaders mocks base method
func (*MockIRabbitMq) EXPECT ¶
func (m *MockIRabbitMq) EXPECT() *MockIRabbitMqMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockIRabbitMq) ExchangeDeclare ¶
func (m *MockIRabbitMq) ExchangeDeclare()
ExchangeDeclare mocks base method
func (*MockIRabbitMq) GetConsumeChannelBox ¶
func (m *MockIRabbitMq) GetConsumeChannelBox(queueName string, opCodes []string) *rabbitmq.ChannelBox
GetConsumeChannelBox mocks base method
func (*MockIRabbitMq) Publish ¶
func (m *MockIRabbitMq) Publish(opCode string, data interface{}, dftOpUid ...string) bool
Publish mocks base method
func (*MockIRabbitMq) SetPanicRecover ¶
func (m *MockIRabbitMq) SetPanicRecover(v bool)
SetPanicRecover mocks base method
type MockIRabbitMqMockRecorder ¶
type MockIRabbitMqMockRecorder struct {
// contains filtered or unexported fields
}
MockIRabbitMqMockRecorder is the mock recorder for MockIRabbitMq
func (*MockIRabbitMqMockRecorder) Consume ¶
func (mr *MockIRabbitMqMockRecorder) Consume(queueName, opCodes, limit, autoAck, noWait, exclusive interface{}) *gomock.Call
Consume indicates an expected call of Consume
func (*MockIRabbitMqMockRecorder) DecodeBody ¶
func (mr *MockIRabbitMqMockRecorder) DecodeBody(d, ret interface{}) *gomock.Call
DecodeBody indicates an expected call of DecodeBody
func (*MockIRabbitMqMockRecorder) DecodeHeaders ¶
func (mr *MockIRabbitMqMockRecorder) DecodeHeaders(d interface{}) *gomock.Call
DecodeHeaders indicates an expected call of DecodeHeaders
func (*MockIRabbitMqMockRecorder) ExchangeDeclare ¶
func (mr *MockIRabbitMqMockRecorder) ExchangeDeclare() *gomock.Call
ExchangeDeclare indicates an expected call of ExchangeDeclare
func (*MockIRabbitMqMockRecorder) GetConsumeChannelBox ¶
func (mr *MockIRabbitMqMockRecorder) GetConsumeChannelBox(queueName, opCodes interface{}) *gomock.Call
GetConsumeChannelBox indicates an expected call of GetConsumeChannelBox
func (*MockIRabbitMqMockRecorder) Publish ¶
func (mr *MockIRabbitMqMockRecorder) Publish(opCode, data interface{}, dftOpUid ...interface{}) *gomock.Call
Publish indicates an expected call of Publish
func (*MockIRabbitMqMockRecorder) SetPanicRecover ¶
func (mr *MockIRabbitMqMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
SetPanicRecover indicates an expected call of SetPanicRecover
type MockIRedis ¶
type MockIRedis struct {
// contains filtered or unexported fields
}
MockIRedis is a mock of IRedis interface
func NewMockIRedis ¶
func NewMockIRedis(ctrl *gomock.Controller) *MockIRedis
NewMockIRedis creates a new mock instance
func (*MockIRedis) Add ¶
func (m *MockIRedis) Add(key string, value interface{}, expire ...time.Duration) bool
Add mocks base method
func (*MockIRedis) Do ¶
func (m *MockIRedis) Do(cmd string, args ...interface{}) interface{}
Do mocks base method
func (*MockIRedis) EXPECT ¶
func (m *MockIRedis) EXPECT() *MockIRedisMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockIRedis) Incr ¶
func (m *MockIRedis) Incr(key string, delta int) int
Incr mocks base method
func (*MockIRedis) MAdd ¶
func (m *MockIRedis) MAdd(items map[string]interface{}, expire ...time.Duration) bool
MAdd mocks base method
func (*MockIRedis) MGet ¶
func (m *MockIRedis) MGet(keys []string) map[string]*value.Value
MGet mocks base method
func (*MockIRedis) MSet ¶
func (m *MockIRedis) MSet(items map[string]interface{}, expire ...time.Duration) bool
MSet mocks base method
func (*MockIRedis) Set ¶
func (m *MockIRedis) Set(key string, value interface{}, expire ...time.Duration) bool
Set mocks base method
func (*MockIRedis) SetPanicRecover ¶
func (m *MockIRedis) SetPanicRecover(v bool)
SetPanicRecover mocks base method
type MockIRedisMockRecorder ¶
type MockIRedisMockRecorder struct {
// contains filtered or unexported fields
}
MockIRedisMockRecorder is the mock recorder for MockIRedis
func (*MockIRedisMockRecorder) Add ¶
func (mr *MockIRedisMockRecorder) Add(key, value interface{}, expire ...interface{}) *gomock.Call
Add indicates an expected call of Add
func (*MockIRedisMockRecorder) Del ¶
func (mr *MockIRedisMockRecorder) Del(key interface{}) *gomock.Call
Del indicates an expected call of Del
func (*MockIRedisMockRecorder) Do ¶
func (mr *MockIRedisMockRecorder) Do(cmd interface{}, args ...interface{}) *gomock.Call
Do indicates an expected call of Do
func (*MockIRedisMockRecorder) Exists ¶
func (mr *MockIRedisMockRecorder) Exists(key interface{}) *gomock.Call
Exists indicates an expected call of Exists
func (*MockIRedisMockRecorder) Get ¶
func (mr *MockIRedisMockRecorder) Get(key interface{}) *gomock.Call
Get indicates an expected call of Get
func (*MockIRedisMockRecorder) Incr ¶
func (mr *MockIRedisMockRecorder) Incr(key, delta interface{}) *gomock.Call
Incr indicates an expected call of Incr
func (*MockIRedisMockRecorder) MAdd ¶
func (mr *MockIRedisMockRecorder) MAdd(items interface{}, expire ...interface{}) *gomock.Call
MAdd indicates an expected call of MAdd
func (*MockIRedisMockRecorder) MDel ¶
func (mr *MockIRedisMockRecorder) MDel(keys interface{}) *gomock.Call
MDel indicates an expected call of MDel
func (*MockIRedisMockRecorder) MGet ¶
func (mr *MockIRedisMockRecorder) MGet(keys interface{}) *gomock.Call
MGet indicates an expected call of MGet
func (*MockIRedisMockRecorder) MSet ¶
func (mr *MockIRedisMockRecorder) MSet(items interface{}, expire ...interface{}) *gomock.Call
MSet indicates an expected call of MSet
func (*MockIRedisMockRecorder) Set ¶
func (mr *MockIRedisMockRecorder) Set(key, value interface{}, expire ...interface{}) *gomock.Call
Set indicates an expected call of Set
func (*MockIRedisMockRecorder) SetPanicRecover ¶
func (mr *MockIRedisMockRecorder) SetPanicRecover(v interface{}) *gomock.Call
SetPanicRecover indicates an expected call of SetPanicRecover
type MockIRow ¶
type MockIRow struct {
// contains filtered or unexported fields
}
MockIRow is a mock of IRow interface
func NewMockIRow ¶
func NewMockIRow(ctrl *gomock.Controller) *MockIRow
NewMockIRow creates a new mock instance
func (*MockIRow) EXPECT ¶
func (m *MockIRow) EXPECT() *MockIRowMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockIRow) GetObjPool ¶
func (m *MockIRow) GetObjPool(funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
GetObjPool mocks base method
func (*MockIRow) GetObjPoolCtx ¶
func (m *MockIRow) GetObjPoolCtx(ctr iface.IContext, funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
GetObjPoolCtx mocks base method
func (*MockIRow) GetObjSingle ¶
func (m *MockIRow) GetObjSingle(name string, funcName iface.IObjSingleFunc, params ...interface{}) iface.IObject
GetObjSingle mocks base method
func (*MockIRow) GetObjSingleCtx ¶
func (m *MockIRow) GetObjSingleCtx(ctx iface.IContext, name string, funcName iface.IObjSingleFunc, params ...interface{}) iface.IObject
GetObjSingleCtx mocks base method
func (*MockIRow) SetContext ¶
SetContext mocks base method
type MockIRowMockRecorder ¶
type MockIRowMockRecorder struct {
// contains filtered or unexported fields
}
MockIRowMockRecorder is the mock recorder for MockIRow
func (*MockIRowMockRecorder) Context ¶
func (mr *MockIRowMockRecorder) Context() *gomock.Call
Context indicates an expected call of Context
func (*MockIRowMockRecorder) GetObj ¶
func (mr *MockIRowMockRecorder) GetObj(obj interface{}) *gomock.Call
GetObj indicates an expected call of GetObj
func (*MockIRowMockRecorder) GetObjCtx ¶
func (mr *MockIRowMockRecorder) GetObjCtx(ctx, obj interface{}) *gomock.Call
GetObjCtx indicates an expected call of GetObjCtx
func (*MockIRowMockRecorder) GetObjPool ¶
func (mr *MockIRowMockRecorder) GetObjPool(funcName interface{}, params ...interface{}) *gomock.Call
GetObjPool indicates an expected call of GetObjPool
func (*MockIRowMockRecorder) GetObjPoolCtx ¶
func (mr *MockIRowMockRecorder) GetObjPoolCtx(ctr, funcName interface{}, params ...interface{}) *gomock.Call
GetObjPoolCtx indicates an expected call of GetObjPoolCtx
func (*MockIRowMockRecorder) GetObjSingle ¶
func (mr *MockIRowMockRecorder) GetObjSingle(name, funcName interface{}, params ...interface{}) *gomock.Call
GetObjSingle indicates an expected call of GetObjSingle
func (*MockIRowMockRecorder) GetObjSingleCtx ¶
func (mr *MockIRowMockRecorder) GetObjSingleCtx(ctx, name, funcName interface{}, params ...interface{}) *gomock.Call
GetObjSingleCtx indicates an expected call of GetObjSingleCtx
func (*MockIRowMockRecorder) Scan ¶
func (mr *MockIRowMockRecorder) Scan(dest ...interface{}) *gomock.Call
Scan indicates an expected call of Scan
func (*MockIRowMockRecorder) SetContext ¶
func (mr *MockIRowMockRecorder) SetContext(ctx interface{}) *gomock.Call
SetContext indicates an expected call of SetContext
type MockIStmt ¶
type MockIStmt struct {
// contains filtered or unexported fields
}
MockIStmt is a mock of IStmt interface
func NewMockIStmt ¶
func NewMockIStmt(ctrl *gomock.Controller) *MockIStmt
NewMockIStmt creates a new mock instance
func (*MockIStmt) EXPECT ¶
func (m *MockIStmt) EXPECT() *MockIStmtMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockIStmt) ExecContext ¶
ExecContext mocks base method
func (*MockIStmt) GetObjPool ¶
func (m *MockIStmt) GetObjPool(funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
GetObjPool mocks base method
func (*MockIStmt) GetObjPoolCtx ¶
func (m *MockIStmt) GetObjPoolCtx(ctr iface.IContext, funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
GetObjPoolCtx mocks base method
func (*MockIStmt) GetObjSingle ¶
func (m *MockIStmt) GetObjSingle(name string, funcName iface.IObjSingleFunc, params ...interface{}) iface.IObject
GetObjSingle mocks base method
func (*MockIStmt) GetObjSingleCtx ¶
func (m *MockIStmt) GetObjSingleCtx(ctx iface.IContext, name string, funcName iface.IObjSingleFunc, params ...interface{}) iface.IObject
GetObjSingleCtx mocks base method
func (*MockIStmt) QueryContext ¶
QueryContext mocks base method
func (*MockIStmt) QueryOneContext ¶
QueryOneContext mocks base method
func (*MockIStmt) SetContext ¶
SetContext mocks base method
type MockIStmtMockRecorder ¶
type MockIStmtMockRecorder struct {
// contains filtered or unexported fields
}
MockIStmtMockRecorder is the mock recorder for MockIStmt
func (*MockIStmtMockRecorder) Close ¶
func (mr *MockIStmtMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close
func (*MockIStmtMockRecorder) Context ¶
func (mr *MockIStmtMockRecorder) Context() *gomock.Call
Context indicates an expected call of Context
func (*MockIStmtMockRecorder) Exec ¶
func (mr *MockIStmtMockRecorder) Exec(args ...interface{}) *gomock.Call
Exec indicates an expected call of Exec
func (*MockIStmtMockRecorder) ExecContext ¶
func (mr *MockIStmtMockRecorder) ExecContext(ctx interface{}, args ...interface{}) *gomock.Call
ExecContext indicates an expected call of ExecContext
func (*MockIStmtMockRecorder) GetObj ¶
func (mr *MockIStmtMockRecorder) GetObj(obj interface{}) *gomock.Call
GetObj indicates an expected call of GetObj
func (*MockIStmtMockRecorder) GetObjCtx ¶
func (mr *MockIStmtMockRecorder) GetObjCtx(ctx, obj interface{}) *gomock.Call
GetObjCtx indicates an expected call of GetObjCtx
func (*MockIStmtMockRecorder) GetObjPool ¶
func (mr *MockIStmtMockRecorder) GetObjPool(funcName interface{}, params ...interface{}) *gomock.Call
GetObjPool indicates an expected call of GetObjPool
func (*MockIStmtMockRecorder) GetObjPoolCtx ¶
func (mr *MockIStmtMockRecorder) GetObjPoolCtx(ctr, funcName interface{}, params ...interface{}) *gomock.Call
GetObjPoolCtx indicates an expected call of GetObjPoolCtx
func (*MockIStmtMockRecorder) GetObjSingle ¶
func (mr *MockIStmtMockRecorder) GetObjSingle(name, funcName interface{}, params ...interface{}) *gomock.Call
GetObjSingle indicates an expected call of GetObjSingle
func (*MockIStmtMockRecorder) GetObjSingleCtx ¶
func (mr *MockIStmtMockRecorder) GetObjSingleCtx(ctx, name, funcName interface{}, params ...interface{}) *gomock.Call
GetObjSingleCtx indicates an expected call of GetObjSingleCtx
func (*MockIStmtMockRecorder) Query ¶
func (mr *MockIStmtMockRecorder) Query(args ...interface{}) *gomock.Call
Query indicates an expected call of Query
func (*MockIStmtMockRecorder) QueryContext ¶
func (mr *MockIStmtMockRecorder) QueryContext(ctx interface{}, args ...interface{}) *gomock.Call
QueryContext indicates an expected call of QueryContext
func (*MockIStmtMockRecorder) QueryOne ¶
func (mr *MockIStmtMockRecorder) QueryOne(args ...interface{}) *gomock.Call
QueryOne indicates an expected call of QueryOne
func (*MockIStmtMockRecorder) QueryOneContext ¶
func (mr *MockIStmtMockRecorder) QueryOneContext(ctx interface{}, args ...interface{}) *gomock.Call
QueryOneContext indicates an expected call of QueryOneContext
func (*MockIStmtMockRecorder) SetContext ¶
func (mr *MockIStmtMockRecorder) SetContext(ctx interface{}) *gomock.Call
SetContext indicates an expected call of SetContext
type MockITx ¶
type MockITx struct {
// contains filtered or unexported fields
}
MockITx is a mock of ITx interface
func NewMockITx ¶
func NewMockITx(ctrl *gomock.Controller) *MockITx
NewMockITx creates a new mock instance
func (*MockITx) EXPECT ¶
func (m *MockITx) EXPECT() *MockITxMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockITx) ExecContext ¶
ExecContext mocks base method
func (*MockITx) GetObjPool ¶
func (m *MockITx) GetObjPool(funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
GetObjPool mocks base method
func (*MockITx) GetObjPoolCtx ¶
func (m *MockITx) GetObjPoolCtx(ctr iface.IContext, funcName iface.IObjPoolFunc, params ...interface{}) iface.IObject
GetObjPoolCtx mocks base method
func (*MockITx) GetObjSingle ¶
func (m *MockITx) GetObjSingle(name string, funcName iface.IObjSingleFunc, params ...interface{}) iface.IObject
GetObjSingle mocks base method
func (*MockITx) GetObjSingleCtx ¶
func (m *MockITx) GetObjSingleCtx(ctx iface.IContext, name string, funcName iface.IObjSingleFunc, params ...interface{}) iface.IObject
GetObjSingleCtx mocks base method
func (*MockITx) PrepareContext ¶
PrepareContext mocks base method
func (*MockITx) QueryContext ¶
QueryContext mocks base method
func (*MockITx) QueryOneContext ¶
func (m *MockITx) QueryOneContext(ctx context.Context, query string, args ...interface{}) adapter.IRow
QueryOneContext mocks base method
func (*MockITx) SetContext ¶
SetContext mocks base method
type MockITxMockRecorder ¶
type MockITxMockRecorder struct {
// contains filtered or unexported fields
}
MockITxMockRecorder is the mock recorder for MockITx
func (*MockITxMockRecorder) Commit ¶
func (mr *MockITxMockRecorder) Commit() *gomock.Call
Commit indicates an expected call of Commit
func (*MockITxMockRecorder) Context ¶
func (mr *MockITxMockRecorder) Context() *gomock.Call
Context indicates an expected call of Context
func (*MockITxMockRecorder) Exec ¶
func (mr *MockITxMockRecorder) Exec(query interface{}, args ...interface{}) *gomock.Call
Exec indicates an expected call of Exec
func (*MockITxMockRecorder) ExecContext ¶
func (mr *MockITxMockRecorder) ExecContext(ctx, query interface{}, args ...interface{}) *gomock.Call
ExecContext indicates an expected call of ExecContext
func (*MockITxMockRecorder) GetObj ¶
func (mr *MockITxMockRecorder) GetObj(obj interface{}) *gomock.Call
GetObj indicates an expected call of GetObj
func (*MockITxMockRecorder) GetObjCtx ¶
func (mr *MockITxMockRecorder) GetObjCtx(ctx, obj interface{}) *gomock.Call
GetObjCtx indicates an expected call of GetObjCtx
func (*MockITxMockRecorder) GetObjPool ¶
func (mr *MockITxMockRecorder) GetObjPool(funcName interface{}, params ...interface{}) *gomock.Call
GetObjPool indicates an expected call of GetObjPool
func (*MockITxMockRecorder) GetObjPoolCtx ¶
func (mr *MockITxMockRecorder) GetObjPoolCtx(ctr, funcName interface{}, params ...interface{}) *gomock.Call
GetObjPoolCtx indicates an expected call of GetObjPoolCtx
func (*MockITxMockRecorder) GetObjSingle ¶
func (mr *MockITxMockRecorder) GetObjSingle(name, funcName interface{}, params ...interface{}) *gomock.Call
GetObjSingle indicates an expected call of GetObjSingle
func (*MockITxMockRecorder) GetObjSingleCtx ¶
func (mr *MockITxMockRecorder) GetObjSingleCtx(ctx, name, funcName interface{}, params ...interface{}) *gomock.Call
GetObjSingleCtx indicates an expected call of GetObjSingleCtx
func (*MockITxMockRecorder) Prepare ¶
func (mr *MockITxMockRecorder) Prepare(query interface{}) *gomock.Call
Prepare indicates an expected call of Prepare
func (*MockITxMockRecorder) PrepareContext ¶
func (mr *MockITxMockRecorder) PrepareContext(ctx, query interface{}) *gomock.Call
PrepareContext indicates an expected call of PrepareContext
func (*MockITxMockRecorder) Query ¶
func (mr *MockITxMockRecorder) Query(query interface{}, args ...interface{}) *gomock.Call
Query indicates an expected call of Query
func (*MockITxMockRecorder) QueryContext ¶
func (mr *MockITxMockRecorder) QueryContext(ctx, query interface{}, args ...interface{}) *gomock.Call
QueryContext indicates an expected call of QueryContext
func (*MockITxMockRecorder) QueryOne ¶
func (mr *MockITxMockRecorder) QueryOne(query interface{}, args ...interface{}) *gomock.Call
QueryOne indicates an expected call of QueryOne
func (*MockITxMockRecorder) QueryOneContext ¶
func (mr *MockITxMockRecorder) QueryOneContext(ctx, query interface{}, args ...interface{}) *gomock.Call
QueryOneContext indicates an expected call of QueryOneContext
func (*MockITxMockRecorder) Rollback ¶
func (mr *MockITxMockRecorder) Rollback() *gomock.Call
Rollback indicates an expected call of Rollback
func (*MockITxMockRecorder) SetContext ¶
func (mr *MockITxMockRecorder) SetContext(ctx interface{}) *gomock.Call
SetContext indicates an expected call of SetContext