| Package | Description |
|---|---|
| org.apache.hadoop.hive.llap | |
| org.apache.hadoop.hive.llap.daemon.impl | |
| org.apache.hadoop.hive.llap.tez | |
| org.apache.hadoop.hive.llap.tezplugins |
| Modifier and Type | Field and Description |
|---|---|
protected LlapNodeId |
AsyncPbRpcProxy.NodeCallableRequest.nodeId |
| Modifier and Type | Method and Description |
|---|---|
static LlapNodeId |
LlapNodeId.getInstance(String hostname,
int port) |
abstract LlapNodeId |
AsyncPbRpcProxy.CallableRequest.getNodeId() |
LlapNodeId |
AsyncPbRpcProxy.NodeCallableRequest.getNodeId() |
| Modifier and Type | Method and Description |
|---|---|
protected ProtocolType |
AsyncPbRpcProxy.getProxy(LlapNodeId nodeId,
org.apache.hadoop.security.token.Token<TokenType> nodeToken) |
void |
AsyncPbRpcProxy.RequestManager.requestFinished(LlapNodeId nodeId) |
| Constructor and Description |
|---|
NodeCallableRequest(LlapNodeId nodeId,
REQUEST request,
AsyncPbRpcProxy.ExecuteRequestCallback<RESPONSE> callback) |
| Modifier and Type | Method and Description |
|---|---|
LlapNodeId |
QueryInfo.getAmNodeId() |
| Constructor and Description |
|---|
AMNodeInfo(LlapNodeId amNodeId,
String umbilicalUser,
org.apache.hadoop.security.token.Token<org.apache.tez.common.security.JobTokenIdentifier> jobToken,
QueryIdentifier currentQueryIdentifier,
org.apache.hadoop.io.retry.RetryPolicy retryPolicy,
long timeout,
SocketFactory socketFactory,
org.apache.hadoop.conf.Configuration conf) |
QueryInfo(QueryIdentifier queryIdentifier,
String appIdString,
String dagIdString,
String dagName,
String hiveQueryIdString,
int dagIdentifier,
String user,
ConcurrentMap<String,org.apache.hadoop.hive.llap.daemon.rpc.LlapDaemonProtocolProtos.SourceStateProto> sourceStateMap,
String[] localDirsBase,
org.apache.hadoop.fs.FileSystem localFs,
String tokenUserName,
String tokenAppId,
LlapNodeId amNodeId,
String tokenIdentifier,
org.apache.hadoop.security.token.Token<org.apache.tez.common.security.JobTokenIdentifier> appToken,
boolean isExternalQuery) |
| Modifier and Type | Method and Description |
|---|---|
void |
LlapProtocolClientProxy.sendSourceStateUpdate(org.apache.hadoop.hive.llap.daemon.rpc.LlapDaemonProtocolProtos.SourceStateUpdatedRequestProto request,
LlapNodeId nodeId,
AsyncPbRpcProxy.ExecuteRequestCallback<org.apache.hadoop.hive.llap.daemon.rpc.LlapDaemonProtocolProtos.SourceStateUpdatedResponseProto> callback) |
| Modifier and Type | Method and Description |
|---|---|
void |
LlapTaskCommunicator.registerKnownNode(LlapNodeId nodeId) |
void |
LlapTaskCommunicator.registerPingingNode(LlapNodeId nodeId) |
void |
LlapTaskCommunicator.sendStateUpdate(LlapNodeId nodeId,
org.apache.hadoop.hive.llap.daemon.rpc.LlapDaemonProtocolProtos.SourceStateUpdatedRequestProto request) |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.