| Package | Description |
|---|---|
| org.apache.hadoop.hive.metastore | |
| org.apache.hadoop.hive.metastore.api |
| Modifier and Type | Method and Description |
|---|---|
AggrStats |
HiveMetaStore.HMSHandler.get_aggr_stats_for(PartitionsStatsRequest request) |
PartitionsStatsResult |
HiveMetaStore.HMSHandler.get_partitions_statistics_req(PartitionsStatsRequest request) |
| Modifier and Type | Method and Description |
|---|---|
PartitionsStatsRequest |
PartitionsStatsRequest.deepCopy() |
PartitionsStatsRequest |
ThriftHiveMetastore.get_partitions_statistics_req_args.getRequest() |
PartitionsStatsRequest |
ThriftHiveMetastore.get_aggr_stats_for_args.getRequest() |
| Modifier and Type | Method and Description |
|---|---|
int |
PartitionsStatsRequest.compareTo(PartitionsStatsRequest other) |
boolean |
PartitionsStatsRequest.equals(PartitionsStatsRequest that) |
AggrStats |
ThriftHiveMetastore.Iface.get_aggr_stats_for(PartitionsStatsRequest request) |
AggrStats |
ThriftHiveMetastore.Client.get_aggr_stats_for(PartitionsStatsRequest request) |
void |
ThriftHiveMetastore.AsyncIface.get_aggr_stats_for(PartitionsStatsRequest request,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.get_aggr_stats_for(PartitionsStatsRequest request,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call> resultHandler) |
PartitionsStatsResult |
ThriftHiveMetastore.Iface.get_partitions_statistics_req(PartitionsStatsRequest request) |
PartitionsStatsResult |
ThriftHiveMetastore.Client.get_partitions_statistics_req(PartitionsStatsRequest request) |
void |
ThriftHiveMetastore.AsyncIface.get_partitions_statistics_req(PartitionsStatsRequest request,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req(PartitionsStatsRequest request,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call> resultHandler) |
void |
ThriftHiveMetastore.Client.send_get_aggr_stats_for(PartitionsStatsRequest request) |
void |
ThriftHiveMetastore.Client.send_get_partitions_statistics_req(PartitionsStatsRequest request) |
void |
ThriftHiveMetastore.get_partitions_statistics_req_args.setRequest(PartitionsStatsRequest request) |
void |
ThriftHiveMetastore.get_aggr_stats_for_args.setRequest(PartitionsStatsRequest request) |
| Constructor and Description |
|---|
PartitionsStatsRequest(PartitionsStatsRequest other)
Performs a deep copy on other.
|
ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call(PartitionsStatsRequest request,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_aggr_stats_for_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call(PartitionsStatsRequest request,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.get_partitions_statistics_req_call> resultHandler,
org.apache.thrift.async.TAsyncClient client,
org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.transport.TNonblockingTransport transport) |
ThriftHiveMetastore.get_aggr_stats_for_args(PartitionsStatsRequest request) |
ThriftHiveMetastore.get_partitions_statistics_req_args(PartitionsStatsRequest request) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.