mock

package
v1.1.0-beta.0...-8106d93 Latest Latest
Warning

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

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

Documentation

Overview

Package mock is a generated GoMock package.

Package mock is a generated GoMock package.

Package mock is a generated GoMock package.

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type MockCleanUpRoutine

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

MockCleanUpRoutine is a mock of CleanUpRoutine interface.

func NewMockCleanUpRoutine

func NewMockCleanUpRoutine(ctrl *gomock.Controller) *MockCleanUpRoutine

NewMockCleanUpRoutine creates a new mock instance.

func (*MockCleanUpRoutine) CleanUp

func (m *MockCleanUpRoutine) CleanUp(arg0 context.Context, arg1 *proto.Task) error

CleanUp mocks base method.

func (*MockCleanUpRoutine) EXPECT

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

func (*MockCleanUpRoutine) ISGOMOCK

func (m *MockCleanUpRoutine) ISGOMOCK() struct{}

ISGOMOCK indicates that this struct is a gomock mock.

type MockCleanUpRoutineMockRecorder

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

MockCleanUpRoutineMockRecorder is the mock recorder for MockCleanUpRoutine.

func (*MockCleanUpRoutineMockRecorder) CleanUp

func (mr *MockCleanUpRoutineMockRecorder) CleanUp(arg0, arg1 any) *gomock.Call

CleanUp indicates an expected call of CleanUp.

type MockExtension

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

MockExtension is a mock of Extension interface.

func NewMockExtension

func NewMockExtension(ctrl *gomock.Controller) *MockExtension

NewMockExtension creates a new mock instance.

func (*MockExtension) EXPECT

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

func (*MockExtension) GetStepExecutor

func (m *MockExtension) GetStepExecutor(arg0 *proto.Task) (execute.StepExecutor, error)

GetStepExecutor mocks base method.

func (*MockExtension) ISGOMOCK

func (m *MockExtension) ISGOMOCK() struct{}

ISGOMOCK indicates that this struct is a gomock mock.

func (*MockExtension) IsIdempotent

func (m *MockExtension) IsIdempotent(arg0 *proto.Subtask) bool

IsIdempotent mocks base method.

func (*MockExtension) IsRetryableError

func (m *MockExtension) IsRetryableError(arg0 error) bool

IsRetryableError mocks base method.

type MockExtensionMockRecorder

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

MockExtensionMockRecorder is the mock recorder for MockExtension.

func (*MockExtensionMockRecorder) GetStepExecutor

func (mr *MockExtensionMockRecorder) GetStepExecutor(arg0 any) *gomock.Call

GetStepExecutor indicates an expected call of GetStepExecutor.

func (*MockExtensionMockRecorder) IsIdempotent

func (mr *MockExtensionMockRecorder) IsIdempotent(arg0 any) *gomock.Call

IsIdempotent indicates an expected call of IsIdempotent.

func (*MockExtensionMockRecorder) IsRetryableError

func (mr *MockExtensionMockRecorder) IsRetryableError(arg0 any) *gomock.Call

IsRetryableError indicates an expected call of IsRetryableError.

type MockLogicalPlan

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

MockLogicalPlan is a mock of LogicalPlan interface.

func NewMockLogicalPlan

func NewMockLogicalPlan(ctrl *gomock.Controller) *MockLogicalPlan

NewMockLogicalPlan creates a new mock instance.

func (*MockLogicalPlan) EXPECT

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

func (*MockLogicalPlan) FromTaskMeta

func (m *MockLogicalPlan) FromTaskMeta(arg0 []byte) error

FromTaskMeta mocks base method.

func (*MockLogicalPlan) ISGOMOCK

func (m *MockLogicalPlan) ISGOMOCK() struct{}

ISGOMOCK indicates that this struct is a gomock mock.

func (*MockLogicalPlan) ToPhysicalPlan

func (m *MockLogicalPlan) ToPhysicalPlan(arg0 planner.PlanCtx) (*planner.PhysicalPlan, error)

ToPhysicalPlan mocks base method.

func (*MockLogicalPlan) ToTaskMeta

func (m *MockLogicalPlan) ToTaskMeta() ([]byte, error)

ToTaskMeta mocks base method.

type MockLogicalPlanMockRecorder

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

MockLogicalPlanMockRecorder is the mock recorder for MockLogicalPlan.

func (*MockLogicalPlanMockRecorder) FromTaskMeta

func (mr *MockLogicalPlanMockRecorder) FromTaskMeta(arg0 any) *gomock.Call

FromTaskMeta indicates an expected call of FromTaskMeta.

func (*MockLogicalPlanMockRecorder) ToPhysicalPlan

func (mr *MockLogicalPlanMockRecorder) ToPhysicalPlan(arg0 any) *gomock.Call

