public class SimrSchedulerBackend extends CoarseGrainedSchedulerBackend implements Logging
CoarseGrainedSchedulerBackend.DriverActor
Constructor and Description |
---|
SimrSchedulerBackend(TaskSchedulerImpl scheduler,
SparkContext sc,
String driverFilePath) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.fs.Path |
filePath() |
int |
maxCores() |
void |
start() |
void |
stop() |
org.apache.hadoop.fs.Path |
tmpPath() |
ACTOR_NAME, actorSystem, conf, createTime, defaultParallelism, driverActor, isReady, killExecutors, killTask, maxRegisteredWaitingTime, minRegisteredRatio, numExistingExecutors, removeExecutor, requestExecutors, requestTotalExecutors, reviveOffers, stopExecutors, sufficientResourcesRegistered, taskIdsOnSlave, totalCoreCount, totalRegisteredExecutors
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
killExecutor
appId, applicationId
public SimrSchedulerBackend(TaskSchedulerImpl scheduler, SparkContext sc, String driverFilePath)
public org.apache.hadoop.fs.Path tmpPath()
public org.apache.hadoop.fs.Path filePath()
public int maxCores()
public void start()
start
in interface SchedulerBackend
start
in class CoarseGrainedSchedulerBackend
public void stop()
stop
in interface SchedulerBackend
stop
in class CoarseGrainedSchedulerBackend