public class HiveShimV210 extends HiveShimV201
Modifier and Type | Field and Description |
---|---|
protected boolean |
hasFollowingStatsTask |
holdDDLTime, inheritTableSpecs, isAcid, isSkewedStoreAsSubdir
Constructor and Description |
---|
HiveShimV210() |
Modifier and Type | Method and Description |
---|---|
void |
alterPartition(org.apache.hadoop.hive.metastore.IMetaStoreClient client,
String databaseName,
String tableName,
org.apache.hadoop.hive.metastore.api.Partition partition) |
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.
|
Optional<UniqueConstraint> |
getPrimaryKey(org.apache.hadoop.hive.metastore.IMetaStoreClient client,
String dbName,
String tableName,
byte requiredTrait)
Get the primary key of a Hive table and convert it to a UniqueConstraint.
|
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) |
createOrcBulkWriterFactory, getHiveMetastoreClient
alterTable, getIntervalDayTimeTypeInfo, getIntervalYearMonthTypeInfo, isDateStats, isIntervalDayTimeType, isIntervalYearMonthType, listBuiltInFunctions, registerTemporaryFunction, toFlinkDateColStats, toHiveDateColStats
getFieldsFromDeserializer, getHiveOutputFormatClass, getHiveRecordWriter
createUDAFParameterInfo, getBuiltInFunctionInfo, getDateDataTypeClass, getDateWritableClass, getHiveMetaStoreUtilsClass, getMetaStoreUtilsClass, getNotNullColumns, getTimestampDataTypeClass, getTimestampWritableClass, getViews, hivePrimitiveToWritable, toFlinkDate, toFlinkTimestamp, toHiveDate, toHiveTimestamp
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
isMaterializedView
protected final boolean hasFollowingStatsTask
public void alterPartition(org.apache.hadoop.hive.metastore.IMetaStoreClient client, String databaseName, String tableName, org.apache.hadoop.hive.metastore.api.Partition partition) throws org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
alterPartition
in interface HiveShim
alterPartition
in class HiveShimV100
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public Optional<UniqueConstraint> getPrimaryKey(org.apache.hadoop.hive.metastore.IMetaStoreClient client, String dbName, String tableName, byte requiredTrait)
HiveShim
getPrimaryKey
in interface HiveShim
getPrimaryKey
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 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 HiveShimV200
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 HiveShimV200
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.