Browse Source

Merge pull request #4097 from CalvinKirs/ack_status

[FIX-#4084][server]fix taskInstance state change error
pull/3/MERGE
dailidong 4 years ago committed by GitHub
parent
commit
656ec295b9
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
  1. 56
      dolphinscheduler-server/src/main/java/org/apache/dolphinscheduler/server/master/consumer/TaskPriorityQueueConsumer.java
  2. 26
      dolphinscheduler-server/src/main/java/org/apache/dolphinscheduler/server/master/processor/queue/TaskResponseService.java
  3. 99
      dolphinscheduler-server/src/test/java/org/apache/dolphinscheduler/server/master/processor/queue/TaskResponseServiceTest.java
  4. 97
      dolphinscheduler-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessService.java
  5. 1
      pom.xml

56
dolphinscheduler-server/src/main/java/org/apache/dolphinscheduler/server/master/consumer/TaskPriorityQueueConsumer.java

@ -19,8 +19,8 @@ package org.apache.dolphinscheduler.server.master.consumer;
import org.apache.dolphinscheduler.common.Constants; import org.apache.dolphinscheduler.common.Constants;
import org.apache.dolphinscheduler.common.enums.ExecutionStatus; import org.apache.dolphinscheduler.common.enums.ExecutionStatus;
import org.apache.dolphinscheduler.common.enums.SqoopJobType;
import org.apache.dolphinscheduler.common.enums.ResourceType; import org.apache.dolphinscheduler.common.enums.ResourceType;
import org.apache.dolphinscheduler.common.enums.SqoopJobType;
import org.apache.dolphinscheduler.common.enums.TaskType; import org.apache.dolphinscheduler.common.enums.TaskType;
import org.apache.dolphinscheduler.common.enums.UdfType; import org.apache.dolphinscheduler.common.enums.UdfType;
import org.apache.dolphinscheduler.common.model.TaskNode; import org.apache.dolphinscheduler.common.model.TaskNode;
@ -33,10 +33,24 @@ import org.apache.dolphinscheduler.common.task.sqoop.SqoopParameters;
import org.apache.dolphinscheduler.common.task.sqoop.sources.SourceMysqlParameter; import org.apache.dolphinscheduler.common.task.sqoop.sources.SourceMysqlParameter;
import org.apache.dolphinscheduler.common.task.sqoop.targets.TargetMysqlParameter; import org.apache.dolphinscheduler.common.task.sqoop.targets.TargetMysqlParameter;
import org.apache.dolphinscheduler.common.thread.Stopper; import org.apache.dolphinscheduler.common.thread.Stopper;
import org.apache.dolphinscheduler.common.utils.*; import org.apache.dolphinscheduler.common.utils.CollectionUtils;
import org.apache.dolphinscheduler.dao.entity.*; import org.apache.dolphinscheduler.common.utils.EnumUtils;
import org.apache.dolphinscheduler.common.utils.FileUtils;
import org.apache.dolphinscheduler.common.utils.JSONUtils;
import org.apache.dolphinscheduler.common.utils.StringUtils;
import org.apache.dolphinscheduler.common.utils.TaskParametersUtils;
import org.apache.dolphinscheduler.dao.entity.DataSource;
import org.apache.dolphinscheduler.dao.entity.Resource;
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.server.builder.TaskExecutionContextBuilder; import org.apache.dolphinscheduler.server.builder.TaskExecutionContextBuilder;
import org.apache.dolphinscheduler.server.entity.*; import org.apache.dolphinscheduler.server.entity.DataxTaskExecutionContext;
import org.apache.dolphinscheduler.server.entity.ProcedureTaskExecutionContext;
import org.apache.dolphinscheduler.server.entity.SQLTaskExecutionContext;
import org.apache.dolphinscheduler.server.entity.SqoopTaskExecutionContext;
import org.apache.dolphinscheduler.server.entity.TaskExecutionContext;
import org.apache.dolphinscheduler.server.entity.TaskPriority;
import org.apache.dolphinscheduler.server.master.config.MasterConfig; import org.apache.dolphinscheduler.server.master.config.MasterConfig;
import org.apache.dolphinscheduler.server.master.dispatch.ExecutorDispatcher; import org.apache.dolphinscheduler.server.master.dispatch.ExecutorDispatcher;
import org.apache.dolphinscheduler.server.master.dispatch.context.ExecutionContext; import org.apache.dolphinscheduler.server.master.dispatch.context.ExecutionContext;
@ -44,16 +58,22 @@ 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.exceptions.ExecuteException;
import org.apache.dolphinscheduler.service.process.ProcessService; import org.apache.dolphinscheduler.service.process.ProcessService;
import org.apache.dolphinscheduler.service.queue.TaskPriorityQueue; import org.apache.dolphinscheduler.service.queue.TaskPriorityQueue;
import java.util.ArrayList;
import java.util.HashMap;
import java.util.List;
import java.util.Map;
import java.util.Set;
import java.util.stream.Collectors;
import java.util.stream.Stream;
import javax.annotation.PostConstruct;
import org.slf4j.Logger; import org.slf4j.Logger;
import org.slf4j.LoggerFactory; import org.slf4j.LoggerFactory;
import org.springframework.beans.factory.annotation.Autowired; import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.stereotype.Component; import org.springframework.stereotype.Component;
import javax.annotation.PostConstruct;
import java.util.*;
import java.util.stream.Collectors;
import java.util.stream.Stream;
/** /**
* TaskUpdateQueue consumer * TaskUpdateQueue consumer
*/ */
@ -125,7 +145,6 @@ public class TaskPriorityQueueConsumer extends Thread{
} }
} }
/** /**
* dispatch task * dispatch task
* *
@ -150,10 +169,10 @@ public class TaskPriorityQueueConsumer extends Thread{
return result; return result;
} }
/** /**
* taskInstance is final state * taskInstance is final state
* successfailurekillstoppausethreadwaiting is final state * successfailurekillstoppausethreadwaiting is final state
*
* @param taskInstanceId taskInstanceId * @param taskInstanceId taskInstanceId
* @return taskInstance is final state * @return taskInstance is final state
*/ */
@ -164,6 +183,7 @@ public class TaskPriorityQueueConsumer extends Thread{
/** /**
* get TaskExecutionContext * get TaskExecutionContext
*
* @param taskInstanceId taskInstanceId * @param taskInstanceId taskInstanceId
* @return TaskExecutionContext * @return TaskExecutionContext
*/ */
@ -181,7 +201,7 @@ public class TaskPriorityQueueConsumer extends Thread{
// verify tenant is null // verify tenant is null
if (verifyTenantIsNull(tenant, taskInstance)) { if (verifyTenantIsNull(tenant, taskInstance)) {
processService.changeTaskState(ExecutionStatus.FAILURE, processService.changeTaskState(taskInstance, ExecutionStatus.FAILURE,
taskInstance.getStartTime(), taskInstance.getStartTime(),
taskInstance.getHost(), taskInstance.getHost(),
null, null,
@ -196,13 +216,11 @@ public class TaskPriorityQueueConsumer extends Thread{
taskInstance.setExecutePath(getExecLocalPath(taskInstance)); taskInstance.setExecutePath(getExecLocalPath(taskInstance));
taskInstance.setResources(getResourceFullNames(taskNode)); taskInstance.setResources(getResourceFullNames(taskNode));
SQLTaskExecutionContext sqlTaskExecutionContext = new SQLTaskExecutionContext(); SQLTaskExecutionContext sqlTaskExecutionContext = new SQLTaskExecutionContext();
DataxTaskExecutionContext dataxTaskExecutionContext = new DataxTaskExecutionContext(); DataxTaskExecutionContext dataxTaskExecutionContext = new DataxTaskExecutionContext();
ProcedureTaskExecutionContext procedureTaskExecutionContext = new ProcedureTaskExecutionContext(); ProcedureTaskExecutionContext procedureTaskExecutionContext = new ProcedureTaskExecutionContext();
SqoopTaskExecutionContext sqoopTaskExecutionContext = new SqoopTaskExecutionContext(); SqoopTaskExecutionContext sqoopTaskExecutionContext = new SqoopTaskExecutionContext();
// SQL task // SQL task
if (taskType == TaskType.SQL) { if (taskType == TaskType.SQL) {
setSQLTaskRelation(sqlTaskExecutionContext, taskNode); setSQLTaskRelation(sqlTaskExecutionContext, taskNode);
@ -214,7 +232,6 @@ public class TaskPriorityQueueConsumer extends Thread{
setDataxTaskRelation(dataxTaskExecutionContext, taskNode); setDataxTaskRelation(dataxTaskExecutionContext, taskNode);
} }
// procedure task // procedure task
if (taskType == TaskType.PROCEDURE) { if (taskType == TaskType.PROCEDURE) {
setProcedureTaskRelation(procedureTaskExecutionContext, taskNode); setProcedureTaskRelation(procedureTaskExecutionContext, taskNode);
@ -224,7 +241,6 @@ public class TaskPriorityQueueConsumer extends Thread{
setSqoopTaskRelation(sqoopTaskExecutionContext, taskNode); setSqoopTaskRelation(sqoopTaskExecutionContext, taskNode);
} }
return TaskExecutionContextBuilder.get() return TaskExecutionContextBuilder.get()
.buildTaskInstanceRelatedInfo(taskInstance) .buildTaskInstanceRelatedInfo(taskInstance)
.buildProcessInstanceRelatedInfo(taskInstance.getProcessInstance()) .buildProcessInstanceRelatedInfo(taskInstance.getProcessInstance())
@ -238,6 +254,7 @@ public class TaskPriorityQueueConsumer extends Thread{
/** /**
* set procedure task relation * set procedure task relation
*
* @param procedureTaskExecutionContext procedureTaskExecutionContext * @param procedureTaskExecutionContext procedureTaskExecutionContext
* @param taskNode taskNode * @param taskNode taskNode
*/ */
@ -250,6 +267,7 @@ public class TaskPriorityQueueConsumer extends Thread{
/** /**
* set datax task relation * set datax task relation
*
* @param dataxTaskExecutionContext dataxTaskExecutionContext * @param dataxTaskExecutionContext dataxTaskExecutionContext
* @param taskNode taskNode * @param taskNode taskNode
*/ */
@ -259,7 +277,6 @@ public class TaskPriorityQueueConsumer extends Thread{
DataSource dataSource = processService.findDataSourceById(dataxParameters.getDataSource()); DataSource dataSource = processService.findDataSourceById(dataxParameters.getDataSource());
DataSource dataTarget = processService.findDataSourceById(dataxParameters.getDataTarget()); DataSource dataTarget = processService.findDataSourceById(dataxParameters.getDataTarget());
if (dataSource != null) { if (dataSource != null) {
dataxTaskExecutionContext.setDataSourceId(dataxParameters.getDataSource()); dataxTaskExecutionContext.setDataSourceId(dataxParameters.getDataSource());
dataxTaskExecutionContext.setSourcetype(dataSource.getType().getCode()); dataxTaskExecutionContext.setSourcetype(dataSource.getType().getCode());
@ -273,9 +290,9 @@ public class TaskPriorityQueueConsumer extends Thread{
} }
} }
/** /**
* set sqoop task relation * set sqoop task relation
*
* @param sqoopTaskExecutionContext sqoopTaskExecutionContext * @param sqoopTaskExecutionContext sqoopTaskExecutionContext
* @param taskNode taskNode * @param taskNode taskNode
*/ */
@ -306,6 +323,7 @@ public class TaskPriorityQueueConsumer extends Thread{
/** /**
* set SQL task relation * set SQL task relation
*
* @param sqlTaskExecutionContext sqlTaskExecutionContext * @param sqlTaskExecutionContext sqlTaskExecutionContext
* @param taskNode taskNode * @param taskNode taskNode
*/ */
@ -349,9 +367,9 @@ public class TaskPriorityQueueConsumer extends Thread{
taskInstance.getId()); taskInstance.getId());
} }
/** /**
* whehter tenant is null * whehter tenant is null
*
* @param tenant tenant * @param tenant tenant
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @return result * @return result

26
dolphinscheduler-server/src/main/java/org/apache/dolphinscheduler/server/master/processor/queue/TaskResponseService.java

@ -17,7 +17,6 @@
package org.apache.dolphinscheduler.server.master.processor.queue; package org.apache.dolphinscheduler.server.master.processor.queue;
import io.netty.channel.Channel;
import org.apache.dolphinscheduler.common.enums.Event; import org.apache.dolphinscheduler.common.enums.Event;
import org.apache.dolphinscheduler.common.enums.ExecutionStatus; import org.apache.dolphinscheduler.common.enums.ExecutionStatus;
import org.apache.dolphinscheduler.common.thread.Stopper; import org.apache.dolphinscheduler.common.thread.Stopper;
@ -25,18 +24,22 @@ import org.apache.dolphinscheduler.dao.entity.TaskInstance;
import org.apache.dolphinscheduler.remote.command.DBTaskAckCommand; import org.apache.dolphinscheduler.remote.command.DBTaskAckCommand;
import org.apache.dolphinscheduler.remote.command.DBTaskResponseCommand; import org.apache.dolphinscheduler.remote.command.DBTaskResponseCommand;
import org.apache.dolphinscheduler.service.process.ProcessService; import org.apache.dolphinscheduler.service.process.ProcessService;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.stereotype.Component;
import javax.annotation.PostConstruct;
import javax.annotation.PreDestroy;
import java.util.ArrayList; import java.util.ArrayList;
import java.util.List; import java.util.List;
import java.util.concurrent.BlockingQueue; import java.util.concurrent.BlockingQueue;
import java.util.concurrent.LinkedBlockingQueue; import java.util.concurrent.LinkedBlockingQueue;
import javax.annotation.PostConstruct;
import javax.annotation.PreDestroy;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.stereotype.Component;
import io.netty.channel.Channel;
/** /**
* task manager * task manager
*/ */
@ -65,7 +68,6 @@ public class TaskResponseService {
*/ */
private Thread taskResponseWorker; private Thread taskResponseWorker;
@PostConstruct @PostConstruct
public void start() { public void start() {
this.taskResponseWorker = new TaskResponseWorker(); this.taskResponseWorker = new TaskResponseWorker();
@ -99,7 +101,6 @@ public class TaskResponseService {
} }
} }
/** /**
* task worker thread * task worker thread
*/ */
@ -126,6 +127,7 @@ public class TaskResponseService {
/** /**
* persist taskResponseEvent * persist taskResponseEvent
*
* @param taskResponseEvent taskResponseEvent * @param taskResponseEvent taskResponseEvent
*/ */
private void persist(TaskResponseEvent taskResponseEvent) { private void persist(TaskResponseEvent taskResponseEvent) {
@ -136,8 +138,8 @@ public class TaskResponseService {
case ACK: case ACK:
try { try {
TaskInstance taskInstance = processService.findTaskInstanceById(taskResponseEvent.getTaskInstanceId()); TaskInstance taskInstance = processService.findTaskInstanceById(taskResponseEvent.getTaskInstanceId());
if (taskInstance != null){ if (taskInstance != null && !taskInstance.getState().typeIsFinished()) {
processService.changeTaskState(taskResponseEvent.getState(), processService.changeTaskState(taskInstance, taskResponseEvent.getState(),
taskResponseEvent.getStartTime(), taskResponseEvent.getStartTime(),
taskResponseEvent.getWorkerAddress(), taskResponseEvent.getWorkerAddress(),
taskResponseEvent.getExecutePath(), taskResponseEvent.getExecutePath(),
@ -157,7 +159,7 @@ public class TaskResponseService {
try { try {
TaskInstance taskInstance = processService.findTaskInstanceById(taskResponseEvent.getTaskInstanceId()); TaskInstance taskInstance = processService.findTaskInstanceById(taskResponseEvent.getTaskInstanceId());
if (taskInstance != null) { if (taskInstance != null) {
processService.changeTaskState(taskResponseEvent.getState(), processService.changeTaskState(taskInstance, taskResponseEvent.getState(),
taskResponseEvent.getEndTime(), taskResponseEvent.getEndTime(),
taskResponseEvent.getProcessId(), taskResponseEvent.getProcessId(),
taskResponseEvent.getAppIds(), taskResponseEvent.getAppIds(),

99
dolphinscheduler-server/src/test/java/org/apache/dolphinscheduler/server/master/processor/queue/TaskResponseServiceTest.java

@ -14,55 +14,80 @@
* See the License for the specific language governing permissions and * See the License for the specific language governing permissions and
* limitations under the License. * limitations under the License.
*/ */
package org.apache.dolphinscheduler.server.master.processor.queue;
package org.apache.dolphinscheduler.server.master.processor.queue;
import org.apache.dolphinscheduler.common.enums.ExecutionStatus; import org.apache.dolphinscheduler.common.enums.ExecutionStatus;
import org.apache.dolphinscheduler.server.registry.DependencyConfig; import org.apache.dolphinscheduler.dao.entity.TaskInstance;
import org.apache.dolphinscheduler.server.registry.ZookeeperNodeManager; import org.apache.dolphinscheduler.service.process.ProcessService;
import org.apache.dolphinscheduler.server.registry.ZookeeperRegistryCenter;
import org.apache.dolphinscheduler.server.zk.SpringZKServer; import java.util.Date;
import org.apache.dolphinscheduler.service.zk.CuratorZookeeperClient;
import org.apache.dolphinscheduler.service.zk.ZookeeperCachedOperator; import org.junit.After;
import org.apache.dolphinscheduler.service.zk.ZookeeperConfig; import org.junit.Before;
import org.junit.Assert;
import org.junit.Test; import org.junit.Test;
import org.junit.runner.RunWith; import org.junit.runner.RunWith;
import org.springframework.beans.factory.annotation.Autowired; import org.mockito.InjectMocks;
import org.springframework.test.context.ContextConfiguration; import org.mockito.Mock;
import org.springframework.test.context.junit4.SpringJUnit4ClassRunner; import org.mockito.Mockito;
import org.mockito.junit.MockitoJUnitRunner;
import java.util.Date; import io.netty.channel.Channel;
@RunWith(SpringJUnit4ClassRunner.class) @RunWith(MockitoJUnitRunner.class)
@ContextConfiguration(classes={DependencyConfig.class, SpringZKServer.class, TaskResponseService.class, ZookeeperRegistryCenter.class,
ZookeeperCachedOperator.class, ZookeeperConfig.class, ZookeeperNodeManager.class, TaskResponseService.class,
CuratorZookeeperClient.class})
public class TaskResponseServiceTest { public class TaskResponseServiceTest {
@Autowired @Mock(name = "processService")
private TaskResponseService taskResponseService; private ProcessService processService;
@Test @InjectMocks
public void testAdd(){ TaskResponseService taskRspService;
TaskResponseEvent taskResponseEvent = TaskResponseEvent.newAck(ExecutionStatus.RUNNING_EXECUTION, new Date(),
"", "", "", 1,null); @Mock
taskResponseService.addResponse(taskResponseEvent); private Channel channel;
Assert.assertTrue(taskResponseService.getEventQueue().size() == 1);
try { private TaskResponseEvent ackEvent;
Thread.sleep(10);
} catch (InterruptedException ignore) { private TaskResponseEvent resultEvent;
}
//after sleep, inner worker will take the event private TaskInstance taskInstance;
Assert.assertTrue(taskResponseService.getEventQueue().size() == 0);
@Before
public void before() {
taskRspService.start();
ackEvent = TaskResponseEvent.newAck(ExecutionStatus.RUNNING_EXECUTION,
new Date(),
"127.*.*.*",
"path",
"logPath",
22,
channel);
resultEvent = TaskResponseEvent.newResult(ExecutionStatus.SUCCESS,
new Date(),
1,
"ids",
22,
"varPol",
channel);
taskInstance = new TaskInstance();
taskInstance.setId(22);
taskInstance.setState(ExecutionStatus.RUNNING_EXECUTION);
} }
@Test @Test
public void testStop(){ public void testAddResponse() {
TaskResponseEvent taskResponseEvent = TaskResponseEvent.newAck(ExecutionStatus.RUNNING_EXECUTION, new Date(), Mockito.when(processService.findTaskInstanceById(Mockito.any())).thenReturn(taskInstance);
"", "", "", 1,null); Mockito.when(channel.writeAndFlush(Mockito.any())).thenReturn(null);
taskResponseService.addResponse(taskResponseEvent); taskRspService.addResponse(ackEvent);
taskResponseService.stop(); taskRspService.addResponse(resultEvent);
Assert.assertTrue(taskResponseService.getEventQueue().size() == 0); }
@After
public void after() {
taskRspService.stop();
} }
} }

97
dolphinscheduler-service/src/main/java/org/apache/dolphinscheduler/service/process/ProcessService.java

@ -79,8 +79,6 @@ import org.apache.dolphinscheduler.remote.utils.Host;
import org.apache.dolphinscheduler.service.log.LogClientService; import org.apache.dolphinscheduler.service.log.LogClientService;
import org.apache.dolphinscheduler.service.quartz.cron.CronUtils; import org.apache.dolphinscheduler.service.quartz.cron.CronUtils;
import org.apache.commons.lang.ArrayUtils;
import java.util.ArrayList; import java.util.ArrayList;
import java.util.Arrays; import java.util.Arrays;
import java.util.Calendar; import java.util.Calendar;
@ -158,6 +156,7 @@ public class ProcessService {
/** /**
* handle Command (construct ProcessInstance from Command) , wrapped in transaction * handle Command (construct ProcessInstance from Command) , wrapped in transaction
*
* @param logger logger * @param logger logger
* @param host host * @param host host
* @param validThreadNum validThreadNum * @param validThreadNum validThreadNum
@ -187,6 +186,7 @@ public class ProcessService {
/** /**
* save error command, and delete original command * save error command, and delete original command
*
* @param command command * @param command command
* @param message message * @param message message
*/ */
@ -199,6 +199,7 @@ public class ProcessService {
/** /**
* set process waiting thread * set process waiting thread
*
* @param command command * @param command command
* @param processInstance processInstance * @param processInstance processInstance
* @return process instance * @return process instance
@ -216,6 +217,7 @@ public class ProcessService {
/** /**
* check thread num * check thread num
*
* @param command command * @param command command
* @param validThreadNum validThreadNum * @param validThreadNum validThreadNum
* @return if thread is enough * @return if thread is enough
@ -227,6 +229,7 @@ public class ProcessService {
/** /**
* insert one command * insert one command
*
* @param command command * @param command command
* @return create result * @return create result
*/ */
@ -240,6 +243,7 @@ public class ProcessService {
/** /**
* find one command from queue list * find one command from queue list
*
* @return command * @return command
*/ */
public Command findOneCommand() { public Command findOneCommand() {
@ -248,6 +252,7 @@ public class ProcessService {
/** /**
* check the input command exists in queue list * check the input command exists in queue list
*
* @param command command * @param command command
* @return create command result * @return create command result
*/ */
@ -280,6 +285,7 @@ public class ProcessService {
/** /**
* find process instance detail by id * find process instance detail by id
*
* @param processId processId * @param processId processId
* @return process instance * @return process instance
*/ */
@ -289,6 +295,7 @@ public class ProcessService {
/** /**
* get task node list by definitionId * get task node list by definitionId
*
* @param defineId * @param defineId
* @return * @return
*/ */
@ -313,6 +320,7 @@ public class ProcessService {
/** /**
* find process instance by id * find process instance by id
*
* @param processId processId * @param processId processId
* @return process instance * @return process instance
*/ */
@ -322,6 +330,7 @@ public class ProcessService {
/** /**
* find process define by id. * find process define by id.
*
* @param processDefinitionId processDefinitionId * @param processDefinitionId processDefinitionId
* @return process definition * @return process definition
*/ */
@ -331,6 +340,7 @@ public class ProcessService {
/** /**
* delete work process instance by id * delete work process instance by id
*
* @param processInstanceId processInstanceId * @param processInstanceId processInstanceId
* @return delete process instance result * @return delete process instance result
*/ */
@ -340,6 +350,7 @@ public class ProcessService {
/** /**
* delete all sub process by parent instance id * delete all sub process by parent instance id
*
* @param processInstanceId processInstanceId * @param processInstanceId processInstanceId
* @return delete all sub process instance result * @return delete all sub process instance result
*/ */
@ -358,6 +369,7 @@ public class ProcessService {
/** /**
* remove task log file * remove task log file
*
* @param processInstanceId processInstanceId * @param processInstanceId processInstanceId
*/ */
public void removeTaskLogFile(Integer processInstanceId) { public void removeTaskLogFile(Integer processInstanceId) {
@ -398,6 +410,7 @@ public class ProcessService {
/** /**
* calculate sub process number in the process define. * calculate sub process number in the process define.
*
* @param processDefinitionId processDefinitionId * @param processDefinitionId processDefinitionId
* @return process thread num count * @return process thread num count
*/ */
@ -409,6 +422,7 @@ public class ProcessService {
/** /**
* recursive query sub process definition id by parent id. * recursive query sub process definition id by parent id.
*
* @param parentId parentId * @param parentId parentId
* @param ids ids * @param ids ids
*/ */
@ -440,6 +454,7 @@ public class ProcessService {
* sub work process instance need not to create recovery command. * sub work process instance need not to create recovery command.
* create recovery waiting thread command and delete origin command at the same time. * 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 * if the recovery command is exists, only update the field update_time
*
* @param originCommand originCommand * @param originCommand originCommand
* @param processInstance processInstance * @param processInstance processInstance
*/ */
@ -491,6 +506,7 @@ public class ProcessService {
/** /**
* get schedule time from command * get schedule time from command
*
* @param command command * @param command command
* @param cmdParam cmdParam map * @param cmdParam cmdParam map
* @return date * @return date
@ -507,6 +523,7 @@ public class ProcessService {
/** /**
* generate a new work process instance from command. * generate a new work process instance from command.
*
* @param processDefinition processDefinition * @param processDefinition processDefinition
* @param command command * @param command command
* @param cmdParam cmdParam map * @param cmdParam cmdParam map
@ -564,6 +581,7 @@ public class ProcessService {
* there is tenant id in definition, use the tenant of the definition. * 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 * if there is not tenant id in the definiton or the tenant not exist
* use definition creator's tenant. * use definition creator's tenant.
*
* @param tenantId tenantId * @param tenantId tenantId
* @param userId userId * @param userId userId
* @return tenant * @return tenant
@ -587,6 +605,7 @@ public class ProcessService {
/** /**
* check command parameters is valid * check command parameters is valid
*
* @param command command * @param command command
* @param cmdParam cmdParam map * @param cmdParam cmdParam map
* @return whether command param is valid * @return whether command param is valid
@ -605,6 +624,7 @@ public class ProcessService {
/** /**
* construct process instance according to one command. * construct process instance according to one command.
*
* @param command command * @param command command
* @param host host * @param host host
* @return process instance * @return process instance
@ -761,6 +781,7 @@ public class ProcessService {
/** /**
* return complement data if the process start with complement data * return complement data if the process start with complement data
*
* @param processInstance processInstance * @param processInstance processInstance
* @param command command * @param command command
* @return command type * @return command type
@ -775,6 +796,7 @@ public class ProcessService {
/** /**
* initialize complement data parameters * initialize complement data parameters
*
* @param processDefinition processDefinition * @param processDefinition processDefinition
* @param processInstance processInstance * @param processInstance processInstance
* @param cmdParam cmdParam * @param cmdParam cmdParam
@ -802,6 +824,7 @@ public class ProcessService {
* set sub work process parameters. * set sub work process parameters.
* handle sub work process instance, update relation table and command parameters * handle sub work process instance, update relation table and command parameters
* set sub work process flag, extends parent work process command parameters * set sub work process flag, extends parent work process command parameters
*
* @param subProcessInstance subProcessInstance * @param subProcessInstance subProcessInstance
* @return process instance * @return process instance
*/ */
@ -846,6 +869,7 @@ public class ProcessService {
/** /**
* join parent global params into sub process. * join parent global params into sub process.
* only the keys doesn't in sub process global would be joined. * only the keys doesn't in sub process global would be joined.
*
* @param parentGlobalParams parentGlobalParams * @param parentGlobalParams parentGlobalParams
* @param subGlobalParams subGlobalParams * @param subGlobalParams subGlobalParams
* @return global params join * @return global params join
@ -867,6 +891,7 @@ public class ProcessService {
/** /**
* initialize task instance * initialize task instance
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
*/ */
private void initTaskInstance(TaskInstance taskInstance) { private void initTaskInstance(TaskInstance taskInstance) {
@ -885,6 +910,7 @@ public class ProcessService {
/** /**
* submit task to db * submit task to db
* submit sub process to command * submit sub process to command
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @return task instance * @return task instance
*/ */
@ -914,6 +940,7 @@ public class ProcessService {
* consider o * consider o
* repeat running does not generate new sub process instance * repeat running does not generate new sub process instance
* set map {parent instance id, task instance id, 0(child instance id)} * set map {parent instance id, task instance id, 0(child instance id)}
*
* @param parentInstance parentInstance * @param parentInstance parentInstance
* @param parentTask parentTask * @param parentTask parentTask
* @return process instance map * @return process instance map
@ -942,6 +969,7 @@ public class ProcessService {
/** /**
* find previous task work process map. * find previous task work process map.
*
* @param parentProcessInstance parentProcessInstance * @param parentProcessInstance parentProcessInstance
* @param parentTask parentTask * @param parentTask parentTask
* @return process instance map * @return process instance map
@ -967,6 +995,7 @@ public class ProcessService {
/** /**
* create sub work process command * create sub work process command
*
* @param parentProcessInstance parentProcessInstance * @param parentProcessInstance parentProcessInstance
* @param task task * @param task task
*/ */
@ -994,6 +1023,7 @@ public class ProcessService {
/** /**
* complement data needs transform parent parameter to child. * complement data needs transform parent parameter to child.
*
* @param instanceMap * @param instanceMap
* @param parentProcessInstance * @param parentProcessInstance
* @return * @return
@ -1015,6 +1045,7 @@ public class ProcessService {
/** /**
* create sub work process command * create sub work process command
*
* @param parentProcessInstance * @param parentProcessInstance
* @param childInstance * @param childInstance
* @param instanceMap * @param instanceMap
@ -1048,6 +1079,7 @@ public class ProcessService {
/** /**
* initialize sub work flow state * initialize sub work flow state
* child instance state would be initialized when 'recovery from pause/stop/failure' * child instance state would be initialized when 'recovery from pause/stop/failure'
*
* @param childInstance * @param childInstance
*/ */
private void initSubInstanceState(ProcessInstance childInstance) { private void initSubInstanceState(ProcessInstance childInstance) {
@ -1076,6 +1108,7 @@ public class ProcessService {
/** /**
* update sub process definition * update sub process definition
*
* @param parentProcessInstance parentProcessInstance * @param parentProcessInstance parentProcessInstance
* @param childDefinitionId childDefinitionId * @param childDefinitionId childDefinitionId
*/ */
@ -1091,6 +1124,7 @@ public class ProcessService {
/** /**
* submit task to mysql * submit task to mysql
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @param processInstance processInstance * @param processInstance processInstance
* @return task instance * @return task instance
@ -1140,6 +1174,7 @@ public class ProcessService {
/** /**
* ${processInstancePriority}_${processInstanceId}_${taskInstancePriority}_${taskInstanceId}_${task executed by ip1},${ip2}... * ${processInstancePriority}_${processInstanceId}_${taskInstancePriority}_${taskInstanceId}_${task executed by ip1},${ip2}...
* The tasks with the highest priority are selected by comparing the priorities of the above four levels from high to low. * The tasks with the highest priority are selected by comparing the priorities of the above four levels from high to low.
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @return task zk queue str * @return task zk queue str
*/ */
@ -1203,6 +1238,7 @@ public class ProcessService {
/** /**
* check process instance strategy * check process instance strategy
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @return check strategy result * @return check strategy result
*/ */
@ -1224,6 +1260,7 @@ public class ProcessService {
/** /**
* check the task instance existing in queue * check the task instance existing in queue
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @return whether taskinstance exists queue * @return whether taskinstance exists queue
*/ */
@ -1239,6 +1276,7 @@ public class ProcessService {
/** /**
* create a new process instance * create a new process instance
*
* @param processInstance processInstance * @param processInstance processInstance
*/ */
public void createProcessInstance(ProcessInstance processInstance) { public void createProcessInstance(ProcessInstance processInstance) {
@ -1250,6 +1288,7 @@ public class ProcessService {
/** /**
* insert or update work process instance to data base * insert or update work process instance to data base
*
* @param processInstance processInstance * @param processInstance processInstance
*/ */
public void saveProcessInstance(ProcessInstance processInstance) { public void saveProcessInstance(ProcessInstance processInstance) {
@ -1267,6 +1306,7 @@ public class ProcessService {
/** /**
* insert or update command * insert or update command
*
* @param command command * @param command command
* @return save command result * @return save command result
*/ */
@ -1280,6 +1320,7 @@ public class ProcessService {
/** /**
* insert or update task instance * insert or update task instance
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @return save task instance result * @return save task instance result
*/ */
@ -1293,6 +1334,7 @@ public class ProcessService {
/** /**
* insert task instance * insert task instance
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @return create task instance result * @return create task instance result
*/ */
@ -1303,6 +1345,7 @@ public class ProcessService {
/** /**
* update task instance * update task instance
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @return update task instance result * @return update task instance result
*/ */
@ -1313,6 +1356,7 @@ public class ProcessService {
/** /**
* delete a command by id * delete a command by id
*
* @param id id * @param id id
*/ */
public void delCommandById(int id) { public void delCommandById(int id) {
@ -1321,6 +1365,7 @@ public class ProcessService {
/** /**
* find task instance by id * find task instance by id
*
* @param taskId task id * @param taskId task id
* @return task intance * @return task intance
*/ */
@ -1330,6 +1375,7 @@ public class ProcessService {
/** /**
* package task instanceassociate processInstance and processDefine * package task instanceassociate processInstance and processDefine
*
* @param taskInstId taskInstId * @param taskInstId taskInstId
* @return task instance * @return task instance
*/ */
@ -1351,6 +1397,7 @@ public class ProcessService {
/** /**
* get id list by task state * get id list by task state
*
* @param instanceId instanceId * @param instanceId instanceId
* @param state state * @param state state
* @return task instance states * @return task instance states
@ -1361,6 +1408,7 @@ public class ProcessService {
/** /**
* find valid task list by process definition id * find valid task list by process definition id
*
* @param processInstanceId processInstanceId * @param processInstanceId processInstanceId
* @return task instance list * @return task instance list
*/ */
@ -1370,6 +1418,7 @@ public class ProcessService {
/** /**
* find previous task list by work process id * find previous task list by work process id
*
* @param processInstanceId processInstanceId * @param processInstanceId processInstanceId
* @return task instance list * @return task instance list
*/ */
@ -1379,6 +1428,7 @@ public class ProcessService {
/** /**
* update work process instance map * update work process instance map
*
* @param processInstanceMap processInstanceMap * @param processInstanceMap processInstanceMap
* @return update process instance result * @return update process instance result
*/ */
@ -1388,6 +1438,7 @@ public class ProcessService {
/** /**
* create work process instance map * create work process instance map
*
* @param processInstanceMap processInstanceMap * @param processInstanceMap processInstanceMap
* @return create process instance result * @return create process instance result
*/ */
@ -1401,6 +1452,7 @@ public class ProcessService {
/** /**
* find work process map by parent process id and parent task id. * find work process map by parent process id and parent task id.
*
* @param parentWorkProcessId parentWorkProcessId * @param parentWorkProcessId parentWorkProcessId
* @param parentTaskId parentTaskId * @param parentTaskId parentTaskId
* @return process instance map * @return process instance map
@ -1411,6 +1463,7 @@ public class ProcessService {
/** /**
* delete work process map by parent process id * delete work process map by parent process id
*
* @param parentWorkProcessId parentWorkProcessId * @param parentWorkProcessId parentWorkProcessId
* @return delete process map result * @return delete process map result
*/ */
@ -1421,6 +1474,7 @@ public class ProcessService {
/** /**
* find sub process instance * find sub process instance
*
* @param parentProcessId parentProcessId * @param parentProcessId parentProcessId
* @param parentTaskId parentTaskId * @param parentTaskId parentTaskId
* @return process instance * @return process instance
@ -1437,6 +1491,7 @@ public class ProcessService {
/** /**
* find parent process instance * find parent process instance
*
* @param subProcessId subProcessId * @param subProcessId subProcessId
* @return process instance * @return process instance
*/ */
@ -1452,6 +1507,7 @@ public class ProcessService {
/** /**
* change task state * change task state
*
* @param state state * @param state state
* @param startTime startTime * @param startTime startTime
* @param host host * @param host host
@ -1459,11 +1515,10 @@ public class ProcessService {
* @param logPath logPath * @param logPath logPath
* @param taskInstId taskInstId * @param taskInstId taskInstId
*/ */
public void changeTaskState(ExecutionStatus state, Date startTime, String host, public void changeTaskState(TaskInstance taskInstance, ExecutionStatus state, Date startTime, String host,
String executePath, String executePath,
String logPath, String logPath,
int taskInstId) { int taskInstId) {
TaskInstance taskInstance = taskInstanceMapper.selectById(taskInstId);
taskInstance.setState(state); taskInstance.setState(state);
taskInstance.setStartTime(startTime); taskInstance.setStartTime(startTime);
taskInstance.setHost(host); taskInstance.setHost(host);
@ -1474,6 +1529,7 @@ public class ProcessService {
/** /**
* update process instance * update process instance
*
* @param processInstance processInstance * @param processInstance processInstance
* @return update process instance result * @return update process instance result
*/ */
@ -1483,6 +1539,7 @@ public class ProcessService {
/** /**
* update the process instance * update the process instance
*
* @param processInstanceId processInstanceId * @param processInstanceId processInstanceId
* @param processJson processJson * @param processJson processJson
* @param globalParams globalParams * @param globalParams globalParams
@ -1509,18 +1566,18 @@ public class ProcessService {
/** /**
* change task state * change task state
*
* @param state state * @param state state
* @param endTime endTime * @param endTime endTime
* @param taskInstId taskInstId * @param taskInstId taskInstId
* @param varPool varPool * @param varPool varPool
*/ */
public void changeTaskState(ExecutionStatus state, public void changeTaskState(TaskInstance taskInstance, ExecutionStatus state,
Date endTime, Date endTime,
int processId, int processId,
String appIds, String appIds,
int taskInstId, int taskInstId,
String varPool) { String varPool) {
TaskInstance taskInstance = taskInstanceMapper.selectById(taskInstId);
taskInstance.setPid(processId); taskInstance.setPid(processId);
taskInstance.setAppLink(appIds); taskInstance.setAppLink(appIds);
taskInstance.setState(state); taskInstance.setState(state);
@ -1531,6 +1588,7 @@ public class ProcessService {
/** /**
* convert integer list to string list * convert integer list to string list
*
* @param intList intList * @param intList intList
* @return string list * @return string list
*/ */
@ -1547,6 +1605,7 @@ public class ProcessService {
/** /**
* query schedule by id * query schedule by id
*
* @param id id * @param id id
* @return schedule * @return schedule
*/ */
@ -1556,6 +1615,7 @@ public class ProcessService {
/** /**
* query Schedule by processDefinitionId * query Schedule by processDefinitionId
*
* @param processDefinitionId processDefinitionId * @param processDefinitionId processDefinitionId
* @see Schedule * @see Schedule
*/ */
@ -1565,6 +1625,7 @@ public class ProcessService {
/** /**
* query need failover process instance * query need failover process instance
*
* @param host host * @param host host
* @return process instance list * @return process instance list
*/ */
@ -1574,6 +1635,7 @@ public class ProcessService {
/** /**
* process need failover process instance * process need failover process instance
*
* @param processInstance processInstance * @param processInstance processInstance
*/ */
@Transactional(rollbackFor = RuntimeException.class) @Transactional(rollbackFor = RuntimeException.class)
@ -1593,6 +1655,7 @@ public class ProcessService {
/** /**
* query all need failover task instances by host * query all need failover task instances by host
*
* @param host host * @param host host
* @return task instance list * @return task instance list
*/ */
@ -1603,6 +1666,7 @@ public class ProcessService {
/** /**
* find data source by id * find data source by id
*
* @param id id * @param id id
* @return datasource * @return datasource
*/ */
@ -1612,6 +1676,7 @@ public class ProcessService {
/** /**
* update process instance state by id * update process instance state by id
*
* @param processInstanceId processInstanceId * @param processInstanceId processInstanceId
* @param executionStatus executionStatus * @param executionStatus executionStatus
* @return update process result * @return update process result
@ -1625,6 +1690,7 @@ public class ProcessService {
/** /**
* find process instance by the task id * find process instance by the task id
*
* @param taskId taskId * @param taskId taskId
* @return process instance * @return process instance
*/ */
@ -1638,6 +1704,7 @@ public class ProcessService {
/** /**
* find udf function list by id list string * find udf function list by id list string
*
* @param ids ids * @param ids ids
* @return udf function list * @return udf function list
*/ */
@ -1647,6 +1714,7 @@ public class ProcessService {
/** /**
* find tenant code by resource name * find tenant code by resource name
*
* @param resName resource name * @param resName resource name
* @param resourceType resource type * @param resourceType resource type
* @return tenant code * @return tenant code
@ -1659,6 +1727,7 @@ public class ProcessService {
/** /**
* find schedule list by process define id. * find schedule list by process define id.
*
* @param ids ids * @param ids ids
* @return schedule list * @return schedule list
*/ */
@ -1669,6 +1738,7 @@ public class ProcessService {
/** /**
* get dependency cycle by work process define id and scheduler fire time * get dependency cycle by work process define id and scheduler fire time
*
* @param masterId masterId * @param masterId masterId
* @param processDefinitionId processDefinitionId * @param processDefinitionId processDefinitionId
* @param scheduledFireTime the time the task schedule is expected to trigger * @param scheduledFireTime the time the task schedule is expected to trigger
@ -1683,6 +1753,7 @@ public class ProcessService {
/** /**
* get dependency cycle list by work process define id list and scheduler fire time * get dependency cycle list by work process define id list and scheduler fire time
*
* @param masterId masterId * @param masterId masterId
* @param ids ids * @param ids ids
* @param scheduledFireTime the time the task schedule is expected to trigger * @param scheduledFireTime the time the task schedule is expected to trigger
@ -1691,7 +1762,7 @@ public class ProcessService {
*/ */
public List<CycleDependency> getCycleDependencies(int masterId, int[] ids, Date scheduledFireTime) throws Exception { public List<CycleDependency> getCycleDependencies(int masterId, int[] ids, Date scheduledFireTime) throws Exception {
List<CycleDependency> cycleDependencyList = new ArrayList<CycleDependency>(); List<CycleDependency> cycleDependencyList = new ArrayList<CycleDependency>();
if(ArrayUtils.isEmpty(ids)){ if (null == ids || ids.length == 0) {
logger.warn("ids[] is empty!is invalid!"); logger.warn("ids[] is empty!is invalid!");
return cycleDependencyList; return cycleDependencyList;
} }
@ -1754,6 +1825,7 @@ public class ProcessService {
/** /**
* find last scheduler process instance in the date interval * find last scheduler process instance in the date interval
*
* @param definitionId definitionId * @param definitionId definitionId
* @param dateInterval dateInterval * @param dateInterval dateInterval
* @return process instance * @return process instance
@ -1766,6 +1838,7 @@ public class ProcessService {
/** /**
* find last manual process instance interval * find last manual process instance interval
*
* @param definitionId process definition id * @param definitionId process definition id
* @param dateInterval dateInterval * @param dateInterval dateInterval
* @return process instance * @return process instance
@ -1778,6 +1851,7 @@ public class ProcessService {
/** /**
* find last running process instance * find last running process instance
*
* @param definitionId process definition id * @param definitionId process definition id
* @param startTime start time * @param startTime start time
* @param endTime end time * @param endTime end time
@ -1792,6 +1866,7 @@ public class ProcessService {
/** /**
* query user queue by process instance id * query user queue by process instance id
*
* @param processInstanceId processInstanceId * @param processInstanceId processInstanceId
* @return queue * @return queue
*/ */
@ -1811,6 +1886,7 @@ public class ProcessService {
/** /**
* get task worker group * get task worker group
*
* @param taskInstance taskInstance * @param taskInstance taskInstance
* @return workerGroupId * @return workerGroupId
*/ */
@ -1832,6 +1908,7 @@ public class ProcessService {
/** /**
* get have perm project list * get have perm project list
*
* @param userId userId * @param userId userId
* @return project list * @return project list
*/ */
@ -1851,6 +1928,7 @@ public class ProcessService {
/** /**
* get have perm project ids * get have perm project ids
*
* @param userId userId * @param userId userId
* @return project ids * @return project ids
*/ */
@ -1865,6 +1943,7 @@ public class ProcessService {
/** /**
* list unauthorized udf function * list unauthorized udf function
*
* @param userId user id * @param userId user id
* @param needChecks data source id array * @param needChecks data source id array
* @return unauthorized udf function list * @return unauthorized udf function list
@ -1908,6 +1987,7 @@ public class ProcessService {
/** /**
* get user by user id * get user by user id
*
* @param userId user id * @param userId user id
* @return User * @return User
*/ */
@ -1917,6 +1997,7 @@ public class ProcessService {
/** /**
* get resource by resoruce id * get resource by resoruce id
*
* @param resoruceId resource id * @param resoruceId resource id
* @return Resource * @return Resource
*/ */
@ -1926,6 +2007,7 @@ public class ProcessService {
/** /**
* list resources by ids * list resources by ids
*
* @param resIds resIds * @param resIds resIds
* @return resource list * @return resource list
*/ */
@ -1935,6 +2017,7 @@ public class ProcessService {
/** /**
* format task app id in task instance * format task app id in task instance
*
* @param taskInstance * @param taskInstance
* @return * @return
*/ */

1
pom.xml

@ -835,6 +835,7 @@
<include>**/server/master/SubProcessTaskTest.java</include> <include>**/server/master/SubProcessTaskTest.java</include>
<include>**/server/master/processor/TaskAckProcessorTest.java</include> <include>**/server/master/processor/TaskAckProcessorTest.java</include>
<include>**/server/master/processor/TaskKillResponseProcessorTest.java</include> <include>**/server/master/processor/TaskKillResponseProcessorTest.java</include>
<include>**/server/master/processor/queue/TaskResponseServiceTest.java</include>
<include>**/server/register/ZookeeperNodeManagerTest.java</include> <include>**/server/register/ZookeeperNodeManagerTest.java</include>
<include>**/server/utils/DataxUtilsTest.java</include> <include>**/server/utils/DataxUtilsTest.java</include>
<include>**/server/utils/ExecutionContextTestUtils.java</include> <include>**/server/utils/ExecutionContextTestUtils.java</include>

Loading…
Cancel
Save