public class LlapTaskSchedulerService
extends org.apache.tez.serviceplugins.api.TaskScheduler
| Modifier and Type | Field and Description |
|---|---|
static String |
LLAP_PLUGIN_ENDPOINT_ENABLED
Whether to enable the endpoint.
|
| Constructor and Description |
|---|
LlapTaskSchedulerService(org.apache.tez.serviceplugins.api.TaskSchedulerContext taskSchedulerContext) |
LlapTaskSchedulerService(org.apache.tez.serviceplugins.api.TaskSchedulerContext taskSchedulerContext,
org.apache.hadoop.yarn.util.Clock clock,
boolean initMetrics) |
| Modifier and Type | Method and Description |
|---|---|
void |
allocateTask(Object task,
org.apache.hadoop.yarn.api.records.Resource capability,
org.apache.hadoop.yarn.api.records.ContainerId containerId,
org.apache.hadoop.yarn.api.records.Priority priority,
Object containerSignature,
Object clientCookie) |
void |
allocateTask(Object task,
org.apache.hadoop.yarn.api.records.Resource capability,
String[] hosts,
String[] racks,
org.apache.hadoop.yarn.api.records.Priority priority,
Object containerSignature,
Object clientCookie) |
void |
blacklistNode(org.apache.hadoop.yarn.api.records.NodeId nodeId) |
protected void |
checkAndSendGuaranteedStateUpdate(org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo ti) |
void |
dagComplete() |
Object |
deallocateContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId) |
boolean |
deallocateTask(Object task,
boolean taskSucceeded,
org.apache.tez.serviceplugins.api.TaskAttemptEndReason endReason,
String diagnostics) |
org.apache.hadoop.yarn.api.records.Resource |
getAvailableResources()
The difference between this and getTotalResources() is that this only gives currently free
resource instances, while the other lists all the instances that may become available in a
while.
|
int |
getClusterNodeCount() |
protected org.apache.tez.dag.records.TezTaskAttemptID |
getTaskAttemptId(Object task) |
protected org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo |
getTaskInfo(Object task) |
org.apache.hadoop.yarn.api.records.Resource |
getTotalResources() |
protected void |
handleUpdateResult(org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo ti,
boolean isOk) |
boolean |
hasUnregistered() |
void |
initialize() |
void |
notifyStarted(org.apache.tez.dag.records.TezTaskAttemptID attemptId) |
protected void |
registerRunningTask(org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo taskInfo) |
protected void |
schedulePendingTasks() |
protected void |
sendUpdateMessageAsync(org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo ti,
boolean newState) |
protected void |
setServiceInstanceSet(LlapServiceInstanceSet serviceInstanceSet) |
void |
setShouldUnregister() |
void |
shutdown() |
void |
start() |
void |
taskInfoUpdated(org.apache.tez.dag.records.TezTaskAttemptID attemptId,
boolean isGuaranteed)
A direct call from communicator to scheduler to propagate data that cannot be passed via Tez.
|
void |
unblacklistNode(org.apache.hadoop.yarn.api.records.NodeId nodeId) |
void |
updateQuery(org.apache.hadoop.hive.llap.plugin.rpc.LlapPluginProtocolProtos.UpdateQueryRequestProto request) |
public static final String LLAP_PLUGIN_ENDPOINT_ENABLED
public LlapTaskSchedulerService(org.apache.tez.serviceplugins.api.TaskSchedulerContext taskSchedulerContext)
public LlapTaskSchedulerService(org.apache.tez.serviceplugins.api.TaskSchedulerContext taskSchedulerContext,
org.apache.hadoop.yarn.util.Clock clock,
boolean initMetrics)
protected void checkAndSendGuaranteedStateUpdate(org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo ti)
protected void handleUpdateResult(org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo ti,
boolean isOk)
public void initialize()
initialize in interface org.apache.tez.common.ServicePluginLifecycleinitialize in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic void start()
throws IOException
start in interface org.apache.tez.common.ServicePluginLifecyclestart in class org.apache.tez.serviceplugins.api.TaskSchedulerIOExceptionprotected void setServiceInstanceSet(LlapServiceInstanceSet serviceInstanceSet)
public void shutdown()
shutdown in interface org.apache.tez.common.ServicePluginLifecycleshutdown in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic org.apache.hadoop.yarn.api.records.Resource getTotalResources()
getTotalResources in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic org.apache.hadoop.yarn.api.records.Resource getAvailableResources()
getAvailableResources in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic int getClusterNodeCount()
getClusterNodeCount in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic void dagComplete()
dagComplete in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic void blacklistNode(org.apache.hadoop.yarn.api.records.NodeId nodeId)
blacklistNode in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic void unblacklistNode(org.apache.hadoop.yarn.api.records.NodeId nodeId)
unblacklistNode in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic void allocateTask(Object task, org.apache.hadoop.yarn.api.records.Resource capability, String[] hosts, String[] racks, org.apache.hadoop.yarn.api.records.Priority priority, Object containerSignature, Object clientCookie)
allocateTask in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic void allocateTask(Object task, org.apache.hadoop.yarn.api.records.Resource capability, org.apache.hadoop.yarn.api.records.ContainerId containerId, org.apache.hadoop.yarn.api.records.Priority priority, Object containerSignature, Object clientCookie)
allocateTask in class org.apache.tez.serviceplugins.api.TaskSchedulerprotected org.apache.tez.dag.records.TezTaskAttemptID getTaskAttemptId(Object task)
public boolean deallocateTask(Object task, boolean taskSucceeded, org.apache.tez.serviceplugins.api.TaskAttemptEndReason endReason, String diagnostics)
deallocateTask in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic void notifyStarted(org.apache.tez.dag.records.TezTaskAttemptID attemptId)
public Object deallocateContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId)
deallocateContainer in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic void setShouldUnregister()
setShouldUnregister in class org.apache.tez.serviceplugins.api.TaskSchedulerpublic boolean hasUnregistered()
hasUnregistered in class org.apache.tez.serviceplugins.api.TaskSchedulerprotected void registerRunningTask(org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo taskInfo)
protected org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo getTaskInfo(Object task)
protected void schedulePendingTasks()
throws InterruptedException
InterruptedExceptionpublic void updateQuery(org.apache.hadoop.hive.llap.plugin.rpc.LlapPluginProtocolProtos.UpdateQueryRequestProto request)
protected void sendUpdateMessageAsync(org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.TaskInfo ti,
boolean newState)
public void taskInfoUpdated(org.apache.tez.dag.records.TezTaskAttemptID attemptId,
boolean isGuaranteed)
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.