ToPhysicalPlan indicates an expected call of ToPhysicalPlan.

func (*MockLogicalPlanMockRecorder) ToTaskMeta

func (mr *MockLogicalPlanMockRecorder) ToTaskMeta() *gomock.Call

ToTaskMeta indicates an expected call of ToTaskMeta.

type MockPipelineSpec

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

MockPipelineSpec is a mock of PipelineSpec interface.

func NewMockPipelineSpec

func NewMockPipelineSpec(ctrl *gomock.Controller) *MockPipelineSpec

NewMockPipelineSpec creates a new mock instance.

func (*MockPipelineSpec) EXPECT

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

func (*MockPipelineSpec) ISGOMOCK

func (m *MockPipelineSpec) ISGOMOCK() struct{}

ISGOMOCK indicates that this struct is a gomock mock.

func (*MockPipelineSpec) ToSubtaskMeta

func (m *MockPipelineSpec) ToSubtaskMeta(arg0 planner.PlanCtx) ([]byte, error)

ToSubtaskMeta mocks base method.

type MockPipelineSpecMockRecorder

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

MockPipelineSpecMockRecorder is the mock recorder for MockPipelineSpec.

func (*MockPipelineSpecMockRecorder) ToSubtaskMeta

func (mr *MockPipelineSpecMockRecorder) ToSubtaskMeta(arg0 any) *gomock.Call

ToSubtaskMeta indicates an expected call of ToSubtaskMeta.

type MockPool

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

MockPool is a mock of Pool interface.

func NewMockPool

func NewMockPool(ctrl *gomock.Controller) *MockPool

NewMockPool creates a new mock instance.

func (*MockPool) EXPECT

func (m *MockPool) EXPECT() *MockPoolMockRecorder

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

func (*MockPool) ISGOMOCK

func (m *MockPool) ISGOMOCK() struct{}

ISGOMOCK indicates that this struct is a gomock mock.

func (*MockPool) ReleaseAndWait

func (m *MockPool) ReleaseAndWait()

ReleaseAndWait mocks base method.

func (*MockPool) Run

func (m *MockPool) Run(arg0 func()) error

Run mocks base method.

func (*MockPool) RunWithConcurrency

func (m *MockPool) RunWithConcurrency(arg0 chan func(), arg1 uint32) error

RunWithConcurrency mocks base method.

type MockPoolMockRecorder

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

MockPoolMockRecorder is the mock recorder for MockPool.

func (*MockPoolMockRecorder) ReleaseAndWait

func (mr *MockPoolMockRecorder) ReleaseAndWait() *gomock.Call

ReleaseAndWait indicates an expected call of ReleaseAndWait.

func (*MockPoolMockRecorder) Run

func (mr *MockPoolMockRecorder) Run(arg0 any) *gomock.Call

Run indicates an expected call of Run.

func (*MockPoolMockRecorder) RunWithConcurrency

func (mr *MockPoolMockRecorder) RunWithConcurrency(arg0, arg1 any) *gomock.Call

RunWithConcurrency indicates an expected call of RunWithConcurrency.

type MockScheduler

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

MockScheduler is a mock of Scheduler interface.

func NewMockScheduler

func NewMockScheduler(ctrl *gomock.Controller) *MockScheduler

NewMockScheduler creates a new mock instance.

func (*MockScheduler) Close

func (m *MockScheduler) Close()

Close mocks base method.

func (*MockScheduler) EXPECT

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

func (*MockScheduler) GetEligibleInstances

func (m *MockScheduler) GetEligibleInstances(arg0 context.Context, arg1 *proto.Task) ([]string, error)

GetEligibleInstances mocks base method.

func (*MockScheduler) GetNextStep

func (m *MockScheduler) GetNextStep(arg0 *proto.TaskBase) proto.Step

GetNextStep mocks base method.

func (*MockScheduler) GetTask

func (m *MockScheduler) GetTask() *proto.Task

GetTask mocks base method.

func (*MockScheduler) ISGOMOCK

func (m *MockScheduler) ISGOMOCK() struct{}

ISGOMOCK indicates that this struct is a gomock mock.

func (*MockScheduler) Init

func (m *MockScheduler) Init() error

Init mocks base method.

func (*MockScheduler) IsRetryableErr

func (m *MockScheduler) IsRetryableErr(arg0 error) bool

IsRetryableErr mocks base method.

func (*MockScheduler) OnDone

func (m *MockScheduler) OnDone(arg0 context.Context, arg1 storage.TaskHandle, arg2 *proto.Task) error

OnDone mocks base method.

func (*MockScheduler) OnNextSubtasksBatch

func (m *MockScheduler) OnNextSubtasksBatch(arg0 context.Context, arg1 storage.TaskHandle, arg2 *proto.Task, arg3 []string, arg4 proto.Step) ([][]byte, error)

