public class LlapTaskCommunicator
extends org.apache.tez.dag.app.TezTaskCommunicatorImpl
| Modifier and Type | Class and Description |
|---|---|
protected class |
LlapTaskCommunicator.LlapTaskUmbilicalProtocolImpl |
static interface |
LlapTaskCommunicator.OperationCallback<ResultType,CtxType> |
| Constructor and Description |
|---|
LlapTaskCommunicator(org.apache.tez.serviceplugins.api.TaskCommunicatorContext taskCommunicatorContext) |
| Modifier and Type | Method and Description |
|---|---|
protected LlapProtocolClientProxy |
createLlapProtocolClientProxy(int numThreads,
org.apache.hadoop.conf.Configuration conf) |
void |
dagComplete(int dagIdentifier) |
String |
getAmHostString() |
String |
getCompletedLogsUrl(org.apache.tez.dag.records.TezTaskAttemptID attemptID,
org.apache.hadoop.yarn.api.records.NodeId containerNodeId) |
String |
getInProgressLogsUrl(org.apache.tez.dag.records.TezTaskAttemptID attemptID,
org.apache.hadoop.yarn.api.records.NodeId containerNodeId) |
void |
initialize() |
void |
onVertexStateUpdated(org.apache.tez.dag.api.event.VertexStateUpdate vertexStateUpdate) |
void |
registerContainerEnd(org.apache.hadoop.yarn.api.records.ContainerId containerId,
org.apache.tez.serviceplugins.api.ContainerEndReason endReason,
String diagnostics) |
void |
registerKnownNode(LlapNodeId nodeId) |
void |
registerPingingNode(LlapNodeId nodeId) |
void |
registerRunningContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId,
String hostname,
int port) |
void |
registerRunningTaskAttempt(org.apache.hadoop.yarn.api.records.ContainerId containerId,
org.apache.tez.runtime.api.impl.TaskSpec taskSpec,
Map<String,org.apache.hadoop.yarn.api.records.LocalResource> additionalResources,
org.apache.hadoop.security.Credentials credentials,
boolean credentialsChanged,
int priority) |
void |
sendStateUpdate(LlapNodeId nodeId,
org.apache.hadoop.hive.llap.daemon.rpc.LlapDaemonProtocolProtos.SourceStateUpdatedRequestProto request) |
void |
shutdown() |
void |
start() |
protected void |
startRpcServer() |
<T> void |
startUpdateGuaranteed(org.apache.tez.dag.records.TezTaskAttemptID attemptId,
org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.NodeInfo assignedNode,
boolean newState,
LlapTaskCommunicator.OperationCallback<Boolean,T> callback,
T ctx) |
void |
unregisterRunningTaskAttempt(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptId,
org.apache.tez.serviceplugins.api.TaskAttemptEndReason endReason,
String diagnostics) |
public LlapTaskCommunicator(org.apache.tez.serviceplugins.api.TaskCommunicatorContext taskCommunicatorContext)
public void initialize()
throws Exception
initialize in interface org.apache.tez.common.ServicePluginLifecycleinitialize in class org.apache.tez.serviceplugins.api.TaskCommunicatorExceptionpublic void start()
start in interface org.apache.tez.common.ServicePluginLifecyclestart in class org.apache.tez.dag.app.TezTaskCommunicatorImplpublic void shutdown()
shutdown in interface org.apache.tez.common.ServicePluginLifecycleshutdown in class org.apache.tez.dag.app.TezTaskCommunicatorImplprotected void startRpcServer()
startRpcServer in class org.apache.tez.dag.app.TezTaskCommunicatorImplprotected LlapProtocolClientProxy createLlapProtocolClientProxy(int numThreads, org.apache.hadoop.conf.Configuration conf)
public void registerRunningContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId,
String hostname,
int port)
registerRunningContainer in class org.apache.tez.dag.app.TezTaskCommunicatorImplpublic void registerContainerEnd(org.apache.hadoop.yarn.api.records.ContainerId containerId,
org.apache.tez.serviceplugins.api.ContainerEndReason endReason,
String diagnostics)
registerContainerEnd in class org.apache.tez.dag.app.TezTaskCommunicatorImplpublic <T> void startUpdateGuaranteed(org.apache.tez.dag.records.TezTaskAttemptID attemptId,
org.apache.hadoop.hive.llap.tezplugins.LlapTaskSchedulerService.NodeInfo assignedNode,
boolean newState,
LlapTaskCommunicator.OperationCallback<Boolean,T> callback,
T ctx)
public void registerRunningTaskAttempt(org.apache.hadoop.yarn.api.records.ContainerId containerId,
org.apache.tez.runtime.api.impl.TaskSpec taskSpec,
Map<String,org.apache.hadoop.yarn.api.records.LocalResource> additionalResources,
org.apache.hadoop.security.Credentials credentials,
boolean credentialsChanged,
int priority)
registerRunningTaskAttempt in class org.apache.tez.dag.app.TezTaskCommunicatorImplpublic void unregisterRunningTaskAttempt(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptId,
org.apache.tez.serviceplugins.api.TaskAttemptEndReason endReason,
String diagnostics)
unregisterRunningTaskAttempt in class org.apache.tez.dag.app.TezTaskCommunicatorImplpublic void dagComplete(int dagIdentifier)
dagComplete in class org.apache.tez.dag.app.TezTaskCommunicatorImplpublic void onVertexStateUpdated(org.apache.tez.dag.api.event.VertexStateUpdate vertexStateUpdate)
onVertexStateUpdated in class org.apache.tez.dag.app.TezTaskCommunicatorImplpublic void sendStateUpdate(LlapNodeId nodeId, org.apache.hadoop.hive.llap.daemon.rpc.LlapDaemonProtocolProtos.SourceStateUpdatedRequestProto request)
public String getInProgressLogsUrl(org.apache.tez.dag.records.TezTaskAttemptID attemptID, org.apache.hadoop.yarn.api.records.NodeId containerNodeId)
getInProgressLogsUrl in class org.apache.tez.serviceplugins.api.TaskCommunicatorpublic String getCompletedLogsUrl(org.apache.tez.dag.records.TezTaskAttemptID attemptID, org.apache.hadoop.yarn.api.records.NodeId containerNodeId)
getCompletedLogsUrl in class org.apache.tez.serviceplugins.api.TaskCommunicatorpublic void registerKnownNode(LlapNodeId nodeId)
public void registerPingingNode(LlapNodeId nodeId)
public String getAmHostString()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.