Package | Description |
---|---|
org.apache.hadoop.hive.metastore | |
org.apache.hadoop.hive.metastore.api | |
org.apache.hadoop.hive.metastore.txn |
Modifier and Type | Method and Description |
---|---|
void |
HiveMetaStore.HMSHandler.heartbeat(HeartbeatRequest ids) |
Modifier and Type | Method and Description |
---|---|
HeartbeatRequest |
HeartbeatRequest.deepCopy() |
HeartbeatRequest |
ThriftHiveMetastore.heartbeat_args.getIds() |
Modifier and Type | Method and Description |
---|---|
int |
HeartbeatRequest.compareTo(HeartbeatRequest other) |
boolean |
HeartbeatRequest.equals(HeartbeatRequest that) |
void |
ThriftHiveMetastore.Iface.heartbeat(HeartbeatRequest ids) |
void |
ThriftHiveMetastore.Client.heartbeat(HeartbeatRequest ids) |
void |
ThriftHiveMetastore.AsyncIface.heartbeat(HeartbeatRequest ids,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.heartbeat_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.heartbeat(HeartbeatRequest ids,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.heartbeat_call> resultHandler) |
void |
ThriftHiveMetastore.Client.send_heartbeat(HeartbeatRequest ids) |
void |
ThriftHiveMetastore.heartbeat_args.setIds(HeartbeatRequest ids) |
Constructor and Description |
---|
HeartbeatRequest(HeartbeatRequest other)
Performs a deep copy on other.
|
ThriftHiveMetastore.AsyncClient.heartbeat_call(HeartbeatRequest ids,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.heartbeat_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.heartbeat_args(HeartbeatRequest ids) |
Modifier and Type | Method and Description |
---|---|
void |
TxnHandler.heartbeat(HeartbeatRequest ids) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.