OnNextSubtasksBatch mocks base method.

func (*MockScheduler) OnTick

func (m *MockScheduler) OnTick(arg0 context.Context, arg1 *proto.Task)

OnTick mocks base method.

func (*MockScheduler) ScheduleTask

func (m *MockScheduler) ScheduleTask()

ScheduleTask mocks base method.

type MockSchedulerMockRecorder

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

MockSchedulerMockRecorder is the mock recorder for MockScheduler.

func (*MockSchedulerMockRecorder) Close

func (mr *MockSchedulerMockRecorder) Close() *gomock.Call

Close indicates an expected call of Close.

func (*MockSchedulerMockRecorder) GetEligibleInstances

func (mr *MockSchedulerMockRecorder) GetEligibleInstances(arg0, arg1 any) *gomock.Call

GetEligibleInstances indicates an expected call of GetEligibleInstances.

func (*MockSchedulerMockRecorder) GetNextStep

func (mr *MockSchedulerMockRecorder) GetNextStep(arg0 any) *gomock.Call

GetNextStep indicates an expected call of GetNextStep.

func (*MockSchedulerMockRecorder) GetTask

func (mr *MockSchedulerMockRecorder) GetTask() *gomock.Call

GetTask indicates an expected call of GetTask.

func (*MockSchedulerMockRecorder) Init

Init indicates an expected call of Init.

func (*MockSchedulerMockRecorder) IsRetryableErr

func (mr *MockSchedulerMockRecorder) IsRetryableErr(arg0 any) *gomock.Call

IsRetryableErr indicates an expected call of IsRetryableErr.

func (*MockSchedulerMockRecorder) OnDone

func (mr *MockSchedulerMockRecorder) OnDone(arg0, arg1, arg2 any) *gomock.Call

OnDone indicates an expected call of OnDone.

func (*MockSchedulerMockRecorder) OnNextSubtasksBatch

func (mr *MockSchedulerMockRecorder) OnNextSubtasksBatch(arg0, arg1, arg2, arg3, arg4 any) *gomock.Call

OnNextSubtasksBatch indicates an expected call of OnNextSubtasksBatch.

func (*MockSchedulerMockRecorder) OnTick

func (mr *MockSchedulerMockRecorder) OnTick(arg0, arg1 any) *gomock.Call

OnTick indicates an expected call of OnTick.

func (*MockSchedulerMockRecorder) ScheduleTask

func (mr *MockSchedulerMockRecorder) ScheduleTask() *gomock.Call

ScheduleTask indicates an expected call of ScheduleTask.

type MockTaskExecutor

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

MockTaskExecutor is a mock of TaskExecutor interface.

func NewMockTaskExecutor

func NewMockTaskExecutor(ctrl *gomock.Controller) *MockTaskExecutor

NewMockTaskExecutor creates a new mock instance.

func (*MockTaskExecutor) Cancel

func (m *MockTaskExecutor) Cancel()

Cancel mocks base method.

func (*MockTaskExecutor) CancelRunningSubtask

func (m *MockTaskExecutor) CancelRunningSubtask()

CancelRunningSubtask mocks base method.

func (*MockTaskExecutor) Close

func (m *MockTaskExecutor) Close()

Close mocks base method.

func (*MockTaskExecutor) EXPECT

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

func (*MockTaskExecutor) GetTaskBase

func (m *MockTaskExecutor) GetTaskBase() *proto.TaskBase

GetTaskBase mocks base method.

func (*MockTaskExecutor) ISGOMOCK

func (m *MockTaskExecutor) ISGOMOCK() struct{}

ISGOMOCK indicates that this struct is a gomock mock.

func (*MockTaskExecutor) Init

func (m *MockTaskExecutor) Init(arg0 context.Context) error

Init mocks base method.

func (*MockTaskExecutor) IsRetryableError

func (m *MockTaskExecutor) IsRetryableError(arg0 error) bool

IsRetryableError mocks base method.

func (*MockTaskExecutor) Run

func (m *MockTaskExecutor) Run(arg0 *proto.StepResource)

Run mocks base method.

type MockTaskExecutorMockRecorder

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

MockTaskExecutorMockRecorder is the mock recorder for MockTaskExecutor.

func (*MockTaskExecutorMockRecorder) Cancel

Cancel indicates an expected call of Cancel.

func (*MockTaskExecutorMockRecorder) CancelRunningSubtask

func (mr *MockTaskExecutorMockRecorder) CancelRunningSubtask() *gomock.Call

CancelRunningSubtask indicates an expected call of CancelRunningSubtask.

func (*MockTaskExecutorMockRecorder) Close

Close indicates an expected call of Close.

