Uses of Class
org.apache.hadoop.hive.metastore.api.FieldSchema

Packages that use FieldSchema
org.apache.hadoop.hive.metastore   
org.apache.hadoop.hive.metastore.api   
org.apache.hadoop.hive.ql.exec Hive QL execution tasks, operators, functions and other handlers. 
org.apache.hadoop.hive.ql.hooks   
org.apache.hadoop.hive.ql.index   
org.apache.hadoop.hive.ql.index.bitmap   
org.apache.hadoop.hive.ql.index.compact   
org.apache.hadoop.hive.ql.metadata   
org.apache.hadoop.hive.ql.metadata.formatting   
org.apache.hadoop.hive.ql.parse   
org.apache.hadoop.hive.ql.plan   
org.apache.hadoop.hive.ql.session   
 

Uses of FieldSchema in org.apache.hadoop.hive.metastore
 

Methods in org.apache.hadoop.hive.metastore that return FieldSchema
static FieldSchema MetaStoreUtils.getFieldSchemaFromTypeInfo(String fieldName, TypeInfo typeInfo)
          Convert TypeInfo to FieldSchema.
 

Methods in org.apache.hadoop.hive.metastore that return types with arguments of type FieldSchema
 List<FieldSchema> HiveMetaStore.HMSHandler.get_fields(String db, String tableName)
           
 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)
           
 

Method parameters in org.apache.hadoop.hive.metastore with type arguments of type FieldSchema
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 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 boolean MetaStoreUtils.validateColNames(List<FieldSchema> cols)
           
static boolean MetaStoreUtils.validateSkewedColNamesSubsetCol(List<String> skewedColNames, List<FieldSchema> cols)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.metastore.api
 

Methods in org.apache.hadoop.hive.metastore.api that return FieldSchema
 FieldSchema FieldSchema.deepCopy()
           
 

Methods in org.apache.hadoop.hive.metastore.api that return types with arguments of type FieldSchema
 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(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_schema_call.getResult()
           
 List<FieldSchema> ThriftHiveMetastore.get_fields_result.getSuccess()
           
 List<FieldSchema> ThriftHiveMetastore.get_schema_result.getSuccess()
           
 Iterator<FieldSchema> ThriftHiveMetastore.get_fields_result.getSuccessIterator()
           
 Iterator<FieldSchema> ThriftHiveMetastore.get_schema_result.getSuccessIterator()
           
 List<FieldSchema> ThriftHiveMetastore.Client.recv_get_fields()
           
 List<FieldSchema> ThriftHiveMetastore.Client.recv_get_schema()
           
 

Methods in org.apache.hadoop.hive.metastore.api with parameters of type FieldSchema
 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_schema_result.addToSuccess(FieldSchema elem)
           
 int FieldSchema.compareTo(FieldSchema other)
           
 boolean FieldSchema.equals(FieldSchema that)
           
 

Method parameters in org.apache.hadoop.hive.metastore.api with type arguments of type FieldSchema
 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_schema_result.setSuccess(List<FieldSchema> success)
           
 

Constructors in org.apache.hadoop.hive.metastore.api with parameters of type FieldSchema
FieldSchema(FieldSchema other)
          Performs a deep copy on other.
 

Constructor parameters in org.apache.hadoop.hive.metastore.api with type arguments of type FieldSchema
Schema(List<FieldSchema> fieldSchemas, Map<String,String> properties)
           
StorageDescriptor(List<FieldSchema> cols, String location, String inputFormat, String outputFormat, boolean compressed, int numBuckets, SerDeInfo serdeInfo, List<String> bucketCols, List<Order> sortCols, Map<String,String> parameters)
           
Table(String tableName, String dbName, String owner, int createTime, int lastAccessTime, int retention, StorageDescriptor sd, List<FieldSchema> partitionKeys, Map<String,String> parameters, String viewOriginalText, String viewExpandedText, String tableType)
           
ThriftHiveMetastore.get_fields_result(List<FieldSchema> success, MetaException o1, UnknownTableException o2, UnknownDBException o3)
           
ThriftHiveMetastore.get_schema_result(List<FieldSchema> success, MetaException o1, UnknownTableException o2, UnknownDBException o3)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.exec
 

Fields in org.apache.hadoop.hive.ql.exec with type parameters of type FieldSchema
 List<FieldSchema> ArchiveUtils.PartSpecInfo.fields
           
 

Methods in org.apache.hadoop.hive.ql.exec that return types with arguments of type FieldSchema
 List<FieldSchema> ExplainTask.getResultSchema()
           
 List<FieldSchema> Task.getResultSchema()
           
 

Method parameters in org.apache.hadoop.hive.ql.exec with type arguments of type FieldSchema
static List<String> Utilities.getColumnNamesFromFieldSchema(List<FieldSchema> partCols)
           
static List<String> Utilities.getFieldSchemaString(List<FieldSchema> fl)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.hooks
 

Methods in org.apache.hadoop.hive.ql.hooks that return FieldSchema
 FieldSchema LineageInfo.BaseColumnInfo.getColumn()
           
 FieldSchema LineageInfo.DependencyKey.getFieldSchema()
           
 

Methods in org.apache.hadoop.hive.ql.hooks with parameters of type FieldSchema
 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)
           
 

