Package | Description |
---|---|
org.apache.hadoop.hive.metastore | |
org.apache.hadoop.hive.metastore.api | |
org.apache.hadoop.hive.ql.metadata |
Modifier and Type | Method and Description |
---|---|
ColumnStatistics |
HiveMetaStore.HMSHandler.get_partition_column_statistics(String dbName,
String tableName,
String partName,
String colName) |
ColumnStatistics |
HiveMetaStore.HMSHandler.get_table_column_statistics(String dbName,
String tableName,
String colName) |
ColumnStatistics |
RawStore.getTableColumnStatistics(String dbName,
String tableName,
List<String> colName)
Returns the relevant column statistics for a given column in a given table in a given database
if such statistics exist.
|
ColumnStatistics |
ObjectStore.getTableColumnStatistics(String dbName,
String tableName,
List<String> colNames) |
protected ColumnStatistics |
ObjectStore.getTableColumnStatisticsInternal(String dbName,
String tableName,
List<String> colNames,
boolean allowSql,
boolean allowJdo) |
Modifier and Type | Method and Description |
---|---|
List<ColumnStatistics> |
RawStore.getPartitionColumnStatistics(String dbName,
String tblName,
List<String> partNames,
List<String> colNames)
Returns the relevant column statistics for given columns in given partitions in a given
table in a given database if such statistics exist.
|
List<ColumnStatistics> |
ObjectStore.getPartitionColumnStatistics(String dbName,
String tableName,
List<String> partNames,
List<String> colNames) |
protected List<ColumnStatistics> |
ObjectStore.getPartitionColumnStatisticsInternal(String dbName,
String tableName,
List<String> partNames,
List<String> colNames,
boolean allowSql,
boolean allowJdo) |
Modifier and Type | Method and Description |
---|---|
boolean |
HiveMetaStore.HMSHandler.update_partition_column_statistics(ColumnStatistics colStats) |
boolean |
HiveMetaStore.HMSHandler.update_table_column_statistics(ColumnStatistics colStats) |
boolean |
IMetaStoreClient.updatePartitionColumnStatistics(ColumnStatistics statsObj)
Write partition level column statistics to persistent store
|
boolean |
HiveMetaStoreClient.updatePartitionColumnStatistics(ColumnStatistics statsObj)
Write partition level column statistics to persistent store
|
boolean |
RawStore.updatePartitionColumnStatistics(ColumnStatistics statsObj,
List<String> partVals)
Persists the given column statistics object to the metastore
|
boolean |
ObjectStore.updatePartitionColumnStatistics(ColumnStatistics colStats,
List<String> partVals) |
boolean |
RawStore.updateTableColumnStatistics(ColumnStatistics colStats)
Persists the given column statistics object to the metastore
|
boolean |
ObjectStore.updateTableColumnStatistics(ColumnStatistics colStats) |
boolean |
IMetaStoreClient.updateTableColumnStatistics(ColumnStatistics statsObj)
Write table level column statistics to persistent store
|
boolean |
HiveMetaStoreClient.updateTableColumnStatistics(ColumnStatistics statsObj)
Write table level column statistics to persistent store
|
Modifier and Type | Method and Description |
---|---|
ColumnStatistics |
ColumnStatistics.deepCopy() |
ColumnStatistics |
ThriftHiveMetastore.Iface.get_partition_column_statistics(String db_name,
String tbl_name,
String part_name,
String col_name) |
ColumnStatistics |
ThriftHiveMetastore.Client.get_partition_column_statistics(String db_name,
String tbl_name,
String part_name,
String col_name) |
ColumnStatistics |
ThriftHiveMetastore.Iface.get_table_column_statistics(String db_name,
String tbl_name,
String col_name) |
ColumnStatistics |
ThriftHiveMetastore.Client.get_table_column_statistics(String db_name,
String tbl_name,
String col_name) |
ColumnStatistics |
ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call.getResult() |
ColumnStatistics |
ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call.getResult() |
ColumnStatistics |
ThriftHiveMetastore.update_table_column_statistics_args.getStats_obj() |
ColumnStatistics |
ThriftHiveMetastore.update_partition_column_statistics_args.getStats_obj() |
ColumnStatistics |
ThriftHiveMetastore.get_table_column_statistics_result.getSuccess() |
ColumnStatistics |
ThriftHiveMetastore.get_partition_column_statistics_result.getSuccess() |
ColumnStatistics |
ThriftHiveMetastore.Client.recv_get_partition_column_statistics() |
ColumnStatistics |
ThriftHiveMetastore.Client.recv_get_table_column_statistics() |
Modifier and Type | Method and Description |
---|---|
List<ColumnStatistics> |
SetPartitionsStatsRequest.getColStats() |
Iterator<ColumnStatistics> |
SetPartitionsStatsRequest.getColStatsIterator() |
Modifier and Type | Method and Description |
---|---|
void |
SetPartitionsStatsRequest.addToColStats(ColumnStatistics elem) |
int |
ColumnStatistics.compareTo(ColumnStatistics other) |
boolean |
ColumnStatistics.equals(ColumnStatistics that) |
void |
ThriftHiveMetastore.Client.send_update_partition_column_statistics(ColumnStatistics stats_obj) |
void |
ThriftHiveMetastore.Client.send_update_table_column_statistics(ColumnStatistics stats_obj) |
void |
ThriftHiveMetastore.update_table_column_statistics_args.setStats_obj(ColumnStatistics stats_obj) |
void |
ThriftHiveMetastore.update_partition_column_statistics_args.setStats_obj(ColumnStatistics stats_obj) |
void |
ThriftHiveMetastore.get_table_column_statistics_result.setSuccess(ColumnStatistics success) |
void |
ThriftHiveMetastore.get_partition_column_statistics_result.setSuccess(ColumnStatistics success) |
boolean |
ThriftHiveMetastore.Iface.update_partition_column_statistics(ColumnStatistics stats_obj) |
boolean |
ThriftHiveMetastore.Client.update_partition_column_statistics(ColumnStatistics stats_obj) |
void |
ThriftHiveMetastore.AsyncIface.update_partition_column_statistics(ColumnStatistics stats_obj,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.update_partition_column_statistics(ColumnStatistics stats_obj,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call> resultHandler) |
boolean |
ThriftHiveMetastore.Iface.update_table_column_statistics(ColumnStatistics stats_obj) |
boolean |
ThriftHiveMetastore.Client.update_table_column_statistics(ColumnStatistics stats_obj) |
void |
ThriftHiveMetastore.AsyncIface.update_table_column_statistics(ColumnStatistics stats_obj,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call> resultHandler) |
void |
ThriftHiveMetastore.AsyncClient.update_table_column_statistics(ColumnStatistics stats_obj,
org.apache.thrift.async.AsyncMethodCallback<ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call> resultHandler) |
Modifier and Type | Method and Description |
---|---|
void |
SetPartitionsStatsRequest.setColStats(List<ColumnStatistics> colStats) |
Constructor and Description |
---|
SetPartitionsStatsRequest(List<ColumnStatistics> colStats) |
Modifier and Type | Method and Description |
---|---|
boolean |
Hive.updatePartitionColumnStatistics(ColumnStatistics statsObj) |
boolean |
SessionHiveMetaStoreClient.updateTableColumnStatistics(ColumnStatistics statsObj)
Write table level column statistics to persistent store
|
boolean |
Hive.updateTableColumnStatistics(ColumnStatistics statsObj) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.