func (*MockTaskExecutorMockRecorder) GetTaskBase

func (mr *MockTaskExecutorMockRecorder) GetTaskBase() *gomock.Call

GetTaskBase indicates an expected call of GetTaskBase.

func (*MockTaskExecutorMockRecorder) Init

func (mr *MockTaskExecutorMockRecorder) Init(arg0 any) *gomock.Call

Init indicates an expected call of Init.

func (*MockTaskExecutorMockRecorder) IsRetryableError

func (mr *MockTaskExecutorMockRecorder) IsRetryableError(arg0 any) *gomock.Call

IsRetryableError indicates an expected call of IsRetryableError.

func (*MockTaskExecutorMockRecorder) Run

Run indicates an expected call of Run.

type MockTaskManager

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

MockTaskManager is a mock of TaskManager interface.

func NewMockTaskManager

func NewMockTaskManager(ctrl *gomock.Controller) *MockTaskManager

NewMockTaskManager creates a new mock instance.

func (*MockTaskManager) CancelTask

func (m *MockTaskManager) CancelTask(arg0 context.Context, arg1 int64) error

CancelTask mocks base method.

func (*MockTaskManager) DeleteDeadNodes

func (m *MockTaskManager) DeleteDeadNodes(arg0 context.Context, arg1 []string) error

DeleteDeadNodes mocks base method.

func (*MockTaskManager) EXPECT

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

func (*MockTaskManager) FailTask

func (m *MockTaskManager) FailTask(arg0 context.Context, arg1 int64, arg2 proto.TaskState, arg3 error) error

FailTask mocks base method.

func (*MockTaskManager) GCSubtasks

func (m *MockTaskManager) GCSubtasks(arg0 context.Context) error

GCSubtasks mocks base method.

func (*MockTaskManager) GetActiveSubtasks

func (m *MockTaskManager) GetActiveSubtasks(arg0 context.Context, arg1 int64) ([]*proto.SubtaskBase, error)

GetActiveSubtasks mocks base method.

func (*MockTaskManager) GetAllNodes

func (m *MockTaskManager) GetAllNodes(arg0 context.Context) ([]proto.ManagedNode, error)

GetAllNodes mocks base method.

func (*MockTaskManager) GetAllSubtasks

func (m *MockTaskManager) GetAllSubtasks(arg0 context.Context) ([]*proto.SubtaskBase, error)

GetAllSubtasks mocks base method.

func (*MockTaskManager) GetAllSubtasksByStepAndState

func (m *MockTaskManager) GetAllSubtasksByStepAndState(arg0 context.Context, arg1 int64, arg2 proto.Step, arg3 proto.SubtaskState) ([]*proto.Subtask, error)

GetAllSubtasksByStepAndState mocks base method.

func (*MockTaskManager) GetSubtaskCntGroupByStates

func (m *MockTaskManager) GetSubtaskCntGroupByStates(arg0 context.Context, arg1 int64, arg2 proto.Step) (map[proto.SubtaskState]int64, error)

GetSubtaskCntGroupByStates mocks base method.

func (*MockTaskManager) GetSubtaskErrors

func (m *MockTaskManager) GetSubtaskErrors(arg0 context.Context, arg1 int64) ([]error, error)

GetSubtaskErrors mocks base method.

func (*MockTaskManager) GetTaskBaseByID

func (m *MockTaskManager) GetTaskBaseByID(arg0 context.Context, arg1 int64) (*proto.TaskBase, error)

GetTaskBaseByID mocks base method.

func (*MockTaskManager) GetTaskByID

func (m *MockTaskManager) GetTaskByID(arg0 context.Context, arg1 int64) (*proto.Task, error)

GetTaskByID mocks base method.

func (*MockTaskManager) GetTasksInStates

func (m *MockTaskManager) GetTasksInStates(arg0 context.Context, arg1 ...any) ([]*proto.Task, error)

GetTasksInStates mocks base method.

func (*MockTaskManager) GetTopUnfinishedTasks

func (m *MockTaskManager) GetTopUnfinishedTasks(arg0 context.Context) ([]*proto.TaskBase, error)

GetTopUnfinishedTasks mocks base method.

func (*MockTaskManager) GetUsedSlotsOnNodes

func (m *MockTaskManager) GetUsedSlotsOnNodes(arg0 context.Context) (map[string]int, error)

GetUsedSlotsOnNodes mocks base method.

func (*MockTaskManager) ISGOMOCK

func (m *MockTaskManager) ISGOMOCK() struct{}

ISGOMOCK indicates that this struct is a gomock mock.

func (*MockTaskManager) PauseTask

func (m *MockTaskManager) PauseTask(arg0 context.Context, arg1 string) (bool, error)

PauseTask mocks base method.

func (*MockTaskManager) PausedTask

