Documentation ¶
Overview ¶
Package mock_frontend is a generated GoMock package.
Package mock_frontend is a generated GoMock package.
Package mock_frontend is a generated GoMock package.
Package mock_frontend is a generated GoMock package.
Package mock_frontend is a generated GoMock package.
Index ¶
- type MockBackgroundExec
- func (m *MockBackgroundExec) ClearExecResultBatches()
- func (m *MockBackgroundExec) ClearExecResultSet()
- func (m *MockBackgroundExec) Close()
- func (m *MockBackgroundExec) EXPECT() *MockBackgroundExecMockRecorder
- func (m *MockBackgroundExec) Exec(arg0 context.Context, arg1 string) error
- func (m *MockBackgroundExec) ExecStmt(arg0 context.Context, arg1 tree.Statement) error
- func (m *MockBackgroundExec) GetExecResultBatches() []*batch.Batch
- func (m *MockBackgroundExec) GetExecResultSet() []interface{}
- type MockBackgroundExecMockRecorder
- func (mr *MockBackgroundExecMockRecorder) ClearExecResultBatches() *gomock.Call
- func (mr *MockBackgroundExecMockRecorder) ClearExecResultSet() *gomock.Call
- func (mr *MockBackgroundExecMockRecorder) Close() *gomock.Call
- func (mr *MockBackgroundExecMockRecorder) Exec(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockBackgroundExecMockRecorder) ExecStmt(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockBackgroundExecMockRecorder) GetExecResultBatches() *gomock.Call
- func (mr *MockBackgroundExecMockRecorder) GetExecResultSet() *gomock.Call
- type MockColumnInfo
- type MockColumnInfoMockRecorder
- type MockComputationRunner
- type MockComputationRunnerMockRecorder
- type MockComputationWrapper
- func (m *MockComputationWrapper) Compile(requestCtx context.Context, u interface{}, ...) (interface{}, error)
- func (m *MockComputationWrapper) EXPECT() *MockComputationWrapperMockRecorder
- func (m *MockComputationWrapper) GetAst() tree.Statement
- func (m *MockComputationWrapper) GetColumns() ([]interface{}, error)
- func (m *MockComputationWrapper) GetLoadTag() bool
- func (m *MockComputationWrapper) GetProcess() *process.Process
- func (m *MockComputationWrapper) GetServerStatus() uint16
- func (m *MockComputationWrapper) GetUUID() []byte
- func (m *MockComputationWrapper) RecordExecPlan(ctx context.Context) error
- func (m *MockComputationWrapper) Run(ts uint64) (*util.RunResult, error)
- func (m *MockComputationWrapper) SetDatabaseName(db string) error
- type MockComputationWrapperMockRecorder
- func (mr *MockComputationWrapperMockRecorder) Compile(requestCtx, u, fill interface{}) *gomock.Call
- func (mr *MockComputationWrapperMockRecorder) GetAst() *gomock.Call
- func (mr *MockComputationWrapperMockRecorder) GetColumns() *gomock.Call
- func (mr *MockComputationWrapperMockRecorder) GetLoadTag() *gomock.Call
- func (mr *MockComputationWrapperMockRecorder) GetProcess() *gomock.Call
- func (mr *MockComputationWrapperMockRecorder) GetServerStatus() *gomock.Call
- func (mr *MockComputationWrapperMockRecorder) GetUUID() *gomock.Call
- func (mr *MockComputationWrapperMockRecorder) RecordExecPlan(ctx interface{}) *gomock.Call
- func (mr *MockComputationWrapperMockRecorder) Run(ts interface{}) *gomock.Call
- func (mr *MockComputationWrapperMockRecorder) SetDatabaseName(db interface{}) *gomock.Call
- type MockConstraint
- type MockConstraintMockRecorder
- type MockDatabase
- func (m *MockDatabase) Create(arg0 context.Context, arg1 string, arg2 []engine.TableDef) error
- func (m *MockDatabase) Delete(arg0 context.Context, arg1 string) error
- func (m *MockDatabase) EXPECT() *MockDatabaseMockRecorder
- func (m *MockDatabase) GetCreateSql(arg0 context.Context) string
- func (m *MockDatabase) GetDatabaseId(arg0 context.Context) string
- func (m *MockDatabase) IsSubscription(arg0 context.Context) bool
- func (m *MockDatabase) Relation(arg0 context.Context, arg1 string, arg2 any) (engine.Relation, error)
- func (m *MockDatabase) Relations(arg0 context.Context) ([]string, error)
- func (m *MockDatabase) Truncate(arg0 context.Context, arg1 string) (uint64, error)
- type MockDatabaseMockRecorder
- func (mr *MockDatabaseMockRecorder) Create(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockDatabaseMockRecorder) Delete(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockDatabaseMockRecorder) GetCreateSql(arg0 interface{}) *gomock.Call
- func (mr *MockDatabaseMockRecorder) GetDatabaseId(arg0 interface{}) *gomock.Call
- func (mr *MockDatabaseMockRecorder) IsSubscription(arg0 interface{}) *gomock.Call
- func (mr *MockDatabaseMockRecorder) Relation(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockDatabaseMockRecorder) Relations(arg0 interface{}) *gomock.Call
- func (mr *MockDatabaseMockRecorder) Truncate(arg0, arg1 interface{}) *gomock.Call
- type MockEngine
- func (m *MockEngine) AllocateIDByKey(ctx context.Context, key string) (uint64, error)
- func (m *MockEngine) Create(ctx context.Context, databaseName string, op client.TxnOperator) error
- func (m *MockEngine) Database(ctx context.Context, databaseName string, op client.TxnOperator) (engine.Database, error)
- func (m *MockEngine) Databases(ctx context.Context, op client.TxnOperator) ([]string, error)
- func (m *MockEngine) Delete(ctx context.Context, databaseName string, op client.TxnOperator) error
- func (m *MockEngine) EXPECT() *MockEngineMockRecorder
- func (m *MockEngine) GetNameById(ctx context.Context, op client.TxnOperator, tableId uint64) (string, string, error)
- func (m *MockEngine) GetRelationById(ctx context.Context, op client.TxnOperator, tableId uint64) (string, string, engine.Relation, error)
- func (m *MockEngine) Hints() engine.Hints
- func (m *MockEngine) New(ctx context.Context, op client.TxnOperator) error
- func (m *MockEngine) NewBlockReader(ctx context.Context, num int, ts timestamp.Timestamp, expr *plan.Expr, ...) ([]engine.Reader, error)
- func (m *MockEngine) Nodes(isInternal bool, tenant, username string, cnLabel map[string]string) (engine.Nodes, error)
- type MockEngineMockRecorder
- func (mr *MockEngineMockRecorder) AllocateIDByKey(ctx, key interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) Create(ctx, databaseName, op interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) Database(ctx, databaseName, op interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) Databases(ctx, op interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) Delete(ctx, databaseName, op interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) GetNameById(ctx, op, tableId interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) GetRelationById(ctx, op, tableId interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) Hints() *gomock.Call
- func (mr *MockEngineMockRecorder) New(ctx, op interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) NewBlockReader(ctx, num, ts, expr, ranges, tblDef, proc interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) Nodes(isInternal, tenant, username, cnLabel interface{}) *gomock.Call
- type MockExecResult
- func (m *MockExecResult) EXPECT() *MockExecResultMockRecorder
- func (m *MockExecResult) GetInt64(ctx context.Context, rindex, cindex uint64) (int64, error)
- func (m *MockExecResult) GetRowCount() uint64
- func (m *MockExecResult) GetString(ctx context.Context, rindex, cindex uint64) (string, error)
- func (m *MockExecResult) GetUint64(ctx context.Context, rindex, cindex uint64) (uint64, error)
- type MockExecResultMockRecorder
- func (mr *MockExecResultMockRecorder) GetInt64(ctx, rindex, cindex interface{}) *gomock.Call
- func (mr *MockExecResultMockRecorder) GetRowCount() *gomock.Call
- func (mr *MockExecResultMockRecorder) GetString(ctx, rindex, cindex interface{}) *gomock.Call
- func (mr *MockExecResultMockRecorder) GetUint64(ctx, rindex, cindex interface{}) *gomock.Call
- type MockIOPackage
- func (m *MockIOPackage) AppendUint16(arg0 []byte, arg1 uint16) []byte
- func (m *MockIOPackage) AppendUint32(arg0 []byte, arg1 uint32) []byte
- func (m *MockIOPackage) AppendUint64(arg0 []byte, arg1 uint64) []byte
- func (m *MockIOPackage) AppendUint8(arg0 []byte, arg1 uint8) []byte
- func (m *MockIOPackage) EXPECT() *MockIOPackageMockRecorder
- func (m *MockIOPackage) IsLittleEndian() bool
- func (m *MockIOPackage) ReadUint16(arg0 []byte, arg1 int) (uint16, int, bool)
- func (m *MockIOPackage) ReadUint32(arg0 []byte, arg1 int) (uint32, int, bool)
- func (m *MockIOPackage) ReadUint64(arg0 []byte, arg1 int) (uint64, int, bool)
- func (m *MockIOPackage) ReadUint8(arg0 []byte, arg1 int) (uint8, int, bool)
- func (m *MockIOPackage) WriteUint16(arg0 []byte, arg1 int, arg2 uint16) int
- func (m *MockIOPackage) WriteUint32(arg0 []byte, arg1 int, arg2 uint32) int
- func (m *MockIOPackage) WriteUint64(arg0 []byte, arg1 int, arg2 uint64) int
- func (m *MockIOPackage) WriteUint8(arg0 []byte, arg1 int, arg2 uint8) int
- type MockIOPackageMockRecorder
- func (mr *MockIOPackageMockRecorder) AppendUint16(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) AppendUint32(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) AppendUint64(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) AppendUint8(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) IsLittleEndian() *gomock.Call
- func (mr *MockIOPackageMockRecorder) ReadUint16(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) ReadUint32(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) ReadUint64(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) ReadUint8(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) WriteUint16(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) WriteUint32(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) WriteUint64(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockIOPackageMockRecorder) WriteUint8(arg0, arg1, arg2 interface{}) *gomock.Call
- type MockIOSession
- func (m *MockIOSession) Close() error
- func (m *MockIOSession) Connect(addr string, timeout time.Duration) error
- func (m *MockIOSession) Connected() bool
- func (m *MockIOSession) Disconnect() error
- func (m *MockIOSession) EXPECT() *MockIOSessionMockRecorder
- func (m *MockIOSession) Flush(timeout time.Duration) error
- func (m *MockIOSession) ID() uint64
- func (m *MockIOSession) OutBuf() *buf.ByteBuf
- func (m *MockIOSession) RawConn() net.Conn
- func (m *MockIOSession) Read(option goetty.ReadOptions) (any, error)
- func (m *MockIOSession) Ref()
- func (m *MockIOSession) RemoteAddress() string
- func (m *MockIOSession) UseConn(arg0 net.Conn)
- func (m *MockIOSession) Write(msg any, options goetty.WriteOptions) error
- type MockIOSessionMockRecorder
- func (mr *MockIOSessionMockRecorder) Close() *gomock.Call
- func (mr *MockIOSessionMockRecorder) Connect(addr, timeout interface{}) *gomock.Call
- func (mr *MockIOSessionMockRecorder) Connected() *gomock.Call
- func (mr *MockIOSessionMockRecorder) Disconnect() *gomock.Call
- func (mr *MockIOSessionMockRecorder) Flush(timeout interface{}) *gomock.Call
- func (mr *MockIOSessionMockRecorder) ID() *gomock.Call
- func (mr *MockIOSessionMockRecorder) OutBuf() *gomock.Call
- func (mr *MockIOSessionMockRecorder) RawConn() *gomock.Call
- func (mr *MockIOSessionMockRecorder) Read(option interface{}) *gomock.Call
- func (mr *MockIOSessionMockRecorder) Ref() *gomock.Call
- func (mr *MockIOSessionMockRecorder) RemoteAddress() *gomock.Call
- func (mr *MockIOSessionMockRecorder) UseConn(arg0 interface{}) *gomock.Call
- func (mr *MockIOSessionMockRecorder) Write(msg, options interface{}) *gomock.Call
- type MockReader
- type MockReaderMockRecorder
- type MockRelation
- func (m *MockRelation) AddTableDef(arg0 context.Context, arg1 engine.TableDef) error
- func (m *MockRelation) AlterTable(ctx context.Context, c *engine.ConstraintDef, constraint [][]byte) error
- func (m *MockRelation) DelTableDef(arg0 context.Context, arg1 engine.TableDef) error
- func (m *MockRelation) Delete(arg0 context.Context, arg1 *batch.Batch, arg2 string) error
- func (m *MockRelation) EXPECT() *MockRelationMockRecorder
- func (m *MockRelation) GetColumMetadataScanInfo(ctx context.Context, name string) ([]*plan.MetadataScanInfo, error)
- func (m *MockRelation) GetDBID(arg0 context.Context) uint64
- func (m *MockRelation) GetEngineType() engine.EngineType
- func (m *MockRelation) GetHideKeys(arg0 context.Context) ([]*engine.Attribute, error)
- func (m *MockRelation) GetPrimaryKeys(arg0 context.Context) ([]*engine.Attribute, error)
- func (m *MockRelation) GetTableID(arg0 context.Context) uint64
- func (m *MockRelation) GetTableName() string
- func (m *MockRelation) MaxAndMinValues(ctx context.Context) ([][2]any, []uint8, error)
- func (m *MockRelation) NewReader(arg0 context.Context, arg1 int, arg2 *plan.Expr, arg3 [][]byte) ([]engine.Reader, error)
- func (m *MockRelation) PrimaryKeysMayBeModified(ctx context.Context, from, to types.TS, keyVector *vector.Vector) (bool, error)
- func (m *MockRelation) Ranges(arg0 context.Context, arg1 []*plan.Expr) ([][]byte, error)
- func (m *MockRelation) Rows(ctx context.Context) (int64, error)
- func (m *MockRelation) Size(ctx context.Context, columnName string) (int64, error)
- func (m *MockRelation) Stats(ctx context.Context, partitionTables []any, statsInfoMap any) bool
- func (m *MockRelation) TableColumns(ctx context.Context) ([]*engine.Attribute, error)
- func (m *MockRelation) TableDefs(arg0 context.Context) ([]engine.TableDef, error)
- func (m *MockRelation) Update(arg0 context.Context, arg1 *batch.Batch) error
- func (m *MockRelation) UpdateBlockInfos(arg0 context.Context) error
- func (m *MockRelation) UpdateConstraint(arg0 context.Context, arg1 *engine.ConstraintDef) error
- func (m *MockRelation) Write(arg0 context.Context, arg1 *batch.Batch) error
- type MockRelationMockRecorder
- func (mr *MockRelationMockRecorder) AddTableDef(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) AlterTable(ctx, c, constraint interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) DelTableDef(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) Delete(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) GetColumMetadataScanInfo(ctx, name interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) GetDBID(arg0 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) GetEngineType() *gomock.Call
- func (mr *MockRelationMockRecorder) GetHideKeys(arg0 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) GetPrimaryKeys(arg0 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) GetTableID(arg0 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) GetTableName() *gomock.Call
- func (mr *MockRelationMockRecorder) MaxAndMinValues(ctx interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) NewReader(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) PrimaryKeysMayBeModified(ctx, from, to, keyVector interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) Ranges(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) Rows(ctx interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) Size(ctx, columnName interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) Stats(ctx, partitionTables, statsInfoMap interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) TableColumns(ctx interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) TableDefs(arg0 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) Update(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) UpdateBlockInfos(arg0 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) UpdateConstraint(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockRelationMockRecorder) Write(arg0, arg1 interface{}) *gomock.Call
- type MockStatistics
- func (m *MockStatistics) EXPECT() *MockStatisticsMockRecorder
- func (m *MockStatistics) Rows(ctx context.Context) (int64, error)
- func (m *MockStatistics) Size(ctx context.Context, columnName string) (int64, error)
- func (m *MockStatistics) Stats(ctx context.Context, partitionTables []any, statsInfoMap any) bool
- type MockStatisticsMockRecorder
- type MockTableDef
- type MockTableDefMockRecorder
- type MockTableInfo
- type MockTableInfoMockRecorder
- type MockTimestampWaiter
- func (m *MockTimestampWaiter) Close()
- func (m *MockTimestampWaiter) EXPECT() *MockTimestampWaiterMockRecorder
- func (m *MockTimestampWaiter) GetTimestamp(arg0 context.Context, arg1 timestamp.Timestamp) (timestamp.Timestamp, error)
- func (m *MockTimestampWaiter) NotifyLatestCommitTS(appliedTS timestamp.Timestamp)
- type MockTimestampWaiterMockRecorder
- type MockTxnClient
- func (m *MockTxnClient) AbortAllRunningTxn()
- func (m *MockTxnClient) CNBasedConsistencyEnabled() bool
- func (m *MockTxnClient) Close() error
- func (m *MockTxnClient) EXPECT() *MockTxnClientMockRecorder
- func (m *MockTxnClient) GetLatestCommitTS() timestamp.Timestamp
- func (m *MockTxnClient) GetSyncLatestCommitTSTimes() uint64
- func (m *MockTxnClient) IterTxns(arg0 func(client.TxnOverview) bool)
- func (m *MockTxnClient) MinTimestamp() timestamp.Timestamp
- func (m *MockTxnClient) New(ctx context.Context, commitTS timestamp.Timestamp, options ...client.TxnOption) (client.TxnOperator, error)
- func (m *MockTxnClient) NewWithSnapshot(snapshot []byte) (client.TxnOperator, error)
- func (m *MockTxnClient) Pause()
- func (m *MockTxnClient) RefreshExpressionEnabled() bool
- func (m *MockTxnClient) Resume()
- func (m *MockTxnClient) SyncLatestCommitTS(arg0 timestamp.Timestamp)
- func (m *MockTxnClient) WaitLogTailAppliedAt(ctx context.Context, ts timestamp.Timestamp) (timestamp.Timestamp, error)
- type MockTxnClientMockRecorder
- func (mr *MockTxnClientMockRecorder) AbortAllRunningTxn() *gomock.Call
- func (mr *MockTxnClientMockRecorder) CNBasedConsistencyEnabled() *gomock.Call
- func (mr *MockTxnClientMockRecorder) Close() *gomock.Call
- func (mr *MockTxnClientMockRecorder) GetLatestCommitTS() *gomock.Call
- func (mr *MockTxnClientMockRecorder) GetSyncLatestCommitTSTimes() *gomock.Call
- func (mr *MockTxnClientMockRecorder) IterTxns(arg0 interface{}) *gomock.Call
- func (mr *MockTxnClientMockRecorder) MinTimestamp() *gomock.Call
- func (mr *MockTxnClientMockRecorder) New(ctx, commitTS interface{}, options ...interface{}) *gomock.Call
- func (mr *MockTxnClientMockRecorder) NewWithSnapshot(snapshot interface{}) *gomock.Call
- func (mr *MockTxnClientMockRecorder) Pause() *gomock.Call
- func (mr *MockTxnClientMockRecorder) RefreshExpressionEnabled() *gomock.Call
- func (mr *MockTxnClientMockRecorder) Resume() *gomock.Call
- func (mr *MockTxnClientMockRecorder) SyncLatestCommitTS(arg0 interface{}) *gomock.Call
- func (mr *MockTxnClientMockRecorder) WaitLogTailAppliedAt(ctx, ts interface{}) *gomock.Call
- type MockTxnIDGenerator
- type MockTxnIDGeneratorMockRecorder
- type MockTxnOperator
- func (m *MockTxnOperator) AddLockTable(locktable lock.LockTable) error
- func (m *MockTxnOperator) AddWaitLock(tableID uint64, rows [][]byte, opt lock.LockOptions) uint64
- func (m *MockTxnOperator) AddWorkspace(workspace client.Workspace)
- func (m *MockTxnOperator) AppendEventCallback(event client.EventType, callbacks ...func(txn.TxnMeta))
- func (m *MockTxnOperator) ApplySnapshot(data []byte) error
- func (m *MockTxnOperator) Commit(ctx context.Context) error
- func (m *MockTxnOperator) Debug(ctx context.Context, ops []txn.TxnRequest) (*rpc.SendResult, error)
- func (m *MockTxnOperator) EXPECT() *MockTxnOperatorMockRecorder
- func (m *MockTxnOperator) GetOverview() client.TxnOverview
- func (m *MockTxnOperator) GetWorkspace() client.Workspace
- func (m *MockTxnOperator) IsRetry() bool
- func (m *MockTxnOperator) Read(ctx context.Context, ops []txn.TxnRequest) (*rpc.SendResult, error)
- func (m *MockTxnOperator) RemoveWaitLock(key uint64)
- func (m *MockTxnOperator) ResetRetry(arg0 bool)
- func (m *MockTxnOperator) Rollback(ctx context.Context) error
- func (m *MockTxnOperator) Snapshot() ([]byte, error)
- func (m *MockTxnOperator) SnapshotTS() timestamp.Timestamp
- func (m *MockTxnOperator) Status() txn.TxnStatus
- func (m *MockTxnOperator) Txn() txn.TxnMeta
- func (m *MockTxnOperator) TxnRef() *txn.TxnMeta
- func (m *MockTxnOperator) UpdateSnapshot(ctx context.Context, ts timestamp.Timestamp) error
- func (m *MockTxnOperator) Write(ctx context.Context, ops []txn.TxnRequest) (*rpc.SendResult, error)
- func (m *MockTxnOperator) WriteAndCommit(ctx context.Context, ops []txn.TxnRequest) (*rpc.SendResult, error)
- type MockTxnOperatorMockRecorder
- func (mr *MockTxnOperatorMockRecorder) AddLockTable(locktable interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) AddWaitLock(tableID, rows, opt interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) AddWorkspace(workspace interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) AppendEventCallback(event interface{}, callbacks ...interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) ApplySnapshot(data interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) Commit(ctx interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) Debug(ctx, ops interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) GetOverview() *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) GetWorkspace() *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) IsRetry() *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) Read(ctx, ops interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) RemoveWaitLock(key interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) ResetRetry(arg0 interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) Rollback(ctx interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) Snapshot() *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) SnapshotTS() *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) Status() *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) Txn() *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) TxnRef() *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) UpdateSnapshot(ctx, ts interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) Write(ctx, ops interface{}) *gomock.Call
- func (mr *MockTxnOperatorMockRecorder) WriteAndCommit(ctx, ops interface{}) *gomock.Call
- type MockVectorPool
- type MockVectorPoolMockRecorder
- type MockWorkspace
- func (m *MockWorkspace) Adjust() error
- func (m *MockWorkspace) Commit(ctx context.Context) ([]txn.TxnRequest, error)
- func (m *MockWorkspace) EXPECT() *MockWorkspaceMockRecorder
- func (m *MockWorkspace) EndStatement()
- func (m *MockWorkspace) GetSQLCount() uint64
- func (m *MockWorkspace) IncrSQLCount()
- func (m *MockWorkspace) IncrStatementID(ctx context.Context, commit bool) error
- func (m *MockWorkspace) Rollback(ctx context.Context) error
- func (m *MockWorkspace) RollbackLastStatement(ctx context.Context) error
- func (m *MockWorkspace) StartStatement()
- type MockWorkspaceMockRecorder
- func (mr *MockWorkspaceMockRecorder) Adjust() *gomock.Call
- func (mr *MockWorkspaceMockRecorder) Commit(ctx interface{}) *gomock.Call
- func (mr *MockWorkspaceMockRecorder) EndStatement() *gomock.Call
- func (mr *MockWorkspaceMockRecorder) GetSQLCount() *gomock.Call
- func (mr *MockWorkspaceMockRecorder) IncrSQLCount() *gomock.Call
- func (mr *MockWorkspaceMockRecorder) IncrStatementID(ctx, commit interface{}) *gomock.Call
- func (mr *MockWorkspaceMockRecorder) Rollback(ctx interface{}) *gomock.Call
- func (mr *MockWorkspaceMockRecorder) RollbackLastStatement(ctx interface{}) *gomock.Call
- func (mr *MockWorkspaceMockRecorder) StartStatement() *gomock.Call
- type MockoutputPool
- type MockoutputPoolMockRecorder
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
This section is empty.
Types ¶
type MockBackgroundExec ¶ added in v0.6.0
type MockBackgroundExec struct {
// contains filtered or unexported fields
}
MockBackgroundExec is a mock of BackgroundExec interface.
func NewMockBackgroundExec ¶ added in v0.6.0
func NewMockBackgroundExec(ctrl *gomock.Controller) *MockBackgroundExec
NewMockBackgroundExec creates a new mock instance.
func (*MockBackgroundExec) ClearExecResultBatches ¶ added in v0.8.0
func (m *MockBackgroundExec) ClearExecResultBatches()
ClearExecResultBatches mocks base method.
func (*MockBackgroundExec) ClearExecResultSet ¶ added in v0.6.0
func (m *MockBackgroundExec) ClearExecResultSet()
ClearExecResultSet mocks base method.
func (*MockBackgroundExec) Close ¶ added in v0.6.0
func (m *MockBackgroundExec) Close()
Close mocks base method.
func (*MockBackgroundExec) EXPECT ¶ added in v0.6.0
func (m *MockBackgroundExec) EXPECT() *MockBackgroundExecMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockBackgroundExec) Exec ¶ added in v0.6.0
func (m *MockBackgroundExec) Exec(arg0 context.Context, arg1 string) error
Exec mocks base method.
func (*MockBackgroundExec) GetExecResultBatches ¶ added in v0.8.0
func (m *MockBackgroundExec) GetExecResultBatches() []*batch.Batch
GetExecResultBatches mocks base method.
func (*MockBackgroundExec) GetExecResultSet ¶ added in v0.6.0
func (m *MockBackgroundExec) GetExecResultSet() []interface{}
GetExecResultSet mocks base method.
type MockBackgroundExecMockRecorder ¶ added in v0.6.0
type MockBackgroundExecMockRecorder struct {
// contains filtered or unexported fields
}
MockBackgroundExecMockRecorder is the mock recorder for MockBackgroundExec.
func (*MockBackgroundExecMockRecorder) ClearExecResultBatches ¶ added in v0.8.0
func (mr *MockBackgroundExecMockRecorder) ClearExecResultBatches() *gomock.Call
ClearExecResultBatches indicates an expected call of ClearExecResultBatches.
func (*MockBackgroundExecMockRecorder) ClearExecResultSet ¶ added in v0.6.0
func (mr *MockBackgroundExecMockRecorder) ClearExecResultSet() *gomock.Call
ClearExecResultSet indicates an expected call of ClearExecResultSet.
func (*MockBackgroundExecMockRecorder) Close ¶ added in v0.6.0
func (mr *MockBackgroundExecMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockBackgroundExecMockRecorder) Exec ¶ added in v0.6.0
func (mr *MockBackgroundExecMockRecorder) Exec(arg0, arg1 interface{}) *gomock.Call
Exec indicates an expected call of Exec.
func (*MockBackgroundExecMockRecorder) ExecStmt ¶ added in v0.8.0
func (mr *MockBackgroundExecMockRecorder) ExecStmt(arg0, arg1 interface{}) *gomock.Call
ExecStmt indicates an expected call of ExecStmt.
func (*MockBackgroundExecMockRecorder) GetExecResultBatches ¶ added in v0.8.0
func (mr *MockBackgroundExecMockRecorder) GetExecResultBatches() *gomock.Call
GetExecResultBatches indicates an expected call of GetExecResultBatches.
func (*MockBackgroundExecMockRecorder) GetExecResultSet ¶ added in v0.6.0
func (mr *MockBackgroundExecMockRecorder) GetExecResultSet() *gomock.Call
GetExecResultSet indicates an expected call of GetExecResultSet.
type MockColumnInfo ¶ added in v0.6.0
type MockColumnInfo struct {
// contains filtered or unexported fields
}
MockColumnInfo is a mock of ColumnInfo interface.
func NewMockColumnInfo ¶ added in v0.6.0
func NewMockColumnInfo(ctrl *gomock.Controller) *MockColumnInfo
NewMockColumnInfo creates a new mock instance.
func (*MockColumnInfo) EXPECT ¶ added in v0.6.0
func (m *MockColumnInfo) EXPECT() *MockColumnInfoMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockColumnInfo) GetName ¶ added in v0.6.0
func (m *MockColumnInfo) GetName() string
GetName mocks base method.
func (*MockColumnInfo) GetType ¶ added in v0.6.0
func (m *MockColumnInfo) GetType() types.T
GetType mocks base method.
type MockColumnInfoMockRecorder ¶ added in v0.6.0
type MockColumnInfoMockRecorder struct {
// contains filtered or unexported fields
}
MockColumnInfoMockRecorder is the mock recorder for MockColumnInfo.
func (*MockColumnInfoMockRecorder) GetName ¶ added in v0.6.0
func (mr *MockColumnInfoMockRecorder) GetName() *gomock.Call
GetName indicates an expected call of GetName.
func (*MockColumnInfoMockRecorder) GetType ¶ added in v0.6.0
func (mr *MockColumnInfoMockRecorder) GetType() *gomock.Call
GetType indicates an expected call of GetType.
type MockComputationRunner ¶ added in v0.5.0
type MockComputationRunner struct {
// contains filtered or unexported fields
}
MockComputationRunner is a mock of ComputationRunner interface.
func NewMockComputationRunner ¶ added in v0.5.0
func NewMockComputationRunner(ctrl *gomock.Controller) *MockComputationRunner
NewMockComputationRunner creates a new mock instance.
func (*MockComputationRunner) EXPECT ¶ added in v0.5.0
func (m *MockComputationRunner) EXPECT() *MockComputationRunnerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
type MockComputationRunnerMockRecorder ¶ added in v0.5.0
type MockComputationRunnerMockRecorder struct {
// contains filtered or unexported fields
}
MockComputationRunnerMockRecorder is the mock recorder for MockComputationRunner.
func (*MockComputationRunnerMockRecorder) Run ¶ added in v0.5.0
func (mr *MockComputationRunnerMockRecorder) Run(ts interface{}) *gomock.Call
Run indicates an expected call of Run.
type MockComputationWrapper ¶
type MockComputationWrapper struct {
// contains filtered or unexported fields
}
MockComputationWrapper is a mock of ComputationWrapper interface.
func NewMockComputationWrapper ¶
func NewMockComputationWrapper(ctrl *gomock.Controller) *MockComputationWrapper
NewMockComputationWrapper creates a new mock instance.
func (*MockComputationWrapper) Compile ¶
func (m *MockComputationWrapper) Compile(requestCtx context.Context, u interface{}, fill func(interface{}, *batch.Batch) error) (interface{}, error)
Compile mocks base method.
func (*MockComputationWrapper) EXPECT ¶
func (m *MockComputationWrapper) EXPECT() *MockComputationWrapperMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockComputationWrapper) GetAst ¶
func (m *MockComputationWrapper) GetAst() tree.Statement
GetAst mocks base method.
func (*MockComputationWrapper) GetColumns ¶
func (m *MockComputationWrapper) GetColumns() ([]interface{}, error)
GetColumns mocks base method.
func (*MockComputationWrapper) GetLoadTag ¶ added in v0.6.0
func (m *MockComputationWrapper) GetLoadTag() bool
GetLoadTag mocks base method.
func (*MockComputationWrapper) GetProcess ¶ added in v0.6.0
func (m *MockComputationWrapper) GetProcess() *process.Process
GetProcess mocks base method.
func (*MockComputationWrapper) GetServerStatus ¶ added in v0.8.1
func (m *MockComputationWrapper) GetServerStatus() uint16
GetServerStatus mocks base method.
func (*MockComputationWrapper) GetUUID ¶ added in v0.6.0
func (m *MockComputationWrapper) GetUUID() []byte
GetUUID mocks base method.
func (*MockComputationWrapper) RecordExecPlan ¶ added in v0.6.0
func (m *MockComputationWrapper) RecordExecPlan(ctx context.Context) error
RecordExecPlan mocks base method.
func (*MockComputationWrapper) Run ¶
func (m *MockComputationWrapper) Run(ts uint64) (*util.RunResult, error)
Run mocks base method.
func (*MockComputationWrapper) SetDatabaseName ¶
func (m *MockComputationWrapper) SetDatabaseName(db string) error
SetDatabaseName mocks base method.
type MockComputationWrapperMockRecorder ¶
type MockComputationWrapperMockRecorder struct {
// contains filtered or unexported fields
}
MockComputationWrapperMockRecorder is the mock recorder for MockComputationWrapper.
func (*MockComputationWrapperMockRecorder) Compile ¶
func (mr *MockComputationWrapperMockRecorder) Compile(requestCtx, u, fill interface{}) *gomock.Call
Compile indicates an expected call of Compile.
func (*MockComputationWrapperMockRecorder) GetAst ¶
func (mr *MockComputationWrapperMockRecorder) GetAst() *gomock.Call
GetAst indicates an expected call of GetAst.
func (*MockComputationWrapperMockRecorder) GetColumns ¶
func (mr *MockComputationWrapperMockRecorder) GetColumns() *gomock.Call
GetColumns indicates an expected call of GetColumns.
func (*MockComputationWrapperMockRecorder) GetLoadTag ¶ added in v0.6.0
func (mr *MockComputationWrapperMockRecorder) GetLoadTag() *gomock.Call
GetLoadTag indicates an expected call of GetLoadTag.
func (*MockComputationWrapperMockRecorder) GetProcess ¶ added in v0.6.0
func (mr *MockComputationWrapperMockRecorder) GetProcess() *gomock.Call
GetProcess indicates an expected call of GetProcess.
func (*MockComputationWrapperMockRecorder) GetServerStatus ¶ added in v0.8.1
func (mr *MockComputationWrapperMockRecorder) GetServerStatus() *gomock.Call
GetServerStatus indicates an expected call of GetServerStatus.
func (*MockComputationWrapperMockRecorder) GetUUID ¶ added in v0.6.0
func (mr *MockComputationWrapperMockRecorder) GetUUID() *gomock.Call
GetUUID indicates an expected call of GetUUID.
func (*MockComputationWrapperMockRecorder) RecordExecPlan ¶ added in v0.6.0
func (mr *MockComputationWrapperMockRecorder) RecordExecPlan(ctx interface{}) *gomock.Call
RecordExecPlan indicates an expected call of RecordExecPlan.
func (*MockComputationWrapperMockRecorder) Run ¶
func (mr *MockComputationWrapperMockRecorder) Run(ts interface{}) *gomock.Call
Run indicates an expected call of Run.
func (*MockComputationWrapperMockRecorder) SetDatabaseName ¶
func (mr *MockComputationWrapperMockRecorder) SetDatabaseName(db interface{}) *gomock.Call
SetDatabaseName indicates an expected call of SetDatabaseName.
type MockConstraint ¶ added in v0.7.0
type MockConstraint struct {
// contains filtered or unexported fields
}
MockConstraint is a mock of Constraint interface.
func NewMockConstraint ¶ added in v0.7.0
func NewMockConstraint(ctrl *gomock.Controller) *MockConstraint
NewMockConstraint creates a new mock instance.
func (*MockConstraint) EXPECT ¶ added in v0.7.0
func (m *MockConstraint) EXPECT() *MockConstraintMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockConstraint) ToPBVersion ¶ added in v0.8.0
func (m *MockConstraint) ToPBVersion() engine.ConstraintPB
ToPBVersion mocks base method.
type MockConstraintMockRecorder ¶ added in v0.7.0
type MockConstraintMockRecorder struct {
// contains filtered or unexported fields
}
MockConstraintMockRecorder is the mock recorder for MockConstraint.
func (*MockConstraintMockRecorder) ToPBVersion ¶ added in v0.8.0
func (mr *MockConstraintMockRecorder) ToPBVersion() *gomock.Call
ToPBVersion indicates an expected call of ToPBVersion.
type MockDatabase ¶
type MockDatabase struct {
// contains filtered or unexported fields
}
MockDatabase is a mock of Database interface.
func NewMockDatabase ¶
func NewMockDatabase(ctrl *gomock.Controller) *MockDatabase
NewMockDatabase creates a new mock instance.
func (*MockDatabase) Delete ¶
func (m *MockDatabase) Delete(arg0 context.Context, arg1 string) error
Delete mocks base method.
func (*MockDatabase) EXPECT ¶
func (m *MockDatabase) EXPECT() *MockDatabaseMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockDatabase) GetCreateSql ¶ added in v0.8.0
func (m *MockDatabase) GetCreateSql(arg0 context.Context) string
GetCreateSql mocks base method.
func (*MockDatabase) GetDatabaseId ¶ added in v0.6.0
func (m *MockDatabase) GetDatabaseId(arg0 context.Context) string
GetDatabaseId mocks base method.
func (*MockDatabase) IsSubscription ¶ added in v0.8.0
func (m *MockDatabase) IsSubscription(arg0 context.Context) bool
IsSubscription mocks base method.
func (*MockDatabase) Relation ¶
func (m *MockDatabase) Relation(arg0 context.Context, arg1 string, arg2 any) (engine.Relation, error)
Relation mocks base method.
type MockDatabaseMockRecorder ¶
type MockDatabaseMockRecorder struct {
// contains filtered or unexported fields
}
MockDatabaseMockRecorder is the mock recorder for MockDatabase.
func (*MockDatabaseMockRecorder) Create ¶
func (mr *MockDatabaseMockRecorder) Create(arg0, arg1, arg2 interface{}) *gomock.Call
Create indicates an expected call of Create.
func (*MockDatabaseMockRecorder) Delete ¶
func (mr *MockDatabaseMockRecorder) Delete(arg0, arg1 interface{}) *gomock.Call
Delete indicates an expected call of Delete.
func (*MockDatabaseMockRecorder) GetCreateSql ¶ added in v0.8.0
func (mr *MockDatabaseMockRecorder) GetCreateSql(arg0 interface{}) *gomock.Call
GetCreateSql indicates an expected call of GetCreateSql.
func (*MockDatabaseMockRecorder) GetDatabaseId ¶ added in v0.6.0
func (mr *MockDatabaseMockRecorder) GetDatabaseId(arg0 interface{}) *gomock.Call
GetDatabaseId indicates an expected call of GetDatabaseId.
func (*MockDatabaseMockRecorder) IsSubscription ¶ added in v0.8.0
func (mr *MockDatabaseMockRecorder) IsSubscription(arg0 interface{}) *gomock.Call
IsSubscription indicates an expected call of IsSubscription.
func (*MockDatabaseMockRecorder) Relation ¶
func (mr *MockDatabaseMockRecorder) Relation(arg0, arg1, arg2 interface{}) *gomock.Call
Relation indicates an expected call of Relation.
func (*MockDatabaseMockRecorder) Relations ¶
func (mr *MockDatabaseMockRecorder) Relations(arg0 interface{}) *gomock.Call
Relations indicates an expected call of Relations.
func (*MockDatabaseMockRecorder) Truncate ¶ added in v0.6.0
func (mr *MockDatabaseMockRecorder) Truncate(arg0, arg1 interface{}) *gomock.Call
Truncate indicates an expected call of Truncate.
type MockEngine ¶
type MockEngine struct {
// contains filtered or unexported fields
}
MockEngine is a mock of Engine interface.
func NewMockEngine ¶
func NewMockEngine(ctrl *gomock.Controller) *MockEngine
NewMockEngine creates a new mock instance.
func (*MockEngine) AllocateIDByKey ¶ added in v0.8.0
AllocateIDByKey mocks base method.
func (*MockEngine) Create ¶
func (m *MockEngine) Create(ctx context.Context, databaseName string, op client.TxnOperator) error
Create mocks base method.
func (*MockEngine) Database ¶
func (m *MockEngine) Database(ctx context.Context, databaseName string, op client.TxnOperator) (engine.Database, error)
Database mocks base method.
func (*MockEngine) Databases ¶
func (m *MockEngine) Databases(ctx context.Context, op client.TxnOperator) ([]string, error)
Databases mocks base method.
func (*MockEngine) Delete ¶
func (m *MockEngine) Delete(ctx context.Context, databaseName string, op client.TxnOperator) error
Delete mocks base method.
func (*MockEngine) EXPECT ¶
func (m *MockEngine) EXPECT() *MockEngineMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockEngine) GetNameById ¶ added in v0.7.0
func (m *MockEngine) GetNameById(ctx context.Context, op client.TxnOperator, tableId uint64) (string, string, error)
GetNameById mocks base method.
func (*MockEngine) GetRelationById ¶ added in v0.7.0
func (m *MockEngine) GetRelationById(ctx context.Context, op client.TxnOperator, tableId uint64) (string, string, engine.Relation, error)
GetRelationById mocks base method.
func (*MockEngine) Hints ¶ added in v0.6.0
func (m *MockEngine) Hints() engine.Hints
Hints mocks base method.
func (*MockEngine) New ¶ added in v0.6.0
func (m *MockEngine) New(ctx context.Context, op client.TxnOperator) error
New mocks base method.
type MockEngineMockRecorder ¶
type MockEngineMockRecorder struct {
// contains filtered or unexported fields
}
MockEngineMockRecorder is the mock recorder for MockEngine.
func (*MockEngineMockRecorder) AllocateIDByKey ¶ added in v0.8.0
func (mr *MockEngineMockRecorder) AllocateIDByKey(ctx, key interface{}) *gomock.Call
AllocateIDByKey indicates an expected call of AllocateIDByKey.
func (*MockEngineMockRecorder) Create ¶
func (mr *MockEngineMockRecorder) Create(ctx, databaseName, op interface{}) *gomock.Call
Create indicates an expected call of Create.
func (*MockEngineMockRecorder) Database ¶
func (mr *MockEngineMockRecorder) Database(ctx, databaseName, op interface{}) *gomock.Call
Database indicates an expected call of Database.
func (*MockEngineMockRecorder) Databases ¶
func (mr *MockEngineMockRecorder) Databases(ctx, op interface{}) *gomock.Call
Databases indicates an expected call of Databases.
func (*MockEngineMockRecorder) Delete ¶
func (mr *MockEngineMockRecorder) Delete(ctx, databaseName, op interface{}) *gomock.Call
Delete indicates an expected call of Delete.
func (*MockEngineMockRecorder) GetNameById ¶ added in v0.7.0
func (mr *MockEngineMockRecorder) GetNameById(ctx, op, tableId interface{}) *gomock.Call
GetNameById indicates an expected call of GetNameById.
func (*MockEngineMockRecorder) GetRelationById ¶ added in v0.7.0
func (mr *MockEngineMockRecorder) GetRelationById(ctx, op, tableId interface{}) *gomock.Call
GetRelationById indicates an expected call of GetRelationById.
func (*MockEngineMockRecorder) Hints ¶ added in v0.6.0
func (mr *MockEngineMockRecorder) Hints() *gomock.Call
Hints indicates an expected call of Hints.
func (*MockEngineMockRecorder) New ¶ added in v0.6.0
func (mr *MockEngineMockRecorder) New(ctx, op interface{}) *gomock.Call
New indicates an expected call of New.
func (*MockEngineMockRecorder) NewBlockReader ¶ added in v0.6.0
func (mr *MockEngineMockRecorder) NewBlockReader(ctx, num, ts, expr, ranges, tblDef, proc interface{}) *gomock.Call
NewBlockReader indicates an expected call of NewBlockReader.
func (*MockEngineMockRecorder) Nodes ¶ added in v0.6.0
func (mr *MockEngineMockRecorder) Nodes(isInternal, tenant, username, cnLabel interface{}) *gomock.Call
Nodes indicates an expected call of Nodes.
type MockExecResult ¶ added in v0.6.0
type MockExecResult struct {
// contains filtered or unexported fields
}
MockExecResult is a mock of ExecResult interface.
func NewMockExecResult ¶ added in v0.6.0
func NewMockExecResult(ctrl *gomock.Controller) *MockExecResult
NewMockExecResult creates a new mock instance.
func (*MockExecResult) EXPECT ¶ added in v0.6.0
func (m *MockExecResult) EXPECT() *MockExecResultMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockExecResult) GetRowCount ¶ added in v0.6.0
func (m *MockExecResult) GetRowCount() uint64
GetRowCount mocks base method.
type MockExecResultMockRecorder ¶ added in v0.6.0
type MockExecResultMockRecorder struct {
// contains filtered or unexported fields
}
MockExecResultMockRecorder is the mock recorder for MockExecResult.
func (*MockExecResultMockRecorder) GetInt64 ¶ added in v0.6.0
func (mr *MockExecResultMockRecorder) GetInt64(ctx, rindex, cindex interface{}) *gomock.Call
GetInt64 indicates an expected call of GetInt64.
func (*MockExecResultMockRecorder) GetRowCount ¶ added in v0.6.0
func (mr *MockExecResultMockRecorder) GetRowCount() *gomock.Call
GetRowCount indicates an expected call of GetRowCount.
func (*MockExecResultMockRecorder) GetString ¶ added in v0.6.0
func (mr *MockExecResultMockRecorder) GetString(ctx, rindex, cindex interface{}) *gomock.Call
GetString indicates an expected call of GetString.
func (*MockExecResultMockRecorder) GetUint64 ¶ added in v0.6.0
func (mr *MockExecResultMockRecorder) GetUint64(ctx, rindex, cindex interface{}) *gomock.Call
GetUint64 indicates an expected call of GetUint64.
type MockIOPackage ¶
type MockIOPackage struct {
// contains filtered or unexported fields
}
MockIOPackage is a mock of IOPackage interface.
func NewMockIOPackage ¶
func NewMockIOPackage(ctrl *gomock.Controller) *MockIOPackage
NewMockIOPackage creates a new mock instance.
func (*MockIOPackage) AppendUint16 ¶
func (m *MockIOPackage) AppendUint16(arg0 []byte, arg1 uint16) []byte
AppendUint16 mocks base method.
func (*MockIOPackage) AppendUint32 ¶
func (m *MockIOPackage) AppendUint32(arg0 []byte, arg1 uint32) []byte
AppendUint32 mocks base method.
func (*MockIOPackage) AppendUint64 ¶
func (m *MockIOPackage) AppendUint64(arg0 []byte, arg1 uint64) []byte
AppendUint64 mocks base method.
func (*MockIOPackage) AppendUint8 ¶
func (m *MockIOPackage) AppendUint8(arg0 []byte, arg1 uint8) []byte
AppendUint8 mocks base method.
func (*MockIOPackage) EXPECT ¶
func (m *MockIOPackage) EXPECT() *MockIOPackageMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockIOPackage) IsLittleEndian ¶
func (m *MockIOPackage) IsLittleEndian() bool
IsLittleEndian mocks base method.
func (*MockIOPackage) ReadUint16 ¶
ReadUint16 mocks base method.
func (*MockIOPackage) ReadUint32 ¶
ReadUint32 mocks base method.
func (*MockIOPackage) ReadUint64 ¶
ReadUint64 mocks base method.
func (*MockIOPackage) WriteUint16 ¶
func (m *MockIOPackage) WriteUint16(arg0 []byte, arg1 int, arg2 uint16) int
WriteUint16 mocks base method.
func (*MockIOPackage) WriteUint32 ¶
func (m *MockIOPackage) WriteUint32(arg0 []byte, arg1 int, arg2 uint32) int
WriteUint32 mocks base method.
func (*MockIOPackage) WriteUint64 ¶
func (m *MockIOPackage) WriteUint64(arg0 []byte, arg1 int, arg2 uint64) int
WriteUint64 mocks base method.
func (*MockIOPackage) WriteUint8 ¶
func (m *MockIOPackage) WriteUint8(arg0 []byte, arg1 int, arg2 uint8) int
WriteUint8 mocks base method.
type MockIOPackageMockRecorder ¶
type MockIOPackageMockRecorder struct {
// contains filtered or unexported fields
}
MockIOPackageMockRecorder is the mock recorder for MockIOPackage.
func (*MockIOPackageMockRecorder) AppendUint16 ¶
func (mr *MockIOPackageMockRecorder) AppendUint16(arg0, arg1 interface{}) *gomock.Call
AppendUint16 indicates an expected call of AppendUint16.
func (*MockIOPackageMockRecorder) AppendUint32 ¶
func (mr *MockIOPackageMockRecorder) AppendUint32(arg0, arg1 interface{}) *gomock.Call
AppendUint32 indicates an expected call of AppendUint32.
func (*MockIOPackageMockRecorder) AppendUint64 ¶
func (mr *MockIOPackageMockRecorder) AppendUint64(arg0, arg1 interface{}) *gomock.Call
AppendUint64 indicates an expected call of AppendUint64.
func (*MockIOPackageMockRecorder) AppendUint8 ¶
func (mr *MockIOPackageMockRecorder) AppendUint8(arg0, arg1 interface{}) *gomock.Call
AppendUint8 indicates an expected call of AppendUint8.
func (*MockIOPackageMockRecorder) IsLittleEndian ¶
func (mr *MockIOPackageMockRecorder) IsLittleEndian() *gomock.Call
IsLittleEndian indicates an expected call of IsLittleEndian.
func (*MockIOPackageMockRecorder) ReadUint16 ¶
func (mr *MockIOPackageMockRecorder) ReadUint16(arg0, arg1 interface{}) *gomock.Call
ReadUint16 indicates an expected call of ReadUint16.
func (*MockIOPackageMockRecorder) ReadUint32 ¶
func (mr *MockIOPackageMockRecorder) ReadUint32(arg0, arg1 interface{}) *gomock.Call
ReadUint32 indicates an expected call of ReadUint32.
func (*MockIOPackageMockRecorder) ReadUint64 ¶
func (mr *MockIOPackageMockRecorder) ReadUint64(arg0, arg1 interface{}) *gomock.Call
ReadUint64 indicates an expected call of ReadUint64.
func (*MockIOPackageMockRecorder) ReadUint8 ¶
func (mr *MockIOPackageMockRecorder) ReadUint8(arg0, arg1 interface{}) *gomock.Call
ReadUint8 indicates an expected call of ReadUint8.
func (*MockIOPackageMockRecorder) WriteUint16 ¶
func (mr *MockIOPackageMockRecorder) WriteUint16(arg0, arg1, arg2 interface{}) *gomock.Call
WriteUint16 indicates an expected call of WriteUint16.
func (*MockIOPackageMockRecorder) WriteUint32 ¶
func (mr *MockIOPackageMockRecorder) WriteUint32(arg0, arg1, arg2 interface{}) *gomock.Call
WriteUint32 indicates an expected call of WriteUint32.
func (*MockIOPackageMockRecorder) WriteUint64 ¶
func (mr *MockIOPackageMockRecorder) WriteUint64(arg0, arg1, arg2 interface{}) *gomock.Call
WriteUint64 indicates an expected call of WriteUint64.
func (*MockIOPackageMockRecorder) WriteUint8 ¶
func (mr *MockIOPackageMockRecorder) WriteUint8(arg0, arg1, arg2 interface{}) *gomock.Call
WriteUint8 indicates an expected call of WriteUint8.
type MockIOSession ¶
type MockIOSession struct {
// contains filtered or unexported fields
}
MockIOSession is a mock of IOSession interface.
func NewMockIOSession ¶
func NewMockIOSession(ctrl *gomock.Controller) *MockIOSession
NewMockIOSession creates a new mock instance.
func (*MockIOSession) Connect ¶
func (m *MockIOSession) Connect(addr string, timeout time.Duration) error
Connect mocks base method.
func (*MockIOSession) Connected ¶
func (m *MockIOSession) Connected() bool
Connected mocks base method.
func (*MockIOSession) Disconnect ¶ added in v0.6.0
func (m *MockIOSession) Disconnect() error
Disconnect mocks base method.
func (*MockIOSession) EXPECT ¶
func (m *MockIOSession) EXPECT() *MockIOSessionMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockIOSession) Flush ¶
func (m *MockIOSession) Flush(timeout time.Duration) error
Flush mocks base method.
func (*MockIOSession) OutBuf ¶
func (m *MockIOSession) OutBuf() *buf.ByteBuf
OutBuf mocks base method.
func (*MockIOSession) RawConn ¶
func (m *MockIOSession) RawConn() net.Conn
RawConn mocks base method.
func (*MockIOSession) Read ¶
func (m *MockIOSession) Read(option goetty.ReadOptions) (any, error)
Read mocks base method.
func (*MockIOSession) RemoteAddress ¶ added in v0.6.0
func (m *MockIOSession) RemoteAddress() string
RemoteAddress mocks base method.
func (*MockIOSession) UseConn ¶ added in v0.6.0
func (m *MockIOSession) UseConn(arg0 net.Conn)
UseConn mocks base method.
func (*MockIOSession) Write ¶
func (m *MockIOSession) Write(msg any, options goetty.WriteOptions) error
Write mocks base method.
type MockIOSessionMockRecorder ¶
type MockIOSessionMockRecorder struct {
// contains filtered or unexported fields
}
MockIOSessionMockRecorder is the mock recorder for MockIOSession.
func (*MockIOSessionMockRecorder) Close ¶
func (mr *MockIOSessionMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockIOSessionMockRecorder) Connect ¶
func (mr *MockIOSessionMockRecorder) Connect(addr, timeout interface{}) *gomock.Call
Connect indicates an expected call of Connect.
func (*MockIOSessionMockRecorder) Connected ¶
func (mr *MockIOSessionMockRecorder) Connected() *gomock.Call
Connected indicates an expected call of Connected.
func (*MockIOSessionMockRecorder) Disconnect ¶ added in v0.6.0
func (mr *MockIOSessionMockRecorder) Disconnect() *gomock.Call
Disconnect indicates an expected call of Disconnect.
func (*MockIOSessionMockRecorder) Flush ¶
func (mr *MockIOSessionMockRecorder) Flush(timeout interface{}) *gomock.Call
Flush indicates an expected call of Flush.
func (*MockIOSessionMockRecorder) ID ¶
func (mr *MockIOSessionMockRecorder) ID() *gomock.Call
ID indicates an expected call of ID.
func (*MockIOSessionMockRecorder) OutBuf ¶
func (mr *MockIOSessionMockRecorder) OutBuf() *gomock.Call
OutBuf indicates an expected call of OutBuf.
func (*MockIOSessionMockRecorder) RawConn ¶ added in v0.5.0
func (mr *MockIOSessionMockRecorder) RawConn() *gomock.Call
RawConn indicates an expected call of RawConn.
func (*MockIOSessionMockRecorder) Read ¶
func (mr *MockIOSessionMockRecorder) Read(option interface{}) *gomock.Call
Read indicates an expected call of Read.
func (*MockIOSessionMockRecorder) Ref ¶ added in v0.6.0
func (mr *MockIOSessionMockRecorder) Ref() *gomock.Call
Ref indicates an expected call of Ref.
func (*MockIOSessionMockRecorder) RemoteAddress ¶ added in v0.6.0
func (mr *MockIOSessionMockRecorder) RemoteAddress() *gomock.Call
RemoteAddress indicates an expected call of RemoteAddress.
func (*MockIOSessionMockRecorder) UseConn ¶ added in v0.6.0
func (mr *MockIOSessionMockRecorder) UseConn(arg0 interface{}) *gomock.Call
UseConn indicates an expected call of UseConn.
func (*MockIOSessionMockRecorder) Write ¶
func (mr *MockIOSessionMockRecorder) Write(msg, options interface{}) *gomock.Call
Write indicates an expected call of Write.
type MockReader ¶
type MockReader struct {
// contains filtered or unexported fields
}
MockReader is a mock of Reader interface.
func NewMockReader ¶
func NewMockReader(ctrl *gomock.Controller) *MockReader
NewMockReader creates a new mock instance.
func (*MockReader) Close ¶ added in v0.6.0
func (m *MockReader) Close() error
Close mocks base method.
func (*MockReader) EXPECT ¶
func (m *MockReader) EXPECT() *MockReaderMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
type MockReaderMockRecorder ¶
type MockReaderMockRecorder struct {
// contains filtered or unexported fields
}
MockReaderMockRecorder is the mock recorder for MockReader.
func (*MockReaderMockRecorder) Close ¶ added in v0.6.0
func (mr *MockReaderMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockReaderMockRecorder) Read ¶
func (mr *MockReaderMockRecorder) Read(arg0, arg1, arg2, arg3, arg4 interface{}) *gomock.Call
Read indicates an expected call of Read.
type MockRelation ¶
type MockRelation struct {
// contains filtered or unexported fields
}
MockRelation is a mock of Relation interface.
func NewMockRelation ¶
func NewMockRelation(ctrl *gomock.Controller) *MockRelation
NewMockRelation creates a new mock instance.
func (*MockRelation) AddTableDef ¶
AddTableDef mocks base method.
func (*MockRelation) AlterTable ¶ added in v0.8.0
func (m *MockRelation) AlterTable(ctx context.Context, c *engine.ConstraintDef, constraint [][]byte) error
AlterTable mocks base method.
func (*MockRelation) DelTableDef ¶
DelTableDef mocks base method.
func (*MockRelation) EXPECT ¶
func (m *MockRelation) EXPECT() *MockRelationMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockRelation) GetColumMetadataScanInfo ¶ added in v0.8.0
func (m *MockRelation) GetColumMetadataScanInfo(ctx context.Context, name string) ([]*plan.MetadataScanInfo, error)
GetColumMetadataScanInfo mocks base method.
func (*MockRelation) GetDBID ¶ added in v0.8.0
func (m *MockRelation) GetDBID(arg0 context.Context) uint64
GetDBID mocks base method.
func (*MockRelation) GetEngineType ¶ added in v0.8.0
func (m *MockRelation) GetEngineType() engine.EngineType
GetEngineType mocks base method.
func (*MockRelation) GetHideKeys ¶ added in v0.6.0
GetHideKeys mocks base method.
func (*MockRelation) GetPrimaryKeys ¶ added in v0.5.0
GetPrimaryKeys mocks base method.
func (*MockRelation) GetTableID ¶ added in v0.6.0
func (m *MockRelation) GetTableID(arg0 context.Context) uint64
GetTableID mocks base method.
func (*MockRelation) GetTableName ¶ added in v0.8.0
func (m *MockRelation) GetTableName() string
GetTableName mocks base method.
func (*MockRelation) MaxAndMinValues ¶ added in v0.7.0
MaxAndMinValues mocks base method.
func (*MockRelation) NewReader ¶
func (m *MockRelation) NewReader(arg0 context.Context, arg1 int, arg2 *plan.Expr, arg3 [][]byte) ([]engine.Reader, error)
NewReader mocks base method.
func (*MockRelation) PrimaryKeysMayBeModified ¶ added in v0.8.0
func (m *MockRelation) PrimaryKeysMayBeModified(ctx context.Context, from, to types.TS, keyVector *vector.Vector) (bool, error)
PrimaryKeysMayBeModified mocks base method.
func (*MockRelation) Rows ¶
func (m *MockRelation) Rows(ctx context.Context) (int64, error)
Rows mocks base method.
func (*MockRelation) TableColumns ¶ added in v0.6.0
TableColumns mocks base method.
func (*MockRelation) UpdateBlockInfos ¶
func (m *MockRelation) UpdateBlockInfos(arg0 context.Context) error
UpdateBlockInfos mocks base method.
func (*MockRelation) UpdateConstraint ¶ added in v0.7.0
func (m *MockRelation) UpdateConstraint(arg0 context.Context, arg1 *engine.ConstraintDef) error
UpdateConstraint mocks base method.
type MockRelationMockRecorder ¶
type MockRelationMockRecorder struct {
// contains filtered or unexported fields
}
MockRelationMockRecorder is the mock recorder for MockRelation.
func (*MockRelationMockRecorder) AddTableDef ¶
func (mr *MockRelationMockRecorder) AddTableDef(arg0, arg1 interface{}) *gomock.Call
AddTableDef indicates an expected call of AddTableDef.
func (*MockRelationMockRecorder) AlterTable ¶ added in v0.8.0
func (mr *MockRelationMockRecorder) AlterTable(ctx, c, constraint interface{}) *gomock.Call
AlterTable indicates an expected call of AlterTable.
func (*MockRelationMockRecorder) DelTableDef ¶
func (mr *MockRelationMockRecorder) DelTableDef(arg0, arg1 interface{}) *gomock.Call
DelTableDef indicates an expected call of DelTableDef.
func (*MockRelationMockRecorder) Delete ¶ added in v0.5.0
func (mr *MockRelationMockRecorder) Delete(arg0, arg1, arg2 interface{}) *gomock.Call
Delete indicates an expected call of Delete.
func (*MockRelationMockRecorder) GetColumMetadataScanInfo ¶ added in v0.8.0
func (mr *MockRelationMockRecorder) GetColumMetadataScanInfo(ctx, name interface{}) *gomock.Call
GetColumMetadataScanInfo indicates an expected call of GetColumMetadataScanInfo.
func (*MockRelationMockRecorder) GetDBID ¶ added in v0.8.0
func (mr *MockRelationMockRecorder) GetDBID(arg0 interface{}) *gomock.Call
GetDBID indicates an expected call of GetDBID.
func (*MockRelationMockRecorder) GetEngineType ¶ added in v0.8.0
func (mr *MockRelationMockRecorder) GetEngineType() *gomock.Call
GetEngineType indicates an expected call of GetEngineType.
func (*MockRelationMockRecorder) GetHideKeys ¶ added in v0.6.0
func (mr *MockRelationMockRecorder) GetHideKeys(arg0 interface{}) *gomock.Call
GetHideKeys indicates an expected call of GetHideKeys.
func (*MockRelationMockRecorder) GetPrimaryKeys ¶ added in v0.5.0
func (mr *MockRelationMockRecorder) GetPrimaryKeys(arg0 interface{}) *gomock.Call
GetPrimaryKeys indicates an expected call of GetPrimaryKeys.
func (*MockRelationMockRecorder) GetTableID ¶ added in v0.6.0
func (mr *MockRelationMockRecorder) GetTableID(arg0 interface{}) *gomock.Call
GetTableID indicates an expected call of GetTableID.
func (*MockRelationMockRecorder) GetTableName ¶ added in v0.8.0
func (mr *MockRelationMockRecorder) GetTableName() *gomock.Call
GetTableName indicates an expected call of GetTableName.
func (*MockRelationMockRecorder) MaxAndMinValues ¶ added in v0.7.0
func (mr *MockRelationMockRecorder) MaxAndMinValues(ctx interface{}) *gomock.Call
MaxAndMinValues indicates an expected call of MaxAndMinValues.
func (*MockRelationMockRecorder) NewReader ¶
func (mr *MockRelationMockRecorder) NewReader(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
NewReader indicates an expected call of NewReader.
func (*MockRelationMockRecorder) PrimaryKeysMayBeModified ¶ added in v0.8.0
func (mr *MockRelationMockRecorder) PrimaryKeysMayBeModified(ctx, from, to, keyVector interface{}) *gomock.Call
PrimaryKeysMayBeModified indicates an expected call of PrimaryKeysMayBeModified.
func (*MockRelationMockRecorder) Ranges ¶ added in v0.6.0
func (mr *MockRelationMockRecorder) Ranges(arg0, arg1 interface{}) *gomock.Call
Ranges indicates an expected call of Ranges.
func (*MockRelationMockRecorder) Rows ¶
func (mr *MockRelationMockRecorder) Rows(ctx interface{}) *gomock.Call
Rows indicates an expected call of Rows.
func (*MockRelationMockRecorder) Size ¶
func (mr *MockRelationMockRecorder) Size(ctx, columnName interface{}) *gomock.Call
Size indicates an expected call of Size.
func (*MockRelationMockRecorder) Stats ¶ added in v0.7.0
func (mr *MockRelationMockRecorder) Stats(ctx, partitionTables, statsInfoMap interface{}) *gomock.Call
Stats indicates an expected call of Stats.
func (*MockRelationMockRecorder) TableColumns ¶ added in v0.6.0
func (mr *MockRelationMockRecorder) TableColumns(ctx interface{}) *gomock.Call
TableColumns indicates an expected call of TableColumns.
func (*MockRelationMockRecorder) TableDefs ¶
func (mr *MockRelationMockRecorder) TableDefs(arg0 interface{}) *gomock.Call
TableDefs indicates an expected call of TableDefs.
func (*MockRelationMockRecorder) Update ¶ added in v0.5.0
func (mr *MockRelationMockRecorder) Update(arg0, arg1 interface{}) *gomock.Call
Update indicates an expected call of Update.
func (*MockRelationMockRecorder) UpdateBlockInfos ¶
func (mr *MockRelationMockRecorder) UpdateBlockInfos(arg0 interface{}) *gomock.Call
UpdateBlockInfos indicates an expected call of UpdateBlockInfos.
func (*MockRelationMockRecorder) UpdateConstraint ¶ added in v0.7.0
func (mr *MockRelationMockRecorder) UpdateConstraint(arg0, arg1 interface{}) *gomock.Call
UpdateConstraint indicates an expected call of UpdateConstraint.
func (*MockRelationMockRecorder) Write ¶
func (mr *MockRelationMockRecorder) Write(arg0, arg1 interface{}) *gomock.Call
Write indicates an expected call of Write.
type MockStatistics ¶
type MockStatistics struct {
// contains filtered or unexported fields
}
MockStatistics is a mock of Statistics interface.
func NewMockStatistics ¶
func NewMockStatistics(ctrl *gomock.Controller) *MockStatistics
NewMockStatistics creates a new mock instance.
func (*MockStatistics) EXPECT ¶
func (m *MockStatistics) EXPECT() *MockStatisticsMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockStatistics) Rows ¶
func (m *MockStatistics) Rows(ctx context.Context) (int64, error)
Rows mocks base method.
type MockStatisticsMockRecorder ¶
type MockStatisticsMockRecorder struct {
// contains filtered or unexported fields
}
MockStatisticsMockRecorder is the mock recorder for MockStatistics.
func (*MockStatisticsMockRecorder) Rows ¶
func (mr *MockStatisticsMockRecorder) Rows(ctx interface{}) *gomock.Call
Rows indicates an expected call of Rows.
func (*MockStatisticsMockRecorder) Size ¶
func (mr *MockStatisticsMockRecorder) Size(ctx, columnName interface{}) *gomock.Call
Size indicates an expected call of Size.
func (*MockStatisticsMockRecorder) Stats ¶ added in v0.7.0
func (mr *MockStatisticsMockRecorder) Stats(ctx, partitionTables, statsInfoMap interface{}) *gomock.Call
Stats indicates an expected call of Stats.
type MockTableDef ¶
type MockTableDef struct {
// contains filtered or unexported fields
}
MockTableDef is a mock of TableDef interface.
func NewMockTableDef ¶
func NewMockTableDef(ctrl *gomock.Controller) *MockTableDef
NewMockTableDef creates a new mock instance.
func (*MockTableDef) EXPECT ¶
func (m *MockTableDef) EXPECT() *MockTableDefMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockTableDef) ToPBVersion ¶ added in v0.8.0
func (m *MockTableDef) ToPBVersion() engine.TableDefPB
ToPBVersion mocks base method.
type MockTableDefMockRecorder ¶
type MockTableDefMockRecorder struct {
// contains filtered or unexported fields
}
MockTableDefMockRecorder is the mock recorder for MockTableDef.
func (*MockTableDefMockRecorder) ToPBVersion ¶ added in v0.8.0
func (mr *MockTableDefMockRecorder) ToPBVersion() *gomock.Call
ToPBVersion indicates an expected call of ToPBVersion.
type MockTableInfo ¶ added in v0.6.0
type MockTableInfo struct {
// contains filtered or unexported fields
}
MockTableInfo is a mock of TableInfo interface.
func NewMockTableInfo ¶ added in v0.6.0
func NewMockTableInfo(ctrl *gomock.Controller) *MockTableInfo
NewMockTableInfo creates a new mock instance.
func (*MockTableInfo) EXPECT ¶ added in v0.6.0
func (m *MockTableInfo) EXPECT() *MockTableInfoMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockTableInfo) GetColumns ¶ added in v0.6.0
func (m *MockTableInfo) GetColumns()
GetColumns mocks base method.
type MockTableInfoMockRecorder ¶ added in v0.6.0
type MockTableInfoMockRecorder struct {
// contains filtered or unexported fields
}
MockTableInfoMockRecorder is the mock recorder for MockTableInfo.
func (*MockTableInfoMockRecorder) GetColumns ¶ added in v0.6.0
func (mr *MockTableInfoMockRecorder) GetColumns() *gomock.Call
GetColumns indicates an expected call of GetColumns.
type MockTimestampWaiter ¶ added in v0.8.0
type MockTimestampWaiter struct {
// contains filtered or unexported fields
}
MockTimestampWaiter is a mock of TimestampWaiter interface.
func NewMockTimestampWaiter ¶ added in v0.8.0
func NewMockTimestampWaiter(ctrl *gomock.Controller) *MockTimestampWaiter
NewMockTimestampWaiter creates a new mock instance.
func (*MockTimestampWaiter) Close ¶ added in v0.8.0
func (m *MockTimestampWaiter) Close()
Close mocks base method.
func (*MockTimestampWaiter) EXPECT ¶ added in v0.8.0
func (m *MockTimestampWaiter) EXPECT() *MockTimestampWaiterMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockTimestampWaiter) GetTimestamp ¶ added in v0.8.0
func (m *MockTimestampWaiter) GetTimestamp(arg0 context.Context, arg1 timestamp.Timestamp) (timestamp.Timestamp, error)
GetTimestamp mocks base method.
func (*MockTimestampWaiter) NotifyLatestCommitTS ¶ added in v0.8.0
func (m *MockTimestampWaiter) NotifyLatestCommitTS(appliedTS timestamp.Timestamp)
NotifyLatestCommitTS mocks base method.
type MockTimestampWaiterMockRecorder ¶ added in v0.8.0
type MockTimestampWaiterMockRecorder struct {
// contains filtered or unexported fields
}
MockTimestampWaiterMockRecorder is the mock recorder for MockTimestampWaiter.
func (*MockTimestampWaiterMockRecorder) Close ¶ added in v0.8.0
func (mr *MockTimestampWaiterMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockTimestampWaiterMockRecorder) GetTimestamp ¶ added in v0.8.0
func (mr *MockTimestampWaiterMockRecorder) GetTimestamp(arg0, arg1 interface{}) *gomock.Call
GetTimestamp indicates an expected call of GetTimestamp.
func (*MockTimestampWaiterMockRecorder) NotifyLatestCommitTS ¶ added in v0.8.0
func (mr *MockTimestampWaiterMockRecorder) NotifyLatestCommitTS(appliedTS interface{}) *gomock.Call
NotifyLatestCommitTS indicates an expected call of NotifyLatestCommitTS.
type MockTxnClient ¶ added in v0.6.0
type MockTxnClient struct {
// contains filtered or unexported fields
}
MockTxnClient is a mock of TxnClient interface.
func NewMockTxnClient ¶ added in v0.6.0
func NewMockTxnClient(ctrl *gomock.Controller) *MockTxnClient
NewMockTxnClient creates a new mock instance.
func (*MockTxnClient) AbortAllRunningTxn ¶ added in v0.8.0
func (m *MockTxnClient) AbortAllRunningTxn()
AbortAllRunningTxn mocks base method.
func (*MockTxnClient) CNBasedConsistencyEnabled ¶ added in v1.0.0
func (m *MockTxnClient) CNBasedConsistencyEnabled() bool
CNBasedConsistencyEnabled mocks base method.
func (*MockTxnClient) Close ¶ added in v0.6.0
func (m *MockTxnClient) Close() error
Close mocks base method.
func (*MockTxnClient) EXPECT ¶ added in v0.6.0
func (m *MockTxnClient) EXPECT() *MockTxnClientMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockTxnClient) GetLatestCommitTS ¶ added in v1.0.0
func (m *MockTxnClient) GetLatestCommitTS() timestamp.Timestamp
GetLatestCommitTS mocks base method.
func (*MockTxnClient) GetSyncLatestCommitTSTimes ¶ added in v1.0.0
func (m *MockTxnClient) GetSyncLatestCommitTSTimes() uint64
GetSyncLatestCommitTSTimes mocks base method.
func (*MockTxnClient) IterTxns ¶ added in v1.0.0
func (m *MockTxnClient) IterTxns(arg0 func(client.TxnOverview) bool)
IterTxns mocks base method.
func (*MockTxnClient) MinTimestamp ¶ added in v0.8.0
func (m *MockTxnClient) MinTimestamp() timestamp.Timestamp
MinTimestamp mocks base method.
func (*MockTxnClient) New ¶ added in v0.6.0
func (m *MockTxnClient) New(ctx context.Context, commitTS timestamp.Timestamp, options ...client.TxnOption) (client.TxnOperator, error)
New mocks base method.
func (*MockTxnClient) NewWithSnapshot ¶ added in v0.6.0
func (m *MockTxnClient) NewWithSnapshot(snapshot []byte) (client.TxnOperator, error)
NewWithSnapshot mocks base method.
func (*MockTxnClient) Pause ¶ added in v1.0.0
func (m *MockTxnClient) Pause()
Pause mocks base method.
func (*MockTxnClient) RefreshExpressionEnabled ¶ added in v1.0.0
func (m *MockTxnClient) RefreshExpressionEnabled() bool
RefreshExpressionEnabled mocks base method.
func (*MockTxnClient) Resume ¶ added in v1.0.0
func (m *MockTxnClient) Resume()
Resume mocks base method.
func (*MockTxnClient) SyncLatestCommitTS ¶ added in v1.0.0
func (m *MockTxnClient) SyncLatestCommitTS(arg0 timestamp.Timestamp)
SyncLatestCommitTS mocks base method.
func (*MockTxnClient) WaitLogTailAppliedAt ¶ added in v0.8.0
func (m *MockTxnClient) WaitLogTailAppliedAt(ctx context.Context, ts timestamp.Timestamp) (timestamp.Timestamp, error)
WaitLogTailAppliedAt mocks base method.
type MockTxnClientMockRecorder ¶ added in v0.6.0
type MockTxnClientMockRecorder struct {
// contains filtered or unexported fields
}
MockTxnClientMockRecorder is the mock recorder for MockTxnClient.
func (*MockTxnClientMockRecorder) AbortAllRunningTxn ¶ added in v0.8.0
func (mr *MockTxnClientMockRecorder) AbortAllRunningTxn() *gomock.Call
AbortAllRunningTxn indicates an expected call of AbortAllRunningTxn.
func (*MockTxnClientMockRecorder) CNBasedConsistencyEnabled ¶ added in v1.0.0
func (mr *MockTxnClientMockRecorder) CNBasedConsistencyEnabled() *gomock.Call
CNBasedConsistencyEnabled indicates an expected call of CNBasedConsistencyEnabled.
func (*MockTxnClientMockRecorder) Close ¶ added in v0.6.0
func (mr *MockTxnClientMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockTxnClientMockRecorder) GetLatestCommitTS ¶ added in v1.0.0
func (mr *MockTxnClientMockRecorder) GetLatestCommitTS() *gomock.Call
GetLatestCommitTS indicates an expected call of GetLatestCommitTS.
func (*MockTxnClientMockRecorder) GetSyncLatestCommitTSTimes ¶ added in v1.0.0
func (mr *MockTxnClientMockRecorder) GetSyncLatestCommitTSTimes() *gomock.Call
GetSyncLatestCommitTSTimes indicates an expected call of GetSyncLatestCommitTSTimes.
func (*MockTxnClientMockRecorder) IterTxns ¶ added in v1.0.0
func (mr *MockTxnClientMockRecorder) IterTxns(arg0 interface{}) *gomock.Call
IterTxns indicates an expected call of IterTxns.
func (*MockTxnClientMockRecorder) MinTimestamp ¶ added in v0.8.0
func (mr *MockTxnClientMockRecorder) MinTimestamp() *gomock.Call
MinTimestamp indicates an expected call of MinTimestamp.
func (*MockTxnClientMockRecorder) New ¶ added in v0.6.0
func (mr *MockTxnClientMockRecorder) New(ctx, commitTS interface{}, options ...interface{}) *gomock.Call
New indicates an expected call of New.
func (*MockTxnClientMockRecorder) NewWithSnapshot ¶ added in v0.6.0
func (mr *MockTxnClientMockRecorder) NewWithSnapshot(snapshot interface{}) *gomock.Call
NewWithSnapshot indicates an expected call of NewWithSnapshot.
func (*MockTxnClientMockRecorder) Pause ¶ added in v1.0.0
func (mr *MockTxnClientMockRecorder) Pause() *gomock.Call
Pause indicates an expected call of Pause.
func (*MockTxnClientMockRecorder) RefreshExpressionEnabled ¶ added in v1.0.0
func (mr *MockTxnClientMockRecorder) RefreshExpressionEnabled() *gomock.Call
RefreshExpressionEnabled indicates an expected call of RefreshExpressionEnabled.
func (*MockTxnClientMockRecorder) Resume ¶ added in v1.0.0
func (mr *MockTxnClientMockRecorder) Resume() *gomock.Call
Resume indicates an expected call of Resume.
func (*MockTxnClientMockRecorder) SyncLatestCommitTS ¶ added in v1.0.0
func (mr *MockTxnClientMockRecorder) SyncLatestCommitTS(arg0 interface{}) *gomock.Call
SyncLatestCommitTS indicates an expected call of SyncLatestCommitTS.
func (*MockTxnClientMockRecorder) WaitLogTailAppliedAt ¶ added in v0.8.0
func (mr *MockTxnClientMockRecorder) WaitLogTailAppliedAt(ctx, ts interface{}) *gomock.Call
WaitLogTailAppliedAt indicates an expected call of WaitLogTailAppliedAt.
type MockTxnIDGenerator ¶ added in v0.6.0
type MockTxnIDGenerator struct {
// contains filtered or unexported fields
}
MockTxnIDGenerator is a mock of TxnIDGenerator interface.
func NewMockTxnIDGenerator ¶ added in v0.6.0
func NewMockTxnIDGenerator(ctrl *gomock.Controller) *MockTxnIDGenerator
NewMockTxnIDGenerator creates a new mock instance.
func (*MockTxnIDGenerator) EXPECT ¶ added in v0.6.0
func (m *MockTxnIDGenerator) EXPECT() *MockTxnIDGeneratorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockTxnIDGenerator) Generate ¶ added in v0.6.0
func (m *MockTxnIDGenerator) Generate() []byte
Generate mocks base method.
type MockTxnIDGeneratorMockRecorder ¶ added in v0.6.0
type MockTxnIDGeneratorMockRecorder struct {
// contains filtered or unexported fields
}
MockTxnIDGeneratorMockRecorder is the mock recorder for MockTxnIDGenerator.
func (*MockTxnIDGeneratorMockRecorder) Generate ¶ added in v0.6.0
func (mr *MockTxnIDGeneratorMockRecorder) Generate() *gomock.Call
Generate indicates an expected call of Generate.
type MockTxnOperator ¶ added in v0.6.0
type MockTxnOperator struct {
// contains filtered or unexported fields
}
MockTxnOperator is a mock of TxnOperator interface.
func NewMockTxnOperator ¶ added in v0.6.0
func NewMockTxnOperator(ctrl *gomock.Controller) *MockTxnOperator
NewMockTxnOperator creates a new mock instance.
func (*MockTxnOperator) AddLockTable ¶ added in v0.8.0
func (m *MockTxnOperator) AddLockTable(locktable lock.LockTable) error
AddLockTable mocks base method.
func (*MockTxnOperator) AddWaitLock ¶ added in v1.0.0
func (m *MockTxnOperator) AddWaitLock(tableID uint64, rows [][]byte, opt lock.LockOptions) uint64
AddWaitLock mocks base method.
func (*MockTxnOperator) AddWorkspace ¶ added in v0.8.0
func (m *MockTxnOperator) AddWorkspace(workspace client.Workspace)
AddWorkspace mocks base method.
func (*MockTxnOperator) AppendEventCallback ¶ added in v1.0.0
func (m *MockTxnOperator) AppendEventCallback(event client.EventType, callbacks ...func(txn.TxnMeta))
AppendEventCallback mocks base method.
func (*MockTxnOperator) ApplySnapshot ¶ added in v0.6.0
func (m *MockTxnOperator) ApplySnapshot(data []byte) error
ApplySnapshot mocks base method.
func (*MockTxnOperator) Commit ¶ added in v0.6.0
func (m *MockTxnOperator) Commit(ctx context.Context) error
Commit mocks base method.
func (*MockTxnOperator) Debug ¶ added in v1.0.0
func (m *MockTxnOperator) Debug(ctx context.Context, ops []txn.TxnRequest) (*rpc.SendResult, error)
Debug mocks base method.
func (*MockTxnOperator) EXPECT ¶ added in v0.6.0
func (m *MockTxnOperator) EXPECT() *MockTxnOperatorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockTxnOperator) GetOverview ¶ added in v1.0.0
func (m *MockTxnOperator) GetOverview() client.TxnOverview
GetOverview mocks base method.
func (*MockTxnOperator) GetWorkspace ¶ added in v0.8.0
func (m *MockTxnOperator) GetWorkspace() client.Workspace
GetWorkspace mocks base method.
func (*MockTxnOperator) IsRetry ¶ added in v1.0.0
func (m *MockTxnOperator) IsRetry() bool
IsRetry mocks base method.
func (*MockTxnOperator) Read ¶ added in v0.6.0
func (m *MockTxnOperator) Read(ctx context.Context, ops []txn.TxnRequest) (*rpc.SendResult, error)
Read mocks base method.
func (*MockTxnOperator) RemoveWaitLock ¶ added in v1.0.0
func (m *MockTxnOperator) RemoveWaitLock(key uint64)
RemoveWaitLock mocks base method.
func (*MockTxnOperator) ResetRetry ¶ added in v1.0.0
func (m *MockTxnOperator) ResetRetry(arg0 bool)
ResetRetry mocks base method.
func (*MockTxnOperator) Rollback ¶ added in v0.6.0
func (m *MockTxnOperator) Rollback(ctx context.Context) error
Rollback mocks base method.
func (*MockTxnOperator) Snapshot ¶ added in v0.6.0
func (m *MockTxnOperator) Snapshot() ([]byte, error)
Snapshot mocks base method.
func (*MockTxnOperator) SnapshotTS ¶ added in v1.0.0
func (m *MockTxnOperator) SnapshotTS() timestamp.Timestamp
SnapshotTS mocks base method.
func (*MockTxnOperator) Status ¶ added in v1.0.0
func (m *MockTxnOperator) Status() txn.TxnStatus
Status mocks base method.
func (*MockTxnOperator) Txn ¶ added in v0.6.0
func (m *MockTxnOperator) Txn() txn.TxnMeta
Txn mocks base method.
func (*MockTxnOperator) TxnRef ¶ added in v0.8.0
func (m *MockTxnOperator) TxnRef() *txn.TxnMeta
TxnRef mocks base method.
func (*MockTxnOperator) UpdateSnapshot ¶ added in v0.8.0
UpdateSnapshot mocks base method.
func (*MockTxnOperator) Write ¶ added in v0.6.0
func (m *MockTxnOperator) Write(ctx context.Context, ops []txn.TxnRequest) (*rpc.SendResult, error)
Write mocks base method.
func (*MockTxnOperator) WriteAndCommit ¶ added in v0.6.0
func (m *MockTxnOperator) WriteAndCommit(ctx context.Context, ops []txn.TxnRequest) (*rpc.SendResult, error)
WriteAndCommit mocks base method.
type MockTxnOperatorMockRecorder ¶ added in v0.6.0
type MockTxnOperatorMockRecorder struct {
// contains filtered or unexported fields
}
MockTxnOperatorMockRecorder is the mock recorder for MockTxnOperator.
func (*MockTxnOperatorMockRecorder) AddLockTable ¶ added in v0.8.0
func (mr *MockTxnOperatorMockRecorder) AddLockTable(locktable interface{}) *gomock.Call
AddLockTable indicates an expected call of AddLockTable.
func (*MockTxnOperatorMockRecorder) AddWaitLock ¶ added in v1.0.0
func (mr *MockTxnOperatorMockRecorder) AddWaitLock(tableID, rows, opt interface{}) *gomock.Call
AddWaitLock indicates an expected call of AddWaitLock.
func (*MockTxnOperatorMockRecorder) AddWorkspace ¶ added in v0.8.0
func (mr *MockTxnOperatorMockRecorder) AddWorkspace(workspace interface{}) *gomock.Call
AddWorkspace indicates an expected call of AddWorkspace.
func (*MockTxnOperatorMockRecorder) AppendEventCallback ¶ added in v1.0.0
func (mr *MockTxnOperatorMockRecorder) AppendEventCallback(event interface{}, callbacks ...interface{}) *gomock.Call
AppendEventCallback indicates an expected call of AppendEventCallback.
func (*MockTxnOperatorMockRecorder) ApplySnapshot ¶ added in v0.6.0
func (mr *MockTxnOperatorMockRecorder) ApplySnapshot(data interface{}) *gomock.Call
ApplySnapshot indicates an expected call of ApplySnapshot.
func (*MockTxnOperatorMockRecorder) Commit ¶ added in v0.6.0
func (mr *MockTxnOperatorMockRecorder) Commit(ctx interface{}) *gomock.Call
Commit indicates an expected call of Commit.
func (*MockTxnOperatorMockRecorder) Debug ¶ added in v1.0.0
func (mr *MockTxnOperatorMockRecorder) Debug(ctx, ops interface{}) *gomock.Call
Debug indicates an expected call of Debug.
func (*MockTxnOperatorMockRecorder) GetOverview ¶ added in v1.0.0
func (mr *MockTxnOperatorMockRecorder) GetOverview() *gomock.Call
GetOverview indicates an expected call of GetOverview.
func (*MockTxnOperatorMockRecorder) GetWorkspace ¶ added in v0.8.0
func (mr *MockTxnOperatorMockRecorder) GetWorkspace() *gomock.Call
GetWorkspace indicates an expected call of GetWorkspace.
func (*MockTxnOperatorMockRecorder) IsRetry ¶ added in v1.0.0
func (mr *MockTxnOperatorMockRecorder) IsRetry() *gomock.Call
IsRetry indicates an expected call of IsRetry.
func (*MockTxnOperatorMockRecorder) Read ¶ added in v0.6.0
func (mr *MockTxnOperatorMockRecorder) Read(ctx, ops interface{}) *gomock.Call
Read indicates an expected call of Read.
func (*MockTxnOperatorMockRecorder) RemoveWaitLock ¶ added in v1.0.0
func (mr *MockTxnOperatorMockRecorder) RemoveWaitLock(key interface{}) *gomock.Call
RemoveWaitLock indicates an expected call of RemoveWaitLock.
func (*MockTxnOperatorMockRecorder) ResetRetry ¶ added in v1.0.0
func (mr *MockTxnOperatorMockRecorder) ResetRetry(arg0 interface{}) *gomock.Call
ResetRetry indicates an expected call of ResetRetry.
func (*MockTxnOperatorMockRecorder) Rollback ¶ added in v0.6.0
func (mr *MockTxnOperatorMockRecorder) Rollback(ctx interface{}) *gomock.Call
Rollback indicates an expected call of Rollback.
func (*MockTxnOperatorMockRecorder) Snapshot ¶ added in v0.6.0
func (mr *MockTxnOperatorMockRecorder) Snapshot() *gomock.Call
Snapshot indicates an expected call of Snapshot.
func (*MockTxnOperatorMockRecorder) SnapshotTS ¶ added in v1.0.0
func (mr *MockTxnOperatorMockRecorder) SnapshotTS() *gomock.Call
SnapshotTS indicates an expected call of SnapshotTS.
func (*MockTxnOperatorMockRecorder) Status ¶ added in v1.0.0
func (mr *MockTxnOperatorMockRecorder) Status() *gomock.Call
Status indicates an expected call of Status.
func (*MockTxnOperatorMockRecorder) Txn ¶ added in v0.6.0
func (mr *MockTxnOperatorMockRecorder) Txn() *gomock.Call
Txn indicates an expected call of Txn.
func (*MockTxnOperatorMockRecorder) TxnRef ¶ added in v0.8.0
func (mr *MockTxnOperatorMockRecorder) TxnRef() *gomock.Call
TxnRef indicates an expected call of TxnRef.
func (*MockTxnOperatorMockRecorder) UpdateSnapshot ¶ added in v0.8.0
func (mr *MockTxnOperatorMockRecorder) UpdateSnapshot(ctx, ts interface{}) *gomock.Call
UpdateSnapshot indicates an expected call of UpdateSnapshot.
func (*MockTxnOperatorMockRecorder) Write ¶ added in v0.6.0
func (mr *MockTxnOperatorMockRecorder) Write(ctx, ops interface{}) *gomock.Call
Write indicates an expected call of Write.
func (*MockTxnOperatorMockRecorder) WriteAndCommit ¶ added in v0.6.0
func (mr *MockTxnOperatorMockRecorder) WriteAndCommit(ctx, ops interface{}) *gomock.Call
WriteAndCommit indicates an expected call of WriteAndCommit.
type MockVectorPool ¶ added in v0.8.0
type MockVectorPool struct {
// contains filtered or unexported fields
}
MockVectorPool is a mock of VectorPool interface.
func NewMockVectorPool ¶ added in v0.8.0
func NewMockVectorPool(ctrl *gomock.Controller) *MockVectorPool
NewMockVectorPool creates a new mock instance.
func (*MockVectorPool) EXPECT ¶ added in v0.8.0
func (m *MockVectorPool) EXPECT() *MockVectorPoolMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockVectorPool) GetVector ¶ added in v0.8.0
func (m *MockVectorPool) GetVector(typ types.Type) *vector.Vector
GetVector mocks base method.
func (*MockVectorPool) PutBatch ¶ added in v0.8.0
func (m *MockVectorPool) PutBatch(bat *batch.Batch)
PutBatch mocks base method.
type MockVectorPoolMockRecorder ¶ added in v0.8.0
type MockVectorPoolMockRecorder struct {
// contains filtered or unexported fields
}
MockVectorPoolMockRecorder is the mock recorder for MockVectorPool.
func (*MockVectorPoolMockRecorder) GetVector ¶ added in v0.8.0
func (mr *MockVectorPoolMockRecorder) GetVector(typ interface{}) *gomock.Call
GetVector indicates an expected call of GetVector.
func (*MockVectorPoolMockRecorder) PutBatch ¶ added in v0.8.0
func (mr *MockVectorPoolMockRecorder) PutBatch(bat interface{}) *gomock.Call
PutBatch indicates an expected call of PutBatch.
type MockWorkspace ¶ added in v0.8.0
type MockWorkspace struct {
// contains filtered or unexported fields
}
MockWorkspace is a mock of Workspace interface.
func NewMockWorkspace ¶ added in v0.8.0
func NewMockWorkspace(ctrl *gomock.Controller) *MockWorkspace
NewMockWorkspace creates a new mock instance.
func (*MockWorkspace) Adjust ¶ added in v1.0.0
func (m *MockWorkspace) Adjust() error
Adjust mocks base method.
func (*MockWorkspace) Commit ¶ added in v0.8.0
func (m *MockWorkspace) Commit(ctx context.Context) ([]txn.TxnRequest, error)
Commit mocks base method.
func (*MockWorkspace) EXPECT ¶ added in v0.8.0
func (m *MockWorkspace) EXPECT() *MockWorkspaceMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockWorkspace) EndStatement ¶ added in v1.0.0
func (m *MockWorkspace) EndStatement()
EndStatement mocks base method.
func (*MockWorkspace) GetSQLCount ¶ added in v1.0.0
func (m *MockWorkspace) GetSQLCount() uint64
GetSQLCount mocks base method.
func (*MockWorkspace) IncrSQLCount ¶ added in v1.0.0
func (m *MockWorkspace) IncrSQLCount()
IncrSQLCount mocks base method.
func (*MockWorkspace) IncrStatementID ¶ added in v0.8.0
func (m *MockWorkspace) IncrStatementID(ctx context.Context, commit bool) error
IncrStatementID mocks base method.
func (*MockWorkspace) Rollback ¶ added in v0.8.0
func (m *MockWorkspace) Rollback(ctx context.Context) error
Rollback mocks base method.
func (*MockWorkspace) RollbackLastStatement ¶ added in v0.8.0
func (m *MockWorkspace) RollbackLastStatement(ctx context.Context) error
RollbackLastStatement mocks base method.
func (*MockWorkspace) StartStatement ¶ added in v1.0.0
func (m *MockWorkspace) StartStatement()
StartStatement mocks base method.
type MockWorkspaceMockRecorder ¶ added in v0.8.0
type MockWorkspaceMockRecorder struct {
// contains filtered or unexported fields
}
MockWorkspaceMockRecorder is the mock recorder for MockWorkspace.
func (*MockWorkspaceMockRecorder) Adjust ¶ added in v1.0.0
func (mr *MockWorkspaceMockRecorder) Adjust() *gomock.Call
Adjust indicates an expected call of Adjust.
func (*MockWorkspaceMockRecorder) Commit ¶ added in v0.8.0
func (mr *MockWorkspaceMockRecorder) Commit(ctx interface{}) *gomock.Call
Commit indicates an expected call of Commit.
func (*MockWorkspaceMockRecorder) EndStatement ¶ added in v1.0.0
func (mr *MockWorkspaceMockRecorder) EndStatement() *gomock.Call
EndStatement indicates an expected call of EndStatement.
func (*MockWorkspaceMockRecorder) GetSQLCount ¶ added in v1.0.0
func (mr *MockWorkspaceMockRecorder) GetSQLCount() *gomock.Call
GetSQLCount indicates an expected call of GetSQLCount.
func (*MockWorkspaceMockRecorder) IncrSQLCount ¶ added in v1.0.0
func (mr *MockWorkspaceMockRecorder) IncrSQLCount() *gomock.Call
IncrSQLCount indicates an expected call of IncrSQLCount.
func (*MockWorkspaceMockRecorder) IncrStatementID ¶ added in v0.8.0
func (mr *MockWorkspaceMockRecorder) IncrStatementID(ctx, commit interface{}) *gomock.Call
IncrStatementID indicates an expected call of IncrStatementID.
func (*MockWorkspaceMockRecorder) Rollback ¶ added in v0.8.0
func (mr *MockWorkspaceMockRecorder) Rollback(ctx interface{}) *gomock.Call
Rollback indicates an expected call of Rollback.
func (*MockWorkspaceMockRecorder) RollbackLastStatement ¶ added in v0.8.0
func (mr *MockWorkspaceMockRecorder) RollbackLastStatement(ctx interface{}) *gomock.Call
RollbackLastStatement indicates an expected call of RollbackLastStatement.
func (*MockWorkspaceMockRecorder) StartStatement ¶ added in v1.0.0
func (mr *MockWorkspaceMockRecorder) StartStatement() *gomock.Call
StartStatement indicates an expected call of StartStatement.
type MockoutputPool ¶ added in v0.8.0
type MockoutputPool struct {
// contains filtered or unexported fields
}
MockoutputPool is a mock of outputPool interface.
func NewMockoutputPool ¶ added in v0.8.0
func NewMockoutputPool(ctrl *gomock.Controller) *MockoutputPool
NewMockoutputPool creates a new mock instance.
func (*MockoutputPool) EXPECT ¶ added in v0.8.0
func (m *MockoutputPool) EXPECT() *MockoutputPoolMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
type MockoutputPoolMockRecorder ¶ added in v0.8.0
type MockoutputPoolMockRecorder struct {
// contains filtered or unexported fields
}
MockoutputPoolMockRecorder is the mock recorder for MockoutputPool.