1. 提取触发器逻辑
2. 创建/更新计划时自动生成对应触发器
This commit is contained in:
		| @@ -1,10 +1,12 @@ | ||||
| package repository | ||||
|  | ||||
| import ( | ||||
| 	"encoding/json" | ||||
| 	"errors" | ||||
| 	"fmt" | ||||
|  | ||||
| 	"git.huangwc.com/pig/pig-farm-controller/internal/infra/models" | ||||
| 	"gorm.io/datatypes" | ||||
| 	"gorm.io/gorm" | ||||
| ) | ||||
|  | ||||
| @@ -170,6 +172,11 @@ func (r *gormPlanRepository) CreatePlan(plan *models.Plan) error { | ||||
| 		if err := tx.Create(plan).Error; err != nil { | ||||
| 			return err | ||||
| 		} | ||||
|  | ||||
| 		// 3. 创建触发器Task | ||||
| 		if err := r.createPlanAnalysisTask(tx, plan); err != nil { | ||||
| 			return err | ||||
| 		} | ||||
| 		return nil | ||||
| 	}) | ||||
| } | ||||
| @@ -186,7 +193,12 @@ func (r *gormPlanRepository) updatePlanTx(tx *gorm.DB, plan *models.Plan) error | ||||
| 	if err := r.validatePlanTree(tx, plan); err != nil { | ||||
| 		return err | ||||
| 	} | ||||
| 	return r.reconcilePlanNode(tx, plan) | ||||
| 	if err := r.reconcilePlanNode(tx, plan); err != nil { | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	// 更新Plan触发器 | ||||
| 	return r.updatePlanAnalysisTask(tx, plan) | ||||
| } | ||||
|  | ||||
| // validatePlanTree 对整个计划树进行全面的只读健康检查 | ||||
| @@ -461,51 +473,61 @@ func (r *gormPlanRepository) flattenPlanTasksRecursive(plan *models.Plan) ([]mod | ||||
| func (r *gormPlanRepository) DeleteTask(id int) error { | ||||
| 	// 使用事务确保操作的原子性 | ||||
| 	return r.db.Transaction(func(tx *gorm.DB) error { | ||||
| 		// 1. 检查是否有待执行任务引用了这个任务 | ||||
| 		var pendingTaskCount int64 | ||||
| 		if err := tx.Model(&models.PendingTask{}).Where("task_id = ?", id).Count(&pendingTaskCount).Error; err != nil { | ||||
| 			return fmt.Errorf("检查待执行任务时出错: %w", err) | ||||
| 		} | ||||
|  | ||||
| 		// 如果有待执行任务引用该任务,不能删除 | ||||
| 		if pendingTaskCount > 0 { | ||||
| 			return fmt.Errorf("无法删除任务(ID: %d),因为存在 %d 条待执行任务引用该任务", id, pendingTaskCount) | ||||
| 		} | ||||
|  | ||||
| 		// 2. 检查是否有计划仍在使用这个任务 | ||||
| 		var planCount int64 | ||||
| 		if err := tx.Model(&models.Plan{}).Joins("JOIN tasks ON plans.id = tasks.plan_id").Where("tasks.id = ?", id).Count(&planCount).Error; err != nil { | ||||
| 			return fmt.Errorf("检查计划引用任务时出错: %w", err) | ||||
| 		} | ||||
|  | ||||
| 		// 如果有计划在使用该任务,不能删除 | ||||
| 		if planCount > 0 { | ||||
| 			return fmt.Errorf("无法删除任务(ID: %d),因为存在 %d 个计划仍在使用该任务", id, planCount) | ||||
| 		} | ||||
|  | ||||
| 		// 3. 执行删除操作 | ||||
| 		result := tx.Delete(&models.Task{}, id) | ||||
| 		if result.Error != nil { | ||||
| 			return fmt.Errorf("删除任务失败: %w", result.Error) | ||||
| 		} | ||||
|  | ||||
| 		// 检查是否实际删除了记录 | ||||
| 		if result.RowsAffected == 0 { | ||||
| 			return gorm.ErrRecordNotFound | ||||
| 		} | ||||
|  | ||||
| 		return nil | ||||
| 		return r.deleteTask(tx, id) | ||||
| 	}) | ||||
| } | ||||
|  | ||||
| // deleteTask 根据ID删除任务 | ||||
| func (r *gormPlanRepository) deleteTask(tx *gorm.DB, id int) error { | ||||
| 	// 1. 检查是否有待执行任务引用了这个任务 | ||||
| 	var pendingTaskCount int64 | ||||
| 	if err := tx.Model(&models.PendingTask{}).Where("task_id = ?", id).Count(&pendingTaskCount).Error; err != nil { | ||||
| 		return fmt.Errorf("检查待执行任务时出错: %w", err) | ||||
| 	} | ||||
|  | ||||
| 	// 如果有待执行任务引用该任务,不能删除 | ||||
| 	if pendingTaskCount > 0 { | ||||
| 		return fmt.Errorf("无法删除任务(ID: %d),因为存在 %d 条待执行任务引用该任务", id, pendingTaskCount) | ||||
| 	} | ||||
|  | ||||
| 	// 2. 检查是否有计划仍在使用这个任务 | ||||
| 	var planCount int64 | ||||
| 	if err := tx.Model(&models.Plan{}).Joins("JOIN tasks ON plans.id = tasks.plan_id").Where("tasks.id = ?", id).Count(&planCount).Error; err != nil { | ||||
| 		return fmt.Errorf("检查计划引用任务时出错: %w", err) | ||||
| 	} | ||||
|  | ||||
| 	// 如果有计划在使用该任务,不能删除 | ||||
| 	if planCount > 0 { | ||||
| 		return fmt.Errorf("无法删除任务(ID: %d),因为存在 %d 个计划仍在使用该任务", id, planCount) | ||||
| 	} | ||||
|  | ||||
| 	// 3. 执行删除操作 | ||||
| 	result := tx.Delete(&models.Task{}, id) | ||||
| 	if result.Error != nil { | ||||
| 		return fmt.Errorf("删除任务失败: %w", result.Error) | ||||
| 	} | ||||
|  | ||||
| 	// 检查是否实际删除了记录 | ||||
| 	if result.RowsAffected == 0 { | ||||
| 		return gorm.ErrRecordNotFound | ||||
| 	} | ||||
|  | ||||
| 	return nil | ||||
| } | ||||
|  | ||||
| // FindPlanAnalysisTaskByParamsPlanID 根据Parameters中的ParamsPlanID字段值查找TaskPlanAnalysis类型的Task | ||||
| func (r *gormPlanRepository) FindPlanAnalysisTaskByParamsPlanID(paramsPlanID uint) (*models.Task, error) { | ||||
| 	return r.findPlanAnalysisTaskByParamsPlanID(r.db, paramsPlanID) | ||||
| } | ||||
|  | ||||
| // findPlanAnalysisTaskByParamsPlanID 使用指定db根据Parameters中的ParamsPlanID字段值查找TaskPlanAnalysis类型的Task | ||||
| func (r *gormPlanRepository) findPlanAnalysisTaskByParamsPlanID(tx *gorm.DB, paramsPlanID uint) (*models.Task, error) { | ||||
| 	var task models.Task | ||||
|  | ||||
| 	// 构造JSON查询条件,查找Parameters中包含指定ParamsPlanID且Type为TaskPlanAnalysis的任务 | ||||
| 	// TODO 在JSON字段中查找特定键值的语法取决于数据库类型,这里使用PostgreSQL的语法 | ||||
| 	// TODO 如果使用的是MySQL,则需要相应调整查询条件 | ||||
| 	result := r.db.Where( | ||||
| 	result := tx.Where( | ||||
| 		"type = ? AND parameters->>'plan_id' = ?", | ||||
| 		models.TaskPlanAnalysis, | ||||
| 		fmt.Sprintf("%d", paramsPlanID), | ||||
| @@ -520,3 +542,38 @@ func (r *gormPlanRepository) FindPlanAnalysisTaskByParamsPlanID(paramsPlanID uin | ||||
|  | ||||
| 	return &task, nil | ||||
| } | ||||
|  | ||||
| // createPlanAnalysisTask 用于创建一个TaskPlanAnalysis类型的Task | ||||
| func (r *gormPlanRepository) createPlanAnalysisTask(tx *gorm.DB, plan *models.Plan) error { | ||||
| 	m := map[string]interface{}{ | ||||
| 		models.ParamsPlanID: plan.ID, | ||||
| 	} | ||||
| 	parameters, err := json.Marshal(m) | ||||
| 	if err != nil { | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	task := &models.Task{ | ||||
| 		PlanID:         plan.ID, | ||||
| 		Name:           fmt.Sprintf("'%v'计划触发器", plan.Name), | ||||
| 		Description:    fmt.Sprintf("计划名: %v, 计划ID: %v", plan.Name, plan.ID), | ||||
| 		ExecutionOrder: 0, | ||||
| 		Type:           models.TaskPlanAnalysis, | ||||
| 		Parameters:     datatypes.JSON(parameters), | ||||
| 	} | ||||
|  | ||||
| 	return tx.Create(task).Error | ||||
| } | ||||
|  | ||||
| // updatePlanAnalysisTask 使用简单粗暴的删除再创建方式实现更新, 以控制AnalysisPlanTask的定义全部在createPlanAnalysisTask方法中 | ||||
| func (r *gormPlanRepository) updatePlanAnalysisTask(tx *gorm.DB, plan *models.Plan) error { | ||||
| 	task, err := r.findPlanAnalysisTaskByParamsPlanID(tx, plan.ID) | ||||
| 	if err != nil { | ||||
| 		return err | ||||
| 	} | ||||
| 	err = r.deleteTask(tx, task.ID) | ||||
| 	if err != nil { | ||||
| 		return err | ||||
| 	} | ||||
| 	return r.createPlanAnalysisTask(tx, plan) | ||||
| } | ||||
|   | ||||
| @@ -1,29 +0,0 @@ | ||||
| package task | ||||
|  | ||||
| import ( | ||||
| 	"git.huangwc.com/pig/pig-farm-controller/internal/infra/logs" | ||||
| 	"git.huangwc.com/pig/pig-farm-controller/internal/infra/models" | ||||
| ) | ||||
|  | ||||
| // PlanAnalysisTask 用于在任务执行队列中触发一个plan的执行 | ||||
| // 该任务会解析plan生成扁平化的待执行任务表, 并将任务列表插入任务执行队列 | ||||
| // 该任务会预写入plan所有待执行任务的执行日志 | ||||
| // 每个plan执行完毕时 或 创建plan时 都应该重新创建一个 PlanAnalysisTask 以便触发下次plan执行 | ||||
| // 更新plan后应当更新对应 PlanAnalysisTask | ||||
| type PlanAnalysisTask struct { | ||||
| } | ||||
|  | ||||
| func (p *PlanAnalysisTask) Execute() error { | ||||
| 	//TODO implement me | ||||
| 	panic("implement me") | ||||
| } | ||||
|  | ||||
| func (p *PlanAnalysisTask) ParseParams(logger *logs.Logger, claimedLog *models.TaskExecutionLog) error { | ||||
| 	//TODO implement me | ||||
| 	panic("implement me") | ||||
| } | ||||
|  | ||||
| func (p *PlanAnalysisTask) OnFailure(executeErr error) { | ||||
| 	//TODO implement me | ||||
| 	panic("implement me") | ||||
| } | ||||
| @@ -1,412 +0,0 @@ | ||||
| package task | ||||
|  | ||||
| import ( | ||||
| 	"context" | ||||
| 	"errors" | ||||
| 	"sync" | ||||
| 	"time" | ||||
|  | ||||
| 	"git.huangwc.com/pig/pig-farm-controller/internal/infra/logs" | ||||
| 	"git.huangwc.com/pig/pig-farm-controller/internal/infra/models" | ||||
| 	"git.huangwc.com/pig/pig-farm-controller/internal/infra/repository" | ||||
| 	"git.huangwc.com/pig/pig-farm-controller/internal/infra/utils" | ||||
| 	"github.com/panjf2000/ants/v2" | ||||
| 	"gorm.io/gorm" | ||||
| ) | ||||
|  | ||||
| // ProgressTracker 在内存中跟踪计划的执行状态,包括进度和执行锁 | ||||
| type ProgressTracker struct { | ||||
| 	mu             sync.Mutex | ||||
| 	cond           *sync.Cond    // 用于实现阻塞锁 | ||||
| 	totalTasks     map[uint]int  // key: planExecutionLogID, value: total tasks | ||||
| 	completedTasks map[uint]int  // key: planExecutionLogID, value: completed tasks | ||||
| 	runningPlans   map[uint]bool // key: planExecutionLogID, value: true (用作内存锁) | ||||
| } | ||||
|  | ||||
| // NewProgressTracker 创建一个新的进度跟踪器 | ||||
| func NewProgressTracker() *ProgressTracker { | ||||
| 	t := &ProgressTracker{ | ||||
| 		totalTasks:     make(map[uint]int), | ||||
| 		completedTasks: make(map[uint]int), | ||||
| 		runningPlans:   make(map[uint]bool), | ||||
| 	} | ||||
| 	t.cond = sync.NewCond(&t.mu) | ||||
| 	return t | ||||
| } | ||||
|  | ||||
| // AddNewPlan 添加一个新的计划,并初始化进度跟踪器 | ||||
| func (t *ProgressTracker) AddNewPlan(planLogID uint, totalTasks int) { | ||||
| 	t.mu.Lock() | ||||
| 	t.totalTasks[planLogID] = totalTasks | ||||
| 	t.completedTasks[planLogID] = 0 | ||||
| 	t.mu.Unlock() | ||||
| } | ||||
|  | ||||
| // CompletedTask 通知计数器一个任务被完成 | ||||
| func (t *ProgressTracker) CompletedTask(planLogID uint) { | ||||
| 	t.mu.Lock() | ||||
| 	t.completedTasks[planLogID]++ | ||||
| 	t.mu.Unlock() | ||||
| } | ||||
|  | ||||
| // IsPlanOver 检查计划是否完成 | ||||
| func (t *ProgressTracker) IsPlanOver(planLogID uint) bool { | ||||
| 	t.mu.Lock() | ||||
| 	defer t.mu.Unlock() | ||||
|  | ||||
| 	return t.completedTasks[planLogID] >= t.totalTasks[planLogID] | ||||
| } | ||||
|  | ||||
| // TryLock (非阻塞) 尝试锁定一个计划。如果计划未被锁定,则锁定并返回 true。 | ||||
| func (t *ProgressTracker) TryLock(planLogID uint) bool { | ||||
| 	t.mu.Lock() | ||||
| 	defer t.mu.Unlock() | ||||
| 	if t.runningPlans[planLogID] { | ||||
| 		return false // 已被锁定 | ||||
| 	} | ||||
| 	t.runningPlans[planLogID] = true | ||||
| 	return true | ||||
| } | ||||
|  | ||||
| // Lock (阻塞) 获取一个计划的执行锁。如果锁已被占用,则会一直等待直到锁被释放。 | ||||
| func (t *ProgressTracker) Lock(planLogID uint) { | ||||
| 	t.mu.Lock() | ||||
| 	// 当计划正在运行时,调用 t.cond.Wait() 会原子地解锁 mu 并挂起当前协程。 | ||||
| 	// 当被唤醒时,它会重新锁定 mu 并再次检查循环条件。 | ||||
| 	for t.runningPlans[planLogID] { | ||||
| 		t.cond.Wait() | ||||
| 	} | ||||
| 	// 获取到锁 | ||||
| 	t.runningPlans[planLogID] = true | ||||
| 	t.mu.Unlock() | ||||
| } | ||||
|  | ||||
| // Unlock 解锁一个计划,并唤醒所有正在等待此锁的协程。 | ||||
| func (t *ProgressTracker) Unlock(planLogID uint) { | ||||
| 	t.mu.Lock() | ||||
| 	defer t.mu.Unlock() | ||||
| 	delete(t.runningPlans, planLogID) | ||||
| 	// 唤醒所有在此条件上等待的协程 | ||||
| 	t.cond.Broadcast() | ||||
| } | ||||
|  | ||||
| // GetRunningPlanIDs 获取当前所有正在执行的计划ID列表 | ||||
| func (t *ProgressTracker) GetRunningPlanIDs() []uint { | ||||
| 	t.mu.Lock() | ||||
| 	defer t.mu.Unlock() | ||||
| 	ids := make([]uint, 0, len(t.runningPlans)) | ||||
| 	for id := range t.runningPlans { | ||||
| 		ids = append(ids, id) | ||||
| 	} | ||||
| 	return ids | ||||
| } | ||||
|  | ||||
| // Scheduler 是核心的、持久化的任务调度器 | ||||
| type Scheduler struct { | ||||
| 	logger           *logs.Logger | ||||
| 	pollingInterval  time.Duration | ||||
| 	workers          int | ||||
| 	pendingTaskRepo  repository.PendingTaskRepository | ||||
| 	executionLogRepo repository.ExecutionLogRepository | ||||
| 	planRepo         repository.PlanRepository | ||||
| 	progressTracker  *ProgressTracker | ||||
| 	taskFactory      func(taskType models.TaskType) Task // 调度器需要注入一个任务工厂,用于创建任务实例 | ||||
|  | ||||
| 	pool   *ants.Pool // 使用 ants 协程池来管理并发 | ||||
| 	wg     sync.WaitGroup | ||||
| 	ctx    context.Context | ||||
| 	cancel context.CancelFunc | ||||
| } | ||||
|  | ||||
| // NewScheduler 创建一个新的调度器实例 | ||||
| func NewScheduler( | ||||
| 	pendingTaskRepo repository.PendingTaskRepository, | ||||
| 	executionLogRepo repository.ExecutionLogRepository, | ||||
| 	planRepo repository.PlanRepository, | ||||
| 	taskFactory func(taskType models.TaskType) Task, | ||||
| 	logger *logs.Logger, | ||||
| 	interval time.Duration, | ||||
| 	numWorkers int) *Scheduler { | ||||
| 	ctx, cancel := context.WithCancel(context.Background()) | ||||
|  | ||||
| 	return &Scheduler{ | ||||
| 		pendingTaskRepo:  pendingTaskRepo, | ||||
| 		executionLogRepo: executionLogRepo, | ||||
| 		planRepo:         planRepo, | ||||
| 		logger:           logger, | ||||
| 		pollingInterval:  interval, | ||||
| 		workers:          numWorkers, | ||||
| 		progressTracker:  NewProgressTracker(), | ||||
| 		taskFactory:      taskFactory, | ||||
| 		ctx:              ctx, | ||||
| 		cancel:           cancel, | ||||
| 	} | ||||
| } | ||||
|  | ||||
| // Start 启动调度器,包括初始化协程池和启动主轮询循环 | ||||
| func (s *Scheduler) Start() { | ||||
| 	s.logger.Warnf("任务调度器正在启动,工作协程数: %d...", s.workers) | ||||
| 	pool, err := ants.NewPool(s.workers, ants.WithPanicHandler(func(err interface{}) { | ||||
| 		s.logger.Errorf("[严重] 任务执行时发生 panic: %v", err) | ||||
| 	})) | ||||
| 	if err != nil { | ||||
| 		panic("初始化协程池失败: " + err.Error()) | ||||
| 	} | ||||
| 	s.pool = pool | ||||
|  | ||||
| 	s.wg.Add(1) | ||||
| 	go s.run() | ||||
| 	s.logger.Warnf("任务调度器已成功启动") | ||||
| } | ||||
|  | ||||
| // Stop 优雅地停止调度器 | ||||
| func (s *Scheduler) Stop() { | ||||
| 	s.logger.Warnf("正在停止任务调度器...") | ||||
| 	s.cancel()       // 1. 发出取消信号,停止主循环 | ||||
| 	s.wg.Wait()      // 2. 等待主循环完成 | ||||
| 	s.pool.Release() // 3. 释放 ants 池 (等待所有已提交的任务执行完毕) | ||||
| 	s.logger.Warnf("任务调度器已安全停止") | ||||
| } | ||||
|  | ||||
| // run 是主轮询循环,负责从数据库认领任务并提交到协程池 | ||||
| func (s *Scheduler) run() { | ||||
| 	defer s.wg.Done() | ||||
| 	ticker := time.NewTicker(s.pollingInterval) | ||||
| 	defer ticker.Stop() | ||||
|  | ||||
| 	for { | ||||
| 		select { | ||||
| 		case <-s.ctx.Done(): | ||||
| 			return | ||||
| 		case <-ticker.C: | ||||
| 			go s.claimAndSubmit() | ||||
| 		} | ||||
| 	} | ||||
| } | ||||
|  | ||||
| // claimAndSubmit 实现了最终的“认领-锁定-执行 或 等待-放回”的健壮逻辑 | ||||
| func (s *Scheduler) claimAndSubmit() { | ||||
| 	runningPlanIDs := s.progressTracker.GetRunningPlanIDs() | ||||
|  | ||||
| 	claimedLog, pendingTask, err := s.pendingTaskRepo.ClaimNextAvailableTask(runningPlanIDs) | ||||
| 	if err != nil { | ||||
| 		if !errors.Is(err, gorm.ErrRecordNotFound) { | ||||
| 			s.logger.Errorf("认领任务时发生错误: %v", err) | ||||
| 		} | ||||
| 		// gorm.ErrRecordNotFound 说明没任务要执行 | ||||
| 		return | ||||
| 	} | ||||
|  | ||||
| 	// 尝试获取内存执行锁 | ||||
| 	if s.progressTracker.TryLock(claimedLog.PlanExecutionLogID) { | ||||
| 		// 成功获取锁,正常派发任务 | ||||
| 		err = s.pool.Submit(func() { | ||||
| 			defer s.progressTracker.Unlock(claimedLog.PlanExecutionLogID) | ||||
| 			s.processTask(claimedLog) | ||||
| 		}) | ||||
| 		if err != nil { | ||||
| 			s.logger.Errorf("向协程池提交任务失败: %v", err) | ||||
| 			// 提交失败,必须释放刚刚获取的锁 | ||||
| 			s.progressTracker.Unlock(claimedLog.PlanExecutionLogID) | ||||
| 			// 同样需要将任务安全放回 | ||||
| 			s.handleRequeue(claimedLog.PlanExecutionLogID, pendingTask) | ||||
| 		} | ||||
| 	} else { | ||||
| 		// 获取锁失败,说明有“兄弟”任务正在执行。执行“锁定并安全放回”逻辑。 | ||||
| 		s.handleRequeue(claimedLog.PlanExecutionLogID, pendingTask) | ||||
| 	} | ||||
| } | ||||
|  | ||||
| // handleRequeue 同步地、安全地将一个无法立即执行的任务放回队列。 | ||||
| func (s *Scheduler) handleRequeue(planExecutionLogID uint, taskToRequeue *models.PendingTask) { | ||||
| 	s.logger.Warnf("计划 %d 正在执行,任务 %d (TaskID: %d) 将等待并重新入队...", planExecutionLogID, taskToRequeue.ID, taskToRequeue.TaskID) | ||||
|  | ||||
| 	// 1. 阻塞式地等待,直到可以获取到该计划的锁。 | ||||
| 	s.progressTracker.Lock(planExecutionLogID) | ||||
| 	defer s.progressTracker.Unlock(planExecutionLogID) | ||||
|  | ||||
| 	// 2. 在持有锁的情况下,将任务安全地放回队列。 | ||||
| 	if err := s.pendingTaskRepo.RequeueTask(taskToRequeue); err != nil { | ||||
| 		s.logger.Errorf("[严重] 任务重新入队失败, 原始PendingTaskID: %d, 错误: %v", taskToRequeue.ID, err) | ||||
| 		return | ||||
| 	} | ||||
|  | ||||
| 	s.logger.Warnf("任务 (原始ID: %d) 已成功重新入队,并已释放计划 %d 的锁。", taskToRequeue.ID, planExecutionLogID) | ||||
| } | ||||
|  | ||||
| // processTask 处理单个任务的逻辑 (当前为占位符) | ||||
| func (s *Scheduler) processTask(claimedLog *models.TaskExecutionLog) { | ||||
| 	s.logger.Warnf("开始处理任务, 日志ID: %d, 任务ID: %d, 任务名称: %s", | ||||
| 		claimedLog.ID, claimedLog.TaskID, claimedLog.Task.Name) | ||||
|  | ||||
| 	claimedLog.StartedAt = time.Now() | ||||
| 	claimedLog.Status = models.ExecutionStatusCompleted // 先乐观假定任务成功, 后续失败了再改 | ||||
| 	defer s.updateTaskExecutionLogStatus(claimedLog) | ||||
|  | ||||
| 	// 执行任务 | ||||
| 	err := s.runTask(claimedLog) | ||||
| 	if err != nil { | ||||
| 		claimedLog.Status = models.ExecutionStatusFailed | ||||
| 		claimedLog.Output = err.Error() | ||||
| 		return | ||||
| 	} | ||||
| 	s.logger.Warnf("完成任务, 日志ID: %d", claimedLog.ID) | ||||
|  | ||||
| 	// 任务计数器校验, Plan的任务全部执行完成后需要插入一个新的PlanAnalysisTask用于触发下一次Plan的执行 | ||||
| 	if s.progressTracker.IsPlanOver(claimedLog.PlanExecutionLogID) { | ||||
| 		err = s.createNewAnalysisPlanTask(claimedLog.Task.PlanID) | ||||
| 		if err != nil { | ||||
| 			s.logger.Errorf("[严重] 创建计划分析任务失败, 当前Plan(%v)将无法进行下次触发, 错误: %v", claimedLog.Task.PlanID, err) | ||||
| 		} | ||||
| 	} | ||||
|  | ||||
| } | ||||
|  | ||||
| // runTask 用于执行具体任务 | ||||
| func (s *Scheduler) runTask(claimedLog *models.TaskExecutionLog) error { | ||||
| 	// 这是个特殊任务, 用于解析Plan并将解析出的任务队列添加到待执行队列中 | ||||
| 	if claimedLog.Task.Type == models.TaskPlanAnalysis { | ||||
| 		// 解析plan | ||||
| 		err := s.analysisPlan(claimedLog) | ||||
| 		if err != nil { | ||||
| 			// TODO 这里要处理一下, 比如再插一个新的触发器回去 | ||||
| 			s.logger.Errorf("[严重] 计划解析失败, 日志ID: %d, 错误: %v", claimedLog.ID, err) | ||||
| 			return err | ||||
| 		} | ||||
|  | ||||
| 	} else { | ||||
| 		// 执行普通任务 | ||||
| 		task := s.taskFactory(claimedLog.Task.Type) | ||||
| 		if err := task.ParseParams(s.logger, claimedLog); err != nil { | ||||
|  | ||||
| 			s.logger.Errorf("[严重] 任务参数解析失败, 日志ID: %d, 错误: %v", claimedLog.ID, err) | ||||
| 			return err | ||||
| 		} | ||||
|  | ||||
| 		if err := task.Execute(); err != nil { | ||||
|  | ||||
| 			s.logger.Errorf("[严重] 任务执行失败, 日志ID: %d, 错误: %v", claimedLog.ID, err) | ||||
|  | ||||
| 			task.OnFailure(err) | ||||
| 			return err | ||||
| 		} | ||||
|  | ||||
| 	} | ||||
| 	return nil | ||||
| } | ||||
|  | ||||
| // analysisPlan 解析Plan并将解析出的Task列表插入待执行队列中 | ||||
| func (s *Scheduler) analysisPlan(claimedLog *models.TaskExecutionLog) error { | ||||
| 	// 创建Plan执行记录 | ||||
| 	planLog := &models.PlanExecutionLog{ | ||||
| 		PlanID:    claimedLog.Task.PlanID, | ||||
| 		Status:    models.ExecutionStatusStarted, | ||||
| 		StartedAt: time.Now(), | ||||
| 	} | ||||
| 	if err := s.executionLogRepo.CreatePlanExecutionLog(planLog); err != nil { | ||||
| 		s.logger.Errorf("[严重] 创建计划执行日志失败, 日志ID: %d, 错误: %v", claimedLog.ID, err) | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	// 解析出Task列表 | ||||
| 	tasks, err := s.planRepo.FlattenPlanTasks(claimedLog.Task.PlanID) | ||||
| 	if err != nil { | ||||
| 		s.logger.Errorf("[严重] 解析计划失败, 日志ID: %d, 错误: %v", claimedLog.ID, err) | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	// 写入执行历史 | ||||
| 	taskLogs := make([]*models.TaskExecutionLog, len(tasks)) | ||||
| 	for _, task := range tasks { | ||||
| 		taskLogs = append(taskLogs, &models.TaskExecutionLog{ | ||||
| 			PlanExecutionLogID: planLog.ID, | ||||
| 			TaskID:             task.ID, | ||||
| 			Status:             models.ExecutionStatusWaiting, | ||||
| 		}) | ||||
|  | ||||
| 	} | ||||
| 	err = s.executionLogRepo.CreateTaskExecutionLogsInBatch(taskLogs) | ||||
| 	if err != nil { | ||||
| 		s.logger.Errorf("[严重] 写入执行历史, 日志ID: %d, 错误: %v", claimedLog.ID, err) | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	// 写入待执行队列 | ||||
| 	pendingTasks := make([]*models.PendingTask, len(tasks)) | ||||
| 	for i, task := range tasks { | ||||
| 		pendingTasks = append(pendingTasks, &models.PendingTask{ | ||||
| 			TaskID:             task.ID, | ||||
| 			TaskExecutionLogID: pendingTasks[i].ID, | ||||
|  | ||||
| 			// 待执行队列是通过任务触发时间排序的, 且只要在调度器获取的时间点之前的都可以被触发 | ||||
| 			ExecuteAt: time.Now().Add(time.Duration(i) * time.Second), | ||||
| 		}) | ||||
| 	} | ||||
| 	err = s.pendingTaskRepo.CreatePendingTasksInBatch(pendingTasks) | ||||
| 	if err != nil { | ||||
| 		s.logger.Errorf("[严重] 写入待执行队列, 日志ID: %d, 错误: %v", claimedLog.ID, err) | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	// 将Task列表加入待执行队列中 | ||||
| 	s.progressTracker.AddNewPlan(claimedLog.PlanExecutionLogID, len(tasks)) | ||||
|  | ||||
| 	return nil | ||||
| } | ||||
|  | ||||
| // updateTaskExecutionLogStatus 修改任务历史中的执行状态 | ||||
| func (s *Scheduler) updateTaskExecutionLogStatus(claimedLog *models.TaskExecutionLog) error { | ||||
| 	claimedLog.EndedAt = time.Now() | ||||
|  | ||||
| 	if err := s.executionLogRepo.UpdateTaskExecutionLog(claimedLog); err != nil { | ||||
| 		s.logger.Errorf("[严重] 更新任务执行日志失败, 日志ID: %d, 错误: %v", claimedLog.ID, err) | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	return nil | ||||
| } | ||||
|  | ||||
| // createNewAnalysisPlanTask 创建一个新的Plan解析任务用于下次触发plan执行 | ||||
| func (s *Scheduler) createNewAnalysisPlanTask(planID uint) error { | ||||
| 	// 获取计划信息 | ||||
| 	plan, err := s.planRepo.GetBasicPlanByID(planID) | ||||
| 	if err != nil { | ||||
| 		s.logger.Errorf("[严重] 获取计划失败, 错误: %v", err) | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	// 获取触发任务 | ||||
| 	task, err := s.planRepo.FindPlanAnalysisTaskByParamsPlanID(planID) | ||||
| 	if err != nil { | ||||
| 		s.logger.Errorf("[严重] 获取计划解析任务失败, 错误: %v", err) | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	// 写入执行日志 | ||||
| 	taskLog := &models.TaskExecutionLog{ | ||||
| 		TaskID: task.ID, | ||||
| 		Status: models.ExecutionStatusWaiting, | ||||
| 	} | ||||
| 	if err := s.executionLogRepo.CreateTaskExecutionLogsInBatch([]*models.TaskExecutionLog{taskLog}); err != nil { | ||||
| 		s.logger.Errorf("[严重] 创建任务执行日志失败, 错误: %v", err) | ||||
| 		return err | ||||
| 	} | ||||
|  | ||||
| 	// 写入待执行队列 | ||||
| 	next, err := utils.GetNextCronTime(plan.CronExpression) | ||||
| 	if err != nil { | ||||
| 		s.logger.Errorf("[严重] 执行时间解析失败, 错误: %v", err) | ||||
| 		return err | ||||
| 	} | ||||
| 	pendingTask := &models.PendingTask{ | ||||
| 		TaskID:             task.ID, | ||||
| 		ExecuteAt:          next, | ||||
| 		TaskExecutionLogID: taskLog.ID, | ||||
| 	} | ||||
| 	err = s.pendingTaskRepo.CreatePendingTasksInBatch([]*models.PendingTask{pendingTask}) | ||||
| 	if err != nil { | ||||
| 		s.logger.Errorf("[严重] 创建待执行任务失败, 错误: %v", err) | ||||
| 		return err | ||||
| 	} | ||||
| 	return nil | ||||
| } | ||||
| @@ -1,23 +0,0 @@ | ||||
| package task | ||||
|  | ||||
| import ( | ||||
| 	"git.huangwc.com/pig/pig-farm-controller/internal/infra/logs" | ||||
| 	"git.huangwc.com/pig/pig-farm-controller/internal/infra/models" | ||||
| ) | ||||
|  | ||||
| // Task 定义了所有可被调度器执行的任务必须实现的接口。 | ||||
| type Task interface { | ||||
| 	// Execute 是任务的核心执行逻辑。 | ||||
| 	// ctx: 用于控制任务的超时或取消。 | ||||
| 	// log: 包含了当前任务执行的完整上下文信息,包括从数据库中加载的任务参数等。 | ||||
| 	// 返回的 error 表示任务是否执行成功。调度器会根据返回的 error 是否为 nil 来决定任务状态。 | ||||
| 	Execute() error | ||||
|  | ||||
| 	// ParseParams 解析及校验参数 | ||||
| 	ParseParams(logger *logs.Logger, claimedLog *models.TaskExecutionLog) error | ||||
|  | ||||
| 	// OnFailure 定义了当 Execute 方法返回错误时,需要执行的回滚或清理逻辑。 | ||||
| 	// log: 任务执行的上下文。 | ||||
| 	// executeErr: 从 Execute 方法返回的原始错误。 | ||||
| 	OnFailure(executeErr error) | ||||
| } | ||||
		Reference in New Issue
	
	Block a user