func (m *MockTaskManager) PausedTask(arg0 context.Context, arg1 int64) error

PausedTask mocks base method.

func (*MockTaskManager) ResumeSubtasks

func (m *MockTaskManager) ResumeSubtasks(arg0 context.Context, arg1 int64) error

ResumeSubtasks mocks base method.

func (*MockTaskManager) ResumedTask

func (m *MockTaskManager) ResumedTask(arg0 context.Context, arg1 int64) error

ResumedTask mocks base method.

func (*MockTaskManager) RevertTask

func (m *MockTaskManager) RevertTask(arg0 context.Context, arg1 int64, arg2 proto.TaskState, arg3 error) error

RevertTask mocks base method.

func (*MockTaskManager) RevertedTask

func (m *MockTaskManager) RevertedTask(arg0 context.Context, arg1 int64) error

RevertedTask mocks base method.

func (*MockTaskManager) SucceedTask

func (m *MockTaskManager) SucceedTask(arg0 context.Context, arg1 int64) error

SucceedTask mocks base method.

func (*MockTaskManager) SwitchTaskStep

func (m *MockTaskManager) SwitchTaskStep(arg0 context.Context, arg1 *proto.Task, arg2 proto.TaskState, arg3 proto.Step, arg4 []*proto.Subtask) error

SwitchTaskStep mocks base method.

func (*MockTaskManager) SwitchTaskStepInBatch

func (m *MockTaskManager) SwitchTaskStepInBatch(arg0 context.Context, arg1 *proto.Task, arg2 proto.TaskState, arg3 proto.Step, arg4 []*proto.Subtask) error

SwitchTaskStepInBatch mocks base method.

func (*MockTaskManager) TransferTasks2History

func (m *MockTaskManager) TransferTasks2History(arg0 context.Context, arg1 []*proto.Task) error

TransferTasks2History mocks base method.

func (*MockTaskManager) UpdateSubtasksExecIDs

func (m *MockTaskManager) UpdateSubtasksExecIDs(arg0 context.Context, arg1 []*proto.SubtaskBase) error

UpdateSubtasksExecIDs mocks base method.

func (*MockTaskManager) WithNewSession

func (m *MockTaskManager) WithNewSession(arg0 func(sessionctx.Context) error) error

WithNewSession mocks base method.

func (*MockTaskManager) WithNewTxn

func (m *MockTaskManager) WithNewTxn(arg0 context.Context, arg1 func(sessionctx.Context) error) error

WithNewTxn mocks base method.

type MockTaskManagerMockRecorder

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

MockTaskManagerMockRecorder is the mock recorder for MockTaskManager.

func (*MockTaskManagerMockRecorder) CancelTask

func (mr *MockTaskManagerMockRecorder) CancelTask(arg0, arg1 any) *gomock.Call

CancelTask indicates an expected call of CancelTask.

func (*MockTaskManagerMockRecorder) DeleteDeadNodes

func (mr *MockTaskManagerMockRecorder) DeleteDeadNodes(arg0, arg1 any) *gomock.Call

DeleteDeadNodes indicates an expected call of DeleteDeadNodes.

func (*MockTaskManagerMockRecorder) FailTask

func (mr *MockTaskManagerMockRecorder) FailTask(arg0, arg1, arg2, arg3 any) *gomock.Call

FailTask indicates an expected call of FailTask.

func (*MockTaskManagerMockRecorder) GCSubtasks

func (mr *MockTaskManagerMockRecorder) GCSubtasks(arg0 any) *gomock.Call

GCSubtasks indicates an expected call of GCSubtasks.

func (*MockTaskManagerMockRecorder) GetActiveSubtasks

func (mr *MockTaskManagerMockRecorder) GetActiveSubtasks(arg0, arg1 any) *gomock.Call

GetActiveSubtasks indicates an expected call of GetActiveSubtasks.

func (*MockTaskManagerMockRecorder) GetAllNodes

func (mr *MockTaskManagerMockRecorder) GetAllNodes(arg0 any) *gomock.Call

GetAllNodes indicates an expected call of GetAllNodes.

func (*MockTaskManagerMockRecorder) GetAllSubtasks

func (mr *MockTaskManagerMockRecorder) GetAllSubtasks(arg0 any) *gomock.Call

GetAllSubtasks indicates an expected call of GetAllSubtasks.

func (*MockTaskManagerMockRecorder) GetAllSubtasksByStepAndState

func (mr *MockTaskManagerMockRecorder) GetAllSubtasksByStepAndState(arg0, arg1, arg2, arg3 any) *gomock.Call

GetAllSubtasksByStepAndState indicates an expected call of GetAllSubtasksByStepAndState.

func (*MockTaskManagerMockRecorder) GetSubtaskCntGroupByStates

