Package | Description |
---|---|
org.apache.flink.table.catalog.hive.util | |
org.apache.flink.table.catalog.stats | |
org.apache.flink.table.planner.utils |
Modifier and Type | Method and Description |
---|---|
static Map<String,CatalogColumnStatisticsDataBase> |
HiveStatsUtil.createCatalogColumnStats(List<org.apache.hadoop.hive.metastore.api.ColumnStatisticsObj> hiveColStats,
String hiveVersion)
Create a map of Flink column stats from the given Hive column stats.
|
static Map<String,CatalogColumnStatisticsDataBase> |
HiveStatsUtil.getCatalogPartitionColumnStats(HiveMetastoreClientWrapper client,
HiveShim hiveShim,
org.apache.hadoop.hive.metastore.api.Table hiveTable,
String partitionName,
List<org.apache.hadoop.hive.metastore.api.FieldSchema> partitionColsSchema,
String defaultPartitionName)
Get column statistic for partition columns.
|
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hive.metastore.api.ColumnStatistics |
HiveStatsUtil.createPartitionColumnStats(org.apache.hadoop.hive.metastore.api.Partition hivePartition,
String partName,
Map<String,CatalogColumnStatisticsDataBase> colStats,
String hiveVersion)
Create columnStatistics from the given Hive column stats of a hive partition.
|
static org.apache.hadoop.hive.metastore.api.ColumnStatistics |
HiveStatsUtil.createTableColumnStats(org.apache.hadoop.hive.metastore.api.Table hiveTable,
Map<String,CatalogColumnStatisticsDataBase> colStats,
String hiveVersion)
Create columnStatistics from the given Hive column stats of a hive table.
|
Modifier and Type | Class and Description |
---|---|
class |
CatalogColumnStatisticsDataBinary
Column statistics value of binary type.
|
class |
CatalogColumnStatisticsDataBoolean
Column statistics value of boolean type.
|
class |
CatalogColumnStatisticsDataDate
Column statistics value of date type.
|
class |
CatalogColumnStatisticsDataDouble
Column statistics value of double type.
|
class |
CatalogColumnStatisticsDataLong
Column statistics value of long type.
|
class |
CatalogColumnStatisticsDataString
Column statistics value of string type.
|
Modifier and Type | Method and Description |
---|---|
abstract CatalogColumnStatisticsDataBase |
CatalogColumnStatisticsDataBase.copy()
Create a deep copy of "this" instance.
|
Modifier and Type | Method and Description |
---|---|
Map<String,CatalogColumnStatisticsDataBase> |
CatalogColumnStatistics.getColumnStatisticsData() |
Constructor and Description |
---|
CatalogColumnStatistics(Map<String,CatalogColumnStatisticsDataBase> columnStatisticsData) |
CatalogColumnStatistics(Map<String,CatalogColumnStatisticsDataBase> columnStatisticsData,
Map<String,String> properties) |
Modifier and Type | Method and Description |
---|---|
static Map<String,ColumnStats> |
CatalogTableStatisticsConverter.convertToColumnStatsMap(Map<String,CatalogColumnStatisticsDataBase> columnStatisticsData) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.