public class HiveShimV200 extends HiveShimV122
holdDDLTime, inheritTableSpecs, isAcid, isSkewedStoreAsSubdir
Constructor and Description |
---|
HiveShimV200() |
Modifier and Type | Method and Description |
---|---|
BulkWriter.Factory<RowData> |
createOrcBulkWriterFactory(org.apache.hadoop.conf.Configuration conf,
String schema,
LogicalType[] fieldTypes)
Create orc
BulkWriter.Factory for different hive versions. |
org.apache.hadoop.hive.metastore.IMetaStoreClient |
getHiveMetastoreClient(HiveConf hiveConf)
Create a Hive Metastore client based on the given HiveConf object.
|
void |
loadPartition(org.apache.hadoop.hive.ql.metadata.Hive hive,
org.apache.hadoop.fs.Path loadPath,
String tableName,
Map<String,String> partSpec,
boolean isSkewedStoreAsSubdir,
boolean replace,
boolean isSrcLocal) |
void |
loadTable(org.apache.hadoop.hive.ql.metadata.Hive hive,
org.apache.hadoop.fs.Path loadPath,
String tableName,
boolean replace,
boolean isSrcLocal) |
alterTable, getIntervalDayTimeTypeInfo, getIntervalYearMonthTypeInfo, isDateStats, isIntervalDayTimeType, isIntervalYearMonthType, listBuiltInFunctions, registerTemporaryFunction, toFlinkDateColStats, toHiveDateColStats
getFieldsFromDeserializer, getHiveOutputFormatClass, getHiveRecordWriter
alterPartition, createTableWithConstraints, createUDAFParameterInfo, getBuiltInFunctionInfo, getDateDataTypeClass, getDateWritableClass, getHiveMetaStoreUtilsClass, getMetaStoreUtilsClass, getNotNullColumns, getPrimaryKey, getTimestampDataTypeClass, getTimestampWritableClass, getViews, hivePrimitiveToWritable, toFlinkDate, toFlinkTimestamp, toHiveDate, toHiveTimestamp
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
isMaterializedView
public org.apache.hadoop.hive.metastore.IMetaStoreClient getHiveMetastoreClient(HiveConf hiveConf)
HiveShim
getHiveMetastoreClient
in interface HiveShim
getHiveMetastoreClient
in class HiveShimV120
hiveConf
- HiveConf instancepublic BulkWriter.Factory<RowData> createOrcBulkWriterFactory(org.apache.hadoop.conf.Configuration conf, String schema, LogicalType[] fieldTypes)
HiveShim
BulkWriter.Factory
for different hive versions.createOrcBulkWriterFactory
in interface HiveShim
createOrcBulkWriterFactory
in class HiveShimV100
public void loadTable(org.apache.hadoop.hive.ql.metadata.Hive hive, org.apache.hadoop.fs.Path loadPath, String tableName, boolean replace, boolean isSrcLocal)
loadTable
in interface HiveShim
loadTable
in class HiveShimV100
public void loadPartition(org.apache.hadoop.hive.ql.metadata.Hive hive, org.apache.hadoop.fs.Path loadPath, String tableName, Map<String,String> partSpec, boolean isSkewedStoreAsSubdir, boolean replace, boolean isSrcLocal)
loadPartition
in interface HiveShim
loadPartition
in class HiveShimV100
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.