func (mr *MockTaskManagerMockRecorder) GetSubtaskCntGroupByStates(arg0, arg1, arg2 any) *gomock.Call

GetSubtaskCntGroupByStates indicates an expected call of GetSubtaskCntGroupByStates.

func (*MockTaskManagerMockRecorder) GetSubtaskErrors

func (mr *MockTaskManagerMockRecorder) GetSubtaskErrors(arg0, arg1 any) *gomock.Call

GetSubtaskErrors indicates an expected call of GetSubtaskErrors.

func (*MockTaskManagerMockRecorder) GetTaskBaseByID

func (mr *MockTaskManagerMockRecorder) GetTaskBaseByID(arg0, arg1 any) *gomock.Call

GetTaskBaseByID indicates an expected call of GetTaskBaseByID.

func (*MockTaskManagerMockRecorder) GetTaskByID

func (mr *MockTaskManagerMockRecorder) GetTaskByID(arg0, arg1 any) *gomock.Call

GetTaskByID indicates an expected call of GetTaskByID.

func (*MockTaskManagerMockRecorder) GetTasksInStates

func (mr *MockTaskManagerMockRecorder) GetTasksInStates(arg0 any, arg1 ...any) *gomock.Call

GetTasksInStates indicates an expected call of GetTasksInStates.

func (*MockTaskManagerMockRecorder) GetTopUnfinishedTasks

func (mr *MockTaskManagerMockRecorder) GetTopUnfinishedTasks(arg0 any) *gomock.Call

GetTopUnfinishedTasks indicates an expected call of GetTopUnfinishedTasks.

func (*MockTaskManagerMockRecorder) GetUsedSlotsOnNodes

func (mr *MockTaskManagerMockRecorder) GetUsedSlotsOnNodes(arg0 any) *gomock.Call

GetUsedSlotsOnNodes indicates an expected call of GetUsedSlotsOnNodes.

func (*MockTaskManagerMockRecorder) PauseTask

func (mr *MockTaskManagerMockRecorder) PauseTask(arg0, arg1 any) *gomock.Call

PauseTask indicates an expected call of PauseTask.

func (*MockTaskManagerMockRecorder) PausedTask

func (mr *MockTaskManagerMockRecorder) PausedTask(arg0, arg1 any) *gomock.Call

PausedTask indicates an expected call of PausedTask.

func (*MockTaskManagerMockRecorder) ResumeSubtasks

func (mr *MockTaskManagerMockRecorder) ResumeSubtasks(arg0, arg1 any) *gomock.Call

ResumeSubtasks indicates an expected call of ResumeSubtasks.

func (*MockTaskManagerMockRecorder) ResumedTask

func (mr *MockTaskManagerMockRecorder) ResumedTask(arg0, arg1 any) *gomock.Call

ResumedTask indicates an expected call of ResumedTask.

func (*MockTaskManagerMockRecorder) RevertTask

func (mr *MockTaskManagerMockRecorder) RevertTask(arg0, arg1, arg2, arg3 any) *gomock.Call

RevertTask indicates an expected call of RevertTask.

func (*MockTaskManagerMockRecorder) RevertedTask

func (mr *MockTaskManagerMockRecorder) RevertedTask(arg0, arg1 any) *gomock.Call

RevertedTask indicates an expected call of RevertedTask.

func (*MockTaskManagerMockRecorder) SucceedTask

func (mr *MockTaskManagerMockRecorder) SucceedTask(arg0, arg1 any) *gomock.Call

SucceedTask indicates an expected call of SucceedTask.

func (*MockTaskManagerMockRecorder) SwitchTaskStep

func (mr *MockTaskManagerMockRecorder) SwitchTaskStep(arg0, arg1, arg2, arg3, arg4 any) *gomock.Call

SwitchTaskStep indicates an expected call of SwitchTaskStep.

func (*MockTaskManagerMockRecorder) SwitchTaskStepInBatch

func (mr *MockTaskManagerMockRecorder) SwitchTaskStepInBatch(arg0, arg1, arg2, arg3, arg4 any) *gomock.Call

SwitchTaskStepInBatch indicates an expected call of SwitchTaskStepInBatch.

func (*MockTaskManagerMockRecorder) TransferTasks2History

func (mr *MockTaskManagerMockRecorder) TransferTasks2History(arg0, arg1 any) *gomock.Call

TransferTasks2History indicates an expected call of TransferTasks2History.

func (*MockTaskManagerMockRecorder) UpdateSubtasksExecIDs

func (mr *MockTaskManagerMockRecorder) UpdateSubtasksExecIDs(arg0, arg1 any) *gomock.Call

UpdateSubtasksExecIDs indicates an expected call of UpdateSubtasksExecIDs.

func (*MockTaskManagerMockRecorder) WithNewSession

