You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@iotdb.apache.org by xi...@apache.org on 2023/02/01 12:27:16 UTC

[iotdb] 01/03: delete unused code

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

xiangweiwei pushed a commit to branch timeoutQueue
in repository https://gitbox.apache.org/repos/asf/iotdb.git

commit d786790398ab273c78535541636300ca46138d13
Author: Alima777 <wx...@gmail.com>
AuthorDate: Wed Feb 1 17:49:32 2023 +0800

    delete unused code
---
 .../iotdb/db/mpp/execution/schedule/DriverScheduler.java     | 12 ------------
 .../iotdb/db/mpp/execution/schedule/IDriverScheduler.java    | 11 -----------
 2 files changed, 23 deletions(-)

diff --git a/server/src/main/java/org/apache/iotdb/db/mpp/execution/schedule/DriverScheduler.java b/server/src/main/java/org/apache/iotdb/db/mpp/execution/schedule/DriverScheduler.java
index 67e0fc49e0..a2cd231a38 100644
--- a/server/src/main/java/org/apache/iotdb/db/mpp/execution/schedule/DriverScheduler.java
+++ b/server/src/main/java/org/apache/iotdb/db/mpp/execution/schedule/DriverScheduler.java
@@ -32,9 +32,7 @@ import org.apache.iotdb.db.mpp.execution.schedule.queue.IndexedBlockingQueue;
 import org.apache.iotdb.db.mpp.execution.schedule.queue.L1PriorityQueue;
 import org.apache.iotdb.db.mpp.execution.schedule.queue.multilevelqueue.DriverTaskHandle;
 import org.apache.iotdb.db.mpp.execution.schedule.queue.multilevelqueue.MultilevelPriorityQueue;
-import org.apache.iotdb.db.mpp.execution.schedule.queue.multilevelqueue.Priority;
 import org.apache.iotdb.db.mpp.execution.schedule.task.DriverTask;
-import org.apache.iotdb.db.mpp.execution.schedule.task.DriverTaskId;
 import org.apache.iotdb.db.mpp.execution.schedule.task.DriverTaskStatus;
 import org.apache.iotdb.db.mpp.metric.QueryMetricsManager;
 import org.apache.iotdb.db.utils.SetThreadName;
@@ -257,16 +255,6 @@ public class DriverScheduler implements IDriverScheduler, IService {
     }
   }
 
-  @Override
-  public Priority getSchedulePriority(DriverTaskId driverTaskID) {
-    DriverTask task = timeoutQueue.get(driverTaskID);
-    if (task == null) {
-      throw new IllegalStateException(
-          "the fragmentInstance " + driverTaskID.getFullId() + " has been cleared");
-    }
-    return task.getPriority();
-  }
-
   private void clearDriverTask(DriverTask task) {
     try (SetThreadName driverTaskName =
         new SetThreadName(task.getDriver().getDriverTaskId().getFullId())) {
diff --git a/server/src/main/java/org/apache/iotdb/db/mpp/execution/schedule/IDriverScheduler.java b/server/src/main/java/org/apache/iotdb/db/mpp/execution/schedule/IDriverScheduler.java
index 5729a2718c..ba2259a200 100644
--- a/server/src/main/java/org/apache/iotdb/db/mpp/execution/schedule/IDriverScheduler.java
+++ b/server/src/main/java/org/apache/iotdb/db/mpp/execution/schedule/IDriverScheduler.java
@@ -21,8 +21,6 @@ package org.apache.iotdb.db.mpp.execution.schedule;
 import org.apache.iotdb.db.mpp.common.FragmentInstanceId;
 import org.apache.iotdb.db.mpp.common.QueryId;
 import org.apache.iotdb.db.mpp.execution.driver.IDriver;
-import org.apache.iotdb.db.mpp.execution.schedule.queue.multilevelqueue.Priority;
-import org.apache.iotdb.db.mpp.execution.schedule.task.DriverTaskId;
 
 import java.util.List;
 
@@ -52,13 +50,4 @@ public interface IDriverScheduler {
    * @param instanceId the id of the fragment instance to be aborted.
    */
   void abortFragmentInstance(FragmentInstanceId instanceId);
-
-  /**
-   * Return the schedule priority of a Driver task.
-   *
-   * @param driverTaskID the fragment instance id.
-   * @return the schedule priority.
-   * @throws IllegalStateException if the instance has already been cleared.
-   */
-  Priority getSchedulePriority(DriverTaskId driverTaskID);
 }