Documentation
¶
Index ¶
- Constants
- Variables
- func ConvertGenericID(genericID string) (id int64, agent meta.AgentInfoInterface, err error)
- func ConvertIDToGenericID(dagID int64, isLocal bool, dagType string) string
- func ConvertLocalIDToGenericID(id int64, dagType string) string
- func ConvertObproxyIDToGenericID(id int64) string
- func ConvertToGenericID(instance TaskInfoInterface, dagType string) string
- func IsObproxyTask(genericID string) bool
- func RegisterTaskType(typedNil interface{})
- type AdditionalData
- type AdditionalDataDTO
- type CancelableTask
- type ContinuableTask
- type Dag
- func (dag *Dag) GetContext() *TaskContext
- func (dag *Dag) GetDagType() string
- func (dag *Dag) GetMaintenanceKey() string
- func (dag *Dag) GetMaintenanceType() int
- func (dag *Dag) GetMaxStage() int
- func (dag *Dag) GetStage() int
- func (dag *Dag) IsMaintenance() bool
- func (dag *Dag) MergeContext(ctx *TaskContext)
- func (dag *Dag) SetStage(stage int)
- type DagDetail
- type DagDetailDTO
- type DagOperator
- type DagType
- type Executable
- type ExecutableTask
- type GenericDTO
- type Maintainer
- type Node
- func (node *Node) AddDownstream(downstream *Node)
- func (node *Node) AddSubTask(task ExecutableTask) error
- func (node *Node) AddUpstream(upstream *Node)
- func (node *Node) CanCancel() bool
- func (node *Node) CanContinue() bool
- func (node *Node) CanPass() bool
- func (node *Node) CanRetry() bool
- func (node *Node) CanRollback() bool
- func (node *Node) GetContext() *TaskContext
- func (node *Node) GetDagId() int
- func (node *Node) GetDownstream() *Node
- func (node *Node) GetNodeType() string
- func (node *Node) GetSubTasks() []ExecutableTask
- func (node *Node) GetTaskType() reflect.Type
- func (node *Node) GetUpstream() *Node
- func (node *Node) IsParallel() bool
- func (node *Node) MergeContext(ctx *TaskContext)
- func (node *Node) SetContext(ctx *TaskContext)
- type NodeDetail
- type NodeDetailDTO
- type NodeOperator
- type RemoteTask
- type Retryable
- type RollableTask
- type Task
- func (task *Task) AddExecuteTimes()
- func (task *Task) Cancel()
- func (task *Task) ExecuteErrorLog(err error)
- func (task *Task) ExecuteErrorLogf(format string, args ...interface{})
- func (task *Task) ExecuteInfoLog(text string)
- func (task *Task) ExecuteInfoLogf(format string, args ...interface{})
- func (task *Task) ExecuteLog(text string)
- func (task *Task) ExecuteLogf(format string, args ...interface{})
- func (task *Task) ExecuteWarnLog(err error)
- func (task *Task) ExecuteWarnLogf(format string, args ...interface{})
- func (task *Task) Finish(err error)
- func (task *Task) GetAdditionalData() map[string]interface{}
- func (task *Task) GetContext() *TaskContext
- func (task *Task) GetExecuteAgent() meta.AgentInfo
- func (task *Task) GetExecuteTimes() int
- func (task *Task) GetLocalData(key string) interface{}
- func (task *Task) GetLocalDataWithValue(key string, value interface{}) error
- func (task *Task) GetResult() TaskResult
- func (task *Task) GetTimeout() time.Duration
- func (task *Task) IsContinue() bool
- func (task *Task) Rollback() error
- func (task *Task) SetCanCancel() *Task
- func (task *Task) SetCanContinue() *Task
- func (task *Task) SetCanPass() *Task
- func (task *Task) SetCanRetry() *Task
- func (task *Task) SetCanRollback() *Task
- func (task *Task) SetCancelFunc(cancel context.CancelFunc)
- func (task *Task) SetContext(taskContext *TaskContext)
- func (task *Task) SetExecuteAgent(agent meta.AgentInfo)
- func (task *Task) SetIsContinue()
- func (task *Task) SetLocalData(key string, data interface{})
- func (task *Task) SetLogChannel(logChan chan<- TaskExecuteLogDTO)
- func (task *Task) TimeoutCheck()
- type TaskContext
- func (ctx *TaskContext) GetAgentData(agent meta.AgentInfoInterface, key string) interface{}
- func (ctx *TaskContext) GetAgentDataByAgentKey(agentKey string, key string) interface{}
- func (ctx *TaskContext) GetAgentDataByAgentKeyWithValue(agentKey string, key string, value interface{}) error
- func (ctx *TaskContext) GetAgentDataWithValue(agent meta.AgentInfoInterface, key string, value interface{}) error
- func (ctx *TaskContext) GetData(key string) interface{}
- func (ctx *TaskContext) GetDataWithValue(key string, value interface{}) error
- func (ctx *TaskContext) GetParam(key string) interface{}
- func (ctx *TaskContext) GetParamWithValue(key string, value interface{}) error
- func (ctx *TaskContext) MergeContext(other *TaskContext)
- func (ctx *TaskContext) MergeContextWithoutExecAgents(other *TaskContext)
- func (ctx *TaskContext) MergeContextWithoutFailureExitMaintenance(other *TaskContext)
- func (ctx *TaskContext) MergeContextWithoutKeyords(other *TaskContext)
- func (ctx *TaskContext) SetAgentData(agent meta.AgentInfoInterface, key string, value interface{}) *TaskContext
- func (ctx *TaskContext) SetAgentDataByAgentKey(agentKey string, key string, value interface{}) *TaskContext
- func (ctx *TaskContext) SetData(key string, value interface{}) *TaskContext
- func (ctx *TaskContext) SetParam(key string, value interface{}) *TaskContext
- type TaskDetail
- type TaskDetailDTO
- type TaskExecuteLogDTO
- type TaskInfo
- func (task *TaskInfo) CanCancel() bool
- func (task *TaskInfo) CanContinue() bool
- func (task *TaskInfo) CanPass() bool
- func (task *TaskInfo) CanRetry() bool
- func (task *TaskInfo) CanRollback() bool
- func (task *TaskInfo) GetEndTime() time.Time
- func (task *TaskInfo) GetID() int64
- func (task *TaskInfo) GetName() string
- func (task *TaskInfo) GetOperator() int
- func (task *TaskInfo) GetStartTime() time.Time
- func (task *TaskInfo) GetState() int
- func (task *TaskInfo) IsCancel() bool
- func (task *TaskInfo) IsFail() bool
- func (task *TaskInfo) IsFinished() bool
- func (task *TaskInfo) IsLocalTask() bool
- func (task *TaskInfo) IsPending() bool
- func (task *TaskInfo) IsReady() bool
- func (task *TaskInfo) IsRetry() bool
- func (task *TaskInfo) IsRollback() bool
- func (task *TaskInfo) IsRun() bool
- func (task *TaskInfo) IsRunning() bool
- func (task *TaskInfo) IsSuccess() bool
- func (task *TaskInfo) SetEndTime(endTime time.Time)
- func (task *TaskInfo) SetOperator(operator int)
- func (task *TaskInfo) SetStartTime(startTime time.Time)
- func (task *TaskInfo) SetState(state int)
- type TaskInfoInterface
- type TaskLogInterface
- type TaskResult
- type TaskStatusDTO
- type TaskStatusInterface
- type Template
- type TemplateBuilder
- func (builder *TemplateBuilder) AddNode(node *Node) *TemplateBuilder
- func (builder *TemplateBuilder) AddTask(task ExecutableTask, parallel bool) *TemplateBuilder
- func (builder *TemplateBuilder) AddTemplate(template *Template) *TemplateBuilder
- func (builder *TemplateBuilder) Build() *Template
- func (builder *TemplateBuilder) SetMaintenance(maintenanceType Maintainer) *TemplateBuilder
- func (builder *TemplateBuilder) SetType(dagType DagType) *TemplateBuilder
Constants ¶
View Source
const ( EXECUTE_AGENTS = "execute_agents" FAILURE_EXIT_MAINTENANCE = "failure_exit_maintenance" )
View Source
const ( NOT_BOOTSTRAP = iota NOT_UNDER_MAINTENANCE GLOBAL_MAINTENANCE TENANT_MAINTENANCE OBPROXY_MAINTENACE )
View Source
const ( NORMAL = "normal" PARALLEL = "parallel" )
View Source
const ( PENDING = iota + 1 READY RUNNING FAILED SUCCEED PENDING_STR = "PENDING" READY_STR = "READY" RUNNING_STR = "RUNNING" FAILED_STR = "FAILED" SUCCEED_STR = "SUCCEED" )
State
View Source
const ( RUN = iota + 1 RETRY ROLLBACK CANCEL PASS RUN_STR = "RUN" RETRY_STR = "RETRY" ROLLBACK_STR = "ROLLBACK" CANCEL_STR = "CANCEL" PASS_STR = "PASS" )
Operator
View Source
const DEFAULT_TIMEOUT = 3600 * time.Second
View Source
const TIMEOUT_KEY = "timeout"
Variables ¶
View Source
var ( DAG_TYPE_MAP = map[DagType]string{ DAG_OB: "ob", DAG_OBPROXY: "obproxy", } )
View Source
var (
ERR_WAIT_OPERATOR = errors.New("wait operator to advance")
)
View Source
var OPERATOR_MAP = map[int]string{ RUN: RUN_STR, RETRY: RETRY_STR, ROLLBACK: ROLLBACK_STR, CANCEL: CANCEL_STR, PASS: PASS_STR, }
View Source
var STATE_MAP = map[int]string{ PENDING: PENDING_STR, READY: READY_STR, RUNNING: RUNNING_STR, FAILED: FAILED_STR, SUCCEED: SUCCEED_STR, }
View Source
var TASK_TYPE = make(map[string]reflect.Type)
Functions ¶
func ConvertGenericID ¶
func ConvertGenericID(genericID string) (id int64, agent meta.AgentInfoInterface, err error)
ConvertGenericID will onvert dto id to instance id.
func ConvertIDToGenericID ¶
func ConvertLocalIDToGenericID ¶
ConvertLocalIDToGenericID will convert id of local task to generic id.
func ConvertToGenericID ¶
func ConvertToGenericID(instance TaskInfoInterface, dagType string) string
ConvertToGenericID will convert task instance id to generic dto id.
func IsObproxyTask ¶
func RegisterTaskType ¶
func RegisterTaskType(typedNil interface{})
Types ¶
type AdditionalData ¶
type AdditionalData interface {
GetAdditionalData() map[string]interface{}
}
type AdditionalDataDTO ¶
type AdditionalDataDTO struct { AdditionalData *map[string]any `json:"additional_data"` // contains filtered or unexported fields }
func (*AdditionalDataDTO) SetVisible ¶
func (a *AdditionalDataDTO) SetVisible(visible bool)
type CancelableTask ¶
type CancelableTask interface { IsCancel() bool CanCancel() bool Cancel() SetCancelFunc(cancel context.CancelFunc) }
type ContinuableTask ¶
type Dag ¶
type Dag struct { TaskInfo // contains filtered or unexported fields }
func (*Dag) GetContext ¶
func (dag *Dag) GetContext() *TaskContext
func (*Dag) GetDagType ¶
func (*Dag) GetMaintenanceKey ¶
func (*Dag) GetMaintenanceType ¶
func (*Dag) GetMaxStage ¶
func (*Dag) IsMaintenance ¶
func (*Dag) MergeContext ¶
func (dag *Dag) MergeContext(ctx *TaskContext)
type DagDetail ¶
type DagDetail struct { DagID int64 `json:"dag_id" uri:"dag_id"` Name string `json:"name"` Stage int `json:"stage"` MaxStage int `json:"max_stage"` MaintenanceType int `json:"maintenance_type"` MaintenanceKey string `json:"maintenance_key"` TaskStatusDTO AdditionalDataDTO Nodes []*NodeDetailDTO `json:"nodes"` }
func NewDagDetail ¶
type DagDetailDTO ¶
type DagDetailDTO struct { *GenericDTO *DagDetail }
func NewDagDetailDTO ¶
func NewDagDetailDTO(dag *Dag) *DagDetailDTO
func (*DagDetailDTO) SetVisible ¶
func (a *DagDetailDTO) SetVisible(visible bool)
type DagOperator ¶
type DagOperator struct { DagDetailDTO Operator string `json:"operator" binding:"required"` }
type Executable ¶
type Executable interface { IsRun() bool Execute() error SetLogChannel(logChan chan<- TaskExecuteLogDTO) GetTimeout() time.Duration TimeoutCheck() CanPass() bool GetResult() TaskResult GetContext() *TaskContext SetContext(context *TaskContext) GetLocalData(key string) interface{} GetLocalDataWithValue(key string, value interface{}) error SetLocalData(key string, data interface{}) GetExecuteAgent() meta.AgentInfo GetExecuteTimes() int AddExecuteTimes() Finish(err error) }
type ExecutableTask ¶
type ExecutableTask interface { TaskInfoInterface Executable TaskLogInterface Retryable CancelableTask ContinuableTask RollableTask AdditionalData SetExecuteAgent(agent meta.AgentInfo) GetExecuteAgent() meta.AgentInfo }
func CreateSubTaskInstance ¶
func CreateSubTaskInstance( taskType string, id int64, taskName string, ctx *TaskContext, state int, operator int, canCancel bool, canContinue bool, canPass bool, canRetry bool, canRollback bool, executeTimes int, executerAgent meta.AgentInfo, isLocalTask bool, startTime time.Time, endTime time.Time) (ExecutableTask, error)
type GenericDTO ¶
type GenericDTO struct {
GenericID string `json:"id" uri:"id" binding:"required"`
}
type Maintainer ¶
type Maintainer interface { IsMaintenance() bool GetMaintenanceType() int GetMaintenanceKey() string }
func GlobalMaintenance ¶
func GlobalMaintenance() Maintainer
func NewMaintenance ¶
func NewMaintenance(maintenanceType int, maintenanceKey string) Maintainer
func ObproxyMaintenance ¶
func ObproxyMaintenance() Maintainer
func TenantMaintenance ¶
func TenantMaintenance(tenantName string) Maintainer
func UnMaintenance ¶
func UnMaintenance() Maintainer
type Node ¶
type Node struct { TaskInfo // contains filtered or unexported fields }
func NewNode ¶
func NewNode(task ExecutableTask, paralle bool) *Node
func NewNodeWithContext ¶
func NewNodeWithContext(task ExecutableTask, paralle bool, ctx *TaskContext) *Node
func NewNodeWithId ¶
func (*Node) AddDownstream ¶
func (*Node) AddSubTask ¶
func (node *Node) AddSubTask(task ExecutableTask) error
func (*Node) AddUpstream ¶
func (*Node) CanContinue ¶
func (*Node) CanRollback ¶
func (*Node) GetContext ¶
func (node *Node) GetContext() *TaskContext
func (*Node) GetDownstream ¶
func (*Node) GetNodeType ¶
func (*Node) GetSubTasks ¶
func (node *Node) GetSubTasks() []ExecutableTask
func (*Node) GetTaskType ¶
func (*Node) GetUpstream ¶
func (*Node) IsParallel ¶
func (*Node) MergeContext ¶
func (node *Node) MergeContext(ctx *TaskContext)
func (*Node) SetContext ¶
func (node *Node) SetContext(ctx *TaskContext)
type NodeDetail ¶
type NodeDetail struct { NodeID int64 `json:"node_id" uri:"node_id"` Name string `json:"name"` TaskStatusDTO AdditionalDataDTO SubTasks []*TaskDetailDTO `json:"sub_tasks"` }
func NewNodeDetail ¶
func NewNodeDetail(node *Node) *NodeDetail
type NodeDetailDTO ¶
type NodeDetailDTO struct { *GenericDTO *NodeDetail }
func NewNodeDetailDTO ¶
func NewNodeDetailDTO(node *Node, dagType string) *NodeDetailDTO
func (*NodeDetailDTO) SetVisible ¶
func (a *NodeDetailDTO) SetVisible(visible bool)
type NodeOperator ¶
type NodeOperator struct { NodeDetailDTO Operator string `json:"operator" binding:"required"` }
type RemoteTask ¶
type RemoteTask struct { TaskID int64 `json:"task_id" binding:"required"` Name string `json:"name"` StructName string `json:"struct_name"` State int `json:"state" binding:"required"` Operator int `json:"operator" binding:"required"` CanCancel bool `json:"can_cancel"` CanContinue bool `json:"can_continue"` CanPass bool `json:"can_pass"` CanRetry bool `json:"can_retry"` CanRollback bool `json:"can_rollback"` Context TaskContext `json:"context" binding:"required"` ExecuteTimes int `json:"execute_times" binding:"required"` ExecuterAgent meta.AgentInfo `json:"executer_agent" binding:"required"` StartTime time.Time `json:"start_time"` EndTime time.Time `json:"end_time"` }
func NewRemoteTask ¶
func (*RemoteTask) Execute ¶
func (t *RemoteTask) Execute() error
func (*RemoteTask) GetStructName ¶
func (t *RemoteTask) GetStructName() string
type RollableTask ¶
type Task ¶
type Task struct { TaskInfo // contains filtered or unexported fields }
func NewSubTask ¶
func (*Task) AddExecuteTimes ¶
func (task *Task) AddExecuteTimes()
func (*Task) ExecuteErrorLog ¶
func (*Task) ExecuteErrorLogf ¶
func (*Task) ExecuteInfoLog ¶
func (*Task) ExecuteInfoLogf ¶
func (*Task) ExecuteLog ¶
func (*Task) ExecuteLogf ¶
func (*Task) ExecuteWarnLog ¶
func (*Task) ExecuteWarnLogf ¶
func (*Task) GetAdditionalData ¶
func (*Task) GetContext ¶
func (task *Task) GetContext() *TaskContext
func (*Task) GetExecuteAgent ¶
func (*Task) GetExecuteTimes ¶
func (*Task) GetLocalData ¶
func (*Task) GetLocalDataWithValue ¶
func (*Task) GetResult ¶
func (task *Task) GetResult() TaskResult
func (*Task) GetTimeout ¶
func (*Task) IsContinue ¶
func (*Task) SetCanCancel ¶
func (*Task) SetCanContinue ¶
func (*Task) SetCanPass ¶
func (*Task) SetCanRetry ¶
SetCanRetry set task can retry, and Retryable task must be rollbackable.
func (*Task) SetCanRollback ¶
func (*Task) SetCancelFunc ¶
func (task *Task) SetCancelFunc(cancel context.CancelFunc)
func (*Task) SetContext ¶
func (task *Task) SetContext(taskContext *TaskContext)
func (*Task) SetExecuteAgent ¶
func (*Task) SetIsContinue ¶
func (task *Task) SetIsContinue()
func (*Task) SetLocalData ¶
func (*Task) SetLogChannel ¶
func (task *Task) SetLogChannel(logChan chan<- TaskExecuteLogDTO)
func (*Task) TimeoutCheck ¶
func (task *Task) TimeoutCheck()
type TaskContext ¶
type TaskContext struct { Params map[string]interface{} // params can not be rewritten when merge context Data map[string]interface{} // global data will be rewritten when merge context AgentData map[string]map[string]interface{} AgentDataUpdateCount map[string]int }
func NewTaskContext ¶
func NewTaskContext() *TaskContext
func (*TaskContext) GetAgentData ¶
func (ctx *TaskContext) GetAgentData(agent meta.AgentInfoInterface, key string) interface{}
func (*TaskContext) GetAgentDataByAgentKey ¶
func (ctx *TaskContext) GetAgentDataByAgentKey(agentKey string, key string) interface{}
func (*TaskContext) GetAgentDataByAgentKeyWithValue ¶
func (ctx *TaskContext) GetAgentDataByAgentKeyWithValue(agentKey string, key string, value interface{}) error
func (*TaskContext) GetAgentDataWithValue ¶
func (ctx *TaskContext) GetAgentDataWithValue(agent meta.AgentInfoInterface, key string, value interface{}) error
func (*TaskContext) GetData ¶
func (ctx *TaskContext) GetData(key string) interface{}
func (*TaskContext) GetDataWithValue ¶
func (ctx *TaskContext) GetDataWithValue(key string, value interface{}) error
func (*TaskContext) GetParam ¶
func (ctx *TaskContext) GetParam(key string) interface{}
func (*TaskContext) GetParamWithValue ¶
func (ctx *TaskContext) GetParamWithValue(key string, value interface{}) error
func (*TaskContext) MergeContext ¶
func (ctx *TaskContext) MergeContext(other *TaskContext)
func (*TaskContext) MergeContextWithoutExecAgents ¶
func (ctx *TaskContext) MergeContextWithoutExecAgents(other *TaskContext)
func (*TaskContext) MergeContextWithoutFailureExitMaintenance ¶
func (ctx *TaskContext) MergeContextWithoutFailureExitMaintenance(other *TaskContext)
func (*TaskContext) MergeContextWithoutKeyords ¶
func (ctx *TaskContext) MergeContextWithoutKeyords(other *TaskContext)
func (*TaskContext) SetAgentData ¶
func (ctx *TaskContext) SetAgentData(agent meta.AgentInfoInterface, key string, value interface{}) *TaskContext
func (*TaskContext) SetAgentDataByAgentKey ¶
func (ctx *TaskContext) SetAgentDataByAgentKey(agentKey string, key string, value interface{}) *TaskContext
func (*TaskContext) SetData ¶
func (ctx *TaskContext) SetData(key string, value interface{}) *TaskContext
func (*TaskContext) SetParam ¶
func (ctx *TaskContext) SetParam(key string, value interface{}) *TaskContext
type TaskDetail ¶
type TaskDetail struct { TaskID int64 `json:"task_id" uri:"task_id"` Name string `json:"name"` TaskStatusDTO AdditionalDataDTO ExecuteTimes int `json:"execute_times"` ExecuteAgent meta.AgentInfo `json:"execute_agent"` TaskLogs []string `json:"task_logs"` }
func NewTaskDetail ¶
func NewTaskDetail(task ExecutableTask) *TaskDetail
type TaskDetailDTO ¶
type TaskDetailDTO struct { *GenericDTO *TaskDetail }
func NewTaskDetailDTO ¶
func NewTaskDetailDTO(task ExecutableTask, dagType string) *TaskDetailDTO
type TaskExecuteLogDTO ¶
type TaskInfo ¶
type TaskInfo struct {
// contains filtered or unexported fields
}
func (*TaskInfo) CanContinue ¶
func (*TaskInfo) CanRollback ¶
func (*TaskInfo) GetEndTime ¶
func (*TaskInfo) GetOperator ¶
func (*TaskInfo) GetStartTime ¶
func (*TaskInfo) IsFinished ¶
func (*TaskInfo) IsLocalTask ¶
func (*TaskInfo) IsRollback ¶
func (*TaskInfo) SetEndTime ¶
func (*TaskInfo) SetOperator ¶
func (*TaskInfo) SetStartTime ¶
type TaskInfoInterface ¶
type TaskLogInterface ¶
type TaskLogInterface interface { ExecuteLog(text string) ExecuteInfoLog(text string) ExecuteWarnLog(err error) ExecuteErrorLog(err error) ExecuteLogf(format string, args ...interface{}) ExecuteInfoLogf(format string, args ...interface{}) ExecuteWarnLogf(format string, args ...interface{}) ExecuteErrorLogf(format string, args ...interface{}) }
type TaskResult ¶
type TaskStatusDTO ¶
type TaskStatusDTO struct { State string `json:"state"` Operator string `json:"operator"` StartTime time.Time `json:"start_time"` EndTime time.Time `json:"end_time"` }
func NewTaskStatusDTO ¶
func NewTaskStatusDTO(task *TaskInfo) *TaskStatusDTO
func (*TaskStatusDTO) IsFailed ¶
func (t *TaskStatusDTO) IsFailed() bool
func (*TaskStatusDTO) IsFinished ¶
func (t *TaskStatusDTO) IsFinished() bool
func (*TaskStatusDTO) IsPending ¶
func (t *TaskStatusDTO) IsPending() bool
func (*TaskStatusDTO) IsReady ¶
func (t *TaskStatusDTO) IsReady() bool
func (*TaskStatusDTO) IsRunning ¶
func (t *TaskStatusDTO) IsRunning() bool
func (*TaskStatusDTO) IsSucceed ¶
func (t *TaskStatusDTO) IsSucceed() bool
type TaskStatusInterface ¶
type TaskStatusInterface interface { IsSuccess() bool IsFail() bool IsRunning() bool IsPending() bool IsReady() bool IsFinished() bool IsRollback() bool SetOperator(operator int) GetOperator() int GetStartTime() time.Time GetEndTime() time.Time SetStartTime(startTime time.Time) SetEndTime(endTime time.Time) }
type Template ¶
func (*Template) GetMaintenanceKey ¶
func (*Template) GetMaintenanceType ¶
func (*Template) IsMaintenance ¶
type TemplateBuilder ¶
type TemplateBuilder struct {
Template *Template
}
func NewTemplateBuilder ¶
func NewTemplateBuilder(name string) *TemplateBuilder
func (*TemplateBuilder) AddNode ¶
func (builder *TemplateBuilder) AddNode(node *Node) *TemplateBuilder
func (*TemplateBuilder) AddTask ¶
func (builder *TemplateBuilder) AddTask(task ExecutableTask, parallel bool) *TemplateBuilder
func (*TemplateBuilder) AddTemplate ¶
func (builder *TemplateBuilder) AddTemplate(template *Template) *TemplateBuilder
func (*TemplateBuilder) Build ¶
func (builder *TemplateBuilder) Build() *Template
func (*TemplateBuilder) SetMaintenance ¶
func (builder *TemplateBuilder) SetMaintenance(maintenanceType Maintainer) *TemplateBuilder
func (*TemplateBuilder) SetType ¶
func (builder *TemplateBuilder) SetType(dagType DagType) *TemplateBuilder
Click to show internal directories.
Click to hide internal directories.