status
stringclasses
1 value
repo_name
stringclasses
31 values
repo_url
stringclasses
31 values
issue_id
int64
1
104k
title
stringlengths
4
233
body
stringlengths
0
186k
issue_url
stringlengths
38
56
pull_url
stringlengths
37
54
before_fix_sha
stringlengths
40
40
after_fix_sha
stringlengths
40
40
report_datetime
timestamp[us, tz=UTC]
language
stringclasses
5 values
commit_datetime
timestamp[us, tz=UTC]
updated_file
stringlengths
7
188
chunk_content
stringlengths
1
1.03M
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,238
[Bug] [Master] Cannot recover from failed tasks when force success task
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when the task failed, if I force success the failed task, and then recovery the workflow instance, the master will go into dead loop. This is caused it cannot find the failed tasks. ### What you expected to happen The workflow instance can go into success. ### How to reproduce 1. Create a workflow with one task. 2. The task execute failed. 3. Force success the taskinstance. 4. Recovery the workflow instance. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11238
https://github.com/apache/dolphinscheduler/pull/11239
caa6287d7fb9d73e18cdad2850f1ec08e602ad38
04f3aa97135d79469daf7c21c935029faff827b2
2022-08-01T11:48:04Z
java
2022-08-02T01:30:18Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
/** * remove task from stand by lst * * @param taskInstance task nstance */ prvate boolean removeTaskFromStandbyLst(TaskInstance taskInstance) { return readyToSubmtTaskQueue.remove(taskInstance); } /** * has retry task n standby * * @return Boolean whether has retry task n standby */ prvate boolean hasRetryTaskInStandBy() { for (Iterator<TaskInstance> ter = readyToSubmtTaskQueue.terator(); ter.hasNext(); ) { f (ter.next().getState().typeIsFalure()) { return true; } } return false; } /** * close the on gong tasks */ publc vod kllAllTasks() { logger.nfo("kll called on process nstance d: {}, num: {}", processInstance.getId(), actveTaskProcessorMaps.sze()); f (readyToSubmtTaskQueue.sze() > 0) { readyToSubmtTaskQueue.clear();
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,238
[Bug] [Master] Cannot recover from failed tasks when force success task
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when the task failed, if I force success the failed task, and then recovery the workflow instance, the master will go into dead loop. This is caused it cannot find the failed tasks. ### What you expected to happen The workflow instance can go into success. ### How to reproduce 1. Create a workflow with one task. 2. The task execute failed. 3. Force success the taskinstance. 4. Recovery the workflow instance. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11238
https://github.com/apache/dolphinscheduler/pull/11239
caa6287d7fb9d73e18cdad2850f1ec08e602ad38
04f3aa97135d79469daf7c21c935029faff827b2
2022-08-01T11:48:04Z
java
2022-08-02T01:30:18Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
} for (long taskCode : actveTaskProcessorMaps.keySet()) { ITaskProcessor taskProcessor = actveTaskProcessorMaps.get(taskCode); Integer taskInstanceId = valdTaskMap.get(taskCode); f (taskInstanceId == null || taskInstanceId.equals(0)) { contnue; } TaskInstance taskInstance = processServce.fndTaskInstanceById(taskInstanceId); f (taskInstance == null || taskInstance.getState().typeIsFnshed()) { contnue; } taskProcessor.acton(TaskActon.STOP); f (taskProcessor.taskInstance().getState().typeIsFnshed()) { StateEvent stateEvent = new StateEvent(); stateEvent.setType(StateEventType.TASK_STATE_CHANGE); stateEvent.setProcessInstanceId(ths.processInstance.getId()); stateEvent.setTaskInstanceId(taskInstance.getId()); stateEvent.setExecutonStatus(taskProcessor.taskInstance().getState()); ths.addStateEvent(stateEvent); } } } publc boolean workFlowFnsh() { return ths.processInstance.getState().typeIsFnshed(); } /** * handlng the lst of tasks to be submtted */ publc vod submtStandByTask() throws StateEventHandleExcepton { nt length = readyToSubmtTaskQueue.sze();
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,238
[Bug] [Master] Cannot recover from failed tasks when force success task
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when the task failed, if I force success the failed task, and then recovery the workflow instance, the master will go into dead loop. This is caused it cannot find the failed tasks. ### What you expected to happen The workflow instance can go into success. ### How to reproduce 1. Create a workflow with one task. 2. The task execute failed. 3. Force success the taskinstance. 4. Recovery the workflow instance. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11238
https://github.com/apache/dolphinscheduler/pull/11239
caa6287d7fb9d73e18cdad2850f1ec08e602ad38
04f3aa97135d79469daf7c21c935029faff827b2
2022-08-01T11:48:04Z
java
2022-08-02T01:30:18Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
for (nt = 0; < length; ++) { TaskInstance task = readyToSubmtTaskQueue.peek(); f (task == null) { contnue; } // stop ta f (task.taskCanRetry()) { TaskInstance retryTask = processServce.fndTaskInstanceById(task.getId()); f (retryTask != null && retryTask.getState().equals(ExecutonStatus.FORCED_SUCCESS)) { task.setState(retryTask.getState()); logger.nfo("task: {} has been forced success, put t nto complete task lst and stop retryng", task.getName()); removeTaskFromStandbyLst(task); completeTaskMap.put(task.getTaskCode(), task.getId()); taskInstanceMap.put(task.getId(), task); submtPostNode(Long.toStrng(task.getTaskCode())); contnue; } } //nt var f (task.sFrstRun()) { //get pre Set<Strng> preTask = dag.getPrevousNodes(Long.toStrng(task.getTaskCode())); getPreVarPool(task, preTask); } DependResult dependResult = getDependResultForTask(task); f (DependResult.SUCCESS == dependResult) { Optonal<TaskInstance> taskInstanceOptonal = submtTaskExec(task); f (!taskInstanceOptonal.sPresent()) { ths.taskFaledSubmt = true; // Remove
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,238
[Bug] [Master] Cannot recover from failed tasks when force success task
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when the task failed, if I force success the failed task, and then recovery the workflow instance, the master will go into dead loop. This is caused it cannot find the failed tasks. ### What you expected to happen The workflow instance can go into success. ### How to reproduce 1. Create a workflow with one task. 2. The task execute failed. 3. Force success the taskinstance. 4. Recovery the workflow instance. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11238
https://github.com/apache/dolphinscheduler/pull/11239
caa6287d7fb9d73e18cdad2850f1ec08e602ad38
04f3aa97135d79469daf7c21c935029faff827b2
2022-08-01T11:48:04Z
java
2022-08-02T01:30:18Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
f (!removeTaskFromStandbyLst(task)) { logger.error( "Task submt faled, remove from standby lst faled, workflowInstanceId: {}, taskCode: {}", processInstance.getId(), task.getTaskCode()); } completeTaskMap.put(task.getTaskCode(), task.getId()); taskInstanceMap.put(task.getId(), task); errorTaskMap.put(task.getTaskCode(), task.getId()); actveTaskProcessorMaps.remove(task.getTaskCode()); logger.error("Task submtted faled, workflowInstanceId: {}, taskInstanceId: {}, taskCode: {}", task.getProcessInstanceId(), task.getId(), task.getTaskCode()); } else { removeTaskFromStandbyLst(task); } } else f (DependResult.FAILED == dependResult) { // f the dependFaledTaskMap.put(task.getTaskCode(), task.getId()); removeTaskFromStandbyLst(task); logger.nfo("Task dependent result s faled, taskInstanceId:{} depend result : {}", task.getId(), dependResult); } else f (DependResult.NON_EXEC == dependResult) { // for som removeTaskFromStandbyLst(task); logger.nfo("Remove task due to depend result not executed, taskInstanceId:{} depend result : {}", task.getId(), dependResult); } } } /**
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,238
[Bug] [Master] Cannot recover from failed tasks when force success task
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when the task failed, if I force success the failed task, and then recovery the workflow instance, the master will go into dead loop. This is caused it cannot find the failed tasks. ### What you expected to happen The workflow instance can go into success. ### How to reproduce 1. Create a workflow with one task. 2. The task execute failed. 3. Force success the taskinstance. 4. Recovery the workflow instance. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11238
https://github.com/apache/dolphinscheduler/pull/11239
caa6287d7fb9d73e18cdad2850f1ec08e602ad38
04f3aa97135d79469daf7c21c935029faff827b2
2022-08-01T11:48:04Z
java
2022-08-02T01:30:18Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
* Get start task nstance lst from recover * * @param cmdParam command param * @return task nstance lst */ protected Lst<TaskInstance> getRecoverTaskInstanceLst(Strng cmdParam) { Map<Strng, Strng> paramMap = JSONUtls.toMap(cmdParam); // todo: Can we use a better way to set the recover taskInstanceId lst? rather then use the cmdParam f (paramMap != null && paramMap.contansKey(CMD_PARAM_RECOVERY_START_NODE_STRING)) { Strng[] dLst = paramMap.get(CMD_PARAM_RECOVERY_START_NODE_STRING).splt(Constants.COMMA); f (ArrayUtls.sNotEmpty(dLst)) { Lst<Integer> taskInstanceIds = Arrays.stream(dLst).map(Integer::valueOf).collect(Collectors.toLst()); return processServce.fndTaskInstanceByIdLst(taskInstanceIds); } } return Collectons.emptyLst(); } /** * parse "StartNodeNameLst" from cmd param * * @param cmdParam command param * @return start node name lst */ prvate Lst<Strng> parseStartNodeName(Strng cmdParam) { Lst<Strng> startNodeNameLst = new ArrayLst<>(); Map<Strng, Strng> paramMap = JSONUtls.toMap(cmdParam); f (paramMap == null) { return startNodeNameLst; } f (paramMap.contansKey(CMD_PARAM_START_NODES)) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,238
[Bug] [Master] Cannot recover from failed tasks when force success task
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when the task failed, if I force success the failed task, and then recovery the workflow instance, the master will go into dead loop. This is caused it cannot find the failed tasks. ### What you expected to happen The workflow instance can go into success. ### How to reproduce 1. Create a workflow with one task. 2. The task execute failed. 3. Force success the taskinstance. 4. Recovery the workflow instance. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11238
https://github.com/apache/dolphinscheduler/pull/11239
caa6287d7fb9d73e18cdad2850f1ec08e602ad38
04f3aa97135d79469daf7c21c935029faff827b2
2022-08-01T11:48:04Z
java
2022-08-02T01:30:18Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
startNodeNameLst = Arrays.asLst(paramMap.get(CMD_PARAM_START_NODES).splt(Constants.COMMA)); } return startNodeNameLst; } /** * generate start node code lst from parsng command param; * f "StartNodeIdLst" exsts n command param, return StartNodeIdLst * * @return recovery node code lst */ prvate Lst<Strng> getRecoveryNodeCodeLst(Lst<TaskInstance> recoverNodeLst) { Lst<Strng> recoveryNodeCodeLst = new ArrayLst<>(); f (CollectonUtls.sNotEmpty(recoverNodeLst)) { for (TaskInstance task : recoverNodeLst) { recoveryNodeCodeLst.add(Long.toStrng(task.getTaskCode())); } } return recoveryNodeCodeLst; } /** * generate flow dag * * @param totalTaskNodeLst total task node lst * @param startNodeNameLst start node name lst * @param recoveryNodeCodeLst recovery node code lst * @param depNodeType depend node type * @return ProcessDag process dag * @throws Excepton excepton */ publc ProcessDag generateFlowDag(Lst<TaskNode> totalTaskNodeLst,
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,238
[Bug] [Master] Cannot recover from failed tasks when force success task
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when the task failed, if I force success the failed task, and then recovery the workflow instance, the master will go into dead loop. This is caused it cannot find the failed tasks. ### What you expected to happen The workflow instance can go into success. ### How to reproduce 1. Create a workflow with one task. 2. The task execute failed. 3. Force success the taskinstance. 4. Recovery the workflow instance. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11238
https://github.com/apache/dolphinscheduler/pull/11239
caa6287d7fb9d73e18cdad2850f1ec08e602ad38
04f3aa97135d79469daf7c21c935029faff827b2
2022-08-01T11:48:04Z
java
2022-08-02T01:30:18Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
Lst<Strng> startNodeNameLst, Lst<Strng> recoveryNodeCodeLst, TaskDependType depNodeType) throws Excepton { return DagHelper.generateFlowDag(totalTaskNodeLst, startNodeNameLst, recoveryNodeCodeLst, depNodeType); } /** * check task queue */ prvate boolean checkTaskQueue() { AtomcBoolean result = new AtomcBoolean(false); taskInstanceMap.forEach((d, taskInstance) -> { f (taskInstance != null && taskInstance.getTaskGroupId() > 0) { result.set(true); } }); return result.get(); } /** * s new process nstance */ prvate boolean sNewProcessInstance() { f (Flag.YES.equals(processInstance.getRecovery())) { logger.nfo("Ths workInstance wll be recover by ths executon"); return false; } f (ExecutonStatus.RUNNING_EXECUTION == processInstance.getState() && processInstance.getRunTmes() == 1) { return true; } logger.nfo( "The workflowInstance has been executed before, ths executon s to reRun, processInstance status: {}, runTmes: {}",
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,238
[Bug] [Master] Cannot recover from failed tasks when force success task
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when the task failed, if I force success the failed task, and then recovery the workflow instance, the master will go into dead loop. This is caused it cannot find the failed tasks. ### What you expected to happen The workflow instance can go into success. ### How to reproduce 1. Create a workflow with one task. 2. The task execute failed. 3. Force success the taskinstance. 4. Recovery the workflow instance. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11238
https://github.com/apache/dolphinscheduler/pull/11239
caa6287d7fb9d73e18cdad2850f1ec08e602ad38
04f3aa97135d79469daf7c21c935029faff827b2
2022-08-01T11:48:04Z
java
2022-08-02T01:30:18Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
processInstance.getState(), processInstance.getRunTmes()); return false; } publc vod resubmt(long taskCode) throws Excepton { ITaskProcessor taskProcessor = actveTaskProcessorMaps.get(taskCode); f (taskProcessor != null) { taskProcessor.acton(TaskActon.RESUBMIT); logger.debug("RESUBMIT: task code:{}", taskCode); } else { throw new Excepton("resubmt error, taskProcessor s null, task code: " + taskCode); } } publc Map<Long, Integer> getCompleteTaskMap() { return completeTaskMap; } publc Map<Long, ITaskProcessor> getActveTaskProcessMap() { return actveTaskProcessorMaps; } publc Map<Long, TaskInstance> getWatToRetryTaskInstanceMap() { return watToRetryTaskInstanceMap; } prvate vod setGlobalParamIfCommanded(ProcessDefnton processDefnton, Map<Strng, Strng> cmdParam) { // get start params from command param Map<Strng, Strng> startParamMap = new HashMap<>(); f (cmdParam.contansKey(Constants.CMD_PARAM_START_PARAMS)) { Strng startParamJson = cmdParam.get(Constants.CMD_PARAM_START_PARAMS); startParamMap = JSONUtls.toMap(startParamJson); } Map<Strng, Strng> fatherParamMap = new HashMap<>();
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,238
[Bug] [Master] Cannot recover from failed tasks when force success task
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when the task failed, if I force success the failed task, and then recovery the workflow instance, the master will go into dead loop. This is caused it cannot find the failed tasks. ### What you expected to happen The workflow instance can go into success. ### How to reproduce 1. Create a workflow with one task. 2. The task execute failed. 3. Force success the taskinstance. 4. Recovery the workflow instance. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11238
https://github.com/apache/dolphinscheduler/pull/11239
caa6287d7fb9d73e18cdad2850f1ec08e602ad38
04f3aa97135d79469daf7c21c935029faff827b2
2022-08-01T11:48:04Z
java
2022-08-02T01:30:18Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
f (cmdParam.contansKey(Constants.CMD_PARAM_FATHER_PARAMS)) { Strng fatherParamJson = cmdParam.get(Constants.CMD_PARAM_FATHER_PARAMS); fatherParamMap = JSONUtls.toMap(fatherParamJson); } startParamMap.putAll(fatherParamMap); // set start param nto global params Map<Strng, Strng> globalMap = processDefnton.getGlobalParamMap(); Lst<Property> globalParamLst = processDefnton.getGlobalParamLst(); f (startParamMap.sze() > 0 && globalMap != null) { //start pa for (Map.Entry<Strng, Strng> param : globalMap.entrySet()) { Strng val = startParamMap.get(param.getKey()); f (val != null) { param.setValue(val); } } //start pa for (Map.Entry<Strng, Strng> startParam : startParamMap.entrySet()) { f (!globalMap.contansKey(startParam.getKey())) { globalMap.put(startParam.getKey(), startParam.getValue()); globalParamLst.add(new Property(startParam.getKey(), IN, VARCHAR, startParam.getValue())); } } } } prvate enum WorkflowRunnableStatus { CREATED, INITIALIZE_DAG, INITIALIZE_QUEUE, STARTED, ; } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-alert/dolphinscheduler-alert-server/src/main/java/org/apache/dolphinscheduler/alert/AlertSenderService.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.alert;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-alert/dolphinscheduler-alert-server/src/main/java/org/apache/dolphinscheduler/alert/AlertSenderService.java
import org.apache.dolphinscheduler.alert.api.AlertChannel; import org.apache.dolphinscheduler.alert.api.AlertConstants; import org.apache.dolphinscheduler.alert.api.AlertData; import org.apache.dolphinscheduler.alert.api.AlertInfo; import org.apache.dolphinscheduler.alert.api.AlertResult; import org.apache.dolphinscheduler.common.Constants; import org.apache.dolphinscheduler.common.enums.AlertStatus; import org.apache.dolphinscheduler.common.enums.AlertType; import org.apache.dolphinscheduler.common.enums.WarningType; import org.apache.dolphinscheduler.common.thread.Stopper; import org.apache.dolphinscheduler.common.thread.ThreadUtils; import org.apache.dolphinscheduler.common.utils.JSONUtils; import org.apache.dolphinscheduler.dao.AlertDao; import org.apache.dolphinscheduler.dao.entity.Alert; import org.apache.dolphinscheduler.dao.entity.AlertPluginInstance; import org.apache.dolphinscheduler.remote.command.alert.AlertSendResponseCommand; import org.apache.dolphinscheduler.remote.command.alert.AlertSendResponseResult; import org.apache.commons.collections.CollectionUtils; import java.util.ArrayList; import java.util.List; import java.util.Map; import java.util.Optional; import java.util.concurrent.CompletableFuture; import java.util.concurrent.TimeUnit; import javax.annotation.Nullable; import org.slf4j.Logger; import org.slf4j.LoggerFactory; import org.springframework.stereotype.Service; import com.google.common.collect.Lists; @Service
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-alert/dolphinscheduler-alert-server/src/main/java/org/apache/dolphinscheduler/alert/AlertSenderService.java
public final class AlertSenderService extends Thread { private static final Logger logger = LoggerFactory.getLogger(AlertSenderService.class); private final AlertDao alertDao; private final AlertPluginManager alertPluginManager; private final AlertConfig alertConfig; public AlertSenderService(AlertDao alertDao, AlertPluginManager alertPluginManager, AlertConfig alertConfig) { this.alertDao = alertDao; this.alertPluginManager = alertPluginManager; this.alertConfig = alertConfig; } @Override public synchronized void start() { super.setName("AlertSenderService"); super.start(); } @Override public void run() { logger.info("alert sender started");
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-alert/dolphinscheduler-alert-server/src/main/java/org/apache/dolphinscheduler/alert/AlertSenderService.java
while (Stopper.isRunning()) { try { List<Alert> alerts = alertDao.listPendingAlerts(); this.send(alerts); ThreadUtils.sleep(Constants.SLEEP_TIME_MILLIS * 5L); } catch (Exception e) { logger.error("alert sender thread error", e); } } } public void send(List<Alert> alerts) { for (Alert alert : alerts) { int alertId = Optional.ofNullable(alert.getId()).orElse(0); int alertGroupId = Optional.ofNullable(alert.getAlertGroupId()).orElse(0); List<AlertPluginInstance> alertInstanceList = alertDao.listInstanceByAlertGroupId(alertGroupId); if (CollectionUtils.isEmpty(alertInstanceList)) { logger.error("send alert msg fail,no bind plugin instance."); List<AlertResult> alertResults = Lists.newArrayList(new AlertResult("false", "no bind plugin instance")); alertDao.updateAlert(AlertStatus.EXECUTION_FAILURE, JSONUtils.toJsonString(alertResults), alertId); continue; } AlertData alertData = AlertData.builder() .id(alertId) .content(alert.getContent()) .log(alert.getLog()) .title(alert.getTitle()) .warnType(alert.getWarningType().getCode()) .alertType(alert.getAlertType().getCode())
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-alert/dolphinscheduler-alert-server/src/main/java/org/apache/dolphinscheduler/alert/AlertSenderService.java
.build(); int sendSuccessCount = 0; List<AlertResult> alertResults = new ArrayList<>(); for (AlertPluginInstance instance : alertInstanceList) { AlertResult alertResult = this.alertResultHandler(instance, alertData); if (alertResult != null) { AlertStatus sendStatus = Boolean.parseBoolean(String.valueOf(alertResult.getStatus())) ? AlertStatus.EXECUTION_SUCCESS : AlertStatus.EXECUTION_FAILURE; alertDao.addAlertSendStatus(sendStatus, JSONUtils.toJsonString(alertResult), alertId, instance.getId()); if (sendStatus.equals(AlertStatus.EXECUTION_SUCCESS)) { sendSuccessCount++; } alertResults.add(alertResult); } } AlertStatus alertStatus = AlertStatus.EXECUTION_SUCCESS; if (sendSuccessCount == 0) { alertStatus = AlertStatus.EXECUTION_FAILURE; } else if (sendSuccessCount < alertInstanceList.size()) { alertStatus = AlertStatus.EXECUTION_PARTIAL_SUCCESS; } alertDao.updateAlert(alertStatus, JSONUtils.toJsonString(alertResults), alertId); } } /** * sync send alert handler * * @param alertGroupId alertGroupId * @param title title * @param content content * @return AlertSendResponseCommand
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-alert/dolphinscheduler-alert-server/src/main/java/org/apache/dolphinscheduler/alert/AlertSenderService.java
*/ public AlertSendResponseCommand syncHandler(int alertGroupId, String title, String content, int warnType) { List<AlertPluginInstance> alertInstanceList = alertDao.listInstanceByAlertGroupId(alertGroupId); AlertData alertData = AlertData.builder() .content(content) .title(title) .warnType(warnType) .build(); boolean sendResponseStatus = true; List<AlertSendResponseResult> sendResponseResults = new ArrayList<>(); if (CollectionUtils.isEmpty(alertInstanceList)) { AlertSendResponseResult alertSendResponseResult = new AlertSendResponseResult(); String message = String.format("Alert GroupId %s send error : not found alert instance", alertGroupId); alertSendResponseResult.setStatus(false); alertSendResponseResult.setMessage(message); sendResponseResults.add(alertSendResponseResult); logger.error("Alert GroupId {} send error : not found alert instance", alertGroupId); return new AlertSendResponseCommand(false, sendResponseResults); } for (AlertPluginInstance instance : alertInstanceList) { AlertResult alertResult = this.alertResultHandler(instance, alertData); if (alertResult != null) { AlertSendResponseResult alertSendResponseResult = new AlertSendResponseResult( Boolean.parseBoolean(String.valueOf(alertResult.getStatus())), alertResult.getMessage()); sendResponseStatus = sendResponseStatus && alertSendResponseResult.getStatus(); sendResponseResults.add(alertSendResponseResult); } } return new AlertSendResponseCommand(sendResponseStatus, sendResponseResults); }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-alert/dolphinscheduler-alert-server/src/main/java/org/apache/dolphinscheduler/alert/AlertSenderService.java
/** * alert result handler * * @param instance instance * @param alertData alertData * @return AlertResult */ private @Nullable AlertResult alertResultHandler(AlertPluginInstance instance, AlertData alertData) { String pluginInstanceName = instance.getInstanceName(); int pluginDefineId = instance.getPluginDefineId(); Optional<AlertChannel> alertChannelOptional = alertPluginManager.getAlertChannel(instance.getPluginDefineId()); if (!alertChannelOptional.isPresent()) { String message = String.format("Alert Plugin %s send error: the channel doesn't exist, pluginDefineId: %s", pluginInstanceName, pluginDefineId); logger.error("Alert Plugin {} send error : not found plugin {}", pluginInstanceName, pluginDefineId); return new AlertResult("false", message); } AlertChannel alertChannel = alertChannelOptional.get(); Map<String, String> paramsMap = JSONUtils.toMap(instance.getPluginInstanceParams()); String instanceWarnType = WarningType.ALL.getDescp(); if (paramsMap != null) { instanceWarnType = paramsMap.getOrDefault(AlertConstants.NAME_WARNING_TYPE, WarningType.ALL.getDescp()); } WarningType warningType = WarningType.of(instanceWarnType); if (warningType == null) { String message = String.format("Alert Plugin %s send error : plugin warnType is null", pluginInstanceName); logger.error("Alert Plugin {} send error : plugin warnType is null", pluginInstanceName); return new AlertResult("false", message); }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-alert/dolphinscheduler-alert-server/src/main/java/org/apache/dolphinscheduler/alert/AlertSenderService.java
boolean sendWarning = false; switch (warningType) { case ALL: sendWarning = true; break; case SUCCESS: if (alertData.getWarnType() == WarningType.SUCCESS.getCode()) { sendWarning = true; } break; case FAILURE: if (alertData.getWarnType() == WarningType.FAILURE.getCode()) { sendWarning = true; } break; default: } if (!sendWarning) { logger.info("Alert Plugin {} send ignore warning type not match: plugin warning type is {}, alert data warning type is {}", pluginInstanceName, warningType.getCode(), alertData.getWarnType()); return null; } AlertInfo alertInfo = AlertInfo.builder() .alertData(alertData) .alertParams(paramsMap) .alertPluginInstanceId(instance.getId()) .build(); int waitTimeout = alertConfig.getWaitTimeout(); try { AlertResult alertResult;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-alert/dolphinscheduler-alert-server/src/main/java/org/apache/dolphinscheduler/alert/AlertSenderService.java
if (waitTimeout <= 0) { if (alertData.getAlertType() == AlertType.CLOSE_ALERT.getCode()) { alertResult = alertChannel.closeAlert(alertInfo); } else { alertResult = alertChannel.process(alertInfo); } } else { CompletableFuture<AlertResult> future; if (alertData.getAlertType() == AlertType.CLOSE_ALERT.getCode()) { future = CompletableFuture.supplyAsync(() -> alertChannel.closeAlert(alertInfo)); } else { future = CompletableFuture.supplyAsync(() -> alertChannel.process(alertInfo)); } alertResult = future.get(waitTimeout, TimeUnit.MILLISECONDS); } if (alertResult == null) { throw new RuntimeException("Alert result cannot be null"); } return alertResult; } catch (InterruptedException e) { logger.error("send alert error alert data id :{},", alertData.getId(), e); Thread.currentThread().interrupt(); return new AlertResult("false", e.getMessage()); } catch (Exception e) { logger.error("send alert error alert data id :{},", alertData.getId(), e); return new AlertResult("false", e.getMessage()); } } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/metrics/MasterServerMetrics.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.server.master.metrics; import io.micrometer.core.instrument.Counter; import io.micrometer.core.instrument.Metrics; public final class MasterServerMetrics {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/metrics/MasterServerMetrics.java
private MasterServerMetrics() { throw new UnsupportedOperationException("Utility class"); } /** * Used to measure the master server is overload. */ private static final Counter MASTER_OVERLOAD_COUNTER = Counter.builder("ds.master.overload.count") .description("Master server overload count") .register(Metrics.globalRegistry); /** * Used to measure the number of process command consumed by master. */ private static final Counter MASTER_CONSUME_COMMAND_COUNTER = Counter.builder("ds.master.consume.command.count") .description("Master server consume command count") .register(Metrics.globalRegistry); public static void incMasterOverload() { MASTER_OVERLOAD_COUNTER.increment(); } public static void incMasterConsumeCommand(int commandCount) { MASTER_CONSUME_COMMAND_COUNTER.increment(commandCount); } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/metrics/ProcessInstanceMetrics.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.server.master.metrics; import java.util.HashMap; import java.util.Map; import java.util.Set; import java.util.concurrent.TimeUnit; import java.util.function.Supplier; import com.google.common.collect.ImmutableSet; import io.micrometer.core.instrument.Counter; import io.micrometer.core.instrument.Gauge; import io.micrometer.core.instrument.Metrics; import io.micrometer.core.instrument.Timer; public final class ProcessInstanceMetrics {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/metrics/ProcessInstanceMetrics.java
private ProcessInstanceMetrics() { throw new UnsupportedOperationException("Utility class"); } private static Map<String, Counter> PROCESS_INSTANCE_COUNTERS = new HashMap<>(); private static final Set<String> PROCESS_INSTANCE_STATES = ImmutableSet.of( "submit", "timeout", "finish", "failover", "success", "fail", "stop"); static { for (final String state : PROCESS_INSTANCE_STATES) { PROCESS_INSTANCE_COUNTERS.put( state, Counter.builder("ds.workflow.instance.count") .tag("state", state) .description(String.format("Process instance %s total count", state)) .register(Metrics.globalRegistry) ); }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/metrics/ProcessInstanceMetrics.java
} private static final Timer COMMAND_QUERY_TIMETER = Timer.builder("ds.workflow.command.query.duration") .description("Command query duration") .register(Metrics.globalRegistry); private static final Timer PROCESS_INSTANCE_GENERATE_TIMER = Timer.builder("ds.workflow.instance.generate.duration") .description("Process instance generated duration") .register(Metrics.globalRegistry); public static void recordCommandQueryTime(long milliseconds) { COMMAND_QUERY_TIMETER.record(milliseconds, TimeUnit.MILLISECONDS); } public static void recordProcessInstanceGenerateTime(long milliseconds) { PROCESS_INSTANCE_GENERATE_TIMER.record(milliseconds, TimeUnit.MILLISECONDS); } public static synchronized void registerProcessInstanceRunningGauge(Supplier<Number> function) { Gauge.builder("ds.workflow.instance.running", function) .description("The current running process instance count") .register(Metrics.globalRegistry); } public static synchronized void registerProcessInstanceResubmitGauge(Supplier<Number> function) { Gauge.builder("ds.workflow.instance.resubmit", function) .description("The current process instance need to resubmit count") .register(Metrics.globalRegistry); } public static void incProcessInstanceByState(final String state) { PROCESS_INSTANCE_COUNTERS.get(state).increment(); } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/metrics/TaskMetrics.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.server.master.metrics; import java.util.HashMap; import java.util.Map; import java.util.Set; import java.util.function.Supplier; import com.facebook.presto.jdbc.internal.guava.collect.ImmutableSet; import io.micrometer.core.instrument.Counter; import io.micrometer.core.instrument.Gauge; import io.micrometer.core.instrument.Metrics; public final class TaskMetrics {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/metrics/TaskMetrics.java
private TaskMetrics() { throw new UnsupportedOperationException("Utility class"); } private static Map<String, Counter> TASK_INSTANCE_COUNTERS = new HashMap<>(); private static final Set<String> TASK_INSTANCE_STATES = ImmutableSet.of( "submit", "timeout", "finish", "failover", "retry", "dispatch", "success", "fail", "stop"); static { for (final String state : TASK_INSTANCE_STATES) { TASK_INSTANCE_COUNTERS.put( state, Counter.builder("ds.task.instance.count") .tags("state", state) .description(String.format("Process instance %s total count", state)) .register(Metrics.globalRegistry) ); } } private static final Counter TASK_DISPATCH_COUNTER =
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/metrics/TaskMetrics.java
Counter.builder("ds.task.dispatch.count") .description("Task dispatch count") .register(Metrics.globalRegistry); private static final Counter TASK_DISPATCHER_FAILED = Counter.builder("ds.task.dispatch.failure.count") .description("Task dispatch failures count, retried ones included") .register(Metrics.globalRegistry); private static final Counter TASK_DISPATCH_ERROR = Counter.builder("ds.task.dispatch.error.count") .description("Number of errors during task dispatch") .register(Metrics.globalRegistry); public synchronized static void registerTaskPrepared(Supplier<Number> consumer) { Gauge.builder("ds.task.prepared", consumer) .description("Task prepared count") .register(Metrics.globalRegistry); } public static void incTaskDispatchFailed(int failedCount) { TASK_DISPATCHER_FAILED.increment(failedCount); } public static void incTaskDispatchError() { TASK_DISPATCH_ERROR.increment(); } public static void incTaskDispatch() { TASK_DISPATCH_COUNTER.increment(); } public static void incTaskInstanceByState(final String state) { TASK_INSTANCE_COUNTERS.get(state).increment(); } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-worker/src/main/java/org/apache/dolphinscheduler/server/worker/metrics/TaskMetrics.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.server.worker.metrics; import org.apache.dolphinscheduler.plugin.task.api.TaskChannelFactory; import java.util.HashMap; import java.util.Map; import java.util.ServiceLoader; import io.micrometer.core.instrument.Counter; import io.micrometer.core.instrument.Metrics; public final class TaskMetrics {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-worker/src/main/java/org/apache/dolphinscheduler/server/worker/metrics/TaskMetrics.java
private TaskMetrics() { throw new UnsupportedOperationException("Utility class"); } private static Map<String, Counter> TASK_TYPE_EXECUTE_COUNTER = new HashMap<>(); private static final Counter UNKNOWN_TASK_EXECUTE_COUNTER = Counter.builder("ds.task.execution.count.by.type") .tag("task_type", "unknown") .description("task execution counter by type") .register(Metrics.globalRegistry); static { for (TaskChannelFactory taskChannelFactory : ServiceLoader.load(TaskChannelFactory.class)) { TASK_TYPE_EXECUTE_COUNTER.put( taskChannelFactory.getName(), Counter.builder("ds.task.execution.count.by.type") .tag("task_type", taskChannelFactory.getName()) .description("task execution counter by type") .register(Metrics.globalRegistry) ); } } public static void incrTaskTypeExecuteCount(String taskType) { TASK_TYPE_EXECUTE_COUNTER.getOrDefault(taskType, UNKNOWN_TASK_EXECUTE_COUNTER).increment(); } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-worker/src/main/java/org/apache/dolphinscheduler/server/worker/metrics/WorkerServerMetrics.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.server.worker.metrics; import java.util.concurrent.TimeUnit; import java.util.function.Supplier; import io.micrometer.core.instrument.Counter; import io.micrometer.core.instrument.DistributionSummary; import io.micrometer.core.instrument.Gauge; import io.micrometer.core.instrument.Metrics; import io.micrometer.core.instrument.Timer; import lombok.experimental.UtilityClass; @UtilityClass
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-worker/src/main/java/org/apache/dolphinscheduler/server/worker/metrics/WorkerServerMetrics.java
public class WorkerServerMetrics { private static final Counter WORKER_OVERLOAD_COUNTER = Counter.builder("ds.worker.overload.count") .description("overloaded workers count") .register(Metrics.globalRegistry); private static final Counter WORKER_SUBMIT_QUEUE_IS_FULL_COUNTER = Counter.builder("ds.worker.full.submit.queue.count") .description("full worker submit queues count") .register(Metrics.globalRegistry); private static final Counter WORKER_RESOURCE_DOWNLOAD_SUCCESS_COUNTER = Counter.builder("ds.worker.resource.download.count") .tag("status", "success") .description("worker resource download success count") .register(Metrics.globalRegistry); private static final Counter WORKER_RESOURCE_DOWNLOAD_FAILURE_COUNTER = Counter.builder("ds.worker.resource.download.count") .tag("status", "fail") .description("worker resource download failure count") .register(Metrics.globalRegistry); private static final Timer WORKER_RESOURCE_DOWNLOAD_DURATION_TIMER = Timer.builder("ds.worker.resource.download.duration") .publishPercentiles(0.5, 0.75, 0.95, 0.99) .publishPercentileHistogram() .description("time cost of resource download on workers") .register(Metrics.globalRegistry); private static final DistributionSummary WORKER_RESOURCE_DOWNLOAD_SIZE_DISTRIBUTION = DistributionSummary.builder("ds.worker.resource.download.size")
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,131
[Improvement][Metrics] Add metrics for alert server
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar feature requirement. ### Description * Currently we don't have any metrics in `alert server`. If `alert server` fails, with metrics, it would be easier to track down the issues. * Furthermore, metrics enable users to monitor alert server from external system and decrease the probability of failure. * related: #10211 ### Are you willing to submit a PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11131
https://github.com/apache/dolphinscheduler/pull/11240
adfec41986f1a4ae19f2f24f9e37e00355236c3e
9ca1eb96c429f76574bfa98b0ca5eff8d8c89a82
2022-07-25T00:53:01Z
java
2022-08-03T07:42:06Z
dolphinscheduler-worker/src/main/java/org/apache/dolphinscheduler/server/worker/metrics/WorkerServerMetrics.java
.baseUnit("bytes") .publishPercentiles(0.5, 0.75, 0.95, 0.99) .publishPercentileHistogram() .description("size of downloaded resource files on worker") .register(Metrics.globalRegistry); public static void incWorkerOverloadCount() { WORKER_OVERLOAD_COUNTER.increment(); } public static void incWorkerSubmitQueueIsFullCount() { WORKER_SUBMIT_QUEUE_IS_FULL_COUNTER.increment(); } public static void incWorkerResourceDownloadSuccessCount() { WORKER_RESOURCE_DOWNLOAD_SUCCESS_COUNTER.increment(); } public static void incWorkerResourceDownloadFailureCount() { WORKER_RESOURCE_DOWNLOAD_FAILURE_COUNTER.increment(); } public static void recordWorkerResourceDownloadTime(final long milliseconds) { WORKER_RESOURCE_DOWNLOAD_DURATION_TIMER.record(milliseconds, TimeUnit.MILLISECONDS); } public static void recordWorkerResourceDownloadSize(final long size) { WORKER_RESOURCE_DOWNLOAD_SIZE_DISTRIBUTION.record(size); } public static void registerWorkerRunningTaskGauge(final Supplier<Number> supplier) { Gauge.builder("ds.task.running", supplier) .description("number of running tasks on workers") .register(Metrics.globalRegistry); } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/entity/TaskGroupQueue.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.dao.entity; import org.apache.dolphinscheduler.common.enums.TaskGroupQueueStatus; import java.io.Serializable; import java.util.Date; import com.baomidou.mybatisplus.annotation.IdType; import com.baomidou.mybatisplus.annotation.TableField; import com.baomidou.mybatisplus.annotation.TableId; import com.baomidou.mybatisplus.annotation.TableName; /** * Task Group Queue */ @TableName("t_ds_task_group_queue")
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/entity/TaskGroupQueue.java
public class TaskGroupQueue implements Serializable { /** * key */ @TableId(value = "id", type = IdType.AUTO) private int id; /** * taskIntanceid */ private int taskId; /** * TaskInstance name */ private String taskName; /** * project name */ @TableField(exist = false) private String projectName; /** * project code */ @TableField(exist = false)
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/entity/TaskGroupQueue.java
private String projectCode; /** * process instance name */ @TableField(exist = false) private String processInstanceName; /** * taskGroup id */ private int groupId; /** * processInstace id */ private int processId; /** * the priority of task instance */ private int priority; /** * is force start * 0 NO ,1 YES */ private int forceStart; /** * ready to get the queue by other task finish * 0 NO ,1 YES */ private int inQueue; /** * -1: waiting 1: running 2: finished
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/entity/TaskGroupQueue.java
*/ private TaskGroupQueueStatus status; /** * create time */ private Date createTime; /** * update time */ private Date updateTime; public TaskGroupQueue() { } public TaskGroupQueue(int taskId, String taskName, int groupId, int processId, int priority, TaskGroupQueueStatus status) { this.taskId = taskId; this.taskName = taskName; this.groupId = groupId; this.processId = processId; this.priority = priority; this.status = status; } public int getId() { return id; } public void setId(int id) { this.id = id; } public int getTaskId() { return taskId; } public void setTaskId(int taskId) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/entity/TaskGroupQueue.java
this.taskId = taskId; } public String getTaskName() { return taskName; } public void setTaskName(String taskName) { this.taskName = taskName; } public int getGroupId() { return groupId; } public void setGroupId(int groupId) { this.groupId = groupId; } public int getProcessId() { return processId; } public void setProcessId(int processId) { this.processId = processId; } public int getPriority() { return priority; } public void setPriority(int priority) { this.priority = priority; } public Date getCreateTime() { return createTime; } public void setCreateTime(Date createTime) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/entity/TaskGroupQueue.java
this.createTime = createTime; } public Date getUpdateTime() { return updateTime; } public void setUpdateTime(Date updateTime) { this.updateTime = updateTime; } @Override public String toString() { return "TaskGroupQueue{" + "id=" + id + ", taskId=" + taskId + ", taskName='" + taskName + '\'' + ", groupId=" + groupId + ", processId=" + processId + ", priority=" + priority + ", status=" + status + ", createTime=" + createTime + ", updateTime=" + updateTime + '}'; } public TaskGroupQueueStatus getStatus() { return status; } public void setStatus(TaskGroupQueueStatus status) { this.status = status; } public int getForceStart() { return forceStart;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/entity/TaskGroupQueue.java
} public void setForceStart(int forceStart) { this.forceStart = forceStart; } public int getInQueue() { return inQueue; } public void setInQueue(int inQueue) { this.inQueue = inQueue; } public String getProjectName() { return projectName; } public void setProjectName(String projectName) { this.projectName = projectName; } public String getProcessInstanceName() { return processInstanceName; } public void setProcessInstanceName(String processInstanceName) { this.processInstanceName = processInstanceName; } public String getProjectCode() { return projectCode; } public void setProjectCode(String projectCode) { this.projectCode = projectCode; } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/mapper/TaskGroupMapper.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.dao.mapper; import org.apache.dolphinscheduler.dao.entity.TaskGroup; import org.apache.ibatis.annotations.Param; import com.baomidou.mybatisplus.core.mapper.BaseMapper; import com.baomidou.mybatisplus.core.metadata.IPage; import com.baomidou.mybatisplus.extension.plugins.pagination.Page; import java.util.List; /** * the Dao interfaces of task group * * @author yinrui * @since 2021-08-07 */ public interface TaskGroupMapper extends BaseMapper<TaskGroup> {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/mapper/TaskGroupMapper.java
/** * compard and set to update table of task group * * @param id primary key * @return affected rows */ int updateTaskGroupResource(@Param("id") int id, @Param("queueId") int queueId, @Param("queueStatus") int queueStatus); /** * update table of task group * * @param id primary key * @return affected rows */ int releaseTaskGroupResource(@Param("id") int id, @Param("useSize") int useSize, @Param("queueId") int queueId, @Param("queueStatus") int queueStatus);
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/mapper/TaskGroupMapper.java
/** * select task groups paging * * @param page page * @param userId user id * @param name name * @param status status * @return result page */ IPage<TaskGroup> queryTaskGroupPaging(IPage<TaskGroup> page, @Param("ids") List<Integer> ids, @Param("name") String name, @Param("status") Integer status); /** * query by task group name * * @param userId user id * @param name name * @return task group */ TaskGroup queryByName(@Param("userId") int userId, @Param("name") String name); int selectAvailableCountById(@Param("groupId") int groupId); int selectCountByIdStatus(@Param("id") int id,@Param("status") int status); IPage<TaskGroup> queryTaskGroupPagingByProjectCode(Page<TaskGroup> page, @Param("ids") List<Integer> ids, @Param("projectCode") Long projectCode); /** * listAuthorizedResource * @param userId * @return */ List<TaskGroup> listAuthorizedResource(@Param("userId") int userId); }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/mapper/TaskGroupQueueMapper.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.dao.mapper; import org.apache.dolphinscheduler.dao.entity.Project;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/mapper/TaskGroupQueueMapper.java
import org.apache.dolphinscheduler.dao.entity.TaskGroupQueue; import org.apache.ibatis.annotations.Param; import java.util.List; import com.baomidou.mybatisplus.core.mapper.BaseMapper; import com.baomidou.mybatisplus.core.metadata.IPage; import com.baomidou.mybatisplus.extension.plugins.pagination.Page; /** * the Dao interfaces of task group queue * * @author yinrui * @since 2021-08-07 */ public interface TaskGroupQueueMapper extends BaseMapper<TaskGroupQueue> { /** * select task group queues by some conditions * * @param page page * @param groupId group id * @return task group queue list */ IPage<TaskGroupQueue> queryTaskGroupQueuePaging(IPage<TaskGroupQueue> page, @Param("groupId") int groupId ); TaskGroupQueue queryByTaskId(@Param("taskId") int taskId); /** * query by status * * @param status status * @return result */
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-dao/src/main/java/org/apache/dolphinscheduler/dao/mapper/TaskGroupQueueMapper.java
List<TaskGroupQueue> queryByStatus(@Param("status") int status); /** * delete by task id * * @param taskId task id * @return affected rows */ int deleteByTaskId(@Param("taskId") int taskId); /** * update status by task id * * @param taskId task id * @param status status * @return */ int updateStatusByTaskId(@Param("taskId") int taskId, @Param("status") int status); List<TaskGroupQueue> queryHighPriorityTasks(@Param("groupId") int groupId, @Param("priority") int priority, @Param("status") int status); TaskGroupQueue queryTheHighestPriorityTasks(@Param("groupId") int groupId, @Param("status") int status, @Param("forceStart") int forceStart, @Param("inQueue") int inQueue); void updateInQueue(@Param("inQueue") int inQueue, @Param("id") int id); void updateForceStart(@Param("queueId") int queueId, @Param("forceStart") int forceStart); int updateInQueueLimit1(@Param("oldValue") int oldValue, @Param("newValue") int newValue , @Param("groupId") int id, @Param("status") int status); int updateInQueueCAS(@Param("oldValue") int oldValue, @Param("newValue") int newValue, @Param("id") int id); void modifyPriority(@Param("queueId") int queueId, @Param("priority") int priority); IPage<TaskGroupQueue> queryTaskGroupQueueByTaskGroupIdPaging(Page<TaskGroupQueue> page, @Param("taskName")String taskName ,@Param("processName") String processName,@Param("status") Integer status,@Param("groupId") int groupId ,@Param("projects") List<Project> projects); }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/event/TaskStateEventHandler.java
/* * Licensed to the Apache Software Foundation (ASF) under one or more * contributor license agreements. See the NOTICE file distributed with * this work for additional information regarding copyright ownership. * The ASF licenses this file to You under the Apache License, Version 2.0 * (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.dolphinscheduler.server.master.event; import org.apache.dolphinscheduler.common.enums.StateEventType; import org.apache.dolphinscheduler.dao.entity.TaskInstance; import org.apache.dolphinscheduler.server.master.metrics.TaskMetrics; import org.apache.dolphinscheduler.server.master.runner.WorkflowExecuteRunnable; import org.apache.dolphinscheduler.server.master.runner.task.ITaskProcessor; import org.apache.dolphinscheduler.server.master.runner.task.TaskAction; import java.util.Map; import java.util.Optional; import org.slf4j.Logger; import org.slf4j.LoggerFactory; import com.google.auto.service.AutoService; @AutoService(StateEventHandler.class)
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/event/TaskStateEventHandler.java
public class TaskStateEventHandler implements StateEventHandler { private static final Logger logger = LoggerFactory.getLogger(TaskStateEventHandler.class); @Override public boolean handleStateEvent(WorkflowExecuteRunnable workflowExecuteRunnable, StateEvent stateEvent) throws StateEventHandleException, StateEventHandleError { measureTaskState(stateEvent); workflowExecuteRunnable.checkTaskInstanceByStateEvent(stateEvent); Optional<TaskInstance> taskInstanceOptional = workflowExecuteRunnable.getTaskInstance(stateEvent.getTaskInstanceId()); TaskInstance task = taskInstanceOptional.orElseThrow(() -> new StateEventHandleError( "Cannot find task instance from taskMap by task instance id: " + stateEvent.getTaskInstanceId()));
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/event/TaskStateEventHandler.java
if (task.getState() == null) { throw new StateEventHandleError("Task state event handle error due to task state is null"); } Map<Long, Integer> completeTaskMap = workflowExecuteRunnable.getCompleteTaskMap(); if (task.getState().typeIsFinished()) { if (completeTaskMap.containsKey(task.getTaskCode()) && completeTaskMap.get(task.getTaskCode()) == task.getId()) { logger.warn("The task instance is already complete, stateEvent: {}", stateEvent); return true; } workflowExecuteRunnable.taskFinished(task); if (task.getTaskGroupId() > 0) { workflowExecuteRunnable.releaseTaskGroup(task); } return true; } Map<Long, ITaskProcessor> activeTaskProcessMap = workflowExecuteRunnable.getActiveTaskProcessMap(); if (activeTaskProcessMap.containsKey(task.getTaskCode())) { ITaskProcessor iTaskProcessor = activeTaskProcessMap.get(task.getTaskCode()); iTaskProcessor.action(TaskAction.RUN); if (iTaskProcessor.taskInstance().getState().typeIsFinished()) { if (iTaskProcessor.taskInstance().getState() != task.getState()) { task.setState(iTaskProcessor.taskInstance().getState()); } workflowExecuteRunnable.taskFinished(task); } return true; } throw new StateEventHandleException( "Task state event handle error, due to the task is not in activeTaskProcessorMaps");
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/event/TaskStateEventHandler.java
} @Override public StateEventType getEventType() { return StateEventType.TASK_STATE_CHANGE; } private void measureTaskState(StateEvent taskStateEvent) { if (taskStateEvent == null || taskStateEvent.getExecutionStatus() == null) { logger.warn("The task event is broken..., taskEvent: {}", taskStateEvent); return; } if (taskStateEvent.getExecutionStatus().typeIsFinished()) { TaskMetrics.incTaskInstanceByState("finish"); } switch (taskStateEvent.getExecutionStatus()) { case STOP: TaskMetrics.incTaskInstanceByState("stop"); break; case SUCCESS: TaskMetrics.incTaskInstanceByState("success"); break; case FAILURE: TaskMetrics.incTaskInstanceByState("fail"); break; default: break; } } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
/* * Lcensed to the Apache Software Foundaton (ASF) under one or more * contrbutor lcense agreements. See the NOTICE fle dstrbuted wth * ths work for addtonal nformaton regardng copyrght ownershp. * The ASF lcenses ths fle to You under the Apache Lcense, Verson 2.0 * (the "Lcense"); you may not use ths fle except n complance wth * the Lcense. You may obtan a copy of the Lcense at * * http://www.apache.org/lcenses/LICENSE-2.0 * * Unless requred by applcable law or agreed to n wrtng, software * dstrbuted under the Lcense s dstrbuted on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, ether express or mpled. * See the Lcense for the specfc language governng permssons and * lmtatons under the Lcense. */ package org.apache.dolphnscheduler.server.master.runner; mport statc org.apache.dolphnscheduler.common.Constants.CMDPARAM_COMPLEMENT_DATA_END_DATE; mport statc org.apache.dolphnscheduler.common.Constants.CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST; mport statc org.apache.dolphnscheduler.common.Constants.CMDPARAM_COMPLEMENT_DATA_START_DATE;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
mport statc org.apache.dolphnscheduler.common.Constants.CMD_PARAM_RECOVERY_START_NODE_STRING; mport statc org.apache.dolphnscheduler.common.Constants.CMD_PARAM_RECOVER_PROCESS_ID_STRING; mport statc org.apache.dolphnscheduler.common.Constants.CMD_PARAM_START_NODES; mport statc org.apache.dolphnscheduler.common.Constants.COMMA; mport statc org.apache.dolphnscheduler.common.Constants.DEFAULT_WORKER_GROUP; mport statc org.apache.dolphnscheduler.common.Constants.YYYY_MM_DD_HH_MM_SS; mport statc org.apache.dolphnscheduler.plugn.task.ap.TaskConstants.TASK_TYPE_BLOCKING; mport statc org.apache.dolphnscheduler.plugn.task.ap.enums.DataType.VARCHAR; mport statc org.apache.dolphnscheduler.plugn.task.ap.enums.Drect.IN; mport org.apache.dolphnscheduler.common.Constants; mport org.apache.dolphnscheduler.common.enums.CommandType; mport org.apache.dolphnscheduler.common.enums.FalureStrategy; mport org.apache.dolphnscheduler.common.enums.Flag; mport org.apache.dolphnscheduler.common.enums.Prorty; mport org.apache.dolphnscheduler.common.enums.StateEventType; mport org.apache.dolphnscheduler.common.enums.TaskDependType; mport org.apache.dolphnscheduler.common.enums.TaskGroupQueueStatus; mport org.apache.dolphnscheduler.common.graph.DAG; mport org.apache.dolphnscheduler.common.model.TaskNode; mport org.apache.dolphnscheduler.common.model.TaskNodeRelaton; mport org.apache.dolphnscheduler.common.process.ProcessDag; mport org.apache.dolphnscheduler.common.thread.ThreadUtls; mport org.apache.dolphnscheduler.common.utls.DateUtls; mport org.apache.dolphnscheduler.common.utls.JSONUtls; mport org.apache.dolphnscheduler.common.utls.LoggerUtls; mport org.apache.dolphnscheduler.common.utls.NetUtls; mport org.apache.dolphnscheduler.dao.entty.Command; mport org.apache.dolphnscheduler.dao.entty.Envronment; mport org.apache.dolphnscheduler.dao.entty.ProcessDefnton; mport org.apache.dolphnscheduler.dao.entty.ProcessInstance;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
mport org.apache.dolphnscheduler.dao.entty.ProcessTaskRelaton; mport org.apache.dolphnscheduler.dao.entty.ProjectUser; mport org.apache.dolphnscheduler.dao.entty.Schedule; mport org.apache.dolphnscheduler.dao.entty.TaskDefntonLog; mport org.apache.dolphnscheduler.dao.entty.TaskGroupQueue; mport org.apache.dolphnscheduler.dao.entty.TaskInstance; mport org.apache.dolphnscheduler.dao.utls.DagHelper; mport org.apache.dolphnscheduler.plugn.task.ap.enums.DependResult; mport org.apache.dolphnscheduler.plugn.task.ap.enums.Drect; mport org.apache.dolphnscheduler.plugn.task.ap.enums.ExecutonStatus; mport org.apache.dolphnscheduler.plugn.task.ap.model.Property; mport org.apache.dolphnscheduler.remote.command.HostUpdateCommand; mport org.apache.dolphnscheduler.remote.utls.Host; mport org.apache.dolphnscheduler.server.master.confg.MasterConfg; mport org.apache.dolphnscheduler.server.master.dspatch.executor.NettyExecutorManager; mport org.apache.dolphnscheduler.server.master.event.StateEvent; mport org.apache.dolphnscheduler.server.master.event.StateEventHandleError; mport org.apache.dolphnscheduler.server.master.event.StateEventHandleExcepton; mport org.apache.dolphnscheduler.server.master.event.StateEventHandler; mport org.apache.dolphnscheduler.server.master.event.StateEventHandlerManager; mport org.apache.dolphnscheduler.server.master.metrcs.TaskMetrcs; mport org.apache.dolphnscheduler.server.master.runner.task.ITaskProcessor; mport org.apache.dolphnscheduler.server.master.runner.task.TaskActon; mport org.apache.dolphnscheduler.server.master.runner.task.TaskProcessorFactory; mport org.apache.dolphnscheduler.servce.alert.ProcessAlertManager; mport org.apache.dolphnscheduler.servce.cron.CronUtls; mport org.apache.dolphnscheduler.servce.exceptons.CronParseExcepton; mport org.apache.dolphnscheduler.servce.expand.CurngParamsServce; mport org.apache.dolphnscheduler.servce.process.ProcessServce; mport org.apache.dolphnscheduler.servce.queue.PeerTaskInstancePrortyQueue;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
mport org.apache.commons.collectons.CollectonUtls; mport org.apache.commons.lang3.StrngUtls; mport org.apache.commons.lang3.math.NumberUtls; mport java.utl.ArrayLst; mport java.utl.Arrays; mport java.utl.Collecton; mport java.utl.Collectons; mport java.utl.Date; mport java.utl.HashMap; mport java.utl.HashSet; mport java.utl.Iterator; mport java.utl.Lst; mport java.utl.Map; mport java.utl.Objects; mport java.utl.Optonal; mport java.utl.Set; mport java.utl.concurrent.Callable; mport java.utl.concurrent.ConcurrentHashMap; mport java.utl.concurrent.ConcurrentLnkedQueue; mport java.utl.concurrent.atomc.AtomcBoolean; mport java.utl.stream.Collectors; mport org.slf4j.Logger; mport org.slf4j.LoggerFactory; mport org.sprngframework.beans.BeanUtls; mport com.google.common.collect.Lsts; mport lombok.NonNull; /** * Workflow execute task, used to execute a workflow nstance. */ publc class WorkflowExecuteRunnable mplements Callable<WorkflowSubmtStatue> {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
prvate statc fnal Logger logger = LoggerFactory.getLogger(WorkflowExecuteRunnable.class); prvate fnal ProcessServce processServce; prvate fnal ProcessAlertManager processAlertManager; prvate fnal NettyExecutorManager nettyExecutorManager; prvate fnal ProcessInstance processInstance; prvate ProcessDefnton processDefnton; prvate DAG<Strng, TaskNode, TaskNodeRelaton> dag; /** * unque key of workflow */ prvate Strng key; prvate WorkflowRunnableStatus workflowRunnableStatus = WorkflowRunnableStatus.CREATED; /** * submt falure nodes */ prvate boolean taskFaledSubmt = false; /** * task nstance hash map, taskId as key */ prvate fnal Map<Integer, TaskInstance> taskInstanceMap = new ConcurrentHashMap<>(); /** * runnng taskProcessor, taskCode as key, taskProcessor as value * only on taskProcessor per taskCode */ prvate fnal Map<Long, ITaskProcessor> actveTaskProcessorMaps = new ConcurrentHashMap<>(); /** * vald task map, taskCode as key, taskId as value * n a DAG, only one taskInstance per taskCode s vald */ prvate fnal Map<Long, Integer> valdTaskMap = new ConcurrentHashMap<>();
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
/** * error task map, taskCode as key, taskInstanceId as value * n a DAG, only one taskInstance per taskCode s vald */ prvate fnal Map<Long, Integer> errorTaskMap = new ConcurrentHashMap<>(); /** * complete task map, taskCode as key, taskInstanceId as value * n a DAG, only one taskInstance per taskCode s vald */ prvate fnal Map<Long, Integer> completeTaskMap = new ConcurrentHashMap<>(); /** * depend faled task map, taskCode as key, taskId as value */ prvate fnal Map<Long, Integer> dependFaledTaskMap = new ConcurrentHashMap<>(); /** * forbdden task map, code as key */ prvate fnal Map<Long, TaskNode> forbddenTaskMap = new ConcurrentHashMap<>(); /** * skp task map, code as key */ prvate fnal Map<Strng, TaskNode> skpTaskNodeMap = new ConcurrentHashMap<>(); /** * complement date lst */ prvate Lst<Date> complementLstDate = Lsts.newLnkedLst(); /** * state event queue */ prvate fnal ConcurrentLnkedQueue<StateEvent> stateEvents = new ConcurrentLnkedQueue<>();
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
/** * The StandBy task lst, wll be executed, need to know, the taskInstance n ths queue may doesn't have d. */ prvate fnal PeerTaskInstancePrortyQueue readyToSubmtTaskQueue = new PeerTaskInstancePrortyQueue(); /** * wat to retry taskInstance map, taskCode as key, taskInstance as value * before retry, the taskInstance d s 0 */ prvate fnal Map<Long, TaskInstance> watToRetryTaskInstanceMap = new ConcurrentHashMap<>(); prvate fnal StateWheelExecuteThread stateWheelExecuteThread; prvate fnal CurngParamsServce curngParamsServce; prvate fnal Strng masterAddress; /** * @param processInstance processInstance * @param processServce processServce * @param nettyExecutorManager nettyExecutorManager * @param processAlertManager processAlertManager * @param masterConfg masterConfg * @param stateWheelExecuteThread stateWheelExecuteThread */ publc WorkflowExecuteRunnable( @NonNull ProcessInstance processInstance, @NonNull ProcessServce processServce, @NonNull NettyExecutorManager nettyExecutorManager, @NonNull ProcessAlertManager processAlertManager, @NonNull MasterConfg masterConfg, @NonNull StateWheelExecuteThread stateWheelExecuteThread, @NonNull CurngParamsServce curngParamsServce) { ths.processServce = processServce; ths.processInstance = processInstance;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
ths.nettyExecutorManager = nettyExecutorManager; ths.processAlertManager = processAlertManager; ths.stateWheelExecuteThread = stateWheelExecuteThread; ths.curngParamsServce = curngParamsServce; ths.masterAddress = NetUtls.getAddr(masterConfg.getLstenPort()); TaskMetrcs.regsterTaskPrepared(readyToSubmtTaskQueue::sze); } /** * the process start nodes are submtted completely. */ publc boolean sStart() { return WorkflowRunnableStatus.STARTED == workflowRunnableStatus; } /** * handle event */ publc vod handleEvents() { f (!sStart()) { logger.nfo( "The workflow nstance s not started, wll not handle ts state event, current state event sze: {}", stateEvents); return; } StateEvent stateEvent = null; whle (!ths.stateEvents.sEmpty()) { try { stateEvent = ths.stateEvents.peek(); LoggerUtls.setWorkflowAndTaskInstanceIDMDC(stateEvent.getProcessInstanceId(), stateEvent.getTaskInstanceId());
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
checkProcessInstance(stateEvent); StateEventHandler stateEventHandler = StateEventHandlerManager.getStateEventHandler(stateEvent.getType()) .orElseThrow(() -> new StateEventHandleError("Cannot fnd handler for the gven state event")); logger.nfo("Begn to handle state event, {}", stateEvent); f (stateEventHandler.handleStateEvent(ths, stateEvent)) { ths.stateEvents.remove(stateEvent); } } catch (StateEventHandleError stateEventHandleError) { logger.error("State event handle error, wll remove ths event: {}", stateEvent, stateEventHandleError); ths.stateEvents.remove(stateEvent); ThreadUtls.sleep(Constants.SLEEP_TIME_MILLIS); } catch (StateEventHandleExcepton stateEventHandleExcepton) { logger.error("State event handle error, wll retry ths event: {}", stateEvent, stateEventHandleExcepton); ThreadUtls.sleep(Constants.SLEEP_TIME_MILLIS); } catch (Excepton e) { logger.error("State event handle error, get a unknown excepton, wll retry ths event: {}", stateEvent, e); ThreadUtls.sleep(Constants.SLEEP_TIME_MILLIS); } fnally { LoggerUtls.removeWorkflowAndTaskInstanceIdMDC(); } } } publc Strng getKey() {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
f (StrngUtls.sNotEmpty(key) || ths.processDefnton == null) { return key; } key = Strng.format("%d_%d_%d", ths.processDefnton.getCode(), ths.processDefnton.getVerson(), ths.processInstance.getId()); return key; } publc boolean addStateEvent(StateEvent stateEvent) { f (processInstance.getId() != stateEvent.getProcessInstanceId()) { logger.nfo("state event would be abounded :{}", stateEvent); return false; } ths.stateEvents.add(stateEvent); return true; } publc nt eventSze() { return ths.stateEvents.sze(); } publc ProcessInstance getProcessInstance() { return ths.processInstance; } publc boolean checkForceStartAndWakeUp(StateEvent stateEvent) { TaskGroupQueue taskGroupQueue = ths.processServce.loadTaskGroupQueue(stateEvent.getTaskInstanceId()); f (taskGroupQueue.getForceStart() == Flag.YES.getCode()) { TaskInstance taskInstance = ths.processServce.fndTaskInstanceById(stateEvent.getTaskInstanceId()); ITaskProcessor taskProcessor = actveTaskProcessorMaps.get(taskInstance.getTaskCode()); taskProcessor.acton(TaskActon.DISPATCH); ths.processServce.updateTaskGroupQueueStatus(taskGroupQueue.getTaskId(),
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
TaskGroupQueueStatus.ACQUIRE_SUCCESS.getCode()); return true; } f (taskGroupQueue.getInQueue() == Flag.YES.getCode()) { boolean acqureTaskGroup = processServce.acqureTaskGroupAgan(taskGroupQueue); f (acqureTaskGroup) { TaskInstance taskInstance = ths.processServce.fndTaskInstanceById(stateEvent.getTaskInstanceId()); ITaskProcessor taskProcessor = actveTaskProcessorMaps.get(taskInstance.getTaskCode()); taskProcessor.acton(TaskActon.DISPATCH); return true; } } return false; } publc vod processTmeout() { ProjectUser projectUser = processServce.queryProjectWthUserByProcessInstanceId(processInstance.getId()); ths.processAlertManager.sendProcessTmeoutAlert(ths.processInstance, projectUser); } publc vod taskTmeout(TaskInstance taskInstance) { ProjectUser projectUser = processServce.queryProjectWthUserByProcessInstanceId(processInstance.getId()); processAlertManager.sendTaskTmeoutAlert(processInstance, taskInstance, projectUser); } publc vod taskFnshed(TaskInstance taskInstance) throws StateEventHandleExcepton { logger.nfo("TaskInstance fnshed task code:{} state:{}", taskInstance.getTaskCode(), taskInstance.getState()); try { actveTaskProcessorMaps.remove(taskInstance.getTaskCode()); stateWheelExecuteThread.removeTask4TmeoutCheck(processInstance, taskInstance); stateWheelExecuteThread.removeTask4RetryCheck(processInstance, taskInstance); stateWheelExecuteThread.removeTask4StateCheck(processInstance, taskInstance); f (taskInstance.getState().typeIsSuccess()) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
completeTaskMap.put(taskInstance.getTaskCode(), taskInstance.getId()); processInstance.setVarPool(taskInstance.getVarPool()); processServce.saveProcessInstance(processInstance); f (!processInstance.sBlocked()) { submtPostNode(Long.toStrng(taskInstance.getTaskCode())); } } else f (taskInstance.taskCanRetry() && processInstance.getState() != ExecutonStatus.READY_STOP) { logger.nfo("Retry taskInstance taskInstance state: {}", taskInstance.getState()); retryTaskInstance(taskInstance); } else f (taskInstance.getState().typeIsFalure()) { completeTaskMap.put(taskInstance.getTaskCode(), taskInstance.getId()); f (processInstance.getFalureStrategy() == FalureStrategy.CONTINUE && DagHelper.haveAllNodeAfterNode( Long.toStrng(taskInstance.getTaskCode()), dag)) { submtPostNode(Long.toStrng(taskInstance.getTaskCode())); } else { errorTaskMap.put(taskInstance.getTaskCode(), taskInstance.getId()); f (processInstance.getFalureStrategy() == FalureStrategy.END) { kllAllTasks(); } } } else f (taskInstance.getState().typeIsFnshed()) { completeTaskMap.put(taskInstance.getTaskCode(), taskInstance.getId()); } logger.nfo("TaskInstance fnshed wll try to update the workflow nstance state, task code:{} state:{}", taskInstance.getTaskCode(),
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
taskInstance.getState()); ths.updateProcessInstanceState(); } catch (Excepton ex) { logger.error("Task fnsh faled, get a excepton, wll remove ths taskInstance from completeTaskMap", ex); completeTaskMap.remove(taskInstance.getTaskCode()); throw ex; } } /** * release task group * * @param taskInstance */ publc vod releaseTaskGroup(TaskInstance taskInstance) { f (taskInstance.getTaskGroupId() > 0) { TaskInstance nextTaskInstance = ths.processServce.releaseTaskGroup(taskInstance); f (nextTaskInstance != null) { f (nextTaskInstance.getProcessInstanceId() == taskInstance.getProcessInstanceId()) { StateEvent nextEvent = new StateEvent(); nextEvent.setProcessInstanceId(ths.processInstance.getId()); nextEvent.setTaskInstanceId(nextTaskInstance.getId()); nextEvent.setType(StateEventType.WAIT_TASK_GROUP); ths.stateEvents.add(nextEvent); } else { ProcessInstance processInstance = ths.processServce.fndProcessInstanceById(nextTaskInstance.getProcessInstanceId()); ths.processServce.sendStartTask2Master(processInstance, nextTaskInstance.getId(), org.apache.dolphnscheduler.remote.command.CommandType.TASK_WAKEUP_EVENT_REQUEST); } } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
} /** * crate new task nstance to retry, dfferent objects from the orgnal * * @param taskInstance */ prvate vod retryTaskInstance(TaskInstance taskInstance) throws StateEventHandleExcepton { f (!taskInstance.taskCanRetry()) { return; } TaskInstance newTaskInstance = cloneRetryTaskInstance(taskInstance); f (newTaskInstance == null) { logger.error("retry fal, new taskInstance s null, task code:{}, task d:{}", taskInstance.getTaskCode(), taskInstance.getId()); return; } watToRetryTaskInstanceMap.put(newTaskInstance.getTaskCode(), newTaskInstance); f (!taskInstance.retryTaskIntervalOverTme()) { logger.nfo("falure task wll be submtted: process d: {}, task nstance code: {} state:{} retry tmes:{} / {}, nterval:{}", processInstance.getId(), newTaskInstance.getTaskCode(), newTaskInstance.getState(), newTaskInstance.getRetryTmes(), newTaskInstance.getMaxRetryTmes(), newTaskInstance.getRetryInterval()); stateWheelExecuteThread.addTask4TmeoutCheck(processInstance, newTaskInstance); stateWheelExecuteThread.addTask4RetryCheck(processInstance, newTaskInstance); } else { addTaskToStandByLst(newTaskInstance); submtStandByTask(); watToRetryTaskInstanceMap.remove(newTaskInstance.getTaskCode()); } } /**
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
* update process nstance */ publc vod refreshProcessInstance(nt processInstanceId) { logger.nfo("process nstance update: {}", processInstanceId); ProcessInstance newProcessInstance = processServce.fndProcessInstanceById(processInstanceId); BeanUtls.copyPropertes(newProcessInstance, processInstance); processDefnton = processServce.fndProcessDefnton(processInstance.getProcessDefntonCode(), processInstance.getProcessDefntonVerson()); processInstance.setProcessDefnton(processDefnton); } /** * update task nstance */ publc vod refreshTaskInstance(nt taskInstanceId) { logger.nfo("task nstance update: {} ", taskInstanceId); TaskInstance taskInstance = processServce.fndTaskInstanceById(taskInstanceId); f (taskInstance == null) { logger.error("can not fnd task nstance, d:{}", taskInstanceId); return; } processServce.packageTaskInstance(taskInstance, processInstance); taskInstanceMap.put(taskInstance.getId(), taskInstance); valdTaskMap.remove(taskInstance.getTaskCode()); f (Flag.YES == taskInstance.getFlag()) { valdTaskMap.put(taskInstance.getTaskCode(), taskInstance.getId()); } } /** * check process nstance by state event
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
*/ publc vod checkProcessInstance(StateEvent stateEvent) throws StateEventHandleError { f (ths.processInstance.getId() != stateEvent.getProcessInstanceId()) { throw new StateEventHandleError("The event doesn't contans process nstance d"); } } /** * check f task nstance exst by state event */ publc vod checkTaskInstanceByStateEvent(StateEvent stateEvent) throws StateEventHandleError { f (stateEvent.getTaskInstanceId() == 0) { throw new StateEventHandleError("The taskInstanceId s 0"); } f (!taskInstanceMap.contansKey(stateEvent.getTaskInstanceId())) { throw new StateEventHandleError("Cannot fnd the taskInstance from taskInstanceMap"); } } /** * check f task nstance exst by d */ publc boolean checkTaskInstanceById(nt taskInstanceId) { f (taskInstanceMap.sEmpty()) { return false; } return taskInstanceMap.contansKey(taskInstanceId); } /** * get task nstance from memory */ publc Optonal<TaskInstance> getTaskInstance(nt taskInstanceId) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
f (taskInstanceMap.contansKey(taskInstanceId)) { return Optonal.ofNullable(taskInstanceMap.get(taskInstanceId)); } return Optonal.empty(); } publc Optonal<TaskInstance> getTaskInstance(long taskCode) { f (taskInstanceMap.sEmpty()) { return Optonal.empty(); } for (TaskInstance taskInstance : taskInstanceMap.values()) { f (taskInstance.getTaskCode() == taskCode) { return Optonal.of(taskInstance); } } return Optonal.empty(); } publc Optonal<TaskInstance> getActveTaskInstanceByTaskCode(long taskCode) { Integer taskInstanceId = valdTaskMap.get(taskCode); f (taskInstanceId != null) { return Optonal.ofNullable(taskInstanceMap.get(taskInstanceId)); } return Optonal.empty(); } publc Optonal<TaskInstance> getRetryTaskInstanceByTaskCode(long taskCode) { f (watToRetryTaskInstanceMap.contansKey(taskCode)) { return Optonal.ofNullable(watToRetryTaskInstanceMap.get(taskCode)); } return Optonal.empty(); } publc vod processBlock() {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
ProjectUser projectUser = processServce.queryProjectWthUserByProcessInstanceId(processInstance.getId()); processAlertManager.sendProcessBlockngAlert(processInstance, projectUser); logger.nfo("processInstance {} block alert send successful!", processInstance.getId()); } publc boolean processComplementData() { f (!needComplementProcess()) { return false; } f (processInstance.getState() == ExecutonStatus.READY_STOP || !processInstance.getState().typeIsFnshed()) { return false; } Date scheduleDate = processInstance.getScheduleTme(); f (scheduleDate == null) { scheduleDate = complementLstDate.get(0); } else f (processInstance.getState().typeIsFnshed()) { endProcess(); f (complementLstDate.sEmpty()) { logger.nfo("process complement end. process d:{}", processInstance.getId()); return true; } nt ndex = complementLstDate.ndexOf(scheduleDate); f (ndex >= complementLstDate.sze() - 1 || !processInstance.getState().typeIsSuccess()) { logger.nfo("process complement end. process d:{}", processInstance.getId()); return true; } logger.nfo("process complement contnue. process d:{}, schedule tme:{} complementLstDate:{}", processInstance.getId(), processInstance.getScheduleTme(), complementLstDate); scheduleDate = complementLstDate.get(ndex + 1);
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
} nt create = ths.createComplementDataCommand(scheduleDate); f (create > 0) { logger.nfo("create complement data command successfully."); } return true; } prvate nt createComplementDataCommand(Date scheduleDate) { Command command = new Command(); command.setScheduleTme(scheduleDate); command.setCommandType(CommandType.COMPLEMENT_DATA); command.setProcessDefntonCode(processInstance.getProcessDefntonCode()); Map<Strng, Strng> cmdParam = JSONUtls.toMap(processInstance.getCommandParam()); f (cmdParam.contansKey(Constants.CMD_PARAM_RECOVERY_START_NODE_STRING)) { cmdParam.remove(Constants.CMD_PARAM_RECOVERY_START_NODE_STRING); } f (cmdParam.contansKey(CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST)) { cmdParam.replace(CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST, cmdParam.get(CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST) .substrng(cmdParam.get(CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST).ndexOf(COMMA) + 1)); } f (cmdParam.contansKey(CMDPARAM_COMPLEMENT_DATA_START_DATE)) { cmdParam.replace(CMDPARAM_COMPLEMENT_DATA_START_DATE, DateUtls.format(scheduleDate, YYYY_MM_DD_HH_MM_SS, null)); } command.setCommandParam(JSONUtls.toJsonStrng(cmdParam)); command.setTaskDependType(processInstance.getTaskDependType()); command.setFalureStrategy(processInstance.getFalureStrategy()); command.setWarnngType(processInstance.getWarnngType()); command.setWarnngGroupId(processInstance.getWarnngGroupId());
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
command.setStartTme(new Date()); command.setExecutorId(processInstance.getExecutorId()); command.setUpdateTme(new Date()); command.setProcessInstanceProrty(processInstance.getProcessInstanceProrty()); command.setWorkerGroup(processInstance.getWorkerGroup()); command.setEnvronmentCode(processInstance.getEnvronmentCode()); command.setDryRun(processInstance.getDryRun()); command.setProcessInstanceId(0); command.setProcessDefntonVerson(processInstance.getProcessDefntonVerson()); return processServce.createCommand(command); } prvate boolean needComplementProcess() { f (processInstance.sComplementData() && Flag.NO == processInstance.getIsSubProcess()) { return true; } return false; } /** * ProcessInstance start entrypont. */ @Overrde publc WorkflowSubmtStatue call() { f (sStart()) { logger.warn("[WorkflowInstance-{}] The workflow has already been started", processInstance.getId()); return WorkflowSubmtStatue.DUPLICATED_SUBMITTED; } try { LoggerUtls.setWorkflowInstanceIdMDC(processInstance.getId()); f (workflowRunnableStatus == WorkflowRunnableStatus.CREATED) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
buldFlowDag(); workflowRunnableStatus = WorkflowRunnableStatus.INITIALIZE_DAG; logger.nfo("workflowStatue changed to :{}", workflowRunnableStatus); } f (workflowRunnableStatus == WorkflowRunnableStatus.INITIALIZE_DAG) { ntTaskQueue(); workflowRunnableStatus = WorkflowRunnableStatus.INITIALIZE_QUEUE; logger.nfo("workflowStatue changed to :{}", workflowRunnableStatus); } f (workflowRunnableStatus == WorkflowRunnableStatus.INITIALIZE_QUEUE) { submtPostNode(null); workflowRunnableStatus = WorkflowRunnableStatus.STARTED; logger.nfo("workflowStatue changed to :{}", workflowRunnableStatus); } return WorkflowSubmtStatue.SUCCESS; } catch (Excepton e) { logger.error("Start workflow error", e); return WorkflowSubmtStatue.FAILED; } fnally { LoggerUtls.removeWorkflowInstanceIdMDC(); } } /** * process end handle */ publc vod endProcess() { ths.stateEvents.clear(); f (processDefnton.getExecutonType().typeIsSeralWat() || processDefnton.getExecutonType() .typeIsSeralProrty()) { checkSeralProcess(processDefnton);
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
} f (processInstance.getState().typeIsWatngThread()) { processServce.createRecoveryWatngThreadCommand(null, processInstance); } ProjectUser projectUser = processServce.queryProjectWthUserByProcessInstanceId(processInstance.getId()); f (processAlertManager.sNeedToSendWarnng(processInstance)) { processAlertManager.sendAlertProcessInstance(processInstance, getValdTaskLst(), projectUser); } f (processInstance.getState().typeIsSuccess()) { processAlertManager.closeAlert(processInstance); } f (checkTaskQueue()) { processServce.releaseAllTaskGroup(processInstance.getId()); } } publc vod checkSeralProcess(ProcessDefnton processDefnton) { nt nextInstanceId = processInstance.getNextProcessInstanceId(); f (nextInstanceId == 0) { ProcessInstance nextProcessInstance = ths.processServce.loadNextProcess4Seral(processInstance.getProcessDefnton().getCode(), ExecutonStatus.SERIAL_WAIT.getCode(), processInstance.getId()); f (nextProcessInstance == null) { return; } ProcessInstance nextReadyStopProcessInstance = ths.processServce.loadNextProcess4Seral(processInstance.getProcessDefnton().getCode(), ExecutonStatus.READY_STOP.getCode(), processInstance.getId()); f (processDefnton.getExecutonType().typeIsSeralProrty() && nextReadyStopProcessInstance != null) { return; } nextInstanceId = nextProcessInstance.getId();
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
} ProcessInstance nextProcessInstance = ths.processServce.fndProcessInstanceById(nextInstanceId); f (nextProcessInstance.getState().typeIsFnshed() || nextProcessInstance.getState().typeIsRunnng()) { return; } Map<Strng, Object> cmdParam = new HashMap<>(); cmdParam.put(CMD_PARAM_RECOVER_PROCESS_ID_STRING, nextInstanceId); Command command = new Command(); command.setCommandType(CommandType.RECOVER_SERIAL_WAIT); command.setProcessInstanceId(nextProcessInstance.getId()); command.setProcessDefntonCode(processDefnton.getCode()); command.setProcessDefntonVerson(processDefnton.getVerson()); command.setCommandParam(JSONUtls.toJsonStrng(cmdParam)); processServce.createCommand(command); } /** * Generate process dag * * @throws Excepton excepton */ prvate vod buldFlowDag() throws Excepton { processDefnton = processServce.fndProcessDefnton(processInstance.getProcessDefntonCode(), processInstance.getProcessDefntonVerson()); processInstance.setProcessDefnton(processDefnton); Lst<TaskInstance> recoverNodeLst = getRecoverTaskInstanceLst(processInstance.getCommandParam()); Lst<ProcessTaskRelaton> processTaskRelatons = processServce.fndRelatonByCode(processDefnton.getCode(), processDefnton.getVerson()); Lst<TaskDefntonLog> taskDefntonLogs = processServce.getTaskDefneLogLstByRelaton(processTaskRelatons); Lst<TaskNode> taskNodeLst = processServce.transformTask(processTaskRelatons, taskDefntonLogs); forbddenTaskMap.clear(); taskNodeLst.forEach(taskNode -> { f (taskNode.sForbdden()) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
forbddenTaskMap.put(taskNode.getCode(), taskNode); } }); Lst<Strng> recoveryNodeCodeLst = getRecoveryNodeCodeLst(recoverNodeLst); Lst<Strng> startNodeNameLst = parseStartNodeName(processInstance.getCommandParam()); ProcessDag processDag = generateFlowDag(taskNodeLst, startNodeNameLst, recoveryNodeCodeLst, processInstance.getTaskDependType()); f (processDag == null) { logger.error("processDag s null"); return; } dag = DagHelper.buldDagGraph(processDag); logger.nfo("Buld dag success, dag: {}", dag); } /** * nt task queue */ prvate vod ntTaskQueue() throws StateEventHandleExcepton, CronParseExcepton { taskFaledSubmt = false; actveTaskProcessorMaps.clear(); dependFaledTaskMap.clear(); completeTaskMap.clear(); errorTaskMap.clear(); f (!sNewProcessInstance()) { logger.nfo("The workflowInstance s not a newly runnng nstance, runtmes: {}, recover flag: {}", processInstance.getRunTmes(), processInstance.getRecovery()); Lst<TaskInstance> valdTaskInstanceLst = processServce.fndValdTaskLstByProcessId(processInstance.getId());
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
for (TaskInstance task : valdTaskInstanceLst) { try { LoggerUtls.setWorkflowAndTaskInstanceIDMDC(task.getProcessInstanceId(), task.getId()); logger.nfo( "Check the taskInstance from a exst workflowInstance, exstTaskInstanceCode: {}, taskInstanceStatus: {}", task.getTaskCode(), task.getState()); f (valdTaskMap.contansKey(task.getTaskCode())) { nt oldTaskInstanceId = valdTaskMap.get(task.getTaskCode()); TaskInstance oldTaskInstance = taskInstanceMap.get(oldTaskInstanceId); f (!oldTaskInstance.getState().typeIsFnshed() && task.getState().typeIsFnshed()) { task.setFlag(Flag.NO); processServce.updateTaskInstance(task); contnue; } logger.warn("have same taskCode taskInstance when nt task queue, taskCode:{}", task.getTaskCode()); } valdTaskMap.put(task.getTaskCode(), task.getId()); taskInstanceMap.put(task.getId(), task); f (task.sTaskComplete()) { completeTaskMap.put(task.getTaskCode(), task.getId()); contnue; } f (task.sCondtonsTask() || DagHelper.haveCondtonsAfterNode(Long.toStrng(task.getTaskCode()), dag)) { contnue; } f (task.taskCanRetry()) { f (task.getState() == ExecutonStatus.NEED_FAULT_TOLERANCE) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
TaskInstance tolerantTaskInstance = cloneTolerantTaskInstance(task); addTaskToStandByLst(tolerantTaskInstance); } else { retryTaskInstance(task); } contnue; } f (task.getState().typeIsFalure()) { errorTaskMap.put(task.getTaskCode(), task.getId()); } } fnally { LoggerUtls.removeWorkflowAndTaskInstanceIdMDC(); } } } else { logger.nfo("The current workflowInstance s a newly runnng workflowInstance"); } f (processInstance.sComplementData() && complementLstDate.sEmpty()) { Map<Strng, Strng> cmdParam = JSONUtls.toMap(processInstance.getCommandParam()); f (cmdParam != null) { setGlobalParamIfCommanded(processDefnton, cmdParam); Date start = null; Date end = null; f (cmdParam.contansKey(CMDPARAM_COMPLEMENT_DATA_START_DATE) && cmdParam.contansKey(CMDPARAM_COMPLEMENT_DATA_END_DATE)) { start = DateUtls.strngToDate(cmdParam.get(CMDPARAM_COMPLEMENT_DATA_START_DATE)); end = DateUtls.strngToDate(cmdParam.get(CMDPARAM_COMPLEMENT_DATA_END_DATE)); } Lst<Schedule> schedules = processServce.queryReleaseSchedulerLstByProcessDefntonCode(processInstance.getProcessDefntonCode());
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
f (complementLstDate.sEmpty() && needComplementProcess()) { f (start != null && end != null) { complementLstDate = CronUtls.getSelfFreDateLst(start, end, schedules); } f (cmdParam.contansKey(CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST)) { complementLstDate = CronUtls.getSelfScheduleDateLst(cmdParam); } logger.nfo(" process defnton code:{} complement data: {}", processInstance.getProcessDefntonCode(), complementLstDate); f (!complementLstDate.sEmpty() && Flag.NO == processInstance.getIsSubProcess()) { processInstance.setScheduleTme(complementLstDate.get(0)); Strng globalParams = curngParamsServce.curngGlobalParams(processInstance.getId(), processDefnton.getGlobalParamMap(), processDefnton.getGlobalParamLst(), CommandType.COMPLEMENT_DATA, processInstance.getScheduleTme(), cmdParam.get(Constants.SCHEDULE_TIMEZONE)); processInstance.setGlobalParams(globalParams); processServce.updateProcessInstance(processInstance); } } } } logger.nfo("Intalze task queue, dependFaledTaskMap: {}, completeTaskMap: {}, errorTaskMap: {}", dependFaledTaskMap, completeTaskMap, errorTaskMap); } /** * submt task to execute *
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
* @param taskInstance task nstance * @return TaskInstance */ prvate Optonal<TaskInstance> submtTaskExec(TaskInstance taskInstance) { try { processServce.packageTaskInstance(taskInstance, processInstance); ITaskProcessor taskProcessor = TaskProcessorFactory.getTaskProcessor(taskInstance.getTaskType()); taskProcessor.nt(taskInstance, processInstance); f (taskInstance.getState() == ExecutonStatus.RUNNING_EXECUTION && taskProcessor.getType().equalsIgnoreCase(Constants.COMMON_TASK_TYPE)) { notfyProcessHostUpdate(taskInstance); } boolean submt = taskProcessor.acton(TaskActon.SUBMIT); f (!submt) { logger.error("process d:{} name:{} submt standby task d:{} name:{} faled!", processInstance.getId(), processInstance.getName(), taskInstance.getId(), taskInstance.getName()); return Optonal.empty(); } f (valdTaskMap.contansKey(taskInstance.getTaskCode())) { nt oldTaskInstanceId = valdTaskMap.get(taskInstance.getTaskCode()); f (taskInstance.getId() != oldTaskInstanceId) { TaskInstance oldTaskInstance = taskInstanceMap.get(oldTaskInstanceId); oldTaskInstance.setFlag(Flag.NO); processServce.updateTaskInstance(oldTaskInstance); valdTaskMap.remove(taskInstance.getTaskCode()); actveTaskProcessorMaps.remove(taskInstance.getTaskCode());
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
} } valdTaskMap.put(taskInstance.getTaskCode(), taskInstance.getId()); taskInstanceMap.put(taskInstance.getId(), taskInstance); actveTaskProcessorMaps.put(taskInstance.getTaskCode(), taskProcessor); boolean dspatchSuccess = taskProcessor.acton(TaskActon.DISPATCH); f (!dspatchSuccess) { logger.error("process d:{} name:{} dspatch standby task d:{} name:{} faled!", processInstance.getId(), processInstance.getName(), taskInstance.getId(), taskInstance.getName()); return Optonal.empty(); } taskProcessor.acton(TaskActon.RUN); stateWheelExecuteThread.addTask4TmeoutCheck(processInstance, taskInstance); stateWheelExecuteThread.addTask4StateCheck(processInstance, taskInstance); f (taskProcessor.taskInstance().getState().typeIsFnshed()) { f (processInstance.sBlocked()) { StateEvent processBlockEvent = new StateEvent(); processBlockEvent.setProcessInstanceId(ths.processInstance.getId()); processBlockEvent.setTaskInstanceId(taskInstance.getId()); processBlockEvent.setExecutonStatus(taskProcessor.taskInstance().getState()); processBlockEvent.setType(StateEventType.PROCESS_BLOCKED); ths.stateEvents.add(processBlockEvent); } StateEvent taskStateChangeEvent = new StateEvent(); taskStateChangeEvent.setProcessInstanceId(ths.processInstance.getId()); taskStateChangeEvent.setTaskInstanceId(taskInstance.getId()); taskStateChangeEvent.setExecutonStatus(taskProcessor.taskInstance().getState());
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
taskStateChangeEvent.setType(StateEventType.TASK_STATE_CHANGE); ths.stateEvents.add(taskStateChangeEvent); } return Optonal.of(taskInstance); } catch (Excepton e) { logger.error("submt standby task error, taskCode: {}, taskInstanceId: {}", taskInstance.getTaskCode(), taskInstance.getId(), e); return Optonal.empty(); } } prvate vod notfyProcessHostUpdate(TaskInstance taskInstance) { f (StrngUtls.sEmpty(taskInstance.getHost())) { return; } try { HostUpdateCommand hostUpdateCommand = new HostUpdateCommand(); hostUpdateCommand.setProcessHost(masterAddress); hostUpdateCommand.setTaskInstanceId(taskInstance.getId()); Host host = new Host(taskInstance.getHost()); nettyExecutorManager.doExecute(host, hostUpdateCommand.convert2Command()); } catch (Excepton e) { logger.error("notfy process host update", e); } } /** * fnd task nstance n db. * n case submt more than one same name task n the same tme.
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
* * @param taskCode task code * @param taskVerson task verson * @return TaskInstance */ prvate TaskInstance fndTaskIfExsts(Long taskCode, nt taskVerson) { Lst<TaskInstance> valdTaskInstanceLst = getValdTaskLst(); for (TaskInstance taskInstance : valdTaskInstanceLst) { f (taskInstance.getTaskCode() == taskCode && taskInstance.getTaskDefntonVerson() == taskVerson) { return taskInstance; } } return null; } /** * encapsulaton task, ths method wll only create a new task nstance, the return task nstance wll not contan d. * * @param processInstance process nstance * @param taskNode taskNode * @return TaskInstance */ prvate TaskInstance createTaskInstance(ProcessInstance processInstance, TaskNode taskNode) { TaskInstance taskInstance = fndTaskIfExsts(taskNode.getCode(), taskNode.getVerson()); f (taskInstance != null) { return taskInstance; } return newTaskInstance(processInstance, taskNode); } /** * clone a new taskInstance for retry and reset some logc felds
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
* * @return */ publc TaskInstance cloneRetryTaskInstance(TaskInstance taskInstance) { TaskNode taskNode = dag.getNode(Long.toStrng(taskInstance.getTaskCode())); f (taskNode == null) { logger.error("taskNode s null, code:{}", taskInstance.getTaskCode()); return null; } TaskInstance newTaskInstance = newTaskInstance(processInstance, taskNode); newTaskInstance.setTaskDefne(taskInstance.getTaskDefne()); newTaskInstance.setProcessDefne(taskInstance.getProcessDefne()); newTaskInstance.setProcessInstance(processInstance); newTaskInstance.setRetryTmes(taskInstance.getRetryTmes() + 1); newTaskInstance.setState(taskInstance.getState()); newTaskInstance.setEndTme(taskInstance.getEndTme()); return newTaskInstance; } /** * clone a new taskInstance for tolerant and reset some logc felds * * @return */ publc TaskInstance cloneTolerantTaskInstance(TaskInstance taskInstance) { TaskNode taskNode = dag.getNode(Long.toStrng(taskInstance.getTaskCode())); f (taskNode == null) { logger.error("taskNode s null, code:{}", taskInstance.getTaskCode()); return null; }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
TaskInstance newTaskInstance = newTaskInstance(processInstance, taskNode); newTaskInstance.setTaskDefne(taskInstance.getTaskDefne()); newTaskInstance.setProcessDefne(taskInstance.getProcessDefne()); newTaskInstance.setProcessInstance(processInstance); newTaskInstance.setRetryTmes(taskInstance.getRetryTmes()); newTaskInstance.setState(taskInstance.getState()); return newTaskInstance; } /** * new a taskInstance * * @param processInstance * @param taskNode * @return */ publc TaskInstance newTaskInstance(ProcessInstance processInstance, TaskNode taskNode) { TaskInstance taskInstance = new TaskInstance(); taskInstance.setTaskCode(taskNode.getCode()); taskInstance.setTaskDefntonVerson(taskNode.getVerson()); taskInstance.setName(taskNode.getName()); taskInstance.setState(ExecutonStatus.SUBMITTED_SUCCESS); taskInstance.setProcessInstanceId(processInstance.getId()); taskInstance.setTaskType(taskNode.getType().toUpperCase()); taskInstance.setAlertFlag(Flag.NO);
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
taskInstance.setStartTme(null); taskInstance.setFlag(Flag.YES); taskInstance.setDryRun(processInstance.getDryRun()); taskInstance.setRetryTmes(0); taskInstance.setMaxRetryTmes(taskNode.getMaxRetryTmes()); taskInstance.setRetryInterval(taskNode.getRetryInterval()); taskInstance.setTaskParams(taskNode.getTaskParams()); taskInstance.setTaskGroupId(taskNode.getTaskGroupId()); taskInstance.setTaskGroupProrty(taskNode.getTaskGroupProrty()); taskInstance.setCpuQuota(taskNode.getCpuQuota()); taskInstance.setMemoryMax(taskNode.getMemoryMax()); f (taskNode.getTaskInstanceProrty() == null) { taskInstance.setTaskInstanceProrty(Prorty.MEDIUM); } else { taskInstance.setTaskInstanceProrty(taskNode.getTaskInstanceProrty()); } Strng processWorkerGroup = processInstance.getWorkerGroup(); processWorkerGroup = StrngUtls.sBlank(processWorkerGroup) ? DEFAULT_WORKER_GROUP : processWorkerGroup; Strng taskWorkerGroup = StrngUtls.sBlank(taskNode.getWorkerGroup()) ? processWorkerGroup : taskNode.getWorkerGroup(); Long processEnvronmentCode = Objects.sNull(processInstance.getEnvronmentCode()) ? -1 : processInstance.getEnvronmentCode(); Long taskEnvronmentCode = Objects.sNull(taskNode.getEnvronmentCode()) ? processEnvronmentCode : taskNode.getEnvronmentCode();
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
f (!processWorkerGroup.equals(DEFAULT_WORKER_GROUP) && taskWorkerGroup.equals(DEFAULT_WORKER_GROUP)) { taskInstance.setWorkerGroup(processWorkerGroup); taskInstance.setEnvronmentCode(processEnvronmentCode); } else { taskInstance.setWorkerGroup(taskWorkerGroup); taskInstance.setEnvronmentCode(taskEnvronmentCode); } f (!taskInstance.getEnvronmentCode().equals(-1L)) { Envronment envronment = processServce.fndEnvronmentByCode(taskInstance.getEnvronmentCode()); f (Objects.nonNull(envronment) && StrngUtls.sNotEmpty(envronment.getConfg())) { taskInstance.setEnvronmentConfg(envronment.getConfg()); } } taskInstance.setDelayTme(taskNode.getDelayTme()); return taskInstance; } publc vod getPreVarPool(TaskInstance taskInstance, Set<Strng> preTask) { Map<Strng, Property> allProperty = new HashMap<>(); Map<Strng, TaskInstance> allTaskInstance = new HashMap<>(); f (CollectonUtls.sNotEmpty(preTask)) { for (Strng preTaskCode : preTask) { Integer taskId = completeTaskMap.get(Long.parseLong(preTaskCode)); f (taskId == null) { contnue; } TaskInstance preTaskInstance = taskInstanceMap.get(taskId); f (preTaskInstance == null) { contnue; }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
Strng preVarPool = preTaskInstance.getVarPool(); f (StrngUtls.sNotEmpty(preVarPool)) { Lst<Property> propertes = JSONUtls.toLst(preVarPool, Property.class); for (Property nfo : propertes) { setVarPoolValue(allProperty, allTaskInstance, preTaskInstance, nfo); } } } f (allProperty.sze() > 0) { taskInstance.setVarPool(JSONUtls.toJsonStrng(allProperty.values())); } } else { f (StrngUtls.sNotEmpty(processInstance.getVarPool())) { taskInstance.setVarPool(processInstance.getVarPool()); } } } publc Collecton<TaskInstance> getAllTaskInstances() { return taskInstanceMap.values(); } prvate vod setVarPoolValue(Map<Strng, Property> allProperty, Map<Strng, TaskInstance> allTaskInstance, TaskInstance preTaskInstance, Property thsProperty) { thsProperty.setDrect(Drect.IN); Strng proName = thsProperty.getProp(); f (allProperty.contansKey(proName)) { Property otherPro = allProperty.get(proName);
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
f (StrngUtls.sEmpty(thsProperty.getValue())) { allProperty.put(proName, otherPro); } else f (StrngUtls.sNotEmpty(otherPro.getValue())) { TaskInstance otherTask = allTaskInstance.get(proName); f (otherTask.getEndTme().getTme() > preTaskInstance.getEndTme().getTme()) { allProperty.put(proName, thsProperty); allTaskInstance.put(proName, preTaskInstance); } else { allProperty.put(proName, otherPro); } } else { allProperty.put(proName, thsProperty); allTaskInstance.put(proName, preTaskInstance); } } else { allProperty.put(proName, thsProperty); allTaskInstance.put(proName, preTaskInstance); } } /** * get complete task nstance map, taskCode as key */ prvate Map<Strng, TaskInstance> getCompleteTaskInstanceMap() { Map<Strng, TaskInstance> completeTaskInstanceMap = new HashMap<>(); for (Map.Entry<Long, Integer> entry : completeTaskMap.entrySet()) { Long taskConde = entry.getKey(); Integer taskInstanceId = entry.getValue(); TaskInstance taskInstance = taskInstanceMap.get(taskInstanceId); f (taskInstance == null) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
logger.warn("Cannot fnd the taskInstance from taskInstanceMap, taskInstanceId: {}, taskConde: {}", taskInstanceId, taskConde); contnue; } completeTaskInstanceMap.put(Long.toStrng(taskInstance.getTaskCode()), taskInstance); } return completeTaskInstanceMap; } /** * get vald task lst */ prvate Lst<TaskInstance> getValdTaskLst() { Lst<TaskInstance> valdTaskInstanceLst = new ArrayLst<>(); for (Integer taskInstanceId : valdTaskMap.values()) { valdTaskInstanceLst.add(taskInstanceMap.get(taskInstanceId)); } return valdTaskInstanceLst; } prvate vod submtPostNode(Strng parentNodeCode) throws StateEventHandleExcepton { Set<Strng> submtTaskNodeLst = DagHelper.parsePostNodes(parentNodeCode, skpTaskNodeMap, dag, getCompleteTaskInstanceMap()); Lst<TaskInstance> taskInstances = new ArrayLst<>(); for (Strng taskNode : submtTaskNodeLst) { TaskNode taskNodeObject = dag.getNode(taskNode); Optonal<TaskInstance> exstTaskInstanceOptonal = getTaskInstance(taskNodeObject.getCode()); f (exstTaskInstanceOptonal.sPresent()) { taskInstances.add(exstTaskInstanceOptonal.get()); contnue;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
} TaskInstance task = createTaskInstance(processInstance, taskNodeObject); taskInstances.add(task); } f (StrngUtls.sNotEmpty(parentNodeCode) && dag.getEndNode().contans(parentNodeCode)) { TaskInstance endTaskInstance = taskInstanceMap.get(completeTaskMap.get(NumberUtls.toLong(parentNodeCode))); Strng taskInstanceVarPool = endTaskInstance.getVarPool(); f (StrngUtls.sNotEmpty(taskInstanceVarPool)) { Set<Property> taskPropertes = new HashSet<>(JSONUtls.toLst(taskInstanceVarPool, Property.class)); Strng processInstanceVarPool = processInstance.getVarPool(); f (StrngUtls.sNotEmpty(processInstanceVarPool)) { Set<Property> propertes = new HashSet<>(JSONUtls.toLst(processInstanceVarPool, Property.class)); propertes.addAll(taskPropertes); processInstance.setVarPool(JSONUtls.toJsonStrng(propertes)); } else { processInstance.setVarPool(JSONUtls.toJsonStrng(taskPropertes)); } } } for (TaskInstance task : taskInstances) { f (readyToSubmtTaskQueue.contans(task)) { logger.warn("Task s already at submt queue, taskInstanceId: {}", task.getId()); contnue; } f (task.getId() > 0 && completeTaskMap.contansKey(task.getTaskCode())) { logger.nfo("task {} has already run success", task.getName()); contnue; }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
f (task.getState().typeIsPause() || task.getState().typeIsCancel()) { logger.nfo("task {} stopped, the state s {}", task.getName(), task.getState()); contnue; } addTaskToStandByLst(task); } submtStandByTask(); updateProcessInstanceState(); } /** * determne whether the dependences of the task node are complete * * @return DependResult */ prvate DependResult sTaskDepsComplete(Strng taskCode) { Collecton<Strng> startNodes = dag.getBegnNode(); f (startNodes.contans(taskCode)) { return DependResult.SUCCESS; } TaskNode taskNode = dag.getNode(taskCode); Lst<Strng> ndrectDepCodeLst = new ArrayLst<>(); setIndrectDepLst(taskCode, ndrectDepCodeLst); for (Strng depsNode : ndrectDepCodeLst) { f (dag.contansNode(depsNode) && !skpTaskNodeMap.contansKey(depsNode)) { Long despNodeTaskCode = Long.parseLong(depsNode); f (!completeTaskMap.contansKey(despNodeTaskCode)) { return DependResult.WAITING; }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
Integer depsTaskId = completeTaskMap.get(despNodeTaskCode); ExecutonStatus depTaskState = taskInstanceMap.get(depsTaskId).getState(); f (depTaskState.typeIsPause() || depTaskState.typeIsCancel()) { return DependResult.NON_EXEC; } f (taskNode.sBlockngTask()) { contnue; } f (taskNode.sCondtonsTask()) { contnue; } f (!dependTaskSuccess(depsNode, taskCode)) { return DependResult.FAILED; } } } logger.nfo("taskCode: {} completeDependTaskLst: {}", taskCode, Arrays.toStrng(completeTaskMap.keySet().toArray())); return DependResult.SUCCESS; } /** * Ths functon s specally used to handle the dependency stuaton where the parent node s a prohbted node. * When the parent node s a forbdden node, the dependency relatonshp should contnue to be traced * * @param taskCode taskCode * @param ndrectDepCodeLst All ndrectly dependent nodes */ prvate vod setIndrectDepLst(Strng taskCode, Lst<Strng> ndrectDepCodeLst) { TaskNode taskNode = dag.getNode(taskCode);
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
Lst<Strng> depCodeLst = taskNode.getDepLst(); for (Strng depsNode : depCodeLst) { f (forbddenTaskMap.contansKey(Long.parseLong(depsNode))) { setIndrectDepLst(depsNode, ndrectDepCodeLst); } else { ndrectDepCodeLst.add(depsNode); } } } /** * depend node s completed, but here need check the condton task branch s the next node */ prvate boolean dependTaskSuccess(Strng dependNodeName, Strng nextNodeName) { f (dag.getNode(dependNodeName).sCondtonsTask()) { Lst<Strng> nextTaskLst = DagHelper.parseCondtonTask(dependNodeName, skpTaskNodeMap, dag, getCompleteTaskInstanceMap()); f (!nextTaskLst.contans(nextNodeName)) { return false; } } else { long taskCode = Long.parseLong(dependNodeName); Integer taskInstanceId = completeTaskMap.get(taskCode); ExecutonStatus depTaskState = taskInstanceMap.get(taskInstanceId).getState(); f (depTaskState.typeIsFalure()) { return false; } } return true; } /**
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
* query task nstance by complete state * * @param state state * @return task nstance lst */ prvate Lst<TaskInstance> getCompleteTaskByState(ExecutonStatus state) { Lst<TaskInstance> resultLst = new ArrayLst<>(); for (Integer taskInstanceId : completeTaskMap.values()) { TaskInstance taskInstance = taskInstanceMap.get(taskInstanceId); f (taskInstance != null && taskInstance.getState() == state) { resultLst.add(taskInstance); } } return resultLst; } /** * where there are ongong tasks * * @param state state * @return ExecutonStatus */ prvate ExecutonStatus runnngState(ExecutonStatus state) { f (state == ExecutonStatus.READY_STOP || state == ExecutonStatus.READY_PAUSE || state == ExecutonStatus.WAITING_THREAD || state == ExecutonStatus.READY_BLOCK || state == ExecutonStatus.DELAY_EXECUTION) { return state; } else { return ExecutonStatus.RUNNING_EXECUTION; } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
/** * exsts falure task,contans submt falure、dependency falure,execute falure(retry after) * * @return Boolean whether has faled task */ prvate boolean hasFaledTask() { f (ths.taskFaledSubmt) { return true; } f (ths.errorTaskMap.sze() > 0) { return true; } return ths.dependFaledTaskMap.sze() > 0; } /** * process nstance falure * * @return Boolean whether process nstance faled */ prvate boolean processFaled() { f (hasFaledTask()) { logger.nfo("The current process has faled task, the current process faled"); f (processInstance.getFalureStrategy() == FalureStrategy.END) { return true; } f (processInstance.getFalureStrategy() == FalureStrategy.CONTINUE) { return readyToSubmtTaskQueue.sze() == 0 && actveTaskProcessorMaps.sze() == 0 && watToRetryTaskInstanceMap.sze() == 0; } } return false;
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
} /** * whether task for watng thread * * @return Boolean whether has watng thread task */ prvate boolean hasWatngThreadTask() { Lst<TaskInstance> watngLst = getCompleteTaskByState(ExecutonStatus.WAITING_THREAD); return CollectonUtls.sNotEmpty(watngLst); } /** * prepare for pause * 1,faled retry task n the preparaton queue , returns to falure drectly * 2,exsts pause task,complement not completed, pendng submsson of tasks, return to suspenson * 3,success * * @return ExecutonStatus */ prvate ExecutonStatus processReadyPause() { f (hasRetryTaskInStandBy()) { return ExecutonStatus.FAILURE; } Lst<TaskInstance> pauseLst = getCompleteTaskByState(ExecutonStatus.PAUSE); f (CollectonUtls.sNotEmpty(pauseLst) || processInstance.sBlocked() || !sComplementEnd() || readyToSubmtTaskQueue.sze() > 0) { return ExecutonStatus.PAUSE; } else { return ExecutonStatus.SUCCESS; } } /**
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
* prepare for block * f process has tasks stll runnng, pause them * f readyToSubmtTaskQueue s not empty, kll them * else return block status drectly * * @return ExecutonStatus */ prvate ExecutonStatus processReadyBlock() { f (actveTaskProcessorMaps.sze() > 0) { for (ITaskProcessor taskProcessor : actveTaskProcessorMaps.values()) { f (!TASK_TYPE_BLOCKING.equals(taskProcessor.getType())) { taskProcessor.acton(TaskActon.PAUSE); } } } f (readyToSubmtTaskQueue.sze() > 0) { for (Iterator<TaskInstance> ter = readyToSubmtTaskQueue.terator(); ter.hasNext(); ) { ter.next().setState(ExecutonStatus.KILL); } } return ExecutonStatus.BLOCK; } /** * generate the latest process nstance status by the tasks state * * @return process nstance executon status */ prvate ExecutonStatus getProcessInstanceState(ProcessInstance nstance) { ExecutonStatus state = nstance.getState(); f (actveTaskProcessorMaps.sze() > 0 || hasRetryTaskInStandBy()) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
// actve ExecutonStatus executonStatus = runnngState(state); logger.nfo("The workflowInstance has task runnng, the workflowInstance status s {}", executonStatus); return executonStatus; } // block f (state == ExecutonStatus.READY_BLOCK) { ExecutonStatus executonStatus = processReadyBlock(); logger.nfo("The workflowInstance s ready to block, the workflowInstance status s {}", executonStatus); return executonStatus; } // watng thread f (hasWatngThreadTask()) { logger.nfo("The workflowInstance has watng thread task, the workflow status s {}", ExecutonStatus.WAITING_THREAD); return ExecutonStatus.WAITING_THREAD; } // pause f (state == ExecutonStatus.READY_PAUSE) { ExecutonStatus executonStatus = processReadyPause(); logger.nfo("The workflowInstance s ready to pause, the workflow status s {}", executonStatus); return executonStatus; } // stop f (state == ExecutonStatus.READY_STOP) { Lst<TaskInstance> stopLst = getCompleteTaskByState(ExecutonStatus.STOP); Lst<TaskInstance> kllLst = getCompleteTaskByState(ExecutonStatus.KILL); Lst<TaskInstance> falLst = getCompleteTaskByState(ExecutonStatus.FAILURE); ExecutonStatus executonStatus; f (CollectonUtls.sNotEmpty(stopLst) || CollectonUtls.sNotEmpty(kllLst) || CollectonUtls.sNotEmpty(falLst) || !sComplementEnd()) {
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
executonStatus = ExecutonStatus.STOP; } else { executonStatus = ExecutonStatus.SUCCESS; } logger.nfo("The workflowInstance s ready to stop, the workflow status s {}", executonStatus); return executonStatus; } // process falure f (processFaled()) { logger.nfo("The workflowInstance s faled, the workflow status s {}", ExecutonStatus.FAILURE); return ExecutonStatus.FAILURE; } // success f (state == ExecutonStatus.RUNNING_EXECUTION) { Lst<TaskInstance> kllTasks = getCompleteTaskByState(ExecutonStatus.KILL); f (readyToSubmtTaskQueue.sze() > 0 || watToRetryTaskInstanceMap.sze() > 0) { //tasks cu return ExecutonStatus.RUNNING_EXECUTION; } else f (CollectonUtls.sNotEmpty(kllTasks)) { // tasks m return ExecutonStatus.FAILURE; } else { // f the return ExecutonStatus.SUCCESS; } } return state; } /** * whether complement end
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
* * @return Boolean whether s complement end */ prvate boolean sComplementEnd() { f (!processInstance.sComplementData()) { return true; } Map<Strng, Strng> cmdParam = JSONUtls.toMap(processInstance.getCommandParam()); Date endTme = DateUtls.strngToDate(cmdParam.get(CMDPARAM_COMPLEMENT_DATA_END_DATE)); return processInstance.getScheduleTme().equals(endTme); } /** * updateProcessInstance process nstance state * after each batch of tasks s executed, of the process nstance s updated */ prvate vod updateProcessInstanceState() throws StateEventHandleExcepton { ExecutonStatus state = getProcessInstanceState(processInstance); f (processInstance.getState() != state) { logger.nfo("Update workflowInstance states, orgn state: {}, target state: {}", processInstance.getState(), state); updateWorkflowInstanceStatesToDB(state); StateEvent stateEvent = new StateEvent(); stateEvent.setExecutonStatus(processInstance.getState()); stateEvent.setProcessInstanceId(ths.processInstance.getId()); stateEvent.setType(StateEventType.PROCESS_STATE_CHANGE); // replace ths.stateEvents.add(stateEvent); } else { logger.nfo("There s no need to update the workflow nstance state, orgn state: {}, target state: {}",
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
processInstance.getState(), state); } } /** * stateEvent's executon status as process nstance state */ publc vod updateProcessInstanceState(StateEvent stateEvent) throws StateEventHandleExcepton { ExecutonStatus state = stateEvent.getExecutonStatus(); updateWorkflowInstanceStatesToDB(state); } prvate vod updateWorkflowInstanceStatesToDB(ExecutonStatus newStates) throws StateEventHandleExcepton { ExecutonStatus orgnStates = processInstance.getState(); f (orgnStates != newStates) { logger.nfo("Begn to update workflow nstance state , state wll change from {} to {}", orgnStates, newStates); processInstance.setState(newStates); f (newStates.typeIsFnshed()) { processInstance.setEndTme(new Date()); } try { processServce.updateProcessInstance(processInstance); } catch (Excepton ex) { // recover processInstance.setState(orgnStates); processInstance.setEndTme(null); throw new StateEventHandleExcepton("Update process nstance status to DB error", ex); } }
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
} /** * get task dependency result * * @param taskInstance task nstance * @return DependResult */ prvate DependResult getDependResultForTask(TaskInstance taskInstance) { return sTaskDepsComplete(Long.toStrng(taskInstance.getTaskCode())); } /** * add task to standby lst * * @param taskInstance task nstance */ publc vod addTaskToStandByLst(TaskInstance taskInstance) { f (readyToSubmtTaskQueue.contans(taskInstance)) { logger.warn("task was found n ready submt queue, task code:{}", taskInstance.getTaskCode()); return; } logger.nfo("add task to stand by lst, task name:{}, task d:{}, task code:{}", taskInstance.getName(), taskInstance.getId(), taskInstance.getTaskCode()); TaskMetrcs.ncTaskInstanceByState("submt"); readyToSubmtTaskQueue.put(taskInstance); } /** * remove task from stand by lst *
closed
apache/dolphinscheduler
https://github.com/apache/dolphinscheduler
11,253
[Bug] [Master] TaskGroup cannot work and will cause master handle event dead loop.
### Search before asking - [X] I had searched in the [issues](https://github.com/apache/dolphinscheduler/issues?q=is%3Aissue) and found no similar issues. ### What happened I find when we create a workflow with TaskGroup, the workflow may go into dead loop, and status will still in running. ### What you expected to happen work well ### How to reproduce 1. Create a TaskGroup with 3 capaticy. 2. Create a workflow with 6 task, and each task has a unique priority, e.g 1, 2, 3, 4, 5, 6, and use the task group 3. Execute the workflow, find the workflow instance is always running and the master handle event task state change event dead loop, cause by release task group deap loop. ### Anything else _No response_ ### Version dev ### Are you willing to submit PR? - [X] Yes I am willing to submit a PR! ### Code of Conduct - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
https://github.com/apache/dolphinscheduler/issues/11253
https://github.com/apache/dolphinscheduler/pull/11254
aef2fbf36c76d4dbfcf566ec959acea00e7bec4e
acd3d3fab14d08b3b06015be3ac9cfb2f4bfc934
2022-08-02T08:02:09Z
java
2022-08-04T06:43:45Z
dolphinscheduler-master/src/main/java/org/apache/dolphinscheduler/server/master/runner/WorkflowExecuteRunnable.java
* @param taskInstance task nstance */ prvate boolean removeTaskFromStandbyLst(TaskInstance taskInstance) { return readyToSubmtTaskQueue.remove(taskInstance); } /** * has retry task n standby * * @return Boolean whether has retry task n standby */ prvate boolean hasRetryTaskInStandBy() { for (Iterator<TaskInstance> ter = readyToSubmtTaskQueue.terator(); ter.hasNext(); ) { f (ter.next().getState().typeIsFalure()) { return true; } } return false; } /** * close the on gong tasks */ publc vod kllAllTasks() { logger.nfo("kll called on process nstance d: {}, num: {}", processInstance.getId(), actveTaskProcessorMaps.sze()); f (readyToSubmtTaskQueue.sze() > 0) { readyToSubmtTaskQueue.clear(); } for (long taskCode : actveTaskProcessorMaps.keySet()) { ITaskProcessor taskProcessor = actveTaskProcessorMaps.get(taskCode);