func (mr *MockTaskManagerMockRecorder) WithNewSession(arg0 any) *gomock.Call

WithNewSession indicates an expected call of WithNewSession.

func (*MockTaskManagerMockRecorder) WithNewTxn

func (mr *MockTaskManagerMockRecorder) WithNewTxn(arg0, arg1 any) *gomock.Call

WithNewTxn indicates an expected call of WithNewTxn.

type MockTaskTable

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

MockTaskTable is a mock of TaskTable interface.

func NewMockTaskTable

func NewMockTaskTable(ctrl *gomock.Controller) *MockTaskTable

NewMockTaskTable creates a new mock instance.

func (*MockTaskTable) CancelSubtask

func (m *MockTaskTable) CancelSubtask(arg0 context.Context, arg1 string, arg2 int64) error

CancelSubtask mocks base method.

func (*MockTaskTable) EXPECT

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

func (*MockTaskTable) FailSubtask

func (m *MockTaskTable) FailSubtask(arg0 context.Context, arg1 string, arg2 int64, arg3 error) error

FailSubtask mocks base method.

func (*MockTaskTable) FinishSubtask

func (m *MockTaskTable) FinishSubtask(arg0 context.Context, arg1 string, arg2 int64, arg3 []byte) error

FinishSubtask mocks base method.

func (*MockTaskTable) GetFirstSubtaskInStates

func (m *MockTaskTable) GetFirstSubtaskInStates(arg0 context.Context, arg1 string, arg2 int64, arg3 proto.Step, arg4 ...proto.SubtaskState) (*proto.Subtask, error)

GetFirstSubtaskInStates mocks base method.

func (*MockTaskTable) GetSubtasksByExecIDAndStepAndStates

func (m *MockTaskTable) GetSubtasksByExecIDAndStepAndStates(arg0 context.Context, arg1 string, arg2 int64, arg3 proto.Step, arg4 ...proto.SubtaskState) ([]*proto.Subtask, error)

GetSubtasksByExecIDAndStepAndStates mocks base method.

func (*MockTaskTable) GetTaskBaseByID

func (m *MockTaskTable) GetTaskBaseByID(arg0 context.Context, arg1 int64) (*proto.TaskBase, error)

GetTaskBaseByID mocks base method.

func (*MockTaskTable) GetTaskByID

func (m *MockTaskTable) GetTaskByID(arg0 context.Context, arg1 int64) (*proto.Task, error)

GetTaskByID mocks base method.

func (*MockTaskTable) GetTaskExecInfoByExecID

func (m *MockTaskTable) GetTaskExecInfoByExecID(arg0 context.Context, arg1 string) ([]*storage.TaskExecInfo, error)

GetTaskExecInfoByExecID mocks base method.

func (*MockTaskTable) GetTasksInStates

func (m *MockTaskTable) GetTasksInStates(arg0 context.Context, arg1 ...any) ([]*proto.Task, error)

GetTasksInStates mocks base method.

func (*MockTaskTable) HasSubtasksInStates

func (m *MockTaskTable) HasSubtasksInStates(arg0 context.Context, arg1 string, arg2 int64, arg3 proto.Step, arg4 ...proto.SubtaskState) (bool, error)

HasSubtasksInStates mocks base method.

func (*MockTaskTable) ISGOMOCK

func (m *MockTaskTable) ISGOMOCK() struct{}

ISGOMOCK indicates that this struct is a gomock mock.

func (*MockTaskTable) InitMeta

func (m *MockTaskTable) InitMeta(arg0 context.Context, arg1, arg2 string) error

InitMeta mocks base method.

func (*MockTaskTable) PauseSubtasks

func (m *MockTaskTable) PauseSubtasks(arg0 context.Context, arg1 string, arg2 int64) error

PauseSubtasks mocks base method.

func (*MockTaskTable) RecoverMeta

func (m *MockTaskTable) RecoverMeta(arg0 context.Context, arg1, arg2 string) error

RecoverMeta mocks base method.

func (*MockTaskTable) RunningSubtasksBack2Pending

func (m *MockTaskTable) RunningSubtasksBack2Pending(arg0 context.Context, arg1 []*proto.SubtaskBase) error

RunningSubtasksBack2Pending mocks base method.

func (*MockTaskTable) StartSubtask

func (m *MockTaskTable) StartSubtask(arg0 context.Context, arg1 int64, arg2 string) error

StartSubtask mocks base method.

func (*MockTaskTable) UpdateSubtaskStateAndError

func (m *MockTaskTable) UpdateSubtaskStateAndError(arg0 context.Context, arg1 string, arg2 int64, arg3 proto.SubtaskState, arg4 error) error

UpdateSubtaskStateAndError mocks base method.

