public class HiveShimV310 extends HiveShimV239
Modifier and Type | Field and Description |
---|---|
protected int |
stmtIdInLoadTableOrPartition |
protected long |
writeIdInLoadTableOrPartition |
hasFollowingStatsTask
holdDDLTime, inheritTableSpecs, isAcid, isSkewedStoreAsSubdir
Constructor and Description |
---|
HiveShimV310() |
Modifier and Type | Method and Description |
---|---|
void |
createTableWithConstraints(org.apache.hadoop.hive.metastore.IMetaStoreClient client,
org.apache.hadoop.hive.metastore.api.Table table,
org.apache.hadoop.conf.Configuration conf,
UniqueConstraint pk,
List<Byte> pkTraits,
List<String> notNullCols,
List<Byte> nnTraits)
Creates a table with PK and NOT NULL constraints.
|
Class<?> |
getDateDataTypeClass()
Hive Date data type class was changed in Hive 3.1.0.
|
Class<?> |
getDateWritableClass()
Gets writable class for Date type.
|
org.apache.hadoop.hive.metastore.IMetaStoreClient |
getHiveMetastoreClient(HiveConf hiveConf)
Create a Hive Metastore client based on the given HiveConf object.
|
Class<?> |
getHiveMetaStoreUtilsClass()
Get the class of Hive's HiveMetaStoreUtils as it was split from MetaStoreUtils class in Hive
3.1.0.
|
Class<?> |
getMetaStoreUtilsClass()
Get the class of Hive's MetaStoreUtils because its package name was changed in Hive 3.1.0.
|
Set<String> |
getNotNullColumns(org.apache.hadoop.hive.metastore.IMetaStoreClient client,
org.apache.hadoop.conf.Configuration conf,
String dbName,
String tableName)
Get the set of columns that have NOT NULL constraints.
|
Class<?> |
getTimestampDataTypeClass()
Hive Timestamp data type class was changed in Hive 3.1.0.
|
Class<?> |
getTimestampWritableClass()
Gets writable class for Timestamp type.
|
org.apache.hadoop.io.Writable |
hivePrimitiveToWritable(Object value)
Converts a Hive primitive java object to corresponding Writable 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) |
java.time.LocalDate |
toFlinkDate(Object hiveDate)
Converts a hive date instance to LocalDate which is expected by DataFormatConverter.
|
java.time.LocalDateTime |
toFlinkTimestamp(Object hiveTimestamp)
Converts a hive timestamp instance to LocalDateTime which is expected by DataFormatConverter.
|
Object |
toHiveDate(Object flinkDate)
Converts a Flink date instance to what's expected by Hive.
|
Object |
toHiveTimestamp(Object flinkTimestamp)
Converts a Flink timestamp instance to what's expected by Hive.
|
alterTable, createUDAFParameterInfo, getViews, isMaterializedView
alterPartition, getPrimaryKey
createOrcBulkWriterFactory
getIntervalDayTimeTypeInfo, getIntervalYearMonthTypeInfo, isDateStats, isIntervalDayTimeType, isIntervalYearMonthType, listBuiltInFunctions, registerTemporaryFunction, toFlinkDateColStats, toHiveDateColStats
getFieldsFromDeserializer, getHiveOutputFormatClass, getHiveRecordWriter
getBuiltInFunctionInfo
protected final long writeIdInLoadTableOrPartition
protected final int stmtIdInLoadTableOrPartition
public org.apache.hadoop.hive.metastore.IMetaStoreClient getHiveMetastoreClient(HiveConf hiveConf)
HiveShim
getHiveMetastoreClient
in interface HiveShim
getHiveMetastoreClient
in class HiveShimV230
hiveConf
- HiveConf instancepublic Class<?> getMetaStoreUtilsClass()
HiveShim
getMetaStoreUtilsClass
in interface HiveShim
getMetaStoreUtilsClass
in class HiveShimV100
public Class<?> getHiveMetaStoreUtilsClass()
HiveShim
getHiveMetaStoreUtilsClass
in interface HiveShim
getHiveMetaStoreUtilsClass
in class HiveShimV100
public Class<?> getDateDataTypeClass()
HiveShim
getDateDataTypeClass
in interface HiveShim
getDateDataTypeClass
in class HiveShimV100
public Class<?> getDateWritableClass()
HiveShim
getDateWritableClass
in interface HiveShim
getDateWritableClass
in class HiveShimV100
public Class<?> getTimestampDataTypeClass()
HiveShim
getTimestampDataTypeClass
in interface HiveShim
getTimestampDataTypeClass
in class HiveShimV100
public Class<?> getTimestampWritableClass()
HiveShim
getTimestampWritableClass
in interface HiveShim
getTimestampWritableClass
in class HiveShimV100
public Set<String> getNotNullColumns(org.apache.hadoop.hive.metastore.IMetaStoreClient client, org.apache.hadoop.conf.Configuration conf, String dbName, String tableName)
HiveShim
getNotNullColumns
in interface HiveShim
getNotNullColumns
in class HiveShimV100
public Object toHiveTimestamp(Object flinkTimestamp)
HiveShim
toHiveTimestamp
in interface HiveShim
toHiveTimestamp
in class HiveShimV100
public java.time.LocalDateTime toFlinkTimestamp(Object hiveTimestamp)
HiveShim
toFlinkTimestamp
in interface HiveShim
toFlinkTimestamp
in class HiveShimV100
public Object toHiveDate(Object flinkDate)
HiveShim
toHiveDate
in interface HiveShim
toHiveDate
in class HiveShimV100
public java.time.LocalDate toFlinkDate(Object hiveDate)
HiveShim
toFlinkDate
in interface HiveShim
toFlinkDate
in class HiveShimV100
public org.apache.hadoop.io.Writable hivePrimitiveToWritable(Object value)
HiveShim
hivePrimitiveToWritable
in interface HiveShim
hivePrimitiveToWritable
in class HiveShimV100
public void createTableWithConstraints(org.apache.hadoop.hive.metastore.IMetaStoreClient client, org.apache.hadoop.hive.metastore.api.Table table, org.apache.hadoop.conf.Configuration conf, UniqueConstraint pk, List<Byte> pkTraits, List<String> notNullCols, List<Byte> nnTraits)
HiveShim
createTableWithConstraints
in interface HiveShim
createTableWithConstraints
in class HiveShimV210
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 HiveShimV210
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 HiveShimV210
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.