public interface SchedulerBackend
Modifier and Type | Method and Description |
---|---|
scala.Option<String> |
applicationAttemptId()
Get the attempt ID for this run, if the cluster manager supports multiple
attempts.
|
String |
applicationId()
Get an application ID associated with the job.
|
int |
defaultParallelism() |
scala.Option<scala.collection.immutable.Map<String,String>> |
getDriverAttributes()
Get the attributes on driver.
|
scala.Option<scala.collection.immutable.Map<String,String>> |
getDriverLogUrls()
Get the URLs for the driver logs.
|
scala.collection.Seq<BlockManagerId> |
getShufflePushMergerLocations(int numPartitions,
int resourceProfileId)
Get the list of host locations for push based shuffle
|
boolean |
isReady() |
void |
killTask(long taskId,
String executorId,
boolean interruptThread,
String reason)
Requests that an executor kills a running task.
|
int |
maxNumConcurrentTasks(ResourceProfile rp)
Get the max number of tasks that can be concurrent launched based on the ResourceProfile
could be used, even if some of them are being used at the moment.
|
void |
reviveOffers()
Update the current offers and schedule tasks
|
void |
start() |
void |
stop() |
void |
stop(int exitCode) |
scala.Option<String> applicationAttemptId()
String applicationId()
int defaultParallelism()
scala.Option<scala.collection.immutable.Map<String,String>> getDriverAttributes()
scala.Option<scala.collection.immutable.Map<String,String>> getDriverLogUrls()
scala.collection.Seq<BlockManagerId> getShufflePushMergerLocations(int numPartitions, int resourceProfileId)
Currently push based shuffle is disabled for both stage retry and stage reuse cases (for eg: in the case where few partitions are lost due to failure). Hence this method should be invoked only once for a ShuffleDependency.
numPartitions
- (undocumented)resourceProfileId
- (undocumented)boolean isReady()
void killTask(long taskId, String executorId, boolean interruptThread, String reason)
taskId
- Id of the task.executorId
- Id of the executor the task is running on.interruptThread
- Whether the executor should interrupt the task thread.reason
- The reason for the task kill.int maxNumConcurrentTasks(ResourceProfile rp)
rp
- ResourceProfile which to use to calculate max concurrent tasks.void reviveOffers()
void start()
void stop()
void stop(int exitCode)