type MockTaskTableMockRecorder

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

MockTaskTableMockRecorder is the mock recorder for MockTaskTable.

func (*MockTaskTableMockRecorder) CancelSubtask

func (mr *MockTaskTableMockRecorder) CancelSubtask(arg0, arg1, arg2 any) *gomock.Call

CancelSubtask indicates an expected call of CancelSubtask.

func (*MockTaskTableMockRecorder) FailSubtask

func (mr *MockTaskTableMockRecorder) FailSubtask(arg0, arg1, arg2, arg3 any) *gomock.Call

FailSubtask indicates an expected call of FailSubtask.

func (*MockTaskTableMockRecorder) FinishSubtask

func (mr *MockTaskTableMockRecorder) FinishSubtask(arg0, arg1, arg2, arg3 any) *gomock.Call

FinishSubtask indicates an expected call of FinishSubtask.

func (*MockTaskTableMockRecorder) GetFirstSubtaskInStates

func (mr *MockTaskTableMockRecorder) GetFirstSubtaskInStates(arg0, arg1, arg2, arg3 any, arg4 ...any) *gomock.Call

GetFirstSubtaskInStates indicates an expected call of GetFirstSubtaskInStates.

func (*MockTaskTableMockRecorder) GetSubtasksByExecIDAndStepAndStates

func (mr *MockTaskTableMockRecorder) GetSubtasksByExecIDAndStepAndStates(arg0, arg1, arg2, arg3 any, arg4 ...any) *gomock.Call

GetSubtasksByExecIDAndStepAndStates indicates an expected call of GetSubtasksByExecIDAndStepAndStates.

func (*MockTaskTableMockRecorder) GetTaskBaseByID

func (mr *MockTaskTableMockRecorder) GetTaskBaseByID(arg0, arg1 any) *gomock.Call

GetTaskBaseByID indicates an expected call of GetTaskBaseByID.

func (*MockTaskTableMockRecorder) GetTaskByID

func (mr *MockTaskTableMockRecorder) GetTaskByID(arg0, arg1 any) *gomock.Call

GetTaskByID indicates an expected call of GetTaskByID.

func (*MockTaskTableMockRecorder) GetTaskExecInfoByExecID

func (mr *MockTaskTableMockRecorder) GetTaskExecInfoByExecID(arg0, arg1 any) *gomock.Call

GetTaskExecInfoByExecID indicates an expected call of GetTaskExecInfoByExecID.

func (*MockTaskTableMockRecorder) GetTasksInStates

func (mr *MockTaskTableMockRecorder) GetTasksInStates(arg0 any, arg1 ...any) *gomock.Call

GetTasksInStates indicates an expected call of GetTasksInStates.

func (*MockTaskTableMockRecorder) HasSubtasksInStates

func (mr *MockTaskTableMockRecorder) HasSubtasksInStates(arg0, arg1, arg2, arg3 any, arg4 ...any) *gomock.Call

HasSubtasksInStates indicates an expected call of HasSubtasksInStates.

func (*MockTaskTableMockRecorder) InitMeta

func (mr *MockTaskTableMockRecorder) InitMeta(arg0, arg1, arg2 any) *gomock.Call

InitMeta indicates an expected call of InitMeta.

func (*MockTaskTableMockRecorder) PauseSubtasks

func (mr *MockTaskTableMockRecorder) PauseSubtasks(arg0, arg1, arg2 any) *gomock.Call

PauseSubtasks indicates an expected call of PauseSubtasks.

func (*MockTaskTableMockRecorder) RecoverMeta

func (mr *MockTaskTableMockRecorder) RecoverMeta(arg0, arg1, arg2 any) *gomock.Call

RecoverMeta indicates an expected call of RecoverMeta.

func (*MockTaskTableMockRecorder) RunningSubtasksBack2Pending

func (mr *MockTaskTableMockRecorder) RunningSubtasksBack2Pending(arg0, arg1 any) *gomock.Call

RunningSubtasksBack2Pending indicates an expected call of RunningSubtasksBack2Pending.

func (*MockTaskTableMockRecorder) StartSubtask

func (mr *MockTaskTableMockRecorder) StartSubtask(arg0, arg1, arg2 any) *gomock.Call

StartSubtask indicates an expected call of StartSubtask.

func (*MockTaskTableMockRecorder) UpdateSubtaskStateAndError

func (mr *MockTaskTableMockRecorder) UpdateSubtaskStateAndError(arg0, arg1, arg2, arg3, arg4 any) *gomock.Call

UpdateSubtaskStateAndError indicates an expected call of UpdateSubtaskStateAndError.

Directories

Path Synopsis
Package mockexecute is a generated GoMock package.
Package mockexecute is a generated GoMock package.

Jump to

Keyboard shortcuts

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