Modifier and Type | Method and Description |
---|---|
static FieldSchema |
MetaStoreUtils.getFieldSchemaFromTypeInfo(String fieldName,
TypeInfo typeInfo)
Convert TypeInfo to FieldSchema.
|
Modifier and Type | Method and Description |
---|---|
protected List<FieldSchema> |
HiveMetaStoreClient.deepCopyFieldSchemas(List<FieldSchema> schemas) |
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_fields_with_environment_context(String db,
String tableName,
EnvironmentContext envContext) |
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_fields(String db,
String tableName) |
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_schema_with_environment_context(String db,
String tableName,
EnvironmentContext envContext)
Return the schema of the table.
|
List<FieldSchema> |
HiveMetaStore.HMSHandler.get_schema(String db,
String tableName)
Return the schema of the table.
|
List<FieldSchema> |
IMetaStoreClient.getFields(String db,
String tableName) |
List<FieldSchema> |
HiveMetaStoreClient.getFields(String db,
String tableName) |
static List<FieldSchema> |
MetaStoreUtils.getFieldsFromDeserializer(String tableName,
Deserializer deserializer) |
List<FieldSchema> |
IMetaStoreClient.getSchema(String db,
String tableName) |
List<FieldSchema> |
HiveMetaStoreClient.getSchema(String db,
String tableName) |
Modifier and Type | Method and Description |
---|---|
static boolean |
MetaStoreUtils.compareFieldColumns(List<FieldSchema> schema1,
List<FieldSchema> schema2) |
static boolean |
MetaStoreUtils.compareFieldColumns(List<FieldSchema> schema1,
List<FieldSchema> schema2) |
protected List<FieldSchema> |
HiveMetaStoreClient.deepCopyFieldSchemas(List<FieldSchema> schemas) |
static String |
MetaStoreUtils.getColumnCommentsFromFieldSchema(List<FieldSchema> fieldSchemas) |
static String |
MetaStoreUtils.getColumnNamesFromFieldSchema(List<FieldSchema> fieldSchemas)
Convert FieldSchemas to columnNames.
|
static String |
MetaStoreUtils.getColumnTypesFromFieldSchema(List<FieldSchema> fieldSchemas)
Convert FieldSchemas to columnTypes.
|
static String |
MetaStoreUtils.getDDLFromFieldSchema(String structName,
List<FieldSchema> fieldSchemas)
Convert FieldSchemas to Thrift DDL.
|
static String |
MetaStoreUtils.getFullDDLFromFieldSchema(String structName,
List<FieldSchema> fieldSchemas)
Convert FieldSchemas to Thrift DDL + column names and column types
|
static Properties |
MetaStoreUtils.getPartSchemaFromTableSchema(StorageDescriptor sd,
StorageDescriptor tblsd,
Map<String,String> parameters,
String databaseName,
String tableName,
List<FieldSchema> partitionKeys,
Properties tblSchema)
Get partition level schema from table level schema.
|
static List<String> |
MetaStoreUtils.getPvals(List<FieldSchema> partCols,
Map<String,String> partSpec)
Given a list of partition columns and a partial mapping from
some partition columns to values the function returns the values
for the column.
|
static Properties |
MetaStoreUtils.getSchema(StorageDescriptor sd,
StorageDescriptor tblsd,
Map<String,String> parameters,
String databaseName,
String tableName,
List<FieldSchema> partitionKeys) |
static String |
Warehouse.makePartName(List<FieldSchema> partCols,
List<String> vals) |
static String |
Warehouse.makePartName(List<FieldSchema> partCols,
List<String> vals,
String defaultStr)
Makes a valid partition name.
|
static Map<String,String> |
Warehouse.makeSpecFromValues(List<FieldSchema> partCols,
List<String> values) |
static String |
MetaStoreUtils.validateSkewedColNamesSubsetCol(List<String> skewedColNames,
List<FieldSchema> cols) |
static String |
MetaStoreUtils.validateTblColumns(List<FieldSchema> cols) |
Modifier and Type | Method and Description |
---|---|
FieldSchema |
FieldSchema.deepCopy() |
Modifier and Type | Method and Description |
---|---|
List<FieldSchema> |
ThriftHiveMetastore.Iface.get_fields_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
List<FieldSchema> |
ThriftHiveMetastore.Client.get_fields_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
List<FieldSchema> |
ThriftHiveMetastore.Iface.get_fields(String db_name,
String table_name) |
List<FieldSchema> |
ThriftHiveMetastore.Client.get_fields(String db_name,
String table_name) |
List<FieldSchema> |
ThriftHiveMetastore.Iface.get_schema_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
List<FieldSchema> |
ThriftHiveMetastore.Client.get_schema_with_environment_context(String db_name,
String table_name,
EnvironmentContext environment_context) |
List<FieldSchema> |
ThriftHiveMetastore.Iface.get_schema(String db_name,
String table_name) |
List<FieldSchema> |
ThriftHiveMetastore.Client.get_schema(String db_name,
String table_name) |
List<FieldSchema> |
StorageDescriptor.getCols() |
Iterator<FieldSchema> |
StorageDescriptor.getColsIterator() |
List<FieldSchema> |
Type.getFields() |
List<FieldSchema> |
Schema.getFieldSchemas() |
Iterator<FieldSchema> |
Schema.getFieldSchemasIterator() |
Iterator<FieldSchema> |
Type.getFieldsIterator() |
List<FieldSchema> |
Table.getPartitionKeys() |
Iterator<FieldSchema> |
Table.getPartitionKeysIterator() |
List<FieldSchema> |
ThriftHiveMetastore.AsyncClient.get_fields_call.getResult() |
List<FieldSchema> |
ThriftHiveMetastore.AsyncClient.get_fields_with_environment_context_call.getResult() |
List<FieldSchema> |
ThriftHiveMetastore.AsyncClient.get_schema_call.getResult() |
List<FieldSchema> |
ThriftHiveMetastore.AsyncClient.get_schema_with_environment_context_call.getResult() |
List<FieldSchema> |
ThriftHiveMetastore.get_fields_result.getSuccess() |
List<FieldSchema> |
ThriftHiveMetastore.get_fields_with_environment_context_result.getSuccess() |
List<FieldSchema> |
ThriftHiveMetastore.get_schema_result.getSuccess() |
List<FieldSchema> |
ThriftHiveMetastore.get_schema_with_environment_context_result.getSuccess() |
Iterator<FieldSchema> |
ThriftHiveMetastore.get_fields_result.getSuccessIterator() |
Iterator<FieldSchema> |
ThriftHiveMetastore.get_fields_with_environment_context_result.getSuccessIterator() |
Iterator<FieldSchema> |
ThriftHiveMetastore.get_schema_result.getSuccessIterator() |
Iterator<FieldSchema> |
ThriftHiveMetastore.get_schema_with_environment_context_result.getSuccessIterator() |
List<FieldSchema> |
ThriftHiveMetastore.Client.recv_get_fields_with_environment_context() |
List<FieldSchema> |
ThriftHiveMetastore.Client.recv_get_fields() |
List<FieldSchema> |
ThriftHiveMetastore.Client.recv_get_schema_with_environment_context() |
List<FieldSchema> |
ThriftHiveMetastore.Client.recv_get_schema() |
Modifier and Type | Method and Description |
---|---|
void |
StorageDescriptor.addToCols(FieldSchema elem) |
void |
Type.addToFields(FieldSchema elem) |
void |
Schema.addToFieldSchemas(FieldSchema elem) |
void |
Table.addToPartitionKeys(FieldSchema elem) |
void |
ThriftHiveMetastore.get_fields_result.addToSuccess(FieldSchema elem) |
void |
ThriftHiveMetastore.get_fields_with_environment_context_result.addToSuccess(FieldSchema elem) |
void |
ThriftHiveMetastore.get_schema_result.addToSuccess(FieldSchema elem) |
void |
ThriftHiveMetastore.get_schema_with_environment_context_result.addToSuccess(FieldSchema elem) |
int |
FieldSchema.compareTo(FieldSchema other) |
boolean |
FieldSchema.equals(FieldSchema that) |
Modifier and Type | Method and Description |
---|---|
void |
StorageDescriptor.setCols(List<FieldSchema> cols) |
void |
Type.setFields(List<FieldSchema> fields) |
void |
Schema.setFieldSchemas(List<FieldSchema> fieldSchemas) |
void |
Table.setPartitionKeys(List<FieldSchema> partitionKeys) |
void |
ThriftHiveMetastore.get_fields_result.setSuccess(List<FieldSchema> success) |
void |
ThriftHiveMetastore.get_fields_with_environment_context_result.setSuccess(List<FieldSchema> success) |
void |
ThriftHiveMetastore.get_schema_result.setSuccess(List<FieldSchema> success) |
void |
ThriftHiveMetastore.get_schema_with_environment_context_result.setSuccess(List<FieldSchema> success) |
Constructor and Description |
---|
FieldSchema(FieldSchema other)
Performs a deep copy on other.
|
Modifier and Type | Field and Description |
---|---|
List<FieldSchema> |
ArchiveUtils.PartSpecInfo.fields |
Modifier and Type | Method and Description |
---|---|
List<FieldSchema> |
ExplainTask.getResultSchema() |
List<FieldSchema> |
ExplainSQRewriteTask.getResultSchema() |
Modifier and Type | Method and Description |
---|---|
static List<String> |
Utilities.getColumnNamesFromFieldSchema(List<FieldSchema> partCols) |
static List<String> |
Utilities.getFieldSchemaString(List<FieldSchema> fl) |
Modifier and Type | Method and Description |
---|---|
FieldSchema |
LineageInfo.BaseColumnInfo.getColumn() |
FieldSchema |
LineageInfo.DependencyKey.getFieldSchema() |
Modifier and Type | Method and Description |
---|---|
LineageInfo.Dependency |
LineageInfo.getDependency(LineageInfo.DataContainer dc,
FieldSchema col)
Gets the dependency for a table, column tuple.
|
void |
LineageInfo.putDependency(LineageInfo.DataContainer dc,
FieldSchema col,
LineageInfo.Dependency dep)
Puts the dependency for a table, column tuple.
|
void |
LineageInfo.BaseColumnInfo.setColumn(FieldSchema column) |
Constructor and Description |
---|
LineageInfo.DependencyKey(LineageInfo.DataContainer dc,
FieldSchema fld)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
static String |
AbstractIndexHandler.getColumnNames(List<FieldSchema> fieldSchemas) |
protected Task<?> |
TableBasedIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs,
Set<WriteEntity> outputs,
List<FieldSchema> indexField,
boolean partitioned,
PartitionDesc indexTblPartDesc,
String indexTableName,
PartitionDesc baseTablePartDesc,
String baseTableName,
String dbName) |
Modifier and Type | Method and Description |
---|---|
protected Task<?> |
BitmapIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs,
Set<WriteEntity> outputs,
List<FieldSchema> indexField,
boolean partitioned,
PartitionDesc indexTblPartDesc,
String indexTableName,
PartitionDesc baseTablePartDesc,
String baseTableName,
String dbName) |
Modifier and Type | Method and Description |
---|---|
protected Task<?> |
CompactIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs,
Set<WriteEntity> outputs,
List<FieldSchema> indexField,
boolean partitioned,
PartitionDesc indexTblPartDesc,
String indexTableName,
PartitionDesc baseTablePartDesc,
String baseTableName,
String dbName) |
Modifier and Type | Method and Description |
---|---|
List<FieldSchema> |
Table.getAllCols()
Returns a list of all the columns of the table (data columns + partition
columns in that order.
|
List<FieldSchema> |
Table.getCols() |
List<FieldSchema> |
Partition.getCols() |
static List<FieldSchema> |
Hive.getFieldsFromDeserializer(String name,
Deserializer serde) |
List<FieldSchema> |
Table.getPartCols() |
List<FieldSchema> |
Table.getPartitionKeys() |
List<FieldSchema> |
SessionHiveMetaStoreClient.getSchema(String dbName,
String tableName) |
Modifier and Type | Method and Description |
---|---|
static String |
HiveUtils.getUnparsedColumnNamesFromFieldSchema(List<FieldSchema> fieldSchemas)
Convert FieldSchemas to columnNames with backticks around them.
|
void |
Table.setFields(List<FieldSchema> fields) |
void |
Table.setPartCols(List<FieldSchema> partCols) |
static void |
Table.validateColumns(List<FieldSchema> columns,
List<FieldSchema> partCols) |
static void |
Table.validateColumns(List<FieldSchema> columns,
List<FieldSchema> partCols) |
Modifier and Type | Method and Description |
---|---|
void |
MetaDataFormatter.describeTable(DataOutputStream out,
String colPath,
String tableName,
Table tbl,
Partition part,
List<FieldSchema> cols,
boolean isFormatted,
boolean isExt,
boolean isPretty,
boolean isOutputPadded,
List<ColumnStatisticsObj> colStats)
Describe table.
|
void |
JsonMetaDataFormatter.describeTable(DataOutputStream out,
String colPath,
String tableName,
Table tbl,
Partition part,
List<FieldSchema> cols,
boolean isFormatted,
boolean isExt,
boolean isPretty,
boolean isOutputPadded,
List<ColumnStatisticsObj> colStats)
Describe table.
|
static String |
MetaDataFormatUtils.getAllColumnsInformation(List<FieldSchema> cols,
boolean printHeader,
boolean isOutputPadded,
List<ColumnStatisticsObj> colStats)
Write formatted information about the given columns to a string
|
static String |
MetaDataFormatUtils.getAllColumnsInformation(List<FieldSchema> cols,
List<FieldSchema> partCols,
boolean printHeader,
boolean isOutputPadded,
boolean showPartColsSep)
Write formatted information about the given columns, including partition
columns to a string
|
static String |
MetaDataFormatUtils.getAllColumnsInformation(List<FieldSchema> cols,
List<FieldSchema> partCols,
boolean printHeader,
boolean isOutputPadded,
boolean showPartColsSep)
Write formatted information about the given columns, including partition
columns to a string
|
static String |
MetaDataPrettyFormatUtils.getAllColumnsInformation(List<FieldSchema> cols,
List<FieldSchema> partCols,
int prettyOutputNumCols) |
static String |
MetaDataPrettyFormatUtils.getAllColumnsInformation(List<FieldSchema> cols,
List<FieldSchema> partCols,
int prettyOutputNumCols) |
Modifier and Type | Method and Description |
---|---|
static com.google.common.collect.ImmutableMap<String,Integer> |
HiveCalciteUtil.getColNameIndxMap(List<FieldSchema> tableFields) |
Modifier and Type | Method and Description |
---|---|
static ASTNode |
ASTConverter.convert(org.apache.calcite.rel.RelNode relNode,
List<FieldSchema> resultSchema) |
static org.apache.calcite.rel.RelNode |
PlanModifierForReturnPath.convertOpTree(org.apache.calcite.rel.RelNode rel,
List<FieldSchema> resultSchema) |
static org.apache.calcite.rel.RelNode |
PlanModifierForASTConv.convertOpTree(org.apache.calcite.rel.RelNode rel,
List<FieldSchema> resultSchema) |
protected static void |
PlanModifierUtil.fixTopOBSchema(org.apache.calcite.rel.RelNode rootRel,
org.apache.calcite.util.Pair<org.apache.calcite.rel.RelNode,org.apache.calcite.rel.RelNode> topSelparentPair,
List<FieldSchema> resultSchema,
boolean replaceProject) |
protected static String |
PlanModifierUtil.generateInvalidSchemaMessage(org.apache.calcite.rel.core.Project topLevelProj,
List<FieldSchema> resultSchema,
int fieldsForOB) |
Modifier and Type | Method and Description |
---|---|
protected List<FieldSchema> |
BaseSemanticAnalyzer.getColumns(ASTNode ast) |
static List<FieldSchema> |
BaseSemanticAnalyzer.getColumns(ASTNode ast,
boolean lowerCase)
Get the list of FieldSchema out of the ASTNode.
|
List<FieldSchema> |
SemanticAnalyzer.getResultSchema() |
List<FieldSchema> |
ExplainSQRewriteSemanticAnalyzer.getResultSchema() |
List<FieldSchema> |
ExplainSemanticAnalyzer.getResultSchema() |
List<FieldSchema> |
BaseSemanticAnalyzer.getResultSchema() |
Modifier and Type | Method and Description |
---|---|
static Map<String,String> |
EximUtil.makePartSpec(List<FieldSchema> partCols,
List<String> partVals)
Return the partition specification from the specified keys and values
|
static boolean |
EximUtil.schemaCompare(List<FieldSchema> newSchema,
List<FieldSchema> oldSchema)
Compares the schemas - names, types and order, but ignoring comments
|
static boolean |
EximUtil.schemaCompare(List<FieldSchema> newSchema,
List<FieldSchema> oldSchema)
Compares the schemas - names, types and order, but ignoring comments
|
static List<String> |
ParseUtils.validateColumnNameUniqueness(List<FieldSchema> fieldSchemas) |
Modifier and Type | Method and Description |
---|---|
FieldSchema |
AlterTableAlterPartDesc.getPartKeySpec() |
Modifier and Type | Method and Description |
---|---|
List<FieldSchema> |
CreateTableDesc.getCols() |
List<FieldSchema> |
AddPartitionDesc.OnePartitionDesc.getCols() |
static List<FieldSchema> |
PlanUtils.getFieldSchemasFromColumnInfo(ArrayList<ColumnInfo> cols,
String fieldPrefix)
Convert the ColumnInfo to FieldSchema.
|
static List<FieldSchema> |
PlanUtils.getFieldSchemasFromColumnList(List<ExprNodeDesc> cols,
List<String> outputColumnNames,
int start,
String fieldPrefix)
Convert the ColumnList to FieldSchema list.
|
static List<FieldSchema> |
PlanUtils.getFieldSchemasFromColumnList(List<ExprNodeDesc> cols,
String fieldPrefix)
Convert the ColumnList to FieldSchema list.
|
static List<FieldSchema> |
PlanUtils.getFieldSchemasFromColumnListWithLength(List<ExprNodeDesc> cols,
List<List<Integer>> distinctColIndices,
List<String> outputColumnNames,
int length,
String fieldPrefix)
Convert the ColumnList to FieldSchema list.
|
static List<FieldSchema> |
PlanUtils.getFieldSchemasFromRowSchema(RowSchema row,
String fieldPrefix)
Convert the RowSchema to FieldSchema list.
|
ArrayList<FieldSchema> |
AlterTableDesc.getNewCols() |
List<FieldSchema> |
CreateViewDesc.getPartCols() |
List<FieldSchema> |
CreateTableDesc.getPartCols() |
List<FieldSchema> |
CreateViewDesc.getSchema() |
static List<FieldSchema> |
PlanUtils.sortFieldSchemas(List<FieldSchema> schema) |
Modifier and Type | Method and Description |
---|---|
void |
AlterTableAlterPartDesc.setPartKeySpec(FieldSchema partKeySpec) |
Modifier and Type | Method and Description |
---|---|
static TableDesc |
PlanUtils.getIntermediateFileTableDesc(List<FieldSchema> fieldSchemas)
Generate the table descriptor for intermediate files.
|
static TableDesc |
PlanUtils.getMapJoinKeyTableDesc(org.apache.hadoop.conf.Configuration conf,
List<FieldSchema> fieldSchemas)
Generate the table descriptor for Map-side join key.
|
static TableDesc |
PlanUtils.getMapJoinValueTableDesc(List<FieldSchema> fieldSchemas)
Generate the table descriptor for Map-side join value.
|
static TableDesc |
PlanUtils.getReduceKeyTableDesc(List<FieldSchema> fieldSchemas,
String order)
Generate the table descriptor for reduce key.
|
static TableDesc |
PlanUtils.getReduceValueTableDesc(List<FieldSchema> fieldSchemas)
Generate the table descriptor for intermediate files.
|
void |
CreateTableDesc.setCols(ArrayList<FieldSchema> cols) |
void |
AddPartitionDesc.OnePartitionDesc.setCols(List<FieldSchema> cols) |
void |
AlterTableDesc.setNewCols(ArrayList<FieldSchema> newCols) |
void |
CreateTableDesc.setPartCols(ArrayList<FieldSchema> partCols) |
void |
CreateViewDesc.setPartCols(List<FieldSchema> partCols) |
void |
CreateViewDesc.setSchema(List<FieldSchema> schema) |
static List<FieldSchema> |
PlanUtils.sortFieldSchemas(List<FieldSchema> schema) |
Constructor and Description |
---|
AlterTableAlterPartDesc(String tableName,
FieldSchema partKeySpec) |
Constructor and Description |
---|
AlterTableDesc(String name,
HashMap<String,String> partSpec,
List<FieldSchema> newCols,
AlterTableDesc.AlterTableTypes alterType,
boolean isCascade) |
CreateTableDesc(String tableName,
boolean isExternal,
boolean isTemporary,
List<FieldSchema> cols,
List<FieldSchema> partCols,
List<String> bucketCols,
List<Order> sortCols,
int numBuckets,
String fieldDelim,
String fieldEscape,
String collItemDelim,
String mapKeyDelim,
String lineDelim,
String comment,
String inputFormat,
String outputFormat,
String location,
String serName,
String storageHandler,
Map<String,String> serdeProps,
Map<String,String> tblProps,
boolean ifNotExists,
List<String> skewedColNames,
List<List<String>> skewedColValues) |
CreateTableDesc(String tableName,
boolean isExternal,
boolean isTemporary,
List<FieldSchema> cols,
List<FieldSchema> partCols,
List<String> bucketCols,
List<Order> sortCols,
int numBuckets,
String fieldDelim,
String fieldEscape,
String collItemDelim,
String mapKeyDelim,
String lineDelim,
String comment,
String inputFormat,
String outputFormat,
String location,
String serName,
String storageHandler,
Map<String,String> serdeProps,
Map<String,String> tblProps,
boolean ifNotExists,
List<String> skewedColNames,
List<List<String>> skewedColValues) |
CreateTableDesc(String databaseName,
String tableName,
boolean isExternal,
boolean isTemporary,
List<FieldSchema> cols,
List<FieldSchema> partCols,
List<String> bucketCols,
List<Order> sortCols,
int numBuckets,
String fieldDelim,
String fieldEscape,
String collItemDelim,
String mapKeyDelim,
String lineDelim,
String comment,
String inputFormat,
String outputFormat,
String location,
String serName,
String storageHandler,
Map<String,String> serdeProps,
Map<String,String> tblProps,
boolean ifNotExists,
List<String> skewedColNames,
List<List<String>> skewedColValues) |
CreateTableDesc(String databaseName,
String tableName,
boolean isExternal,
boolean isTemporary,
List<FieldSchema> cols,
List<FieldSchema> partCols,
List<String> bucketCols,
List<Order> sortCols,
int numBuckets,
String fieldDelim,
String fieldEscape,
String collItemDelim,
String mapKeyDelim,
String lineDelim,
String comment,
String inputFormat,
String outputFormat,
String location,
String serName,
String storageHandler,
Map<String,String> serdeProps,
Map<String,String> tblProps,
boolean ifNotExists,
List<String> skewedColNames,
List<List<String>> skewedColValues) |
CreateViewDesc(String viewName,
List<FieldSchema> schema,
String comment,
Map<String,String> tblProps,
List<String> partColNames,
boolean ifNotExists,
boolean orReplace,
boolean isAlterViewAs) |
Modifier and Type | Method and Description |
---|---|
void |
LineageState.setLineage(org.apache.hadoop.fs.Path dir,
LineageInfo.DataContainer dc,
List<FieldSchema> cols)
Set the lineage information for the associated directory.
|
Modifier and Type | Method and Description |
---|---|
static List<FieldSchema> |
HCatUtil.getFieldSchemaList(List<HCatFieldSchema> hcatFields) |
static List<FieldSchema> |
HCatUtil.validatePartitionSchema(Table table,
HCatSchema partitionSchema)
Validate partition schema, checks if the column types match between the
partition and the existing table schema.
|
Modifier and Type | Method and Description |
---|---|
static List<HCatFieldSchema> |
HCatUtil.getHCatFieldSchemaList(FieldSchema... fields) |
Modifier and Type | Method and Description |
---|---|
static List<HCatFieldSchema> |
HCatUtil.getHCatFieldSchemaList(List<FieldSchema> fields) |
Modifier and Type | Method and Description |
---|---|
static FieldSchema |
HCatSchemaUtils.getFieldSchema(HCatFieldSchema hcatFieldSchema) |
Modifier and Type | Method and Description |
---|---|
static List<FieldSchema> |
HCatSchemaUtils.getFieldSchemas(List<HCatFieldSchema> hcatFieldSchemas) |
Modifier and Type | Method and Description |
---|---|
HCatSchemaUtils.CollectionBuilder |
HCatSchemaUtils.CollectionBuilder.addField(FieldSchema fieldSchema) |
static HCatFieldSchema |
HCatSchemaUtils.getHCatFieldSchema(FieldSchema fs)
Convert a HCatFieldSchema to a FieldSchema
|
Modifier and Type | Method and Description |
---|---|
static HCatSchema |
HCatSchemaUtils.getHCatSchema(List<? extends FieldSchema> fslist) |
Constructor and Description |
---|
ColumnDescriptor(FieldSchema column,
int position) |
Constructor and Description |
---|
TableSchema(List<FieldSchema> fieldSchemas) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.