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,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 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();
for (nt = 0; < length; ++) {
TaskInstance task = readyToSubmtTaskQueue.peek();
f (task == 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
|
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
f (!removeTaskFromStandbyLst(task)) {
logger.error(
"Task submt faled, remove from standby lst faled, workflowInstanceId: {}, 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
|
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);
}
}
}
/**
* Get start task nstance lst from recover
*
* @param cmdParam command param
|
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 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)) {
Lst<Integer> startTaskInstanceIds = Arrays.stream(paramMap.get(CMD_PARAM_RECOVERY_START_NODE_STRING)
.splt(COMMA))
.flter(StrngUtls::sNotEmpty)
.map(Integer::valueOf)
.collect(Collectors.toLst());
f (CollectonUtls.sNotEmpty(startTaskInstanceIds)) {
return processServce.fndTaskInstanceByIdLst(startTaskInstanceIds);
}
}
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,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
|
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,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> 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,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(),
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,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 (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,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/task/CommonTaskProcessor.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
|
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/task/CommonTaskProcessor.java
|
*
* 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.runner.task;
import org.apache.dolphinscheduler.common.Constants;
import org.apache.dolphinscheduler.plugin.task.api.TaskExecutionContext;
import org.apache.dolphinscheduler.plugin.task.api.enums.ExecutionStatus;
import org.apache.dolphinscheduler.remote.command.TaskKillRequestCommand;
import org.apache.dolphinscheduler.remote.utils.Host;
import org.apache.dolphinscheduler.server.master.dispatch.context.ExecutionContext;
import org.apache.dolphinscheduler.server.master.dispatch.enums.ExecutorType;
import org.apache.dolphinscheduler.server.master.dispatch.exceptions.ExecuteException;
import org.apache.dolphinscheduler.server.master.dispatch.executor.NettyExecutorManager;
import org.apache.dolphinscheduler.service.bean.SpringApplicationContext;
import org.apache.dolphinscheduler.service.queue.TaskPriority;
import org.apache.dolphinscheduler.service.queue.TaskPriorityQueue;
import org.apache.dolphinscheduler.service.queue.TaskPriorityQueueImpl;
import org.apache.commons.lang3.StringUtils;
import java.util.Date;
import com.google.auto.service.AutoService;
/**
* common task processor
*/
@AutoService(ITaskProcessor.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/runner/task/CommonTaskProcessor.java
|
public class CommonTaskProcessor extends BaseTaskProcessor {
private TaskPriorityQueue<TaskPriority> taskUpdateQueue;
private NettyExecutorManager nettyExecutorManager = SpringApplicationContext.getBean(NettyExecutorManager.class);
@Override
protected boolean submitTask() {
this.taskInstance = processService.submitTaskWithRetry(processInstance, taskInstance, maxRetryTimes, commitInterval);
if (this.taskInstance == null) {
return false;
}
int taskGroupId = taskInstance.getTaskGroupId();
if (taskGroupId > 0) {
boolean acquireTaskGroup = processService.acquireTaskGroup(taskInstance.getId(),
taskInstance.getName(),
taskGroupId,
taskInstance.getProcessInstanceId(),
taskInstance.getTaskGroupPriority());
if (!acquireTaskGroup) {
logger.info("submit task name :{}, but the first time to try to acquire task group failed", taskInstance.getName());
return true;
}
}
return true;
}
@Override
protected boolean resubmitTask() {
if (this.taskInstance == null) {
return false;
}
setTaskExecutionLogger();
|
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/task/CommonTaskProcessor.java
|
return dispatchTask();
}
@Override
public boolean runTask() {
return true;
}
@Override
protected boolean taskTimeout() {
return true;
}
/**
* common task cannot be paused
*/
@Override
protected boolean pauseTask() {
return true;
}
@Override
public String getType() {
return Constants.COMMON_TASK_TYPE;
}
@Override
public boolean dispatchTask() {
try {
if (taskUpdateQueue == null) {
this.initQueue();
}
if (taskInstance.getState().typeIsFinished()) {
logger.info("submit task , but task [{}] state [{}] is already finished. ", taskInstance.getName(), taskInstance.getState());
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/task/CommonTaskProcessor.java
|
}
if (taskInstance.getState() == ExecutionStatus.RUNNING_EXECUTION
|| taskInstance.getState() == ExecutionStatus.DELAY_EXECUTION) {
logger.info("submit task, but the status of the task {} is already running or delayed.", taskInstance.getName());
return true;
}
logger.info("task ready to dispatch to worker: taskInstanceId: {}", taskInstance.getId());
TaskPriority taskPriority = new TaskPriority(processInstance.getProcessInstancePriority().getCode(),
processInstance.getId(), taskInstance.getProcessInstancePriority().getCode(),
taskInstance.getId(), taskInstance.getTaskGroupPriority(), org.apache.dolphinscheduler.common.Constants.DEFAULT_WORKER_GROUP);
TaskExecutionContext taskExecutionContext = getTaskExecutionContext(taskInstance);
if (taskExecutionContext == null) {
logger.error("task get taskExecutionContext fail: {}", taskInstance);
return false;
}
taskPriority.setTaskExecutionContext(taskExecutionContext);
taskUpdateQueue.put(taskPriority);
logger.info("Master submit task to priority queue success, taskInstanceId : {}", taskInstance.getId());
return true;
} catch (Exception e) {
logger.error("submit task error", e);
return false;
}
}
public void initQueue() {
this.taskUpdateQueue = SpringApplicationContext.getBean(TaskPriorityQueueImpl.class);
}
@Override
public boolean killTask() {
|
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/task/CommonTaskProcessor.java
|
try {
taskInstance = processService.findTaskInstanceById(taskInstance.getId());
if (taskInstance == null) {
return true;
}
if (taskInstance.getState().typeIsFinished()) {
return true;
}
if (StringUtils.isBlank(taskInstance.getHost())) {
taskInstance.setState(ExecutionStatus.KILL);
taskInstance.setEndTime(new Date());
processService.updateTaskInstance(taskInstance);
return true;
}
TaskKillRequestCommand killCommand = new TaskKillRequestCommand();
killCommand.setTaskInstanceId(taskInstance.getId());
ExecutionContext executionContext = new ExecutionContext(killCommand.convert2Command(), ExecutorType.WORKER, taskInstance);
Host host = Host.of(taskInstance.getHost());
executionContext.setHost(host);
nettyExecutorManager.executeDirectly(executionContext);
} catch (ExecuteException e) {
logger.error("kill task error:", e);
return false;
}
logger.info("master kill taskInstance name :{} taskInstance id:{}",
taskInstance.getName(), taskInstance.getId());
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessService.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.service.process;
import org.apache.dolphinscheduler.common.enums.AuthorizationType;
import org.apache.dolphinscheduler.common.enums.TaskGroupQueueStatus;
import org.apache.dolphinscheduler.common.graph.DAG;
import org.apache.dolphinscheduler.common.model.TaskNode;
import org.apache.dolphinscheduler.common.model.TaskNodeRelation;
import org.apache.dolphinscheduler.common.utils.CodeGenerateUtils;
import org.apache.dolphinscheduler.dao.entity.Command;
import org.apache.dolphinscheduler.dao.entity.DagData;
import org.apache.dolphinscheduler.dao.entity.DataSource;
import org.apache.dolphinscheduler.dao.entity.DependentProcessDefinition;
import org.apache.dolphinscheduler.dao.entity.DqComparisonType;
import org.apache.dolphinscheduler.dao.entity.DqExecuteResult;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessService.java
|
import org.apache.dolphinscheduler.dao.entity.DqRule;
import org.apache.dolphinscheduler.dao.entity.DqRuleExecuteSql;
import org.apache.dolphinscheduler.dao.entity.DqRuleInputEntry;
import org.apache.dolphinscheduler.dao.entity.Environment;
import org.apache.dolphinscheduler.dao.entity.ProcessDefinition;
import org.apache.dolphinscheduler.dao.entity.ProcessDefinitionLog;
import org.apache.dolphinscheduler.dao.entity.ProcessInstance;
import org.apache.dolphinscheduler.dao.entity.ProcessInstanceMap;
import org.apache.dolphinscheduler.dao.entity.ProcessTaskRelation;
import org.apache.dolphinscheduler.dao.entity.ProcessTaskRelationLog;
import org.apache.dolphinscheduler.dao.entity.Project;
import org.apache.dolphinscheduler.dao.entity.ProjectUser;
import org.apache.dolphinscheduler.dao.entity.Resource;
import org.apache.dolphinscheduler.dao.entity.Schedule;
import org.apache.dolphinscheduler.dao.entity.TaskDefinition;
import org.apache.dolphinscheduler.dao.entity.TaskDefinitionLog;
import org.apache.dolphinscheduler.dao.entity.TaskGroupQueue;
import org.apache.dolphinscheduler.dao.entity.TaskInstance;
import org.apache.dolphinscheduler.dao.entity.Tenant;
import org.apache.dolphinscheduler.dao.entity.UdfFunc;
import org.apache.dolphinscheduler.dao.entity.User;
import org.apache.dolphinscheduler.plugin.task.api.enums.ExecutionStatus;
import org.apache.dolphinscheduler.plugin.task.api.model.DateInterval;
import org.apache.dolphinscheduler.service.exceptions.CronParseException;
import org.apache.dolphinscheduler.spi.enums.ResourceType;
import java.util.Date;
import java.util.List;
import java.util.Map;
import org.springframework.transaction.annotation.Transactional;
public interface ProcessService {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessService.java
|
@Transactional
ProcessInstance handleCommand(String host, Command command)
throws CronParseException, CodeGenerateUtils.CodeGenerateException;
void moveToErrorCommand(Command command, String message);
int createCommand(Command command);
List<Command> findCommandPage(int pageSize, int pageNumber);
List<Command> findCommandPageBySlot(int pageSize, int pageNumber, int masterCount, int thisMasterSlot);
boolean verifyIsNeedCreateCommand(Command command);
ProcessInstance findProcessInstanceDetailById(int processId);
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessService.java
|
List<TaskDefinition> getTaskNodeListByDefinition(long defineCode);
ProcessInstance findProcessInstanceById(int processId);
ProcessDefinition findProcessDefineById(int processDefinitionId);
ProcessDefinition findProcessDefinition(Long processDefinitionCode, int processDefinitionVersion);
ProcessDefinition findProcessDefinitionByCode(Long processDefinitionCode);
int deleteWorkProcessInstanceById(int processInstanceId);
int deleteAllSubWorkProcessByParentId(int processInstanceId);
void removeTaskLogFile(Integer processInstanceId);
void deleteWorkTaskInstanceByProcessInstanceId(int processInstanceId);
void recurseFindSubProcess(long parentCode, List<Long> ids);
void createRecoveryWaitingThreadCommand(Command originCommand, ProcessInstance processInstance);
Tenant getTenantForProcess(int tenantId, int userId);
Environment findEnvironmentByCode(Long environmentCode);
void setSubProcessParam(ProcessInstance subProcessInstance);
TaskInstance submitTaskWithRetry(ProcessInstance processInstance, TaskInstance taskInstance, int commitRetryTimes, long commitInterval);
@Transactional
TaskInstance submitTask(ProcessInstance processInstance, TaskInstance taskInstance);
void createSubWorkProcess(ProcessInstance parentProcessInstance, TaskInstance task);
Map<String, String> getGlobalParamMap(String globalParams);
Command createSubProcessCommand(ProcessInstance parentProcessInstance,
ProcessInstance childInstance,
ProcessInstanceMap instanceMap,
TaskInstance task);
TaskInstance submitTaskInstanceToDB(TaskInstance taskInstance, ProcessInstance processInstance);
ExecutionStatus getSubmitTaskState(TaskInstance taskInstance, ProcessInstance processInstance);
void saveProcessInstance(ProcessInstance processInstance);
int saveCommand(Command command);
boolean saveTaskInstance(TaskInstance taskInstance);
boolean createTaskInstance(TaskInstance taskInstance);
boolean updateTaskInstance(TaskInstance taskInstance);
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessService.java
|
TaskInstance findTaskInstanceById(Integer taskId);
List<TaskInstance> findTaskInstanceByIdList(List<Integer> idList);
void packageTaskInstance(TaskInstance taskInstance, ProcessInstance processInstance);
void updateTaskDefinitionResources(TaskDefinition taskDefinition);
List<Integer> findTaskIdByInstanceState(int instanceId, ExecutionStatus state);
List<TaskInstance> findValidTaskListByProcessId(Integer processInstanceId);
List<TaskInstance> findPreviousTaskListByWorkProcessId(Integer processInstanceId);
int updateWorkProcessInstanceMap(ProcessInstanceMap processInstanceMap);
int createWorkProcessInstanceMap(ProcessInstanceMap processInstanceMap);
ProcessInstanceMap findWorkProcessMapByParent(Integer parentWorkProcessId, Integer parentTaskId);
int deleteWorkProcessMapByParentId(int parentWorkProcessId);
ProcessInstance findSubProcessInstance(Integer parentProcessId, Integer parentTaskId);
ProcessInstance findParentProcessInstance(Integer subProcessId);
int updateProcessInstance(ProcessInstance processInstance);
void changeOutParam(TaskInstance taskInstance);
Schedule querySchedule(int id);
List<Schedule> queryReleaseSchedulerListByProcessDefinitionCode(long processDefinitionCode);
Map<Long, String> queryWorkerGroupByProcessDefinitionCodes(List<Long> processDefinitionCodeList);
List<DependentProcessDefinition> queryDependentProcessDefinitionByProcessDefinitionCode(long processDefinitionCode);
List<ProcessInstance> queryNeedFailoverProcessInstances(String host);
List<String> queryNeedFailoverProcessInstanceHost();
@Transactional
void processNeedFailoverProcessInstances(ProcessInstance processInstance);
List<TaskInstance> queryNeedFailoverTaskInstances(String host);
DataSource findDataSourceById(int id);
int updateProcessInstanceState(Integer processInstanceId, ExecutionStatus executionStatus);
ProcessInstance findProcessInstanceByTaskId(int taskId);
List<UdfFunc> queryUdfFunListByIds(Integer[] ids);
String queryTenantCodeByResName(String resName, ResourceType resourceType);
List<Schedule> selectAllByProcessDefineCode(long[] codes);
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessService.java
|
ProcessInstance findLastSchedulerProcessInterval(Long definitionCode, DateInterval dateInterval);
ProcessInstance findLastManualProcessInterval(Long definitionCode, DateInterval dateInterval);
ProcessInstance findLastRunningProcess(Long definitionCode, Date startTime, Date endTime);
String queryUserQueueByProcessInstance(ProcessInstance processInstance);
ProjectUser queryProjectWithUserByProcessInstanceId(int processInstanceId);
String getTaskWorkerGroup(TaskInstance taskInstance);
List<Project> getProjectListHavePerm(int userId);
<T> List<T> listUnauthorized(int userId, T[] needChecks, AuthorizationType authorizationType);
User getUserById(int userId);
Resource getResourceById(int resourceId);
List<Resource> listResourceByIds(Integer[] resIds);
String formatTaskAppId(TaskInstance taskInstance);
int switchVersion(ProcessDefinition processDefinition, ProcessDefinitionLog processDefinitionLog);
int switchProcessTaskRelationVersion(ProcessDefinition processDefinition);
int switchTaskDefinitionVersion(long taskCode, int taskVersion);
String getResourceIds(TaskDefinition taskDefinition);
int saveTaskDefine(User operator, long projectCode, List<TaskDefinitionLog> taskDefinitionLogs, Boolean syncDefine);
int saveProcessDefine(User operator, ProcessDefinition processDefinition, Boolean syncDefine, Boolean isFromProcessDefine);
int saveTaskRelation(User operator, long projectCode, long processDefinitionCode, int processDefinitionVersion,
List<ProcessTaskRelationLog> taskRelationList, List<TaskDefinitionLog> taskDefinitionLogs,
Boolean syncDefine);
boolean isTaskOnline(long taskCode);
DAG<String, TaskNode, TaskNodeRelation> genDagGraph(ProcessDefinition processDefinition);
DagData genDagData(ProcessDefinition processDefinition);
List<TaskDefinitionLog> genTaskDefineList(List<ProcessTaskRelation> processTaskRelations);
List<TaskDefinitionLog> getTaskDefineLogListByRelation(List<ProcessTaskRelation> processTaskRelations);
TaskDefinition findTaskDefinition(long taskCode, int taskDefinitionVersion);
List<ProcessTaskRelation> findRelationByCode(long processDefinitionCode, int processDefinitionVersion);
List<TaskNode> transformTask(List<ProcessTaskRelation> taskRelationList, List<TaskDefinitionLog> taskDefinitionLogs);
Map<ProcessInstance, TaskInstance> notifyProcessList(int processId);
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessService.java
|
DqExecuteResult getDqExecuteResultByTaskInstanceId(int taskInstanceId);
int updateDqExecuteResultUserId(int taskInstanceId);
int updateDqExecuteResultState(DqExecuteResult dqExecuteResult);
int deleteDqExecuteResultByTaskInstanceId(int taskInstanceId);
int deleteTaskStatisticsValueByTaskInstanceId(int taskInstanceId);
DqRule getDqRule(int ruleId);
List<DqRuleInputEntry> getRuleInputEntry(int ruleId);
List<DqRuleExecuteSql> getDqExecuteSql(int ruleId);
DqComparisonType getComparisonTypeById(int id);
boolean acquireTaskGroup(int taskId,
String taskName, int groupId,
int processId, int priority);
boolean robTaskGroupResouce(TaskGroupQueue taskGroupQueue);
boolean acquireTaskGroupAgain(TaskGroupQueue taskGroupQueue);
void releaseAllTaskGroup(int processInstanceId);
TaskInstance releaseTaskGroup(TaskInstance taskInstance);
void changeTaskGroupQueueStatus(int taskId, TaskGroupQueueStatus status);
TaskGroupQueue insertIntoTaskGroupQueue(Integer taskId,
String taskName, Integer groupId,
Integer processId, Integer priority, TaskGroupQueueStatus status);
int updateTaskGroupQueueStatus(Integer taskId, int status);
int updateTaskGroupQueue(TaskGroupQueue taskGroupQueue);
TaskGroupQueue loadTaskGroupQueue(int taskId);
void sendStartTask2Master(ProcessInstance processInstance, int taskId,
org.apache.dolphinscheduler.remote.command.CommandType taskType);
ProcessInstance loadNextProcess4Serial(long code, int state, int id);
public String findConfigYamlByName(String clusterName) ;
void forceProcessInstanceSuccessByTaskInstanceId(Integer 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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.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.
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package org.apache.dolphinscheduler.service.process;
import static java.util.stream.Collectors.toSet;
import static org.apache.dolphinscheduler.common.Constants.CMDPARAM_COMPLEMENT_DATA_END_DATE;
import static org.apache.dolphinscheduler.common.Constants.CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST;
import static org.apache.dolphinscheduler.common.Constants.CMDPARAM_COMPLEMENT_DATA_START_DATE;
import static org.apache.dolphinscheduler.common.Constants.CMD_PARAM_EMPTY_SUB_PROCESS;
import static org.apache.dolphinscheduler.common.Constants.CMD_PARAM_FATHER_PARAMS;
import static org.apache.dolphinscheduler.common.Constants.CMD_PARAM_RECOVER_PROCESS_ID_STRING;
import static org.apache.dolphinscheduler.common.Constants.CMD_PARAM_SUB_PROCESS;
import static org.apache.dolphinscheduler.common.Constants.CMD_PARAM_SUB_PROCESS_DEFINE_CODE;
import static org.apache.dolphinscheduler.common.Constants.CMD_PARAM_SUB_PROCESS_PARENT_INSTANCE_ID;
import static org.apache.dolphinscheduler.common.Constants.LOCAL_PARAMS;
import static org.apache.dolphinscheduler.plugin.task.api.enums.DataType.VARCHAR;
import static org.apache.dolphinscheduler.plugin.task.api.enums.Direct.IN;
import static org.apache.dolphinscheduler.plugin.task.api.utils.DataQualityConstants.TASK_INSTANCE_ID;
import org.apache.dolphinscheduler.common.Constants;
import org.apache.dolphinscheduler.common.enums.AuthorizationType;
import org.apache.dolphinscheduler.common.enums.CommandType;
import org.apache.dolphinscheduler.common.enums.FailureStrategy;
import org.apache.dolphinscheduler.common.enums.Flag;
import org.apache.dolphinscheduler.common.enums.ReleaseState;
import org.apache.dolphinscheduler.common.enums.TaskDependType;
import org.apache.dolphinscheduler.common.enums.TaskGroupQueueStatus;
import org.apache.dolphinscheduler.common.enums.TimeoutFlag;
import org.apache.dolphinscheduler.common.enums.WarningType;
import org.apache.dolphinscheduler.common.graph.DAG;
import org.apache.dolphinscheduler.common.model.TaskNode;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
import org.apache.dolphinscheduler.common.model.TaskNodeRelation;
import org.apache.dolphinscheduler.common.process.ProcessDag;
import org.apache.dolphinscheduler.common.utils.CodeGenerateUtils;
import org.apache.dolphinscheduler.common.utils.CodeGenerateUtils.CodeGenerateException;
import org.apache.dolphinscheduler.common.utils.DateUtils;
import org.apache.dolphinscheduler.common.utils.JSONUtils;
import org.apache.dolphinscheduler.dao.entity.Command;
import org.apache.dolphinscheduler.dao.entity.DagData;
import org.apache.dolphinscheduler.dao.entity.DataSource;
import org.apache.dolphinscheduler.dao.entity.DependentProcessDefinition;
import org.apache.dolphinscheduler.dao.entity.DqComparisonType;
import org.apache.dolphinscheduler.dao.entity.DqExecuteResult;
import org.apache.dolphinscheduler.dao.entity.DqRule;
import org.apache.dolphinscheduler.dao.entity.DqRuleExecuteSql;
import org.apache.dolphinscheduler.dao.entity.DqRuleInputEntry;
import org.apache.dolphinscheduler.dao.entity.DqTaskStatisticsValue;
import org.apache.dolphinscheduler.dao.entity.Environment;
import org.apache.dolphinscheduler.dao.entity.ErrorCommand;
import org.apache.dolphinscheduler.dao.entity.K8s;
import org.apache.dolphinscheduler.dao.entity.ProcessDefinition;
import org.apache.dolphinscheduler.dao.entity.ProcessDefinitionLog;
import org.apache.dolphinscheduler.dao.entity.ProcessInstance;
import org.apache.dolphinscheduler.dao.entity.ProcessInstanceMap;
import org.apache.dolphinscheduler.dao.entity.ProcessTaskRelation;
import org.apache.dolphinscheduler.dao.entity.ProcessTaskRelationLog;
import org.apache.dolphinscheduler.dao.entity.Project;
import org.apache.dolphinscheduler.dao.entity.ProjectUser;
import org.apache.dolphinscheduler.dao.entity.Resource;
import org.apache.dolphinscheduler.dao.entity.Schedule;
import org.apache.dolphinscheduler.dao.entity.TaskDefinition;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
import org.apache.dolphinscheduler.dao.entity.TaskDefinitionLog;
import org.apache.dolphinscheduler.dao.entity.TaskGroup;
import org.apache.dolphinscheduler.dao.entity.TaskGroupQueue;
import org.apache.dolphinscheduler.dao.entity.TaskInstance;
import org.apache.dolphinscheduler.dao.entity.Tenant;
import org.apache.dolphinscheduler.dao.entity.UdfFunc;
import org.apache.dolphinscheduler.dao.entity.User;
import org.apache.dolphinscheduler.dao.mapper.CommandMapper;
import org.apache.dolphinscheduler.dao.mapper.DataSourceMapper;
import org.apache.dolphinscheduler.dao.mapper.DqComparisonTypeMapper;
import org.apache.dolphinscheduler.dao.mapper.DqExecuteResultMapper;
import org.apache.dolphinscheduler.dao.mapper.DqRuleExecuteSqlMapper;
import org.apache.dolphinscheduler.dao.mapper.DqRuleInputEntryMapper;
import org.apache.dolphinscheduler.dao.mapper.DqRuleMapper;
import org.apache.dolphinscheduler.dao.mapper.DqTaskStatisticsValueMapper;
import org.apache.dolphinscheduler.dao.mapper.EnvironmentMapper;
import org.apache.dolphinscheduler.dao.mapper.ErrorCommandMapper;
import org.apache.dolphinscheduler.dao.mapper.K8sMapper;
import org.apache.dolphinscheduler.dao.mapper.ProcessDefinitionLogMapper;
import org.apache.dolphinscheduler.dao.mapper.ProcessDefinitionMapper;
import org.apache.dolphinscheduler.dao.mapper.ProcessInstanceMapMapper;
import org.apache.dolphinscheduler.dao.mapper.ProcessInstanceMapper;
import org.apache.dolphinscheduler.dao.mapper.ProcessTaskRelationLogMapper;
import org.apache.dolphinscheduler.dao.mapper.ProcessTaskRelationMapper;
import org.apache.dolphinscheduler.dao.mapper.ProjectMapper;
import org.apache.dolphinscheduler.dao.mapper.ResourceMapper;
import org.apache.dolphinscheduler.dao.mapper.ResourceUserMapper;
import org.apache.dolphinscheduler.dao.mapper.ScheduleMapper;
import org.apache.dolphinscheduler.dao.mapper.TaskDefinitionLogMapper;
import org.apache.dolphinscheduler.dao.mapper.TaskDefinitionMapper;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
import org.apache.dolphinscheduler.dao.mapper.TaskGroupMapper;
import org.apache.dolphinscheduler.dao.mapper.TaskGroupQueueMapper;
import org.apache.dolphinscheduler.dao.mapper.TaskInstanceMapper;
import org.apache.dolphinscheduler.dao.mapper.TenantMapper;
import org.apache.dolphinscheduler.dao.mapper.UdfFuncMapper;
import org.apache.dolphinscheduler.dao.mapper.UserMapper;
import org.apache.dolphinscheduler.dao.mapper.WorkFlowLineageMapper;
import org.apache.dolphinscheduler.dao.utils.DagHelper;
import org.apache.dolphinscheduler.dao.utils.DqRuleUtils;
import org.apache.dolphinscheduler.plugin.task.api.enums.Direct;
import org.apache.dolphinscheduler.plugin.task.api.enums.ExecutionStatus;
import org.apache.dolphinscheduler.plugin.task.api.enums.dp.DqTaskState;
import org.apache.dolphinscheduler.plugin.task.api.model.DateInterval;
import org.apache.dolphinscheduler.plugin.task.api.model.Property;
import org.apache.dolphinscheduler.plugin.task.api.model.ResourceInfo;
import org.apache.dolphinscheduler.plugin.task.api.parameters.AbstractParameters;
import org.apache.dolphinscheduler.plugin.task.api.parameters.ParametersNode;
import org.apache.dolphinscheduler.plugin.task.api.parameters.SubProcessParameters;
import org.apache.dolphinscheduler.plugin.task.api.parameters.TaskTimeoutParameter;
import org.apache.dolphinscheduler.remote.command.StateEventChangeCommand;
import org.apache.dolphinscheduler.remote.command.TaskEventChangeCommand;
import org.apache.dolphinscheduler.remote.processor.StateEventCallbackService;
import org.apache.dolphinscheduler.remote.utils.Host;
import org.apache.dolphinscheduler.service.cron.CronUtils;
import org.apache.dolphinscheduler.service.exceptions.CronParseException;
import org.apache.dolphinscheduler.service.exceptions.ServiceException;
import org.apache.dolphinscheduler.service.expand.CuringParamsService;
import org.apache.dolphinscheduler.service.log.LogClientService;
import org.apache.dolphinscheduler.service.task.TaskPluginManager;
import org.apache.dolphinscheduler.spi.enums.ResourceType;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
import org.apache.dolphinscheduler.spi.utils.StringUtils;
import org.apache.commons.collections.CollectionUtils;
import java.util.ArrayList;
import java.util.Arrays;
import java.util.Date;
import java.util.EnumMap;
import java.util.HashMap;
import java.util.HashSet;
import java.util.List;
import java.util.Map;
import java.util.Map.Entry;
import java.util.Objects;
import java.util.Set;
import java.util.stream.Collectors;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.stereotype.Component;
import org.springframework.transaction.annotation.Transactional;
import com.baomidou.mybatisplus.core.conditions.query.QueryWrapper;
import com.fasterxml.jackson.core.type.TypeReference;
import com.fasterxml.jackson.databind.node.ObjectNode;
import com.google.common.base.Joiner;
import com.google.common.base.Strings;
import com.google.common.collect.Lists;
import io.micrometer.core.annotation.Counted;
/**
* process relative dao that some mappers in this.
*/
@Component
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
public class ProcessServiceImpl implements ProcessService {
private final Logger logger = LoggerFactory.getLogger(getClass());
@Autowired
private UserMapper userMapper;
@Autowired
private ProcessDefinitionMapper processDefineMapper;
@Autowired
private ProcessDefinitionLogMapper processDefineLogMapper;
@Autowired
private ProcessInstanceMapper processInstanceMapper;
@Autowired
private DataSourceMapper dataSourceMapper;
@Autowired
private ProcessInstanceMapMapper processInstanceMapMapper;
@Autowired
private TaskInstanceMapper taskInstanceMapper;
@Autowired
private CommandMapper commandMapper;
@Autowired
private ScheduleMapper scheduleMapper;
@Autowired
private UdfFuncMapper udfFuncMapper;
@Autowired
private ResourceMapper resourceMapper;
@Autowired
private ResourceUserMapper resourceUserMapper;
@Autowired
private ErrorCommandMapper errorCommandMapper;
@Autowired
private TenantMapper tenantMapper;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
@Autowired
private ProjectMapper projectMapper;
@Autowired
private DqExecuteResultMapper dqExecuteResultMapper;
@Autowired
private DqRuleMapper dqRuleMapper;
@Autowired
private DqRuleInputEntryMapper dqRuleInputEntryMapper;
@Autowired
private DqRuleExecuteSqlMapper dqRuleExecuteSqlMapper;
@Autowired
private DqComparisonTypeMapper dqComparisonTypeMapper;
@Autowired
private DqTaskStatisticsValueMapper dqTaskStatisticsValueMapper;
@Autowired
private TaskDefinitionMapper taskDefinitionMapper;
@Autowired
private TaskDefinitionLogMapper taskDefinitionLogMapper;
@Autowired
private ProcessTaskRelationMapper processTaskRelationMapper;
@Autowired
private ProcessTaskRelationLogMapper processTaskRelationLogMapper;
@Autowired
StateEventCallbackService stateEventCallbackService;
@Autowired
private EnvironmentMapper environmentMapper;
@Autowired
private TaskGroupQueueMapper taskGroupQueueMapper;
@Autowired
private TaskGroupMapper taskGroupMapper;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
@Autowired
private WorkFlowLineageMapper workFlowLineageMapper;
@Autowired
private TaskPluginManager taskPluginManager;
@Autowired
private K8sMapper k8sMapper;
@Autowired
private CuringParamsService curingGlobalParamsService;
@Autowired
private ProcessService processService;
/**
* handle Command (construct ProcessInstance from Command) , wrapped in transaction
*
* @param host host
* @param command found command
* @return process instance
*/
@Override
@Transactional
public ProcessInstance handleCommand(String host, Command command) throws CronParseException,
CodeGenerateException {
ProcessInstance processInstance = constructProcessInstance(command, host);
if (processInstance == null) {
logger.error("scan command, command parameter is error: {}", command);
moveToErrorCommand(command, "process instance is null");
return null;
}
processInstance.setCommandType(command.getCommandType());
processInstance.addHistoryCmd(command.getCommandType());
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
ProcessDefinition processDefinition = this.findProcessDefinition(processInstance.getProcessDefinitionCode(), processInstance.getProcessDefinitionVersion());
if (processDefinition.getExecutionType().typeIsSerial()) {
saveSerialProcess(processInstance, processDefinition);
if (processInstance.getState() != ExecutionStatus.SUBMITTED_SUCCESS) {
setSubProcessParam(processInstance);
deleteCommandWithCheck(command.getId());
return null;
}
} else {
saveProcessInstance(processInstance);
}
setSubProcessParam(processInstance);
deleteCommandWithCheck(command.getId());
return processInstance;
}
protected void saveSerialProcess(ProcessInstance processInstance, ProcessDefinition processDefinition) {
processInstance.setState(ExecutionStatus.SERIAL_WAIT);
saveProcessInstance(processInstance);
if (processDefinition.getExecutionType().typeIsSerialWait()) {
List<ProcessInstance> runningProcessInstances = this.processInstanceMapper.queryByProcessDefineCodeAndProcessDefinitionVersionAndStatusAndNextId(processInstance.getProcessDefinitionCode(),
processInstance.getProcessDefinitionVersion(), Constants.RUNNING_PROCESS_STATE, processInstance.getId());
if (CollectionUtils.isEmpty(runningProcessInstances)) {
processInstance.setState(ExecutionStatus.SUBMITTED_SUCCESS);
saveProcessInstance(processInstance);
}
} else if (processDefinition.getExecutionType().typeIsSerialDiscard()) {
List<ProcessInstance> runningProcessInstances = this.processInstanceMapper.queryByProcessDefineCodeAndProcessDefinitionVersionAndStatusAndNextId(processInstance.getProcessDefinitionCode(),
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
processInstance.getProcessDefinitionVersion(), Constants.RUNNING_PROCESS_STATE, processInstance.getId());
if (CollectionUtils.isNotEmpty(runningProcessInstances)) {
processInstance.setState(ExecutionStatus.STOP);
saveProcessInstance(processInstance);
return;
}
processInstance.setState(ExecutionStatus.SUBMITTED_SUCCESS);
saveProcessInstance(processInstance);
} else if (processDefinition.getExecutionType().typeIsSerialPriority()) {
List<ProcessInstance> runningProcessInstances = this.processInstanceMapper.queryByProcessDefineCodeAndProcessDefinitionVersionAndStatusAndNextId(processInstance.getProcessDefinitionCode(),
processInstance.getProcessDefinitionVersion(), Constants.RUNNING_PROCESS_STATE, processInstance.getId());
if (CollectionUtils.isEmpty(runningProcessInstances)) {
processInstance.setState(ExecutionStatus.SUBMITTED_SUCCESS);
saveProcessInstance(processInstance);
return;
}
for (ProcessInstance info : runningProcessInstances) {
if (Objects.nonNull(info.getState()) && (ExecutionStatus.READY_STOP.equals(info.getState()) || info.getState().typeIsFinished())) {
continue;
}
info.setCommandType(CommandType.STOP);
info.addHistoryCmd(CommandType.STOP);
info.setState(ExecutionStatus.READY_STOP);
int update = updateProcessInstance(info);
if (update > 0) {
StateEventChangeCommand stateEventChangeCommand = new StateEventChangeCommand(
info.getId(), 0, info.getState(), info.getId(), 0
);
try {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
Host host = new Host(info.getHost());
stateEventCallbackService.sendResult(host, stateEventChangeCommand.convert2Command());
} catch (Exception e) {
logger.error("sendResultError", e);
}
}
}
}
}
/**
* Save error command, and delete original command. If the given command has already been moved into error command,
* will throw {@link SQLIntegrityConstraintViolationException ).
*
* @param command command
* @param message message
*/
@Override
public void moveToErrorCommand(Command command, String message) {
ErrorCommand errorCommand = new ErrorCommand(command, message);
this.errorCommandMapper.insert(errorCommand);
this.commandMapper.deleteById(command.getId());
}
/**
* set process waiting thread
*
* @param command command
* @param processInstance processInstance
* @return process instance
*/
private ProcessInstance setWaitingThreadProcess(Command command, 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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
processInstance.setState(ExecutionStatus.WAITING_THREAD);
if (command.getCommandType() != CommandType.RECOVER_WAITING_THREAD) {
processInstance.addHistoryCmd(command.getCommandType());
}
saveProcessInstance(processInstance);
this.setSubProcessParam(processInstance);
createRecoveryWaitingThreadCommand(command, processInstance);
return null;
}
/**
* insert one command
*
* @param command command
* @return create result
*/
@Override
@Counted("ds.workflow.create.command.count")
public int createCommand(Command command) {
int result = 0;
if (command != null) {
Schedule schedule = scheduleMapper.queryByProcessDefinitionCode(command.getProcessDefinitionCode());
Map<String, String> commandParams = JSONUtils.toMap(command.getCommandParam());
if (commandParams != null && schedule != null) {
commandParams.put(Constants.SCHEDULE_TIMEZONE, schedule.getTimezoneId());
command.setCommandParam(JSONUtils.toJsonString(commandParams));
}
result = commandMapper.insert(command);
}
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
}
/**
* get command page
*/
@Override
public List<Command> findCommandPage(int pageSize, int pageNumber) {
return commandMapper.queryCommandPage(pageSize, pageNumber * pageSize);
}
/**
* get command page
*/
@Override
public List<Command> findCommandPageBySlot(int pageSize, int pageNumber, int masterCount, int thisMasterSlot) {
if (masterCount <= 0) {
return Lists.newArrayList();
}
return commandMapper.queryCommandPageBySlot(pageSize, pageNumber * pageSize, masterCount, thisMasterSlot);
}
/**
* check the input command exists in queue list
*
* @param command command
* @return create command result
*/
@Override
public boolean verifyIsNeedCreateCommand(Command command) {
boolean isNeedCreate = true;
EnumMap<CommandType, Integer> cmdTypeMap = new EnumMap<>(CommandType.class);
cmdTypeMap.put(CommandType.REPEAT_RUNNING, 1);
cmdTypeMap.put(CommandType.RECOVER_SUSPENDED_PROCESS, 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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
cmdTypeMap.put(CommandType.START_FAILURE_TASK_PROCESS, 1);
CommandType commandType = command.getCommandType();
if (cmdTypeMap.containsKey(commandType)) {
ObjectNode cmdParamObj = JSONUtils.parseObject(command.getCommandParam());
int processInstanceId = cmdParamObj.path(CMD_PARAM_RECOVER_PROCESS_ID_STRING).asInt();
List<Command> commands = commandMapper.selectList(null);
for (Command tmpCommand : commands) {
if (cmdTypeMap.containsKey(tmpCommand.getCommandType())) {
ObjectNode tempObj = JSONUtils.parseObject(tmpCommand.getCommandParam());
if (tempObj != null && processInstanceId == tempObj.path(CMD_PARAM_RECOVER_PROCESS_ID_STRING).asInt()) {
isNeedCreate = false;
break;
}
}
}
}
return isNeedCreate;
}
/**
* find process instance detail by id
*
* @param processId processId
* @return process instance
*/
@Override
public ProcessInstance findProcessInstanceDetailById(int processId) {
return processInstanceMapper.queryDetailById(processId);
}
/**
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* get task node list by definitionId
*/
@Override
public List<TaskDefinition> getTaskNodeListByDefinition(long defineCode) {
ProcessDefinition processDefinition = processDefineMapper.queryByCode(defineCode);
if (processDefinition == null) {
logger.error("process define not exists");
return Lists.newArrayList();
}
List<ProcessTaskRelationLog> processTaskRelations = processTaskRelationLogMapper.queryByProcessCodeAndVersion(processDefinition.getCode(), processDefinition.getVersion());
Set<TaskDefinition> taskDefinitionSet = new HashSet<>();
for (ProcessTaskRelationLog processTaskRelation : processTaskRelations) {
if (processTaskRelation.getPostTaskCode() > 0) {
taskDefinitionSet.add(new TaskDefinition(processTaskRelation.getPostTaskCode(), processTaskRelation.getPostTaskVersion()));
}
}
if (taskDefinitionSet.isEmpty()) {
return Lists.newArrayList();
}
List<TaskDefinitionLog> taskDefinitionLogs = taskDefinitionLogMapper.queryByTaskDefinitions(taskDefinitionSet);
return Lists.newArrayList(taskDefinitionLogs);
}
/**
* find process instance by id
*
* @param processId processId
* @return process instance
*/
@Override
public ProcessInstance findProcessInstanceById(int processId) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
return processInstanceMapper.selectById(processId);
}
/**
* find process define by id.
*
* @param processDefinitionId processDefinitionId
* @return process definition
*/
@Override
public ProcessDefinition findProcessDefineById(int processDefinitionId) {
return processDefineMapper.selectById(processDefinitionId);
}
/**
* find process define by code and version.
*
* @param processDefinitionCode processDefinitionCode
* @return process definition
*/
@Override
public ProcessDefinition findProcessDefinition(Long processDefinitionCode, int version) {
ProcessDefinition processDefinition = processDefineMapper.queryByCode(processDefinitionCode);
if (processDefinition == null || processDefinition.getVersion() != version) {
processDefinition = processDefineLogMapper.queryByDefinitionCodeAndVersion(processDefinitionCode, version);
if (processDefinition != null) {
processDefinition.setId(0);
}
}
return processDefinition;
}
/**
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* find process define by code.
*
* @param processDefinitionCode processDefinitionCode
* @return process definition
*/
@Override
public ProcessDefinition findProcessDefinitionByCode(Long processDefinitionCode) {
return processDefineMapper.queryByCode(processDefinitionCode);
}
/**
* delete work process instance by id
*
* @param processInstanceId processInstanceId
* @return delete process instance result
*/
@Override
public int deleteWorkProcessInstanceById(int processInstanceId) {
return processInstanceMapper.deleteById(processInstanceId);
}
/**
* delete all sub process by parent instance id
*
* @param processInstanceId processInstanceId
* @return delete all sub process instance result
*/
@Override
public int deleteAllSubWorkProcessByParentId(int processInstanceId) {
List<Integer> subProcessIdList = processInstanceMapMapper.querySubIdListByParentId(processInstanceId);
for (Integer subId : subProcessIdList) {
deleteAllSubWorkProcessByParentId(subId);
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
deleteWorkProcessMapByParentId(subId);
removeTaskLogFile(subId);
deleteWorkProcessInstanceById(subId);
}
return 1;
}
/**
* remove task log file
*
* @param processInstanceId processInstanceId
*/
@Override
public void removeTaskLogFile(Integer processInstanceId) {
List<TaskInstance> taskInstanceList = findValidTaskListByProcessId(processInstanceId);
if (CollectionUtils.isEmpty(taskInstanceList)) {
return;
}
try (LogClientService logClient = new LogClientService()) {
for (TaskInstance taskInstance : taskInstanceList) {
String taskLogPath = taskInstance.getLogPath();
if (Strings.isNullOrEmpty(taskInstance.getHost())) {
continue;
}
Host host = Host.of(taskInstance.getHost());
logClient.removeTaskLog(host.getIp(), host.getPort(), taskLogPath);
}
}
}
/**
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* recursive delete all task instance by process instance id
*/
@Override
public void deleteWorkTaskInstanceByProcessInstanceId(int processInstanceId) {
List<TaskInstance> taskInstanceList = findValidTaskListByProcessId(processInstanceId);
if (CollectionUtils.isEmpty(taskInstanceList)) {
return;
}
List<Integer> taskInstanceIdList = new ArrayList<>();
for (TaskInstance taskInstance : taskInstanceList) {
taskInstanceIdList.add(taskInstance.getId());
}
taskInstanceMapper.deleteBatchIds(taskInstanceIdList);
}
/**
* recursive query sub process definition id by parent id.
*
* @param parentCode parentCode
* @param ids ids
*/
@Override
public void recurseFindSubProcess(long parentCode, List<Long> ids) {
List<TaskDefinition> taskNodeList = this.getTaskNodeListByDefinition(parentCode);
if (taskNodeList != null && !taskNodeList.isEmpty()) {
for (TaskDefinition taskNode : taskNodeList) {
String parameter = taskNode.getTaskParams();
ObjectNode parameterJson = JSONUtils.parseObject(parameter);
if (parameterJson.get(CMD_PARAM_SUB_PROCESS_DEFINE_CODE) != null) {
SubProcessParameters subProcessParam = JSONUtils.parseObject(parameter, SubProcessParameters.class);
ids.add(subProcessParam.getProcessDefinitionCode());
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
recurseFindSubProcess(subProcessParam.getProcessDefinitionCode(), ids);
}
}
}
}
/**
* create recovery waiting thread command when thread pool is not enough for the process instance.
* sub work process instance need not to create recovery command.
* create recovery waiting thread command and delete origin command at the same time.
* if the recovery command is exists, only update the field update_time
*
* @param originCommand originCommand
* @param processInstance processInstance
*/
@Override
public void createRecoveryWaitingThreadCommand(Command originCommand, ProcessInstance processInstance) {
if (processInstance.getIsSubProcess() == Flag.YES) {
if (originCommand != null) {
commandMapper.deleteById(originCommand.getId());
}
return;
}
Map<String, String> cmdParam = new HashMap<>();
cmdParam.put(Constants.CMD_PARAM_RECOVERY_WAITING_THREAD, String.valueOf(processInstance.getId()));
if (originCommand == null) {
Command command = new Command(
CommandType.RECOVER_WAITING_THREAD,
processInstance.getTaskDependType(),
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
processInstance.getFailureStrategy(),
processInstance.getExecutorId(),
processInstance.getProcessDefinition().getCode(),
JSONUtils.toJsonString(cmdParam),
processInstance.getWarningType(),
processInstance.getWarningGroupId(),
processInstance.getScheduleTime(),
processInstance.getWorkerGroup(),
processInstance.getEnvironmentCode(),
processInstance.getProcessInstancePriority(),
processInstance.getDryRun(),
processInstance.getId(),
processInstance.getProcessDefinitionVersion()
);
saveCommand(command);
return;
}
if (originCommand.getCommandType() == CommandType.RECOVER_WAITING_THREAD) {
originCommand.setUpdateTime(new Date());
saveCommand(originCommand);
} else {
commandMapper.deleteById(originCommand.getId());
originCommand.setId(0);
originCommand.setCommandType(CommandType.RECOVER_WAITING_THREAD);
originCommand.setUpdateTime(new Date());
originCommand.setCommandParam(JSONUtils.toJsonString(cmdParam));
originCommand.setProcessInstancePriority(processInstance.getProcessInstancePriority());
saveCommand(originCommand);
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
}
}
/**
* get schedule time from command
*
* @param command command
* @param cmdParam cmdParam map
* @return date
*/
private Date getScheduleTime(Command command, Map<String, String> cmdParam) throws CronParseException {
Date scheduleTime = command.getScheduleTime();
if (scheduleTime == null && cmdParam != null && cmdParam.containsKey(CMDPARAM_COMPLEMENT_DATA_START_DATE)) {
Date start = DateUtils.stringToDate(cmdParam.get(CMDPARAM_COMPLEMENT_DATA_START_DATE));
Date end = DateUtils.stringToDate(cmdParam.get(CMDPARAM_COMPLEMENT_DATA_END_DATE));
List<Schedule> schedules =
queryReleaseSchedulerListByProcessDefinitionCode(command.getProcessDefinitionCode());
List<Date> complementDateList = CronUtils.getSelfFireDateList(start, end, schedules);
if (complementDateList.size() > 0) {
scheduleTime = complementDateList.get(0);
} else {
logger.error("set scheduler time error: complement date list is empty, command: {}",
command.toString());
}
}
return scheduleTime;
}
/**
* generate a new work process instance from command.
*
* @param processDefinition processDefinition
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* @param command command
* @param cmdParam cmdParam map
* @return process instance
*/
private ProcessInstance generateNewProcessInstance(ProcessDefinition processDefinition,
Command command,
Map<String, String> cmdParam) throws CodeGenerateException {
ProcessInstance processInstance = new ProcessInstance(processDefinition);
processInstance.setProcessDefinitionCode(processDefinition.getCode());
processInstance.setProcessDefinitionVersion(processDefinition.getVersion());
processInstance.setState(ExecutionStatus.RUNNING_EXECUTION);
processInstance.setRecovery(Flag.NO);
processInstance.setStartTime(new Date());
processInstance.setRestartTime(null);
processInstance.setRunTimes(1);
processInstance.setMaxTryTimes(0);
processInstance.setCommandParam(command.getCommandParam());
processInstance.setCommandType(command.getCommandType());
processInstance.setIsSubProcess(Flag.NO);
processInstance.setTaskDependType(command.getTaskDependType());
processInstance.setFailureStrategy(command.getFailureStrategy());
processInstance.setExecutorId(command.getExecutorId());
WarningType warningType = command.getWarningType() == null ? WarningType.NONE : command.getWarningType();
processInstance.setWarningType(warningType);
Integer warningGroupId = command.getWarningGroupId() == null ? 0 : command.getWarningGroupId();
processInstance.setWarningGroupId(warningGroupId);
processInstance.setDryRun(command.getDryRun());
if (command.getScheduleTime() != null) {
processInstance.setScheduleTime(command.getScheduleTime());
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
}
processInstance.setCommandStartTime(command.getStartTime());
processInstance.setLocations(processDefinition.getLocations());
setGlobalParamIfCommanded(processDefinition, cmdParam);
Map<String, String> commandParamMap = JSONUtils.toMap(command.getCommandParam());
String timezoneId = null;
if (commandParamMap != null) {
timezoneId = commandParamMap.get(Constants.SCHEDULE_TIMEZONE);
}
String globalParams = curingGlobalParamsService.curingGlobalParams(processInstance.getId(),
processDefinition.getGlobalParamMap(),
processDefinition.getGlobalParamList(),
getCommandTypeIfComplement(processInstance, command),
processInstance.getScheduleTime(), timezoneId);
processInstance.setGlobalParams(globalParams);
processInstance.setProcessInstancePriority(command.getProcessInstancePriority());
String workerGroup = Strings.isNullOrEmpty(command.getWorkerGroup()) ? Constants.DEFAULT_WORKER_GROUP : command.getWorkerGroup();
processInstance.setWorkerGroup(workerGroup);
processInstance.setEnvironmentCode(Objects.isNull(command.getEnvironmentCode()) ? -1 : command.getEnvironmentCode());
processInstance.setTimeout(processDefinition.getTimeout());
processInstance.setTenantId(processDefinition.getTenantId());
return processInstance;
}
private void setGlobalParamIfCommanded(ProcessDefinition processDefinition, Map<String, String> cmdParam) {
Map<String, String> startParamMap = new HashMap<>();
if (cmdParam != null && cmdParam.containsKey(Constants.CMD_PARAM_START_PARAMS)) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
String startParamJson = cmdParam.get(Constants.CMD_PARAM_START_PARAMS);
startParamMap = JSONUtils.toMap(startParamJson);
}
Map<String, String> fatherParamMap = new HashMap<>();
if (cmdParam != null && cmdParam.containsKey(Constants.CMD_PARAM_FATHER_PARAMS)) {
String fatherParamJson = cmdParam.get(Constants.CMD_PARAM_FATHER_PARAMS);
fatherParamMap = JSONUtils.toMap(fatherParamJson);
}
startParamMap.putAll(fatherParamMap);
Map<String, String> globalMap = processDefinition.getGlobalParamMap();
List<Property> globalParamList = processDefinition.getGlobalParamList();
if (startParamMap.size() > 0 && globalMap != null) {
for (Map.Entry<String, String> param : globalMap.entrySet()) {
String val = startParamMap.get(param.getKey());
if (val != null) {
param.setValue(val);
}
}
for (Entry<String, String> startParam : startParamMap.entrySet()) {
if (!globalMap.containsKey(startParam.getKey())) {
globalMap.put(startParam.getKey(), startParam.getValue());
globalParamList.add(new Property(startParam.getKey(), IN, VARCHAR, startParam.getValue()));
}
}
}
}
/**
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* get process tenant
* there is tenant id in definition, use the tenant of the definition.
* if there is not tenant id in the definiton or the tenant not exist
* use definition creator's tenant.
*
* @param tenantId tenantId
* @param userId userId
* @return tenant
*/
@Override
public Tenant getTenantForProcess(int tenantId, int userId) {
Tenant tenant = null;
if (tenantId >= 0) {
tenant = tenantMapper.queryById(tenantId);
}
if (userId == 0) {
return null;
}
if (tenant == null) {
User user = userMapper.selectById(userId);
tenant = tenantMapper.queryById(user.getTenantId());
}
return tenant;
}
/**
* get an environment
* use the code of the environment to find a environment.
*
* @param environmentCode environmentCode
* @return Environment
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
*/
@Override
public Environment findEnvironmentByCode(Long environmentCode) {
Environment environment = null;
if (environmentCode >= 0) {
environment = environmentMapper.queryByEnvironmentCode(environmentCode);
}
return environment;
}
/**
* check command parameters is valid
*
* @param command command
* @param cmdParam cmdParam map
* @return whether command param is valid
*/
private Boolean checkCmdParam(Command command, Map<String, String> cmdParam) {
if (command.getTaskDependType() == TaskDependType.TASK_ONLY || command.getTaskDependType() == TaskDependType.TASK_PRE) {
if (cmdParam == null
|| !cmdParam.containsKey(Constants.CMD_PARAM_START_NODES)
|| cmdParam.get(Constants.CMD_PARAM_START_NODES).isEmpty()) {
logger.error("command node depend type is {}, but start nodes is null ", command.getTaskDependType());
return false;
}
}
return true;
}
/**
* construct process instance according to one command.
*
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* @param command command
* @param host host
* @return process instance
*/
protected ProcessInstance constructProcessInstance(Command command, String host)
throws CronParseException, CodeGenerateException {
ProcessInstance processInstance;
ProcessDefinition processDefinition;
CommandType commandType = command.getCommandType();
processDefinition =
this.findProcessDefinition(command.getProcessDefinitionCode(), command.getProcessDefinitionVersion());
if (processDefinition == null) {
logger.error("cannot find the work process define! define code : {}", command.getProcessDefinitionCode());
throw new IllegalArgumentException("Cannot find the process definition for this workflowInstance");
}
Map<String, String> cmdParam = JSONUtils.toMap(command.getCommandParam());
int processInstanceId = command.getProcessInstanceId();
if (processInstanceId == 0) {
processInstance = generateNewProcessInstance(processDefinition, command, cmdParam);
} else {
processInstance = this.findProcessInstanceDetailById(processInstanceId);
if (processInstance == null) {
return null;
}
}
if (cmdParam != null) {
CommandType commandTypeIfComplement = getCommandTypeIfComplement(processInstance, command);
if (commandTypeIfComplement == CommandType.REPEAT_RUNNING) {
setGlobalParamIfCommanded(processDefinition, cmdParam);
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
}
String timezoneId = cmdParam.get(Constants.SCHEDULE_TIMEZONE);
String globalParams = curingGlobalParamsService.curingGlobalParams(processInstance.getId(),
processDefinition.getGlobalParamMap(),
processDefinition.getGlobalParamList(),
commandTypeIfComplement,
processInstance.getScheduleTime(), timezoneId);
processInstance.setGlobalParams(globalParams);
processInstance.setProcessDefinition(processDefinition);
}
if (processInstance.getCommandParam() != null) {
Map<String, String> processCmdParam = JSONUtils.toMap(processInstance.getCommandParam());
processCmdParam.forEach((key, value) -> {
if (!cmdParam.containsKey(key)) {
cmdParam.put(key, value);
}
});
}
if (cmdParam != null && cmdParam.containsKey(Constants.CMD_PARAM_SUB_PROCESS)) {
processInstance.setCommandParam(command.getCommandParam());
}
if (Boolean.FALSE.equals(checkCmdParam(command, cmdParam))) {
logger.error("command parameter check failed!");
return null;
}
if (command.getScheduleTime() != 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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
processInstance.setScheduleTime(command.getScheduleTime());
}
processInstance.setHost(host);
processInstance.setRestartTime(new Date());
ExecutionStatus runStatus = ExecutionStatus.RUNNING_EXECUTION;
int runTime = processInstance.getRunTimes();
switch (commandType) {
case START_PROCESS:
break;
case START_FAILURE_TASK_PROCESS:
List<Integer> failedList = this.findTaskIdByInstanceState(processInstance.getId(), ExecutionStatus.FAILURE);
List<Integer> toleranceList = this.findTaskIdByInstanceState(processInstance.getId(), ExecutionStatus.NEED_FAULT_TOLERANCE);
List<Integer> killedList = this.findTaskIdByInstanceState(processInstance.getId(), ExecutionStatus.KILL);
cmdParam.remove(Constants.CMD_PARAM_RECOVERY_START_NODE_STRING);
failedList.addAll(killedList);
failedList.addAll(toleranceList);
for (Integer taskId : failedList) {
initTaskInstance(this.findTaskInstanceById(taskId));
}
cmdParam.put(Constants.CMD_PARAM_RECOVERY_START_NODE_STRING,
String.join(Constants.COMMA, convertIntListToString(failedList)));
processInstance.setCommandParam(JSONUtils.toJsonString(cmdParam));
processInstance.setRunTimes(runTime + 1);
break;
case START_CURRENT_TASK_PROCESS:
break;
case RECOVER_WAITING_THREAD:
break;
case RECOVER_SUSPENDED_PROCESS:
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
cmdParam.remove(Constants.CMD_PARAM_RECOVERY_START_NODE_STRING);
List<Integer> suspendedNodeList = this.findTaskIdByInstanceState(processInstance.getId(), ExecutionStatus.PAUSE);
List<Integer> stopNodeList = findTaskIdByInstanceState(processInstance.getId(),
ExecutionStatus.KILL);
suspendedNodeList.addAll(stopNodeList);
for (Integer taskId : suspendedNodeList) {
initTaskInstance(this.findTaskInstanceById(taskId));
}
cmdParam.put(Constants.CMD_PARAM_RECOVERY_START_NODE_STRING, String.join(",", convertIntListToString(suspendedNodeList)));
processInstance.setCommandParam(JSONUtils.toJsonString(cmdParam));
processInstance.setRunTimes(runTime + 1);
break;
case RECOVER_TOLERANCE_FAULT_PROCESS:
processInstance.setRecovery(Flag.YES);
processInstance.setRunTimes(runTime + 1);
runStatus = processInstance.getState();
break;
case COMPLEMENT_DATA:
if (processInstance.getId() != 0) {
List<TaskInstance> taskInstanceList = this.findValidTaskListByProcessId(processInstance.getId());
for (TaskInstance taskInstance : taskInstanceList) {
taskInstance.setFlag(Flag.NO);
this.updateTaskInstance(taskInstance);
}
}
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
case REPEAT_RUNNING:
if (cmdParam.containsKey(Constants.CMD_PARAM_RECOVERY_START_NODE_STRING)) {
cmdParam.remove(Constants.CMD_PARAM_RECOVERY_START_NODE_STRING);
processInstance.setCommandParam(JSONUtils.toJsonString(cmdParam));
}
List<TaskInstance> validTaskList = findValidTaskListByProcessId(processInstance.getId());
for (TaskInstance taskInstance : validTaskList) {
taskInstance.setFlag(Flag.NO);
updateTaskInstance(taskInstance);
}
processInstance.setStartTime(new Date());
processInstance.setRestartTime(processInstance.getStartTime());
processInstance.setEndTime(null);
processInstance.setRunTimes(runTime + 1);
initComplementDataParam(processDefinition, processInstance, cmdParam);
break;
case SCHEDULER:
break;
default:
break;
}
processInstance.setState(runStatus);
return processInstance;
}
/**
* get process definition by command
* If it is a fault-tolerant command, get the specified version of ProcessDefinition through ProcessInstance
* Otherwise, get the latest version of ProcessDefinition
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
*
* @return ProcessDefinition
*/
private ProcessDefinition getProcessDefinitionByCommand(long processDefinitionCode, Map<String, String> cmdParam) {
if (cmdParam != null) {
int processInstanceId = 0;
if (cmdParam.containsKey(Constants.CMD_PARAM_RECOVER_PROCESS_ID_STRING)) {
processInstanceId = Integer.parseInt(cmdParam.get(Constants.CMD_PARAM_RECOVER_PROCESS_ID_STRING));
} else if (cmdParam.containsKey(Constants.CMD_PARAM_SUB_PROCESS)) {
processInstanceId = Integer.parseInt(cmdParam.get(Constants.CMD_PARAM_SUB_PROCESS));
} else if (cmdParam.containsKey(Constants.CMD_PARAM_RECOVERY_WAITING_THREAD)) {
processInstanceId = Integer.parseInt(cmdParam.get(Constants.CMD_PARAM_RECOVERY_WAITING_THREAD));
}
if (processInstanceId != 0) {
ProcessInstance processInstance = this.findProcessInstanceDetailById(processInstanceId);
if (processInstance == null) {
return null;
}
return processDefineLogMapper.queryByDefinitionCodeAndVersion(
processInstance.getProcessDefinitionCode(), processInstance.getProcessDefinitionVersion());
}
}
return processDefineMapper.queryByCode(processDefinitionCode);
}
/**
* return complement data if the process start with complement data
*
* @param processInstance processInstance
* @param command command
* @return command type
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
*/
private CommandType getCommandTypeIfComplement(ProcessInstance processInstance, Command command) {
if (CommandType.COMPLEMENT_DATA == processInstance.getCmdTypeIfComplement()) {
return CommandType.COMPLEMENT_DATA;
} else {
return command.getCommandType();
}
}
/**
* initialize complement data parameters
*
* @param processDefinition processDefinition
* @param processInstance processInstance
* @param cmdParam cmdParam
*/
private void initComplementDataParam(ProcessDefinition processDefinition,
ProcessInstance processInstance,
Map<String, String> cmdParam) throws CronParseException {
if (!processInstance.isComplementData()) {
return;
}
Date start = DateUtils.stringToDate(cmdParam.get(CMDPARAM_COMPLEMENT_DATA_START_DATE));
Date end = DateUtils.stringToDate(cmdParam.get(CMDPARAM_COMPLEMENT_DATA_END_DATE));
List<Date> complementDate = Lists.newLinkedList();
if (start != null && end != null) {
List<Schedule> listSchedules =
queryReleaseSchedulerListByProcessDefinitionCode(processInstance.getProcessDefinitionCode());
complementDate = CronUtils.getSelfFireDateList(start, end, listSchedules);
}
if (cmdParam.containsKey(CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST)) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
complementDate = CronUtils.getSelfScheduleDateList(cmdParam);
}
if (complementDate.size() > 0 && Flag.NO == processInstance.getIsSubProcess()) {
processInstance.setScheduleTime(complementDate.get(0));
}
String timezoneId = cmdParam.get(Constants.SCHEDULE_TIMEZONE);
String globalParams = curingGlobalParamsService.curingGlobalParams(processInstance.getId(),
processDefinition.getGlobalParamMap(),
processDefinition.getGlobalParamList(),
CommandType.COMPLEMENT_DATA, processInstance.getScheduleTime(), timezoneId);
processInstance.setGlobalParams(globalParams);
}
/**
* set sub work process parameters.
* handle sub work process instance, update relation table and command parameters
* set sub work process flag, extends parent work process command parameters
*
* @param subProcessInstance subProcessInstance
*/
@Override
public void setSubProcessParam(ProcessInstance subProcessInstance) {
String cmdParam = subProcessInstance.getCommandParam();
if (Strings.isNullOrEmpty(cmdParam)) {
return;
}
Map<String, String> paramMap = JSONUtils.toMap(cmdParam);
if (paramMap.containsKey(CMD_PARAM_SUB_PROCESS)
&& CMD_PARAM_EMPTY_SUB_PROCESS.equals(paramMap.get(CMD_PARAM_SUB_PROCESS))) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
paramMap.remove(CMD_PARAM_SUB_PROCESS);
paramMap.put(CMD_PARAM_SUB_PROCESS, String.valueOf(subProcessInstance.getId()));
subProcessInstance.setCommandParam(JSONUtils.toJsonString(paramMap));
subProcessInstance.setIsSubProcess(Flag.YES);
this.saveProcessInstance(subProcessInstance);
}
String parentInstanceId = paramMap.get(CMD_PARAM_SUB_PROCESS_PARENT_INSTANCE_ID);
if (!Strings.isNullOrEmpty(parentInstanceId)) {
ProcessInstance parentInstance = findProcessInstanceDetailById(Integer.parseInt(parentInstanceId));
if (parentInstance != null) {
subProcessInstance.setGlobalParams(joinGlobalParams(parentInstance.getGlobalParams(), subProcessInstance.getGlobalParams()));
subProcessInstance.setVarPool(joinVarPool(parentInstance.getVarPool(), subProcessInstance.getVarPool()));
this.saveProcessInstance(subProcessInstance);
} else {
logger.error("sub process command params error, cannot find parent instance: {} ", cmdParam);
}
}
ProcessInstanceMap processInstanceMap = JSONUtils.parseObject(cmdParam, ProcessInstanceMap.class);
if (processInstanceMap == null || processInstanceMap.getParentProcessInstanceId() == 0) {
return;
}
processInstanceMap.setProcessInstanceId(subProcessInstance.getId());
this.updateWorkProcessInstanceMap(processInstanceMap);
}
/**
* join parent global params into sub process.
* only the keys doesn't in sub process global would be joined.
*
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* @param parentGlobalParams parentGlobalParams
* @param subGlobalParams subGlobalParams
* @return global params join
*/
private String joinGlobalParams(String parentGlobalParams, String subGlobalParams) {
List<Property> parentParams = Lists.newArrayList(JSONUtils.toList(parentGlobalParams, Property.class));
List<Property> subParams = JSONUtils.toList(subGlobalParams, Property.class);
Set<String> parentParamKeys = parentParams.stream().map(Property::getProp).collect(toSet());
List<Property> extraSubParams = subParams.stream()
.filter(subProp -> !parentParamKeys.contains(subProp.getProp())).collect(Collectors.toList());
parentParams.addAll(extraSubParams);
return JSONUtils.toJsonString(parentParams);
}
/**
* join parent var pool params into sub process.
* only the keys doesn't in sub process global would be joined.
*
* @param parentValPool
* @param subValPool
* @return
*/
private String joinVarPool(String parentValPool, String subValPool) {
List<Property> parentValPools = Lists.newArrayList(JSONUtils.toList(parentValPool, Property.class));
parentValPools = parentValPools.stream().filter(valPool -> valPool.getDirect() == Direct.OUT).collect(Collectors.toList());
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
List<Property> subValPools = Lists.newArrayList(JSONUtils.toList(subValPool, Property.class));
Set<String> parentValPoolKeys = parentValPools.stream().map(Property::getProp).collect(toSet());
List<Property> extraSubValPools = subValPools.stream().filter(sub -> !parentValPoolKeys.contains(sub.getProp())).collect(Collectors.toList());
parentValPools.addAll(extraSubValPools);
return JSONUtils.toJsonString(parentValPools);
}
/**
* initialize task instance
*
* @param taskInstance taskInstance
*/
private void initTaskInstance(TaskInstance taskInstance) {
if (!taskInstance.isSubProcess()
&& (taskInstance.getState().typeIsCancel() || taskInstance.getState().typeIsFailure())) {
taskInstance.setFlag(Flag.NO);
updateTaskInstance(taskInstance);
return;
}
taskInstance.setState(ExecutionStatus.SUBMITTED_SUCCESS);
updateTaskInstance(taskInstance);
}
/**
* retry submit task to db
*/
@Override
public TaskInstance submitTaskWithRetry(ProcessInstance processInstance, TaskInstance taskInstance, int commitRetryTimes, long commitInterval) {
int retryTimes = 1;
TaskInstance task = null;
while (retryTimes <= commitRetryTimes) {
try {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
task = processService.submitTask(processInstance, taskInstance);
if (task != null && task.getId() != 0) {
break;
}
logger.error(
"task commit to db failed , taskCode: {} has already retry {} times, please check the database",
taskInstance.getTaskCode(),
retryTimes);
Thread.sleep(commitInterval);
} catch (Exception e) {
logger.error("task commit to db failed", e);
} finally {
retryTimes += 1;
}
}
return task;
}
/**
* // todo: This method need to refactor, we find when the db down, but the taskInstanceId is not 0. It's better to change to void, rather than return TaskInstance
* submit task to db
* submit sub process to command
*
* @param processInstance processInstance
* @param taskInstance taskInstance
* @return task instance
*/
@Override
@Transactional
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
public TaskInstance submitTask(ProcessInstance processInstance, TaskInstance taskInstance) {
logger.info("Start save taskInstance to database : {}, processInstance id:{}, state: {}",
taskInstance.getName(),
taskInstance.getProcessInstanceId(),
processInstance.getState());
TaskInstance task = submitTaskInstanceToDB(taskInstance, processInstance);
if (task == null) {
logger.error("Save taskInstance to db error, task name:{}, process id:{} state: {} ",
taskInstance.getName(),
taskInstance.getProcessInstance().getId(),
processInstance.getState());
return null;
}
if (!task.getState().typeIsFinished()) {
createSubWorkProcess(processInstance, task);
}
logger.info(
"End save taskInstance to db successfully:{}, taskInstanceName: {}, taskInstance state:{}, processInstanceId:{}, processInstanceState: {}",
task.getId(),
task.getName(),
task.getState(),
processInstance.getId(),
processInstance.getState());
return task;
}
/**
* set work process instance map
* consider o
* repeat running does not generate new sub process instance
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* set map {parent instance id, task instance id, 0(child instance id)}
*
* @param parentInstance parentInstance
* @param parentTask parentTask
* @param processMap processMap
* @return process instance map
*/
private ProcessInstanceMap setProcessInstanceMap(ProcessInstance parentInstance, TaskInstance parentTask, ProcessInstanceMap processMap) {
if (processMap != null) {
return processMap;
}
if (parentInstance.getCommandType() == CommandType.REPEAT_RUNNING) {
processMap = findPreviousTaskProcessMap(parentInstance, parentTask);
if (processMap != null) {
processMap.setParentTaskInstanceId(parentTask.getId());
updateWorkProcessInstanceMap(processMap);
return processMap;
}
}
processMap = new ProcessInstanceMap();
processMap.setParentProcessInstanceId(parentInstance.getId());
processMap.setParentTaskInstanceId(parentTask.getId());
createWorkProcessInstanceMap(processMap);
return processMap;
}
/**
* find previous task work process map.
*
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* @param parentProcessInstance parentProcessInstance
* @param parentTask parentTask
* @return process instance map
*/
private ProcessInstanceMap findPreviousTaskProcessMap(ProcessInstance parentProcessInstance,
TaskInstance parentTask) {
Integer preTaskId = 0;
List<TaskInstance> preTaskList = this.findPreviousTaskListByWorkProcessId(parentProcessInstance.getId());
for (TaskInstance task : preTaskList) {
if (task.getName().equals(parentTask.getName())) {
preTaskId = task.getId();
ProcessInstanceMap map = findWorkProcessMapByParent(parentProcessInstance.getId(), preTaskId);
if (map != null) {
return map;
}
}
}
logger.info("sub process instance is not found,parent task:{},parent instance:{}",
parentTask.getId(), parentProcessInstance.getId());
return null;
}
/**
* create sub work process command
*
* @param parentProcessInstance parentProcessInstance
* @param task task
*/
@Override
public void createSubWorkProcess(ProcessInstance parentProcessInstance, TaskInstance task) {
if (!task.isSubProcess()) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
return;
}
ProcessInstanceMap instanceMap = findWorkProcessMapByParent(parentProcessInstance.getId(), task.getId());
if (null != instanceMap && CommandType.RECOVER_TOLERANCE_FAULT_PROCESS == parentProcessInstance.getCommandType()) {
return;
}
instanceMap = setProcessInstanceMap(parentProcessInstance, task, instanceMap);
ProcessInstance childInstance = null;
if (instanceMap.getProcessInstanceId() != 0) {
childInstance = findProcessInstanceById(instanceMap.getProcessInstanceId());
}
if (childInstance != null && childInstance.getState() == ExecutionStatus.SUCCESS
&& CommandType.START_FAILURE_TASK_PROCESS == parentProcessInstance.getCommandType()) {
logger.info("sub process instance {} status is success, so skip creating command", childInstance.getId());
return;
}
Command subProcessCommand = createSubProcessCommand(parentProcessInstance, childInstance, instanceMap, task);
updateSubProcessDefinitionByParent(parentProcessInstance, subProcessCommand.getProcessDefinitionCode());
initSubInstanceState(childInstance);
createCommand(subProcessCommand);
logger.info("sub process command created: {} ", subProcessCommand);
}
/**
* complement data needs transform parent parameter to child.
*/
protected String getSubWorkFlowParam(ProcessInstanceMap instanceMap, ProcessInstance parentProcessInstance, Map<String, String> fatherParams) {
String processMapStr = JSONUtils.toJsonString(instanceMap);
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
Map<String, String> cmdParam = JSONUtils.toMap(processMapStr);
if (parentProcessInstance.isComplementData()) {
Map<String, String> parentParam = JSONUtils.toMap(parentProcessInstance.getCommandParam());
String endTime = parentParam.get(CMDPARAM_COMPLEMENT_DATA_END_DATE);
String startTime = parentParam.get(CMDPARAM_COMPLEMENT_DATA_START_DATE);
String scheduleTime = parentParam.get(CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST);
if (StringUtils.isNotEmpty(startTime) && StringUtils.isNotEmpty(endTime)) {
cmdParam.put(CMDPARAM_COMPLEMENT_DATA_END_DATE, endTime);
cmdParam.put(CMDPARAM_COMPLEMENT_DATA_START_DATE, startTime);
}
if (StringUtils.isNotEmpty(scheduleTime)) {
cmdParam.put(CMDPARAM_COMPLEMENT_DATA_SCHEDULE_DATE_LIST, scheduleTime);
}
processMapStr = JSONUtils.toJsonString(cmdParam);
}
if (fatherParams.size() != 0) {
cmdParam.put(CMD_PARAM_FATHER_PARAMS, JSONUtils.toJsonString(fatherParams));
processMapStr = JSONUtils.toJsonString(cmdParam);
}
return processMapStr;
}
@Override
public Map<String, String> getGlobalParamMap(String globalParams) {
List<Property> propList;
Map<String, String> globalParamMap = new HashMap<>();
if (!Strings.isNullOrEmpty(globalParams)) {
propList = JSONUtils.toList(globalParams, Property.class);
globalParamMap = propList.stream().collect(Collectors.toMap(Property::getProp, Property::getValue));
}
return globalParamMap;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
}
/**
* create sub work process command
*/
@Override
public Command createSubProcessCommand(ProcessInstance parentProcessInstance,
ProcessInstance childInstance,
ProcessInstanceMap instanceMap,
TaskInstance task) {
CommandType commandType = getSubCommandType(parentProcessInstance, childInstance);
Map<String, Object> subProcessParam = JSONUtils.toMap(task.getTaskParams(), String.class, Object.class);
long childDefineCode = 0L;
if (subProcessParam.containsKey(Constants.CMD_PARAM_SUB_PROCESS_DEFINE_CODE)) {
childDefineCode = Long.parseLong(String.valueOf(subProcessParam.get(Constants.CMD_PARAM_SUB_PROCESS_DEFINE_CODE)));
}
ProcessDefinition subProcessDefinition = processDefineMapper.queryByCode(childDefineCode);
Object localParams = subProcessParam.get(Constants.LOCAL_PARAMS);
List<Property> allParam = JSONUtils.toList(JSONUtils.toJsonString(localParams), Property.class);
Map<String, String> globalMap = this.getGlobalParamMap(task.getVarPool());
Map<String, String> fatherParams = new HashMap<>();
if (CollectionUtils.isNotEmpty(allParam)) {
for (Property info : allParam) {
if (Direct.OUT == info.getDirect()) {
continue;
}
fatherParams.put(info.getProp(), globalMap.get(info.getProp()));
}
}
String processParam = getSubWorkFlowParam(instanceMap, parentProcessInstance, fatherParams);
int subProcessInstanceId = childInstance == null ? 0 : childInstance.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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
return new Command(
commandType,
TaskDependType.TASK_POST,
parentProcessInstance.getFailureStrategy(),
parentProcessInstance.getExecutorId(),
subProcessDefinition.getCode(),
processParam,
parentProcessInstance.getWarningType(),
parentProcessInstance.getWarningGroupId(),
parentProcessInstance.getScheduleTime(),
task.getWorkerGroup(),
task.getEnvironmentCode(),
parentProcessInstance.getProcessInstancePriority(),
parentProcessInstance.getDryRun(),
subProcessInstanceId,
subProcessDefinition.getVersion()
);
}
/**
* initialize sub work flow state
* child instance state would be initialized when 'recovery from pause/stop/failure'
*/
private void initSubInstanceState(ProcessInstance childInstance) {
if (childInstance != null) {
childInstance.setState(ExecutionStatus.RUNNING_EXECUTION);
updateProcessInstance(childInstance);
}
}
/**
* get sub work flow command type
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* child instance exist: child command = fatherCommand
* child instance not exists: child command = fatherCommand[0]
*/
private CommandType getSubCommandType(ProcessInstance parentProcessInstance, ProcessInstance childInstance) {
CommandType commandType = parentProcessInstance.getCommandType();
if (childInstance == null) {
String fatherHistoryCommand = parentProcessInstance.getHistoryCmd();
commandType = CommandType.valueOf(fatherHistoryCommand.split(Constants.COMMA)[0]);
}
return commandType;
}
/**
* update sub process definition
*
* @param parentProcessInstance parentProcessInstance
* @param childDefinitionCode childDefinitionId
*/
private void updateSubProcessDefinitionByParent(ProcessInstance parentProcessInstance, long childDefinitionCode) {
ProcessDefinition fatherDefinition = this.findProcessDefinition(parentProcessInstance.getProcessDefinitionCode(),
parentProcessInstance.getProcessDefinitionVersion());
ProcessDefinition childDefinition = this.findProcessDefinitionByCode(childDefinitionCode);
if (childDefinition != null && fatherDefinition != null) {
childDefinition.setWarningGroupId(fatherDefinition.getWarningGroupId());
processDefineMapper.updateById(childDefinition);
}
}
/**
* submit task to mysql
*
* @param taskInstance taskInstance
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* @param processInstance processInstance
* @return task instance
*/
@Override
public TaskInstance submitTaskInstanceToDB(TaskInstance taskInstance, ProcessInstance processInstance) {
ExecutionStatus processInstanceState = processInstance.getState();
if (processInstanceState.typeIsFinished() || processInstanceState == ExecutionStatus.READY_STOP) {
logger.warn("processInstance: {} state was: {}, skip submit this task, taskCode: {}",
processInstance.getId(),
processInstanceState,
taskInstance.getTaskCode());
return null;
}
if (processInstanceState == ExecutionStatus.READY_PAUSE) {
taskInstance.setState(ExecutionStatus.PAUSE);
}
taskInstance.setExecutorId(processInstance.getExecutorId());
taskInstance.setState(getSubmitTaskState(taskInstance, processInstance));
if (taskInstance.getSubmitTime() == null) {
taskInstance.setSubmitTime(new Date());
}
if (taskInstance.getFirstSubmitTime() == null) {
taskInstance.setFirstSubmitTime(taskInstance.getSubmitTime());
}
boolean saveResult = saveTaskInstance(taskInstance);
if (!saveResult) {
return null;
}
return taskInstance;
}
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
/**
* get submit task instance state by the work process state
* cannot modify the task state when running/kill/submit success, or this
* task instance is already exists in task queue .
* return pause if work process state is ready pause
* return stop if work process state is ready stop
* if all of above are not satisfied, return submit success
*
* @param taskInstance taskInstance
* @param processInstance processInstance
* @return process instance state
*/
@Override
public ExecutionStatus getSubmitTaskState(TaskInstance taskInstance, ProcessInstance processInstance) {
ExecutionStatus state = taskInstance.getState();
if (
state == ExecutionStatus.RUNNING_EXECUTION
|| state == ExecutionStatus.DELAY_EXECUTION
|| state == ExecutionStatus.KILL
|| state == ExecutionStatus.DISPATCH
) {
return state;
}
if (processInstance.getState() == ExecutionStatus.READY_PAUSE) {
state = ExecutionStatus.PAUSE;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
} else if (processInstance.getState() == ExecutionStatus.READY_STOP
|| !checkProcessStrategy(taskInstance, processInstance)) {
state = ExecutionStatus.KILL;
} else {
state = ExecutionStatus.SUBMITTED_SUCCESS;
}
return state;
}
/**
* check process instance strategy
*
* @param taskInstance taskInstance
* @return check strategy result
*/
private boolean checkProcessStrategy(TaskInstance taskInstance, ProcessInstance processInstance) {
FailureStrategy failureStrategy = processInstance.getFailureStrategy();
if (failureStrategy == FailureStrategy.CONTINUE) {
return true;
}
List<TaskInstance> taskInstances = this.findValidTaskListByProcessId(taskInstance.getProcessInstanceId());
for (TaskInstance task : taskInstances) {
if (task.getState() == ExecutionStatus.FAILURE
&& task.getRetryTimes() >= task.getMaxRetryTimes()) {
return false;
}
}
return true;
}
/**
* insert or update work process instance to data base
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
*
* @param processInstance processInstance
*/
@Override
public void saveProcessInstance(ProcessInstance processInstance) {
if (processInstance == null) {
logger.error("save error, process instance is null!");
return;
}
if (processInstance.getId() != 0) {
processInstanceMapper.updateById(processInstance);
} else {
processInstanceMapper.insert(processInstance);
}
}
/**
* insert or update command
*
* @param command command
* @return save command result
*/
@Override
public int saveCommand(Command command) {
if (command.getId() != 0) {
return commandMapper.updateById(command);
} else {
return commandMapper.insert(command);
}
}
/**
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* insert or update task instance
*
* @param taskInstance taskInstance
* @return save task instance result
*/
@Override
public boolean saveTaskInstance(TaskInstance taskInstance) {
if (taskInstance.getId() != 0) {
return updateTaskInstance(taskInstance);
} else {
return createTaskInstance(taskInstance);
}
}
/**
* insert task instance
*
* @param taskInstance taskInstance
* @return create task instance result
*/
@Override
public boolean createTaskInstance(TaskInstance taskInstance) {
int count = taskInstanceMapper.insert(taskInstance);
return count > 0;
}
/**
* update task instance
*
* @param taskInstance taskInstance
* @return update task instance 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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
@Override
public boolean updateTaskInstance(TaskInstance taskInstance) {
int count = taskInstanceMapper.updateById(taskInstance);
return count > 0;
}
/**
* find task instance by id
*
* @param taskId task id
* @return task instance
*/
@Override
public TaskInstance findTaskInstanceById(Integer taskId) {
return taskInstanceMapper.selectById(taskId);
}
/**
* find task instance list by id list
*
* @param idList task id list
* @return task instance list
*/
@Override
public List<TaskInstance> findTaskInstanceByIdList(List<Integer> idList) {
if (CollectionUtils.isEmpty(idList)) {
return new ArrayList<>();
}
return taskInstanceMapper.selectBatchIds(idList);
}
/**
* package task instance
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
*/
@Override
public void packageTaskInstance(TaskInstance taskInstance, ProcessInstance processInstance) {
taskInstance.setProcessInstance(processInstance);
taskInstance.setProcessDefine(processInstance.getProcessDefinition());
taskInstance.setProcessInstancePriority(processInstance.getProcessInstancePriority());
TaskDefinition taskDefinition = this.findTaskDefinition(
taskInstance.getTaskCode(),
taskInstance.getTaskDefinitionVersion());
this.updateTaskDefinitionResources(taskDefinition);
taskInstance.setTaskDefine(taskDefinition);
}
/**
* Update {@link ResourceInfo} information in {@link TaskDefinition}
*
* @param taskDefinition the given {@link TaskDefinition}
*/
@Override
public void updateTaskDefinitionResources(TaskDefinition taskDefinition) {
Map<String, Object> taskParameters = JSONUtils.parseObject(
taskDefinition.getTaskParams(),
new TypeReference<Map<String, Object>>() {
});
if (taskParameters != null) {
if (taskParameters.containsKey("mainJar")) {
Object mainJarObj = taskParameters.get("mainJar");
ResourceInfo mainJar = JSONUtils.parseObject(
JSONUtils.toJsonString(mainJarObj),
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
ResourceInfo.class);
ResourceInfo resourceInfo = updateResourceInfo(mainJar);
if (resourceInfo != null) {
taskParameters.put("mainJar", resourceInfo);
}
}
if (taskParameters.containsKey("resourceList")) {
String resourceListStr = JSONUtils.toJsonString(taskParameters.get("resourceList"));
List<ResourceInfo> resourceInfos = JSONUtils.toList(resourceListStr, ResourceInfo.class);
List<ResourceInfo> updatedResourceInfos = resourceInfos
.stream()
.map(this::updateResourceInfo)
.filter(Objects::nonNull)
.collect(Collectors.toList());
taskParameters.put("resourceList", updatedResourceInfos);
}
taskDefinition.setTaskParams(JSONUtils.toJsonString(taskParameters));
}
}
/**
* update {@link ResourceInfo} by given original ResourceInfo
*
* @param res origin resource info
* @return {@link ResourceInfo}
*/
private ResourceInfo updateResourceInfo(ResourceInfo res) {
ResourceInfo resourceInfo = 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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
if (res != null) {
int resourceId = res.getId();
if (resourceId <= 0) {
logger.error("invalid resourceId, {}", resourceId);
return null;
}
resourceInfo = new ResourceInfo();
Resource resource = getResourceById(resourceId);
resourceInfo.setId(resourceId);
resourceInfo.setRes(resource.getFileName());
resourceInfo.setResourceName(resource.getFullName());
if (logger.isInfoEnabled()) {
logger.info("updated resource info {}",
JSONUtils.toJsonString(resourceInfo));
}
}
return resourceInfo;
}
/**
* get id list by task state
*
* @param instanceId instanceId
* @param state state
* @return task instance states
*/
@Override
public List<Integer> findTaskIdByInstanceState(int instanceId, ExecutionStatus state) {
return taskInstanceMapper.queryTaskByProcessIdAndState(instanceId, state.ordinal());
}
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
/**
* find valid task list by process definition id
*
* @param processInstanceId processInstanceId
* @return task instance list
*/
@Override
public List<TaskInstance> findValidTaskListByProcessId(Integer processInstanceId) {
return taskInstanceMapper.findValidTaskListByProcessId(processInstanceId, Flag.YES);
}
/**
* find previous task list by work process id
*
* @param processInstanceId processInstanceId
* @return task instance list
*/
@Override
public List<TaskInstance> findPreviousTaskListByWorkProcessId(Integer processInstanceId) {
return taskInstanceMapper.findValidTaskListByProcessId(processInstanceId, Flag.NO);
}
/**
* update work process instance map
*
* @param processInstanceMap processInstanceMap
* @return update process instance result
*/
@Override
public int updateWorkProcessInstanceMap(ProcessInstanceMap processInstanceMap) {
return processInstanceMapMapper.updateById(processInstanceMap);
}
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
/**
* create work process instance map
*
* @param processInstanceMap processInstanceMap
* @return create process instance result
*/
@Override
public int createWorkProcessInstanceMap(ProcessInstanceMap processInstanceMap) {
int count = 0;
if (processInstanceMap != null) {
return processInstanceMapMapper.insert(processInstanceMap);
}
return count;
}
/**
* find work process map by parent process id and parent task id.
*
* @param parentWorkProcessId parentWorkProcessId
* @param parentTaskId parentTaskId
* @return process instance map
*/
@Override
public ProcessInstanceMap findWorkProcessMapByParent(Integer parentWorkProcessId, Integer parentTaskId) {
return processInstanceMapMapper.queryByParentId(parentWorkProcessId, parentTaskId);
}
/**
* delete work process map by parent process id
*
* @param parentWorkProcessId parentWorkProcessId
* @return delete process map 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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
*/
@Override
public int deleteWorkProcessMapByParentId(int parentWorkProcessId) {
return processInstanceMapMapper.deleteByParentProcessId(parentWorkProcessId);
}
/**
* find sub process instance
*
* @param parentProcessId parentProcessId
* @param parentTaskId parentTaskId
* @return process instance
*/
@Override
public ProcessInstance findSubProcessInstance(Integer parentProcessId, Integer parentTaskId) {
ProcessInstance processInstance = null;
ProcessInstanceMap processInstanceMap = processInstanceMapMapper.queryByParentId(parentProcessId, parentTaskId);
if (processInstanceMap == null || processInstanceMap.getProcessInstanceId() == 0) {
return processInstance;
}
processInstance = findProcessInstanceById(processInstanceMap.getProcessInstanceId());
return processInstance;
}
/**
* find parent process instance
*
* @param subProcessId subProcessId
* @return process instance
*/
@Override
public ProcessInstance findParentProcessInstance(Integer subProcessId) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
ProcessInstance processInstance = null;
ProcessInstanceMap processInstanceMap = processInstanceMapMapper.queryBySubProcessId(subProcessId);
if (processInstanceMap == null || processInstanceMap.getProcessInstanceId() == 0) {
return processInstance;
}
processInstance = findProcessInstanceById(processInstanceMap.getParentProcessInstanceId());
return processInstance;
}
/**
* update process instance
*
* @param processInstance processInstance
* @return update process instance result
*/
@Override
public int updateProcessInstance(ProcessInstance processInstance) {
return processInstanceMapper.updateById(processInstance);
}
/**
* for show in page of taskInstance
*/
@Override
public void changeOutParam(TaskInstance taskInstance) {
if (Strings.isNullOrEmpty(taskInstance.getVarPool())) {
return;
}
List<Property> properties = JSONUtils.toList(taskInstance.getVarPool(), Property.class);
if (CollectionUtils.isEmpty(properties)) {
return;
}
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
Map<String, Object> taskParams = JSONUtils.parseObject(taskInstance.getTaskParams(), new TypeReference<Map<String, Object>>() {
});
Object localParams = taskParams.get(LOCAL_PARAMS);
if (localParams == null) {
return;
}
List<Property> allParam = JSONUtils.toList(JSONUtils.toJsonString(localParams), Property.class);
Map<String, String> outProperty = new HashMap<>();
for (Property info : properties) {
if (info.getDirect() == Direct.OUT) {
outProperty.put(info.getProp(), info.getValue());
}
}
for (Property info : allParam) {
if (info.getDirect() == Direct.OUT) {
String paramName = info.getProp();
info.setValue(outProperty.get(paramName));
}
}
taskParams.put(LOCAL_PARAMS, allParam);
taskInstance.setTaskParams(JSONUtils.toJsonString(taskParams));
}
/**
* convert integer list to string list
*
* @param intList intList
* @return string list
*/
private List<String> convertIntListToString(List<Integer> intList) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
if (intList == null) {
return new ArrayList<>();
}
List<String> result = new ArrayList<>(intList.size());
for (Integer intVar : intList) {
result.add(String.valueOf(intVar));
}
return result;
}
/**
* query schedule by id
*
* @param id id
* @return schedule
*/
@Override
public Schedule querySchedule(int id) {
return scheduleMapper.selectById(id);
}
/**
* query Schedule by processDefinitionCode
*
* @param processDefinitionCode processDefinitionCode
* @see Schedule
*/
@Override
public List<Schedule> queryReleaseSchedulerListByProcessDefinitionCode(long processDefinitionCode) {
return scheduleMapper.queryReleaseSchedulerListByProcessDefinitionCode(processDefinitionCode);
}
/**
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* query Schedule by processDefinitionCode
*
* @param processDefinitionCodeList processDefinitionCodeList
* @see Schedule
*/
@Override
public Map<Long, String> queryWorkerGroupByProcessDefinitionCodes(List<Long> processDefinitionCodeList) {
List<Schedule> processDefinitionScheduleList = scheduleMapper.querySchedulesByProcessDefinitionCodes(processDefinitionCodeList);
return processDefinitionScheduleList.stream().collect(Collectors.toMap(Schedule::getProcessDefinitionCode,
Schedule::getWorkerGroup));
}
/**
* query dependent process definition by process definition code
*
* @param processDefinitionCode processDefinitionCode
* @see DependentProcessDefinition
*/
@Override
public List<DependentProcessDefinition> queryDependentProcessDefinitionByProcessDefinitionCode(long processDefinitionCode) {
return workFlowLineageMapper.queryDependentProcessDefinitionByProcessDefinitionCode(processDefinitionCode);
}
/**
* query need failover process instance
*
* @param host host
* @return process instance list
*/
@Override
public List<ProcessInstance> queryNeedFailoverProcessInstances(String host) {
return processInstanceMapper.queryByHostAndStatus(host, ExecutionStatus.getNeedFailoverWorkflowInstanceState());
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
}
@Override
public List<String> queryNeedFailoverProcessInstanceHost() {
return processInstanceMapper.queryNeedFailoverProcessInstanceHost(ExecutionStatus.getNeedFailoverWorkflowInstanceState());
}
/**
* process need failover process instance
*
* @param processInstance processInstance
*/
@Override
@Transactional
public void processNeedFailoverProcessInstances(ProcessInstance processInstance) {
processInstance.setHost(Constants.NULL);
processInstanceMapper.updateById(processInstance);
ProcessDefinition processDefinition = findProcessDefinition(processInstance.getProcessDefinitionCode(), processInstance.getProcessDefinitionVersion());
Command cmd = new Command();
cmd.setProcessDefinitionCode(processDefinition.getCode());
cmd.setProcessDefinitionVersion(processDefinition.getVersion());
cmd.setProcessInstanceId(processInstance.getId());
cmd.setCommandParam(String.format("{\"%s\":%d}", Constants.CMD_PARAM_RECOVER_PROCESS_ID_STRING, processInstance.getId()));
cmd.setExecutorId(processInstance.getExecutorId());
cmd.setCommandType(CommandType.RECOVER_TOLERANCE_FAULT_PROCESS);
cmd.setProcessInstancePriority(processInstance.getProcessInstancePriority());
createCommand(cmd);
}
/**
* query all need failover task instances by host
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
*
* @param host host
* @return task instance list
*/
@Override
public List<TaskInstance> queryNeedFailoverTaskInstances(String host) {
return taskInstanceMapper.queryByHostAndStatus(host,
ExecutionStatus.getNeedFailoverWorkflowInstanceState());
}
/**
* find data source by id
*
* @param id id
* @return datasource
*/
@Override
public DataSource findDataSourceById(int id) {
return dataSourceMapper.selectById(id);
}
/**
* update process instance state by id
*
* @param processInstanceId processInstanceId
* @param executionStatus executionStatus
* @return update process result
*/
@Override
public int updateProcessInstanceState(Integer processInstanceId, ExecutionStatus executionStatus) {
ProcessInstance instance = processInstanceMapper.selectById(processInstanceId);
instance.setState(executionStatus);
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
return processInstanceMapper.updateById(instance);
}
/**
* find process instance by the task id
*
* @param taskId taskId
* @return process instance
*/
@Override
public ProcessInstance findProcessInstanceByTaskId(int taskId) {
TaskInstance taskInstance = taskInstanceMapper.selectById(taskId);
if (taskInstance != null) {
return processInstanceMapper.selectById(taskInstance.getProcessInstanceId());
}
return null;
}
/**
* find udf function list by id list string
*
* @param ids ids
* @return udf function list
*/
@Override
public List<UdfFunc> queryUdfFunListByIds(Integer[] ids) {
return udfFuncMapper.queryUdfByIdStr(ids, null);
}
/**
* find tenant code by resource name
*
* @param resName resource name
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
* @param resourceType resource type
* @return tenant code
*/
@Override
public String queryTenantCodeByResName(String resName, ResourceType resourceType) {
String fullName = resName.startsWith("/") ? resName : String.format("/%s", resName);
List<Resource> resourceList = resourceMapper.queryResource(fullName, resourceType.ordinal());
if (CollectionUtils.isEmpty(resourceList)) {
return "";
}
int userId = resourceList.get(0).getUserId();
User user = userMapper.selectById(userId);
if (Objects.isNull(user)) {
return "";
}
Tenant tenant = tenantMapper.queryById(user.getTenantId());
if (Objects.isNull(tenant)) {
return "";
}
return tenant.getTenantCode();
}
/**
* find schedule list by process define codes.
*
* @param codes codes
* @return schedule list
*/
@Override
public List<Schedule> selectAllByProcessDefineCode(long[] codes) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
return scheduleMapper.selectAllByProcessDefineArray(codes);
}
/**
* find last scheduler process instance in the date interval
*
* @param definitionCode definitionCode
* @param dateInterval dateInterval
* @return process instance
*/
@Override
public ProcessInstance findLastSchedulerProcessInterval(Long definitionCode, DateInterval dateInterval) {
return processInstanceMapper.queryLastSchedulerProcess(definitionCode,
dateInterval.getStartTime(),
dateInterval.getEndTime());
}
/**
* find last manual process instance interval
*
* @param definitionCode process definition code
* @param dateInterval dateInterval
* @return process instance
*/
@Override
public ProcessInstance findLastManualProcessInterval(Long definitionCode, DateInterval dateInterval) {
return processInstanceMapper.queryLastManualProcess(definitionCode,
dateInterval.getStartTime(),
dateInterval.getEndTime());
}
/**
* find last running process instance
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
*
* @param definitionCode process definition code
* @param startTime start time
* @param endTime end time
* @return process instance
*/
@Override
public ProcessInstance findLastRunningProcess(Long definitionCode, Date startTime, Date endTime) {
return processInstanceMapper.queryLastRunningProcess(definitionCode,
startTime,
endTime,
ExecutionStatus.getNeedFailoverWorkflowInstanceState());
}
/**
* query user queue by process instance
*
* @param processInstance processInstance
* @return queue
*/
@Override
public String queryUserQueueByProcessInstance(ProcessInstance processInstance) {
String queue = "";
if (processInstance == null) {
return queue;
}
User executor = userMapper.selectById(processInstance.getExecutorId());
if (executor != null) {
queue = executor.getQueue();
}
return 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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
}
/**
* query project name and user name by processInstanceId.
*
* @param processInstanceId processInstanceId
* @return projectName and userName
*/
@Override
public ProjectUser queryProjectWithUserByProcessInstanceId(int processInstanceId) {
return projectMapper.queryProjectWithUserByProcessInstanceId(processInstanceId);
}
/**
* get task worker group
*
* @param taskInstance taskInstance
* @return workerGroupId
*/
@Override
public String getTaskWorkerGroup(TaskInstance taskInstance) {
String workerGroup = taskInstance.getWorkerGroup();
if (!Strings.isNullOrEmpty(workerGroup)) {
return workerGroup;
}
int processInstanceId = taskInstance.getProcessInstanceId();
ProcessInstance processInstance = findProcessInstanceById(processInstanceId);
if (processInstance != null) {
return processInstance.getWorkerGroup();
}
logger.info("task : {} will use default worker group", taskInstance.getId());
return Constants.DEFAULT_WORKER_GROUP;
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
}
/**
* get have perm project list
*
* @param userId userId
* @return project list
*/
@Override
public List<Project> getProjectListHavePerm(int userId) {
List<Project> createProjects = projectMapper.queryProjectCreatedByUser(userId);
List<Project> authedProjects = projectMapper.queryAuthedProjectListByUserId(userId);
if (createProjects == null) {
createProjects = new ArrayList<>();
}
if (authedProjects != null) {
createProjects.addAll(authedProjects);
}
return createProjects;
}
/**
* list unauthorized udf function
*
* @param userId user id
* @param needChecks data source id array
* @return unauthorized udf function list
*/
@Override
public <T> List<T> listUnauthorized(int userId, T[] needChecks, AuthorizationType authorizationType) {
List<T> resultList = new ArrayList<>();
if (Objects.nonNull(needChecks) && needChecks.length > 0) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
Set<T> originResSet = new HashSet<>(Arrays.asList(needChecks));
switch (authorizationType) {
case RESOURCE_FILE_ID:
case UDF_FILE:
List<Resource> ownUdfResources = resourceMapper.listAuthorizedResourceById(userId, needChecks);
addAuthorizedResources(ownUdfResources, userId);
Set<Integer> authorizedResourceFiles = ownUdfResources.stream().map(Resource::getId).collect(toSet());
originResSet.removeAll(authorizedResourceFiles);
break;
case RESOURCE_FILE_NAME:
List<Resource> ownResources = resourceMapper.listAuthorizedResource(userId, needChecks);
addAuthorizedResources(ownResources, userId);
Set<String> authorizedResources = ownResources.stream().map(Resource::getFullName).collect(toSet());
originResSet.removeAll(authorizedResources);
break;
case DATASOURCE:
Set<Integer> authorizedDatasources = dataSourceMapper.listAuthorizedDataSource(userId, needChecks).stream().map(DataSource::getId).collect(toSet());
originResSet.removeAll(authorizedDatasources);
break;
case UDF:
Set<Integer> authorizedUdfs = udfFuncMapper.listAuthorizedUdfFunc(userId, needChecks).stream().map(UdfFunc::getId).collect(toSet());
originResSet.removeAll(authorizedUdfs);
break;
default:
break;
}
resultList.addAll(originResSet);
}
return resultList;
}
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
/**
* get user by user id
*
* @param userId user id
* @return User
*/
@Override
public User getUserById(int userId) {
return userMapper.selectById(userId);
}
/**
* get resource by resource id
*
* @param resourceId resource id
* @return Resource
*/
@Override
public Resource getResourceById(int resourceId) {
return resourceMapper.selectById(resourceId);
}
/**
* list resources by ids
*
* @param resIds resIds
* @return resource list
*/
@Override
public List<Resource> listResourceByIds(Integer[] resIds) {
return resourceMapper.listResourceByIds(resIds);
}
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
/**
* format task app id in task instance
*/
@Override
public String formatTaskAppId(TaskInstance taskInstance) {
ProcessInstance processInstance = findProcessInstanceById(taskInstance.getProcessInstanceId());
if (processInstance == null) {
return "";
}
ProcessDefinition definition = findProcessDefinition(processInstance.getProcessDefinitionCode(), processInstance.getProcessDefinitionVersion());
if (definition == null) {
return "";
}
return String.format("%s_%s_%s", definition.getId(), processInstance.getId(), taskInstance.getId());
}
/**
* switch process definition version to process definition log version
*/
@Override
public int switchVersion(ProcessDefinition processDefinition, ProcessDefinitionLog processDefinitionLog) {
if (null == processDefinition || null == processDefinitionLog) {
return Constants.DEFINITION_FAILURE;
}
processDefinitionLog.setId(processDefinition.getId());
processDefinitionLog.setReleaseState(ReleaseState.OFFLINE);
processDefinitionLog.setFlag(Flag.YES);
int result = processDefineMapper.updateById(processDefinitionLog);
if (result > 0) {
result = switchProcessTaskRelationVersion(processDefinitionLog);
if (result <= 0) {
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
return Constants.EXIT_CODE_FAILURE;
}
}
return result;
}
@Override
public int switchProcessTaskRelationVersion(ProcessDefinition processDefinition) {
List<ProcessTaskRelation> processTaskRelationList = processTaskRelationMapper.queryByProcessCode(processDefinition.getProjectCode(), processDefinition.getCode());
if (!processTaskRelationList.isEmpty()) {
processTaskRelationMapper.deleteByCode(processDefinition.getProjectCode(), processDefinition.getCode());
}
List<ProcessTaskRelationLog> processTaskRelationLogList = processTaskRelationLogMapper.queryByProcessCodeAndVersion(processDefinition.getCode(), processDefinition.getVersion());
int batchInsert = processTaskRelationMapper.batchInsert(processTaskRelationLogList);
if (batchInsert == 0) {
return Constants.EXIT_CODE_FAILURE;
} else {
int result = 0;
for (ProcessTaskRelationLog taskRelationLog : processTaskRelationLogList) {
int switchResult = switchTaskDefinitionVersion(taskRelationLog.getPostTaskCode(), taskRelationLog.getPostTaskVersion());
if (switchResult != Constants.EXIT_CODE_FAILURE) {
result++;
}
}
return result;
}
}
@Override
public int switchTaskDefinitionVersion(long taskCode, int taskVersion) {
TaskDefinition taskDefinition = taskDefinitionMapper.queryByCode(taskCode);
if (taskDefinition == 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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
return Constants.EXIT_CODE_FAILURE;
}
if (taskDefinition.getVersion() == taskVersion) {
return Constants.EXIT_CODE_SUCCESS;
}
TaskDefinitionLog taskDefinitionUpdate = taskDefinitionLogMapper.queryByDefinitionCodeAndVersion(taskCode, taskVersion);
if (taskDefinitionUpdate == null) {
return Constants.EXIT_CODE_FAILURE;
}
taskDefinitionUpdate.setUpdateTime(new Date());
taskDefinitionUpdate.setId(taskDefinition.getId());
return taskDefinitionMapper.updateById(taskDefinitionUpdate);
}
/**
* get resource ids
*
* @param taskDefinition taskDefinition
* @return resource ids
*/
@Override
public String getResourceIds(TaskDefinition taskDefinition) {
Set<Integer> resourceIds = null;
AbstractParameters params = taskPluginManager.getParameters(ParametersNode.builder().taskType(taskDefinition.getTaskType()).taskParams(taskDefinition.getTaskParams()).build());
if (params != null && CollectionUtils.isNotEmpty(params.getResourceFilesList())) {
resourceIds = params.getResourceFilesList().
stream()
.filter(t -> t.getId() != 0)
.map(ResourceInfo::getId)
.collect(toSet());
}
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
if (CollectionUtils.isEmpty(resourceIds)) {
return "";
}
return Joiner.on(",").join(resourceIds);
}
@Override
public int saveTaskDefine(User operator, long projectCode, List<TaskDefinitionLog> taskDefinitionLogs, Boolean syncDefine) {
Date now = new Date();
List<TaskDefinitionLog> newTaskDefinitionLogs = new ArrayList<>();
List<TaskDefinitionLog> updateTaskDefinitionLogs = new ArrayList<>();
for (TaskDefinitionLog taskDefinitionLog : taskDefinitionLogs) {
taskDefinitionLog.setProjectCode(projectCode);
taskDefinitionLog.setUpdateTime(now);
taskDefinitionLog.setOperateTime(now);
taskDefinitionLog.setOperator(operator.getId());
taskDefinitionLog.setResourceIds(getResourceIds(taskDefinitionLog));
if (taskDefinitionLog.getCode() == 0) {
try {
taskDefinitionLog.setCode(CodeGenerateUtils.getInstance().genCode());
} catch (CodeGenerateException e) {
logger.error("Task code get error, ", e);
return Constants.DEFINITION_FAILURE;
}
}
if (taskDefinitionLog.getVersion() == 0) {
taskDefinitionLog.setVersion(Constants.VERSION_FIRST);
}
TaskDefinitionLog definitionCodeAndVersion = taskDefinitionLogMapper
.queryByDefinitionCodeAndVersion(taskDefinitionLog.getCode(), taskDefinitionLog.getVersion());
|
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-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessServiceImpl.java
|
if (definitionCodeAndVersion == null) {
taskDefinitionLog.setUserId(operator.getId());
taskDefinitionLog.setCreateTime(now);
newTaskDefinitionLogs.add(taskDefinitionLog);
continue;
}
if (taskDefinitionLog.equals(definitionCodeAndVersion)) {
continue;
}
taskDefinitionLog.setUserId(definitionCodeAndVersion.getUserId());
Integer version = taskDefinitionLogMapper.queryMaxVersionForDefinition(taskDefinitionLog.getCode());
taskDefinitionLog.setVersion(version + 1);
taskDefinitionLog.setCreateTime(definitionCodeAndVersion.getCreateTime());
updateTaskDefinitionLogs.add(taskDefinitionLog);
}
int insertResult = 0;
int updateResult = 0;
for (TaskDefinitionLog taskDefinitionToUpdate : updateTaskDefinitionLogs) {
TaskDefinition task = taskDefinitionMapper.queryByCode(taskDefinitionToUpdate.getCode());
if (task == null) {
newTaskDefinitionLogs.add(taskDefinitionToUpdate);
} else {
insertResult += taskDefinitionLogMapper.insert(taskDefinitionToUpdate);
if (Boolean.TRUE.equals(syncDefine)) {
taskDefinitionToUpdate.setId(task.getId());
updateResult += taskDefinitionMapper.updateById(taskDefinitionToUpdate);
} else {
updateResult++;
}
|
Subsets and Splits
No community queries yet
The top public SQL queries from the community will appear here once available.