Interface Schedulable


public interface Schedulable
An interface for schedulable entities. there are two type of Schedulable entities(Pools and TaskSetManagers)
  • Method Details

    • addSchedulable

      void addSchedulable(Schedulable schedulable)
    • checkSpeculatableTasks

      boolean checkSpeculatableTasks(long minTimeToSpeculation)
    • executorDecommission

      void executorDecommission(String executorId)
    • executorLost

      void executorLost(String executorId, String host, org.apache.spark.scheduler.ExecutorLossReason reason)
    • getSchedulableByName

      Schedulable getSchedulableByName(String name)
    • getSortedTaskSetQueue

      scala.collection.mutable.ArrayBuffer<org.apache.spark.scheduler.TaskSetManager> getSortedTaskSetQueue()
    • isSchedulable

      boolean isSchedulable()
    • minShare

      int minShare()
    • name

      String name()
    • parent

      org.apache.spark.scheduler.Pool parent()
    • priority

      int priority()
    • removeSchedulable

      void removeSchedulable(Schedulable schedulable)
    • runningTasks

      int runningTasks()
    • schedulableQueue

      ConcurrentLinkedQueue<Schedulable> schedulableQueue()
    • schedulingMode

      scala.Enumeration.Value schedulingMode()
    • stageId

      int stageId()
    • weight

      int weight()