public class CoarseGrainedSchedulerBackend extends Object implements ExecutorAllocationClient, SchedulerBackend, Logging
Modifier and Type | Class and Description |
---|---|
class |
CoarseGrainedSchedulerBackend.DriverActor |
Constructor and Description |
---|
CoarseGrainedSchedulerBackend(TaskSchedulerImpl scheduler,
akka.actor.ActorSystem actorSystem) |
Modifier and Type | Method and Description |
---|---|
static String |
ACTOR_NAME() |
akka.actor.ActorSystem |
actorSystem() |
SparkConf |
conf() |
long |
createTime() |
int |
defaultParallelism() |
akka.actor.ActorRef |
driverActor() |
boolean |
isReady() |
boolean |
killExecutors(scala.collection.Seq<String> executorIds)
Request that the cluster manager kill the specified executors.
|
void |
killTask(long taskId,
String executorId,
boolean interruptThread) |
int |
maxRegisteredWaitingTime() |
double |
minRegisteredRatio() |
int |
numExistingExecutors()
Return the number of executors currently registered with this backend.
|
void |
removeExecutor(String executorId,
String reason) |
boolean |
requestExecutors(int numAdditionalExecutors)
Request an additional number of executors from the cluster manager.
|
boolean |
requestTotalExecutors(int numExecutors)
Express a preference to the cluster manager for a given total number of executors.
|
void |
reviveOffers() |
void |
start() |
void |
stop() |
void |
stopExecutors() |
boolean |
sufficientResourcesRegistered() |
scala.collection.mutable.HashMap<String,scala.collection.mutable.HashSet<String>> |
taskIdsOnSlave() |
java.util.concurrent.atomic.AtomicInteger |
totalCoreCount() |
java.util.concurrent.atomic.AtomicInteger |
totalRegisteredExecutors() |
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
killExecutor
appId, applicationId
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
public CoarseGrainedSchedulerBackend(TaskSchedulerImpl scheduler, akka.actor.ActorSystem actorSystem)
public static String ACTOR_NAME()
public akka.actor.ActorSystem actorSystem()
public java.util.concurrent.atomic.AtomicInteger totalCoreCount()
public java.util.concurrent.atomic.AtomicInteger totalRegisteredExecutors()
public SparkConf conf()
public double minRegisteredRatio()
public int maxRegisteredWaitingTime()
public long createTime()
public akka.actor.ActorRef driverActor()
public scala.collection.mutable.HashMap<String,scala.collection.mutable.HashSet<String>> taskIdsOnSlave()
public void start()
start
in interface SchedulerBackend
public void stopExecutors()
public void stop()
stop
in interface SchedulerBackend
public void reviveOffers()
reviveOffers
in interface SchedulerBackend
public void killTask(long taskId, String executorId, boolean interruptThread)
killTask
in interface SchedulerBackend
public int defaultParallelism()
defaultParallelism
in interface SchedulerBackend
public void removeExecutor(String executorId, String reason)
public boolean sufficientResourcesRegistered()
public boolean isReady()
isReady
in interface SchedulerBackend
public int numExistingExecutors()
public final boolean requestExecutors(int numAdditionalExecutors)
requestExecutors
in interface ExecutorAllocationClient
public final boolean requestTotalExecutors(int numExecutors)
requestTotalExecutors
in interface ExecutorAllocationClient
public final boolean killExecutors(scala.collection.Seq<String> executorIds)
killExecutors
in interface ExecutorAllocationClient