public class SparkDeploySchedulerBackend extends CoarseGrainedSchedulerBackend implements org.apache.spark.deploy.client.AppClientListener, Logging
CoarseGrainedSchedulerBackend.DriverActor
Constructor and Description |
---|
SparkDeploySchedulerBackend(TaskSchedulerImpl scheduler,
SparkContext sc,
String[] masters) |
Modifier and Type | Method and Description |
---|---|
String |
appId() |
String |
applicationId()
Get an application ID associated with the job.
|
org.apache.spark.deploy.client.AppClient |
client() |
void |
connected(String appId) |
void |
dead(String reason) |
void |
disconnected() |
void |
executorAdded(String fullId,
String workerId,
String hostPort,
int cores,
int memory) |
void |
executorRemoved(String fullId,
String message,
scala.Option<Object> exitStatus) |
scala.Option<Object> |
maxCores() |
boolean |
registrationDone() |
Object |
registrationLock() |
scala.Function1<SparkDeploySchedulerBackend,scala.runtime.BoxedUnit> |
shutdownCallback() |
void |
start() |
void |
stop() |
boolean |
stopping() |
boolean |
sufficientResourcesRegistered() |
int |
totalExpectedCores() |
ACTOR_NAME, actorSystem, conf, createTime, defaultParallelism, driverActor, isReady, killExecutors, killTask, maxRegisteredWaitingTime, minRegisteredRatio, numExistingExecutors, removeExecutor, requestExecutors, reviveOffers, stopExecutors, 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
public SparkDeploySchedulerBackend(TaskSchedulerImpl scheduler, SparkContext sc, String[] masters)
public org.apache.spark.deploy.client.AppClient client()
public boolean stopping()
public scala.Function1<SparkDeploySchedulerBackend,scala.runtime.BoxedUnit> shutdownCallback()
public String appId()
appId
in interface SchedulerBackend
public Object registrationLock()
public boolean registrationDone()
public scala.Option<Object> maxCores()
public int totalExpectedCores()
public void start()
start
in interface SchedulerBackend
start
in class CoarseGrainedSchedulerBackend
public void stop()
stop
in interface SchedulerBackend
stop
in class CoarseGrainedSchedulerBackend
public void connected(String appId)
connected
in interface org.apache.spark.deploy.client.AppClientListener
public void disconnected()
disconnected
in interface org.apache.spark.deploy.client.AppClientListener
public void dead(String reason)
dead
in interface org.apache.spark.deploy.client.AppClientListener
public void executorAdded(String fullId, String workerId, String hostPort, int cores, int memory)
executorAdded
in interface org.apache.spark.deploy.client.AppClientListener
public void executorRemoved(String fullId, String message, scala.Option<Object> exitStatus)
executorRemoved
in interface org.apache.spark.deploy.client.AppClientListener
public boolean sufficientResourcesRegistered()
sufficientResourcesRegistered
in class CoarseGrainedSchedulerBackend
public String applicationId()
SchedulerBackend
applicationId
in interface SchedulerBackend