public class HiveShimV110 extends HiveShimV101
holdDDLTime, inheritTableSpecs, isAcid, isSkewedStoreAsSubdir
Constructor and Description |
---|
HiveShimV110() |
Modifier and Type | Method and Description |
---|---|
List<org.apache.hadoop.hive.metastore.api.FieldSchema> |
getFieldsFromDeserializer(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.hive.metastore.api.Table table,
boolean skipConfError)
Get Hive table schema from deserializer.
|
Class |
getHiveOutputFormatClass(Class outputFormatClz)
For a given OutputFormat class, get the corresponding
HiveOutputFormat class. |
org.apache.hadoop.hive.ql.exec.FileSinkOperator.RecordWriter |
getHiveRecordWriter(org.apache.hadoop.mapred.JobConf jobConf,
Class outputFormatClz,
Class<? extends org.apache.hadoop.io.Writable> outValClz,
boolean isCompressed,
Properties tableProps,
org.apache.hadoop.fs.Path outPath)
Get Hive's FileSinkOperator.RecordWriter.
|
alterPartition, alterTable, createOrcBulkWriterFactory, createTableWithConstraints, createUDAFParameterInfo, getBuiltInFunctionInfo, getDateDataTypeClass, getDateWritableClass, getHiveMetastoreClient, getHiveMetaStoreUtilsClass, getMetaStoreUtilsClass, getNotNullColumns, getPrimaryKey, getTimestampDataTypeClass, getTimestampWritableClass, getViews, hivePrimitiveToWritable, isDateStats, listBuiltInFunctions, loadPartition, loadTable, registerTemporaryFunction, toFlinkDate, toFlinkDateColStats, toFlinkTimestamp, toHiveDate, toHiveDateColStats, toHiveTimestamp
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getIntervalDayTimeTypeInfo, getIntervalYearMonthTypeInfo, isIntervalDayTimeType, isIntervalYearMonthType, isMaterializedView
public org.apache.hadoop.hive.ql.exec.FileSinkOperator.RecordWriter getHiveRecordWriter(org.apache.hadoop.mapred.JobConf jobConf, Class outputFormatClz, Class<? extends org.apache.hadoop.io.Writable> outValClz, boolean isCompressed, Properties tableProps, org.apache.hadoop.fs.Path outPath)
HiveShim
getHiveRecordWriter
in interface HiveShim
getHiveRecordWriter
in class HiveShimV100
public Class getHiveOutputFormatClass(Class outputFormatClz)
HiveShim
HiveOutputFormat
class.getHiveOutputFormatClass
in interface HiveShim
getHiveOutputFormatClass
in class HiveShimV100
public List<org.apache.hadoop.hive.metastore.api.FieldSchema> getFieldsFromDeserializer(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hive.metastore.api.Table table, boolean skipConfError)
HiveShim
getFieldsFromDeserializer
in interface HiveShim
getFieldsFromDeserializer
in class HiveShimV100
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.