public interface Schedulable
| Modifier and Type | Method and Description | 
|---|---|
void | 
addSchedulable(Schedulable schedulable)  | 
boolean | 
checkSpeculatableTasks(int minTimeToSpeculation)  | 
void | 
executorDecommission(String executorId)  | 
void | 
executorLost(String executorId,
            String host,
            org.apache.spark.scheduler.ExecutorLossReason reason)  | 
Schedulable | 
getSchedulableByName(String name)  | 
scala.collection.mutable.ArrayBuffer<org.apache.spark.scheduler.TaskSetManager> | 
getSortedTaskSetQueue()  | 
boolean | 
isSchedulable()  | 
int | 
minShare()  | 
String | 
name()  | 
org.apache.spark.scheduler.Pool | 
parent()  | 
int | 
priority()  | 
void | 
removeSchedulable(Schedulable schedulable)  | 
int | 
runningTasks()  | 
java.util.concurrent.ConcurrentLinkedQueue<Schedulable> | 
schedulableQueue()  | 
scala.Enumeration.Value | 
schedulingMode()  | 
int | 
stageId()  | 
int | 
weight()  | 
void addSchedulable(Schedulable schedulable)
boolean checkSpeculatableTasks(int minTimeToSpeculation)
void executorDecommission(String executorId)
void executorLost(String executorId,
                  String host,
                  org.apache.spark.scheduler.ExecutorLossReason reason)
Schedulable getSchedulableByName(String name)
scala.collection.mutable.ArrayBuffer<org.apache.spark.scheduler.TaskSetManager> getSortedTaskSetQueue()
boolean isSchedulable()
int minShare()
String name()
org.apache.spark.scheduler.Pool parent()
int priority()
void removeSchedulable(Schedulable schedulable)
int runningTasks()
java.util.concurrent.ConcurrentLinkedQueue<Schedulable> schedulableQueue()
scala.Enumeration.Value schedulingMode()
int stageId()
int weight()