public interface LlapTaskUmbilicalProtocol
extends org.apache.hadoop.ipc.VersionedProtocol
| Modifier and Type | Interface and Description |
|---|---|
static class |
LlapTaskUmbilicalProtocol.BooleanArray |
static class |
LlapTaskUmbilicalProtocol.TezAttemptArray |
| Modifier and Type | Field and Description |
|---|---|
static long |
versionID |
| Modifier and Type | Method and Description |
|---|---|
boolean |
canCommit(org.apache.tez.dag.records.TezTaskAttemptID taskid) |
org.apache.tez.runtime.api.impl.TezHeartbeatResponse |
heartbeat(org.apache.tez.runtime.api.impl.TezHeartbeatRequest request) |
void |
nodeHeartbeat(org.apache.hadoop.io.Text hostname,
org.apache.hadoop.io.Text uniqueId,
int port,
LlapTaskUmbilicalProtocol.TezAttemptArray aw,
LlapTaskUmbilicalProtocol.BooleanArray guaranteed) |
void |
taskKilled(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptId) |
static final long versionID
boolean canCommit(org.apache.tez.dag.records.TezTaskAttemptID taskid)
throws IOException
IOExceptionorg.apache.tez.runtime.api.impl.TezHeartbeatResponse heartbeat(org.apache.tez.runtime.api.impl.TezHeartbeatRequest request)
throws IOException,
org.apache.tez.dag.api.TezException
IOExceptionorg.apache.tez.dag.api.TezExceptionvoid nodeHeartbeat(org.apache.hadoop.io.Text hostname,
org.apache.hadoop.io.Text uniqueId,
int port,
LlapTaskUmbilicalProtocol.TezAttemptArray aw,
LlapTaskUmbilicalProtocol.BooleanArray guaranteed)
throws IOException
IOExceptionvoid taskKilled(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptId)
throws IOException
IOExceptionCopyright © 2019 The Apache Software Foundation. All Rights Reserved.