Constructors in org.apache.hadoop.hive.ql.hooks with parameters of type FieldSchema
LineageInfo.DependencyKey(LineageInfo.DataContainer dc, FieldSchema fld)
          Constructor.
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.index
 

Method parameters in org.apache.hadoop.hive.ql.index with type arguments of type FieldSchema
static String AbstractIndexHandler.getColumnNames(List<FieldSchema> fieldSchemas)
           
protected  Task<?> AggregateIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs, Set<WriteEntity> outputs, List<FieldSchema> indexField, boolean partitioned, PartitionDesc indexTblPartDesc, String indexTableName, PartitionDesc baseTablePartDesc, String baseTableName, String dbName)
           
protected abstract  Task<?> TableBasedIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs, Set<WriteEntity> outputs, List<FieldSchema> indexField, boolean partitioned, PartitionDesc indexTblPartDesc, String indexTableName, PartitionDesc baseTablePartDesc, String baseTableName, String dbName)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.index.bitmap
 

Method parameters in org.apache.hadoop.hive.ql.index.bitmap with type arguments of type FieldSchema
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)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.index.compact
 

Method parameters in org.apache.hadoop.hive.ql.index.compact with type arguments of type FieldSchema
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)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.metadata
 

Methods in org.apache.hadoop.hive.ql.metadata that return types with arguments of type FieldSchema
 List<FieldSchema> Table.getAllCols()
          Returns a list of all the columns of the table (data columns + partition columns in that order.
 List<FieldSchema> Partition.getCols()
           
 List<FieldSchema> Table.getCols()
           
static List<FieldSchema> Hive.getFieldsFromDeserializer(String name, Deserializer serde)
           
 List<FieldSchema> Table.getPartCols()
           
 List<FieldSchema> Table.getPartitionKeys()
           
 

Method parameters in org.apache.hadoop.hive.ql.metadata with type arguments of type FieldSchema
 Partition Hive.createPartition(Table tbl, Map<String,String> partSpec, org.apache.hadoop.fs.Path location, Map<String,String> partParams, String inputFormat, String outputFormat, int numBuckets, List<FieldSchema> cols, String serializationLib, Map<String,String> serdeParams, List<String> bucketCols, List<Order> sortCols)
          Creates a partition
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)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.metadata.formatting
 

Method parameters in org.apache.hadoop.hive.ql.metadata.formatting with type arguments of type FieldSchema
 void JsonMetaDataFormatter.describeTable(DataOutputStream out, String colPath, String tableName, Table tbl, Partition part, List<FieldSchema> cols, boolean isFormatted, boolean isExt)
          Describe table.
 void MetaDataFormatter.describeTable(DataOutputStream out, String colPath, String tableName, Table tbl, Partition part, List<FieldSchema> cols, boolean isFormatted, boolean isExt)
          Describe table.
 void TextMetaDataFormatter.describeTable(DataOutputStream outStream, String colPath, String tableName, Table tbl, Partition part, List<FieldSchema> cols, boolean isFormatted, boolean isExt)
           
static String MetaDataFormatUtils.displayColsUnformatted(List<FieldSchema> cols)
           
static String MetaDataFormatUtils.getAllColumnsInformation(List<FieldSchema> cols)
           
static String MetaDataFormatUtils.getAllColumnsInformation(List<FieldSchema> cols, List<FieldSchema> partCols)
           
static String MetaDataFormatUtils.getAllColumnsInformation(List<FieldSchema> cols, List<FieldSchema> partCols)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.parse
 

Methods in org.apache.hadoop.hive.ql.parse that return types with arguments of type FieldSchema
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> ExplainSemanticAnalyzer.getResultSchema()
           
 List<FieldSchema> SemanticAnalyzer.getResultSchema()
           
 List<FieldSchema> BaseSemanticAnalyzer.getResultSchema()
           
 

Method parameters in org.apache.hadoop.hive.ql.parse with type arguments of type FieldSchema
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)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.plan
 

Methods in org.apache.hadoop.hive.ql.plan that return types with arguments of type FieldSchema
 List<FieldSchema> AddPartitionDesc.getCols()
           
 ArrayList<FieldSchema> CreateTableDesc.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()
           
 ArrayList<FieldSchema> CreateTableDesc.getPartCols()
           
 List<FieldSchema> CreateViewDesc.getSchema()
           
static List<FieldSchema> PlanUtils.sortFieldSchemas(List<FieldSchema> schema)
           
 

Method parameters in org.apache.hadoop.hive.ql.plan with type arguments of type FieldSchema
static TableDesc PlanUtils.getIntermediateFileTableDesc(List<FieldSchema> fieldSchemas)
          Generate the table descriptor for intermediate files.
static TableDesc PlanUtils.getMapJoinKeyTableDesc(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 key.
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.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 parameters in org.apache.hadoop.hive.ql.plan with type arguments of type FieldSchema
AlterTableDesc(String name, List<FieldSchema> newCols, AlterTableDesc.AlterTableTypes alterType)
           
CreateTableDesc(String tableName, boolean isExternal, 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, 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, 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, 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)
           
 

Uses of FieldSchema in org.apache.hadoop.hive.ql.session
 

Method parameters in org.apache.hadoop.hive.ql.session with type arguments of type FieldSchema
 void LineageState.setLineage(String dir, LineageInfo.DataContainer dc, List<FieldSchema> cols)
          Set the lineage information for the associated directory.
 



Copyright © 2011 The Apache Software Foundation