You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@linkis.apache.org by pe...@apache.org on 2023/04/19 06:56:31 UTC

[linkis] branch dev-1.4.0 updated: Executor code optimization and Remove useless code (#4472)

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

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


The following commit(s) were added to refs/heads/dev-1.4.0 by this push:
     new 415d5cd19 Executor code optimization and Remove useless code (#4472)
415d5cd19 is described below

commit 415d5cd19a7598c4e98a37025a780b81f988603b
Author: ChengJie1053 <18...@163.com>
AuthorDate: Wed Apr 19 14:56:22 2023 +0800

    Executor code optimization and Remove useless code (#4472)
    
    * Executor code optimization and Remove useless code
    
    * update AccessibleExecutor
---
 .../computation/executor/execute/ComputationExecutor.scala         | 7 -------
 .../computation/executor/execute/EngineExecutionContext.scala      | 1 -
 .../apache/linkis/engineconn/common/conf/EngineConnConstant.scala  | 4 ----
 3 files changed, 12 deletions(-)

diff --git a/linkis-computation-governance/linkis-engineconn/linkis-computation-engineconn/src/main/scala/org/apache/linkis/engineconn/computation/executor/execute/ComputationExecutor.scala b/linkis-computation-governance/linkis-engineconn/linkis-computation-engineconn/src/main/scala/org/apache/linkis/engineconn/computation/executor/execute/ComputationExecutor.scala
index 780db4215..00622da92 100644
--- a/linkis-computation-governance/linkis-engineconn/linkis-computation-engineconn/src/main/scala/org/apache/linkis/engineconn/computation/executor/execute/ComputationExecutor.scala
+++ b/linkis-computation-governance/linkis-engineconn/linkis-computation-engineconn/src/main/scala/org/apache/linkis/engineconn/computation/executor/execute/ComputationExecutor.scala
@@ -56,7 +56,6 @@ abstract class ComputationExecutor(val outputPrintLimit: Int = 1000)
 
   private val listenerBusContext = ExecutorListenerBusContext.getExecutorListenerBusContext()
 
-  //  private val taskMap: util.Map[String, EngineConnTask] = new ConcurrentHashMap[String, EngineConnTask](8)
   private val taskCache: Cache[String, EngineConnTask] = CacheBuilder
     .newBuilder()
     .expireAfterAccess(EngineConnConf.ENGINE_TASK_EXPIRE_TIME.getValue, TimeUnit.MILLISECONDS)
@@ -71,8 +70,6 @@ abstract class ComputationExecutor(val outputPrintLimit: Int = 1000)
 
   protected val runningTasks: Count = new Count
 
-  protected val pendingTasks: Count = new Count
-
   protected val succeedTasks: Count = new Count
 
   protected val failedTasks: Count = new Count
@@ -139,8 +136,6 @@ abstract class ComputationExecutor(val outputPrintLimit: Int = 1000)
     super.close()
   }
 
-  //  override def getName: String = ComputationExecutorConf.DEFAULT_COMPUTATION_NAME
-
   protected def ensureOp[A](f: => A): A = if (!isEngineInitialized) {
     f
   } else ensureIdle(f)
@@ -208,7 +203,6 @@ abstract class ComputationExecutor(val outputPrintLimit: Int = 1000)
         } else executeLine(engineExecutionContext, code)) { t =>
           ErrorExecuteResponse(ExceptionUtils.getRootCauseMessage(t), t)
         }
-        // info(s"Finished to execute task ${engineConnTask.getTaskId}")
         incomplete ++= code
         response match {
           case e: ErrorExecuteResponse =>
@@ -269,7 +263,6 @@ abstract class ComputationExecutor(val outputPrintLimit: Int = 1000)
 
     Utils.tryAndWarn(afterExecute(engineConnTask, response))
     logger.info(s"Finished to execute task ${engineConnTask.getTaskId}")
-    // lastTask = null
     response
   }
 
diff --git a/linkis-computation-governance/linkis-engineconn/linkis-computation-engineconn/src/main/scala/org/apache/linkis/engineconn/computation/executor/execute/EngineExecutionContext.scala b/linkis-computation-governance/linkis-engineconn/linkis-computation-engineconn/src/main/scala/org/apache/linkis/engineconn/computation/executor/execute/EngineExecutionContext.scala
index 08124f222..b97bb1cd9 100644
--- a/linkis-computation-governance/linkis-engineconn/linkis-computation-engineconn/src/main/scala/org/apache/linkis/engineconn/computation/executor/execute/EngineExecutionContext.scala
+++ b/linkis-computation-governance/linkis-engineconn/linkis-computation-engineconn/src/main/scala/org/apache/linkis/engineconn/computation/executor/execute/EngineExecutionContext.scala
@@ -188,7 +188,6 @@ class EngineExecutionContext(executor: ComputationExecutor, executorUser: String
     logger.info(log)
   } else {
     val listenerBus = getEngineSyncListenerBus
-    // jobId.foreach(jId => listenerBus.post(TaskLogUpdateEvent(jId, log)))
     getJobId.foreach(jId => listenerBus.postToAll(TaskLogUpdateEvent(jId, log)))
   }
 
diff --git a/linkis-computation-governance/linkis-engineconn/linkis-engineconn-common/src/main/scala/org/apache/linkis/engineconn/common/conf/EngineConnConstant.scala b/linkis-computation-governance/linkis-engineconn/linkis-engineconn-common/src/main/scala/org/apache/linkis/engineconn/common/conf/EngineConnConstant.scala
index 352a9039c..e74f5b789 100644
--- a/linkis-computation-governance/linkis-engineconn/linkis-engineconn-common/src/main/scala/org/apache/linkis/engineconn/common/conf/EngineConnConstant.scala
+++ b/linkis-computation-governance/linkis-engineconn/linkis-engineconn-common/src/main/scala/org/apache/linkis/engineconn/common/conf/EngineConnConstant.scala
@@ -20,8 +20,4 @@ package org.apache.linkis.engineconn.common.conf
 object EngineConnConstant {
 
   val MAX_TASK_NUM = 10000
-
-  val SPRING_CONF_MAP_NAME = "SpringConfMap"
-
-  val MAX_EXECUTOR_ID_NAME = "MaxExecutorId"
 }


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