You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@linkis.apache.org by ca...@apache.org on 2022/09/03 06:10:45 UTC

[incubator-linkis] branch dev-1.3.1 updated: [linkis-orchestrator-core] Modification of scala file floating red (#3184)

This is an automated email from the ASF dual-hosted git repository.

casion pushed a commit to branch dev-1.3.1
in repository https://gitbox.apache.org/repos/asf/incubator-linkis.git


The following commit(s) were added to refs/heads/dev-1.3.1 by this push:
     new a83476af7 [linkis-orchestrator-core] Modification of scala file floating red (#3184)
a83476af7 is described below

commit a83476af74070871fc4a19b44a62c0cc7c9c1294
Author: 成彬彬 <10...@users.noreply.github.com>
AuthorDate: Sat Sep 3 14:10:41 2022 +0800

    [linkis-orchestrator-core] Modification of scala file floating red (#3184)
    
    * [linkis-orchestrator-core] Modification of scala file floating red
---
 .../scala/org/apache/linkis/orchestrator/Orchestrator.scala  |  4 ++--
 .../linkis/orchestrator/core/AbstractOrchestration.scala     |  1 +
 .../linkis/orchestrator/core/AbstractOrchestrator.scala      |  6 ++++--
 .../scala/org/apache/linkis/orchestrator/domain/JobReq.scala | 12 ++++++------
 .../apache/linkis/orchestrator/domain/req/DataViewReq.scala  |  2 +-
 .../linkis/orchestrator/execution/AbstractExecution.scala    |  4 ++--
 .../linkis/orchestrator/execution/ExecutionFactory.scala     |  4 ++--
 .../orchestrator/execution/impl/BaseExecutionTask.scala      |  7 ++++---
 .../orchestrator/execution/impl/DefaultTaskManager.scala     |  5 +++--
 .../orchestrator/execution/impl/UserRunningNumber.scala      |  2 +-
 .../orchestrator/execution/impl/UserTaskRunnerQueue.scala    |  8 ++++----
 .../listener/OrchestratorListenerBusContext.scala            |  2 +-
 .../apache/linkis/orchestrator/plans/ast/AbstractJob.scala   | 10 +++++-----
 .../apache/linkis/orchestrator/plans/ast/AbstractStage.scala |  2 +-
 .../apache/linkis/orchestrator/plans/ast/QueryParams.scala   |  4 ++--
 .../apache/linkis/orchestrator/plans/ast/RuntimeParams.scala |  7 ++++---
 .../linkis/orchestrator/plans/logical/AbstractTask.scala     |  4 ++--
 .../apache/linkis/orchestrator/plans/logical/JobTask.scala   |  3 ++-
 .../apache/linkis/orchestrator/plans/logical/Origin.scala    |  3 ++-
 .../linkis/orchestrator/plans/physical/JobExecTask.scala     |  5 +++--
 .../linkis/orchestrator/plans/unit/CodeLogicalUnit.scala     |  4 ++--
 .../linkis/orchestrator/strategy/ResultSetExecTask.scala     |  2 +-
 .../strategy/async/AsyncExecTaskRunnerImpl.scala             |  1 -
 .../org/apache/linkis/orchestrator/OrchestratorSuite.scala   |  1 +
 24 files changed, 56 insertions(+), 47 deletions(-)

diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/Orchestrator.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/Orchestrator.scala
index 2a19a0732..f35096ac0 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/Orchestrator.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/Orchestrator.scala
@@ -58,9 +58,9 @@ object Orchestrator extends Logging {
     if (orchestrator == null) synchronized {
       if (orchestrator == null) {
         val orchestratorBuilder =
-          if (StringUtils.isNotBlank(ORCHESTRATOR_BUILDER_CLASS.getValue))
+          if (StringUtils.isNotBlank(ORCHESTRATOR_BUILDER_CLASS.getValue)) {
             ClassUtils.getClassInstance(ORCHESTRATOR_BUILDER_CLASS.getValue)
-          else () => new OrchestratorImpl
+          } else () => new OrchestratorImpl
         logger.info(
           "Use " + orchestratorBuilder.getClass.getName + " to instance a new orchestrator."
         )
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/core/AbstractOrchestration.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/core/AbstractOrchestration.scala
index fe84b808b..46263fd4a 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/core/AbstractOrchestration.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/core/AbstractOrchestration.scala
@@ -115,6 +115,7 @@ abstract class AbstractOrchestration(
 
   protected def getFileSystem(fsPath: FsPath): Fs
 
+  // scalastyle:off println
   override def collectAndPrint(): Unit = println(collectAsString())
 
   override def asyncExecute(): OrchestrationFuture = {
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/core/AbstractOrchestrator.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/core/AbstractOrchestrator.scala
index 12a08cc8c..65d004d9f 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/core/AbstractOrchestrator.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/core/AbstractOrchestrator.scala
@@ -56,10 +56,12 @@ abstract class AbstractOrchestrator extends Orchestrator {
 
   override def createOrchestratorSessionBuilder(): OrchestratorSessionBuilder = {
     val builder = newOrchestratorSessionBuilder().setOrchestrator(this)
-    if (getOrchestratorContext.getGlobalExtensions != null)
+    if (getOrchestratorContext.getGlobalExtensions != null) {
       getOrchestratorContext.getGlobalExtensions.foreach(builder.withExtensions)
-    if (getOrchestratorContext.getGlobalConfigs != null)
+    }
+    if (getOrchestratorContext.getGlobalConfigs != null) {
       getOrchestratorContext.getGlobalConfigs.foreach { case (k, v) => builder.config(k, v) }
+    }
     builder
   }
 
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/domain/JobReq.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/domain/JobReq.scala
index f149be133..be24baa35 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/domain/JobReq.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/domain/JobReq.scala
@@ -58,29 +58,29 @@ object AbstractJobReq {
 
     protected val jobReq: AbstractJobReq = createJobReq()
 
-    def clone(jobReq: JobReq) = {
+    def clone(jobReq: JobReq): AbstractJobReqBuilder = {
       setExecuteUser(jobReq.getExecuteUser)
       setLabels(jobReq.getLabels)
       setParams(jobReq.getParams)
       setPriority(jobReq.getPriority)
     }
 
-    def setExecuteUser(executeUser: String) = {
+    def setExecuteUser(executeUser: String): AbstractJobReqBuilder = {
       jobReq.executeUser = executeUser
       this
     }
 
-    def setLabels(labels: util.List[Label[_]]) = {
+    def setLabels(labels: util.List[Label[_]]): AbstractJobReqBuilder = {
       jobReq.labels = labels
       this
     }
 
-    def setParams(params: util.Map[String, Any]) = {
+    def setParams(params: util.Map[String, Any]): AbstractJobReqBuilder = {
       jobReq.params = params
       this
     }
 
-    def setPriority(priority: Int) = {
+    def setPriority(priority: Int): AbstractJobReqBuilder = {
       jobReq.priority = priority
       this
     }
@@ -94,5 +94,5 @@ object AbstractJobReq {
 }
 
 object JobReq {
-  def getDefaultPriority = 0
+  def getDefaultPriority: Unit = 0
 }
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/domain/req/DataViewReq.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/domain/req/DataViewReq.scala
index fa84e0ecf..6ac145165 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/domain/req/DataViewReq.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/domain/req/DataViewReq.scala
@@ -33,7 +33,7 @@ class ShowDataViewReq private () extends AbstractJobReq with DataViewReq {
 
   override def getDataView: String = dataView
 
-  override def getId: String = ???
+  override def getId: String = null
 
 }
 
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/AbstractExecution.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/AbstractExecution.scala
index be334108c..5662c395b 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/AbstractExecution.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/AbstractExecution.scala
@@ -81,12 +81,12 @@ abstract class AbstractExecution extends Execution with Logging {
   class ExecutionClearListener(rootExecTask: ExecTask) extends NotifyListener {
 
     override def apply(taskResponse: TaskResponse): Unit = taskResponse match {
-      case t: CompletedTaskResponse => {
+      case t: CompletedTaskResponse =>
         logger.info(
           s"${rootExecTask.getIDInfo()} completed, Now to remove from execTaskToExecutionTasks"
         )
         execTaskToExecutionTasks.remove(rootExecTask)
-      }
+
       case _ =>
     }
 
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/ExecutionFactory.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/ExecutionFactory.scala
index 4a3bddc26..80830f7c8 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/ExecutionFactory.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/ExecutionFactory.scala
@@ -50,11 +50,11 @@ object ExecutionFactory extends Logging {
           if (
               StringUtils
                 .isNotBlank(OrchestratorConfiguration.ORCHESTRATOR_EXECUTION_FACTORY.getValue)
-          )
+          ) {
             ClassUtils.getClassInstance(
               OrchestratorConfiguration.ORCHESTRATOR_EXECUTION_FACTORY.getValue
             )
-          else {
+          } else {
             throw new FatalException(
               OrchestratorErrorCodeSummary.EXECUTION_FATAL_CODE,
               s"Execution Factory class is null,please set ${OrchestratorConfiguration.ORCHESTRATOR_EXECUTION_FACTORY.key} "
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/BaseExecutionTask.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/BaseExecutionTask.scala
index c6f0c26be..45f2141da 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/BaseExecutionTask.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/BaseExecutionTask.scala
@@ -69,11 +69,12 @@ class BaseExecutionTask(maxParallelism: Int, rootExecTask: ExecTask)
   override def getRootExecTask: ExecTask = rootExecTask
 
   override def transientStatus(status: ExecutionNodeStatus): Unit = {
-    if (status.ordinal() < this.status.ordinal() && status != ExecutionNodeStatus.WaitForRetry)
+    if (status.ordinal() < this.status.ordinal() && status != ExecutionNodeStatus.WaitForRetry) {
       throw new OrchestratorErrorException(
         OrchestratorErrorCodeSummary.EXECUTION_FOR_EXECUTION_ERROR_CODE,
         s"Task status flip error! Cause: Failed to flip from ${this.status} to $status."
-      ) // 抛异常
+      )
+    }
     logger.info(s"$getId change status ${this.status} => $status.")
     beforeStatusChanged(this.status, status)
     val oldStatus = this.status
@@ -81,7 +82,7 @@ class BaseExecutionTask(maxParallelism: Int, rootExecTask: ExecTask)
     afterStatusChanged(oldStatus, status)
   }
 
-  // status 完成后返回执行响应
+  // status Return the execution response after completion
   def afterStatusChanged(fromStatus: ExecutionNodeStatus, toStatus: ExecutionNodeStatus): Unit = {
     if (ExecutionNodeStatus.isCompleted(toStatus)) {
       Utils.tryAndWarn(listeners.foreach(listener => listener(getResponse)))
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/DefaultTaskManager.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/DefaultTaskManager.scala
index 4d62e9626..8e4219967 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/DefaultTaskManager.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/DefaultTaskManager.scala
@@ -319,15 +319,16 @@ class DefaultTaskManager extends AbstractTaskManager with Logging {
       execTask: ExecTask,
       subTasks: mutable.Set[ExecTask]
   ): Unit = {
-    if (subTasks.size > executionTask.getMaxParallelism || isExecuted(executionTask, execTask))
+    if (subTasks.size > executionTask.getMaxParallelism || isExecuted(executionTask, execTask)) {
       return
+    }
     val tasks = findUnCompletedExecTasks(executionTask.getId, execTask.getChildren)
     if (null == tasks || tasks.isEmpty) {
       if (execTask.canExecute) {
         subTasks.add(execTask)
       }
     } else {
-      // 递归子节点
+      // Recursive child node
       tasks.foreach(getSubTasksRecursively(executionTask, _, subTasks))
     }
   }
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/UserRunningNumber.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/UserRunningNumber.scala
index b863bc00e..ffab7dc95 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/UserRunningNumber.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/UserRunningNumber.scala
@@ -70,7 +70,7 @@ class UserRunningNumber {
   }
 
   /**
-   * TODO 统一getKey方法
+   * TODO Unified getKey method
    * @param labels
    * @return
    */
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/UserTaskRunnerQueue.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/UserTaskRunnerQueue.scala
index a74f608a4..01f0c89a0 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/UserTaskRunnerQueue.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/execution/impl/UserTaskRunnerQueue.scala
@@ -68,9 +68,9 @@ class UserTaskRunnerPriorityQueue extends UserTaskRunnerQueue {
     val user = astContext.getExecuteUser
     val labels = astContext.getLabels
     val maxRunningNumber =
-      if (userParallelOrchestratorPlugin.isDefined)
+      if (userParallelOrchestratorPlugin.isDefined) {
         userParallelOrchestratorPlugin.get.getUserMaxRunningJobs(user, labels)
-      else {
+      } else {
         DEFAULT_MAX_RUNNING
       }
     val runningNumber = userRunningNumber.getRunningNumber(user, labels)
@@ -87,9 +87,9 @@ class UserTaskRunnerPriorityQueue extends UserTaskRunnerQueue {
         val user = astContext.getExecuteUser
         val labels = astContext.getLabels
         val maxRunningNumber =
-          if (userParallelOrchestratorPlugin.isDefined)
+          if (userParallelOrchestratorPlugin.isDefined) {
             userParallelOrchestratorPlugin.get.getUserMaxRunningJobs(user, labels)
-          else {
+          } else {
             DEFAULT_MAX_RUNNING
           }
         UserTaskRunner(
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/listener/OrchestratorListenerBusContext.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/listener/OrchestratorListenerBusContext.scala
index cf0711099..0c2806c8b 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/listener/OrchestratorListenerBusContext.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/listener/OrchestratorListenerBusContext.scala
@@ -62,7 +62,7 @@ object OrchestratorListenerBusContext {
 
   private val listenerBusContext = new OrchestratorListenerBusContextImpl
 
-  def getListenerBusContext() = listenerBusContext
+  def getListenerBusContext(): OrchestratorListenerBusContextImpl = listenerBusContext
 
   def createBusContext: OrchestratorListenerBusContext = new OrchestratorListenerBusContextImpl
 
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/AbstractJob.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/AbstractJob.scala
index f5d2c49e3..cab994ef8 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/AbstractJob.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/AbstractJob.scala
@@ -31,20 +31,20 @@ abstract class AbstractJob extends Job {
 
   private var executeUser: String = _
 
-  def getParams = params
+  def getParams: util.Map[String, Any] = params
 
-  def setParams(params: util.Map[String, Any]) = this.params = params
+  def setParams(params: util.Map[String, Any]): Unit = this.params = params
 
   def getExecuteUser: String = executeUser
 
-  def setExecuteUser(executeUser: String) = this.executeUser = executeUser
+  def setExecuteUser(executeUser: String): Unit = this.executeUser = executeUser
 
   def getLabels: util.List[Label[_]] = labels
 
-  def setLabels(labels: util.List[Label[_]]) = this.labels = labels
+  def setLabels(labels: util.List[Label[_]]): Unit = this.labels = labels
 
   def getPriority: Int = priority
 
-  def setPriority(priority: Int) = this.priority = priority
+  def setPriority(priority: Int): Unit = this.priority = priority
 
 }
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/AbstractStage.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/AbstractStage.scala
index 02cb0e537..59e6d763c 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/AbstractStage.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/AbstractStage.scala
@@ -23,6 +23,6 @@ abstract class AbstractStage extends Stage {
 
   override def getASTContext: ASTContext = this.astContext
 
-  def setAstContext(astContext: ASTContext) = this.astContext = astContext
+  def setAstContext(astContext: ASTContext): Unit = this.astContext = astContext
 
 }
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/QueryParams.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/QueryParams.scala
index 629319939..b7dae98d8 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/QueryParams.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/QueryParams.scala
@@ -104,10 +104,10 @@ object QueryParams {
 
   val CONTEXT_KEY = "context" // TaskConstant.PARAMS_CONTEXT
 
-  @Deprecated
+  @deprecated
   val CONTEXT_KEY_FOR_ID = "contextID"
 
-  @Deprecated
+  @deprecated
   val CONTEXT_KEY_FOR_NODE_NAME = "nodeName"
 
   val JOB_KEY = "job" // in runtime map
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/RuntimeParams.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/RuntimeParams.scala
index fae85fc5a..da5623014 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/RuntimeParams.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/ast/RuntimeParams.scala
@@ -29,7 +29,7 @@ trait RuntimeParams {
 
   def getDataSources: util.Map[String, AnyRef]
 
-  @Deprecated
+  @deprecated
   def getSpecials: util.Map[String, AnyRef]
 
   def getJobs: util.Map[String, AnyRef]
@@ -62,18 +62,19 @@ class RuntimeParamsImpl(
 
   init()
 
-  @Deprecated
+  @deprecated
   private def initContextMap(
       runtime: util.Map[String, AnyRef],
       context: util.Map[String, AnyRef]
   ): Unit = {
     if (context.isEmpty && runtime.containsKey(QueryParams.CONTEXT_KEY_FOR_ID)) {
       context.put(QueryParams.CONTEXT_KEY_FOR_ID, runtime.get(QueryParams.CONTEXT_KEY_FOR_ID))
-      if (runtime.containsKey(QueryParams.CONTEXT_KEY_FOR_NODE_NAME))
+      if (runtime.containsKey(QueryParams.CONTEXT_KEY_FOR_NODE_NAME)) {
         context.put(
           QueryParams.CONTEXT_KEY_FOR_NODE_NAME,
           runtime.get(QueryParams.CONTEXT_KEY_FOR_NODE_NAME)
         )
+      }
     }
   }
 
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/AbstractTask.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/AbstractTask.scala
index 7ecb24013..7f98b5e0c 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/AbstractTask.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/AbstractTask.scala
@@ -30,9 +30,9 @@ abstract class AbstractTask extends Task {
 
   override def isResolved: Boolean = _isResolved
 
-  override def simpleString: String = ???
+  override def simpleString: String = null
 
-  override def verboseString: String = ???
+  override def verboseString: String = null
 
   // override def theSame(other: Task): Boolean = ???
 
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/JobTask.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/JobTask.scala
index c11fd60d8..9a1e48ab1 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/JobTask.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/JobTask.scala
@@ -40,7 +40,7 @@ class JobTask(protected var parents: Array[Task], protected var children: Array[
 
   override def theSame(other: Task): Boolean = if (super.equals(other)) true
   else if (other == null) false
-  else
+  else {
     other match {
       case jobTask: JobTask =>
         jobTask.getParents.sameElements(parents) && jobTask.getChildren.sameElements(
@@ -48,6 +48,7 @@ class JobTask(protected var parents: Array[Task], protected var children: Array[
         ) && jobTask.getTaskDesc == getTaskDesc
       case _ => false
     }
+  }
 
   override def getId: String = {
     if (null == id) synchronized {
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/Origin.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/Origin.scala
index c574e3c96..c2e26fef0 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/Origin.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/logical/Origin.scala
@@ -37,12 +37,13 @@ object Origin {
     override def getPosition: Int = position
 
     override def equals(obj: Any): Boolean = if (super.equals(obj)) true
-    else
+    else {
       obj match {
         case o: Origin =>
           o.getASTOrchestration == getASTOrchestration && position == o.getPosition
         case _ => false
       }
+    }
 
   }
 
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/physical/JobExecTask.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/physical/JobExecTask.scala
index e783bafc1..07e286405 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/physical/JobExecTask.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/physical/JobExecTask.scala
@@ -39,7 +39,7 @@ class JobExecTask(parents: Array[ExecTask], children: Array[ExecTask])
 
   override def theSame(other: ExecTask): Boolean = if (super.equals(other)) true
   else if (other == null) false
-  else
+  else {
     other match {
       case jobTask: ExecTask =>
         jobTask.getParents.sameElements(parents) && jobTask.getChildren.sameElements(
@@ -47,12 +47,13 @@ class JobExecTask(parents: Array[ExecTask], children: Array[ExecTask])
         ) && jobTask.getTaskDesc == getTaskDesc
       case _ => false
     }
+  }
 
   override def initialize(physicalContext: PhysicalContext): Unit = {
     this.physicalContext = physicalContext
   }
 
-  override def verboseString: String = ???
+  override def verboseString: String = null
 
   override def getId: String = {
     if (null == id) synchronized {
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/unit/CodeLogicalUnit.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/unit/CodeLogicalUnit.scala
index c02e68f5f..0540edb79 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/unit/CodeLogicalUnit.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/plans/unit/CodeLogicalUnit.scala
@@ -45,13 +45,13 @@ class CodeLogicalUnit(
 
   def getLabel: CodeLanguageLabel = codeLogicalLabel
 
-  def getSeparator = separator
+  def getSeparator: String = separator
 
   def parseCodes(op: String => String): CodeLogicalUnit = {
     new CodeLogicalUnit(codes.asScala.map(op).asJava, codeLogicalLabel, separator)
   }
 
-  def getCodes = codes
+  def getCodes: java.util.List[String] = codes
 
 }
 
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/strategy/ResultSetExecTask.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/strategy/ResultSetExecTask.scala
index 370e34fe3..a5d5924ac 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/strategy/ResultSetExecTask.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/strategy/ResultSetExecTask.scala
@@ -45,7 +45,7 @@ trait ResultSetExecTask extends ExecTask {
   }
 
   /**
-   * 移除子节点的response
+   * Remove the response of the child node 移除子节点的response
    * @return
    */
   def removeResultSet(): Unit = {
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/strategy/async/AsyncExecTaskRunnerImpl.scala b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/strategy/async/AsyncExecTaskRunnerImpl.scala
index 8d74b7a80..d546889b6 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/strategy/async/AsyncExecTaskRunnerImpl.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/main/scala/org/apache/linkis/orchestrator/strategy/async/AsyncExecTaskRunnerImpl.scala
@@ -164,7 +164,6 @@ class AsyncExecTaskRunnerImpl(override val task: ExecTask)
             )
               resultSets.wait(1000)
           }
-          // if (isWaitForPersistedTimeout(startWaitForPersistedTime)) onFailure("persist resultSets timeout!", new EntranceErrorException(20305, "persist resultSets timeout!"))
         }
       case _ =>
     }
diff --git a/linkis-orchestrator/linkis-orchestrator-core/src/test/scala/org/apache/linkis/orchestrator/OrchestratorSuite.scala b/linkis-orchestrator/linkis-orchestrator-core/src/test/scala/org/apache/linkis/orchestrator/OrchestratorSuite.scala
index ca7086eef..678e3ebf1 100644
--- a/linkis-orchestrator/linkis-orchestrator-core/src/test/scala/org/apache/linkis/orchestrator/OrchestratorSuite.scala
+++ b/linkis-orchestrator/linkis-orchestrator-core/src/test/scala/org/apache/linkis/orchestrator/OrchestratorSuite.scala
@@ -38,6 +38,7 @@ object OrchestratorSuite extends App {
   }
 
   val orchestration = orchestratorSession.orchestrate(jobReq)
+  // scalastyle:off println
   println(orchestration.explain(true))
   orchestration.collectAndPrint()
   orchestratorSession.close()


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@linkis.apache.org
For additional commands, e-mail: commits-help@linkis.apache.org