| Package | Description |
|---|---|
| org.apache.drill.exec.physical.impl.scan.convert |
Standard type conversion tools for the case in which the input
types are the standard Java types already supported by the
ValuesWriter interface. |
| org.apache.drill.exec.physical.impl.scan.project |
Provides run-time semantic analysis of the projection list for the
scan operator.
|
| org.apache.drill.exec.physical.impl.scan.v3.schema |
Provides run-time semantic analysis of the projection list for the
scan operator.
|
| org.apache.drill.exec.physical.resultSet.impl |
Handles the details of the result set loader implementation.
|
| org.apache.drill.exec.physical.resultSet.model |
The "row set model" provides a "dual" of the vector structure used to create,
allocate and work with a collection of vectors.
|
| org.apache.drill.exec.physical.resultSet.model.hyper |
Implementation of a row set model for hyper-batches.
|
| org.apache.drill.exec.physical.resultSet.project | |
| org.apache.drill.exec.physical.rowSet |
Provides a set of tools to work with row sets.
|
| org.apache.drill.exec.record | |
| org.apache.drill.exec.record.metadata |
Provides a fluent schema builder.
|
| org.apache.drill.exec.record.metadata.schema.parser | |
| org.apache.drill.exec.store.avro | |
| org.apache.drill.exec.store.easy.json.extended |
Provides parsing for Mongo extended types which are generally of the form
{ "$type": value }. |
| org.apache.drill.exec.store.easy.json.loader | |
| org.apache.drill.exec.store.easy.json.values | |
| org.apache.drill.exec.store.hive | |
| org.apache.drill.exec.store.ischema | |
| org.apache.drill.exec.vector.accessor |
Provides a light-weight, simplified set of column readers and writers that
can be plugged into a variety of row-level readers and writers.
|
| org.apache.drill.exec.vector.accessor.reader |
Provides the reader hierarchy as explained in the API package.
|
| org.apache.drill.exec.vector.accessor.writer |
Implementation of the vector writers.
|
| org.apache.drill.exec.vector.accessor.writer.dummy |
This package provides a "dummy" set of writers.
|
| org.apache.drill.metastore.metadata | |
| org.apache.drill.metastore.util |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
ColumnConverter.schema() |
| Modifier and Type | Method and Description |
|---|---|
StandardConversions.ConversionDefn |
StandardConversions.analyze(ColumnMetadata inputSchema,
ColumnMetadata outputSchema)
Create converters for standard cases.
|
StandardConversions.ConversionDefn |
StandardConversions.analyze(TypeProtos.MinorType inputType,
ColumnMetadata outputSchema) |
ValueWriter |
StandardConversions.converterFor(ScalarWriter scalarWriter,
ColumnMetadata inputSchema) |
Class<? extends DirectConverter> |
StandardConversions.convertFromVarchar(ColumnMetadata outputDefn) |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
ResolvedColumn.metadata() |
ColumnMetadata |
AbstractUnresolvedColumn.UnresolvedColumn.metadata() |
ColumnMetadata |
NullColumnLoader.NullColumnSpec.metadata() |
| Modifier and Type | Method and Description |
|---|---|
ResolvedNullColumn |
NullColumnBuilder.add(ColumnMetadata colDefn) |
| Constructor and Description |
|---|
ResolvedColumn(ColumnMetadata outputCol,
VectorSource source,
int sourceIndex) |
ResolvedNullColumn(ColumnMetadata colDefn,
VectorSource source,
int sourceIndex) |
ResolvedTableColumn(ColumnMetadata outputCol,
VectorSource source,
int sourceIndex) |
UnresolvedColumn(RequestedColumn inCol,
ColumnMetadata colDefn) |
| Modifier and Type | Class and Description |
|---|---|
class |
ProjectedColumn
Enhanced form of a dynamic column which records all information from
the project list.
|
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
MutableTupleSchema.ColumnHandle.column() |
ColumnMetadata |
ProjectedColumn.copy() |
| Modifier and Type | Method and Description |
|---|---|
void |
MutableTupleSchema.add(ColumnMetadata col) |
ProjectionFilter.ProjResult |
DynamicSchemaFilter.buildProjection(ColumnMetadata schemaCol,
ColumnMetadata probeCol) |
static void |
SchemaUtils.copyMapProperties(ProjectedColumn source,
ColumnMetadata dest) |
void |
SchemaBasedTracker.expandImplicitCol(ColumnMetadata resolved,
ImplicitColumnMarker marker) |
void |
ProjectionSchemaTracker.expandImplicitCol(ColumnMetadata resolved,
ImplicitColumnMarker marker) |
void |
ScanSchemaTracker.expandImplicitCol(ColumnMetadata resolved,
ImplicitColumnMarker marker)
Drill defines a wildcard to expand not just reader columns, but also
partition columns.
|
protected ProjectionFilter.ProjResult |
DynamicSchemaFilter.fromSchema(ColumnMetadata schemaCol,
ColumnMetadata probeCol)
A column exists in the scan schema, and is concrete.
|
static String |
SchemaUtils.implicitColType(ColumnMetadata col) |
MutableTupleSchema.ColumnHandle |
MutableTupleSchema.insert(ColumnMetadata col) |
MutableTupleSchema.ColumnHandle |
MutableTupleSchema.insert(int posn,
ColumnMetadata col) |
static boolean |
SchemaUtils.isConsistent(ProjectedColumn colReq,
ColumnMetadata readCol)
Check if the given read column is consistent with the projection requested for
that column.
|
static boolean |
SchemaUtils.isExcludedFromWildcard(ColumnMetadata col) |
static boolean |
SchemaUtils.isImplicit(ColumnMetadata col) |
static void |
SchemaUtils.markAsPartition(ColumnMetadata col,
int level) |
static void |
SchemaUtils.markExcludeFromWildcard(ColumnMetadata col) |
static void |
SchemaUtils.markImplicit(ColumnMetadata col,
String value) |
static void |
SchemaUtils.markProjectAll(ColumnMetadata col) |
static void |
SchemaUtils.mergeColProperties(ColumnMetadata existing,
ColumnMetadata revised) |
ProjectionFilter.ProjResult |
DynamicSchemaFilter.DynamicTupleFilter.projection(ColumnMetadata col) |
ProjectionFilter.ProjResult |
DynamicSchemaFilter.RowSchemaFilter.projection(ColumnMetadata col) |
void |
MutableTupleSchema.replace(MutableTupleSchema.ColumnHandle col,
ColumnMetadata resolved) |
void |
MutableTupleSchema.resolve(MutableTupleSchema.ColumnHandle col,
ColumnMetadata resolved) |
void |
MutableTupleSchema.resolveImplicit(MutableTupleSchema.ColumnHandle col,
ColumnMetadata resolved,
ImplicitColumnMarker marker) |
static void |
SchemaUtils.verifyCompatibility(ProjectedColumn colReq,
ColumnMetadata actual,
String source,
CustomErrorContext errorContext)
Perform the column-level projection as described in
#isConsistent(RequestedColumn, ColumnMetadata), and raise a
UserException if the column is not consistent with projection. |
static void |
SchemaUtils.verifyConsistency(ColumnMetadata existing,
ColumnMetadata revised,
String source,
CustomErrorContext errorContext) |
static void |
SchemaUtils.verifyProjection(ColumnMetadata existing,
ColumnMetadata revised,
String source,
CustomErrorContext errorContext) |
| Constructor and Description |
|---|
ColumnHandle(ColumnMetadata col) |
| Modifier and Type | Field and Description |
|---|---|
protected ColumnMetadata |
TupleState.MapColumnState.outputSchema |
protected ColumnMetadata |
TupleState.DictColumnState.outputSchema |
ColumnMetadata |
ProjectionFilter.ProjResult.projection |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
RepeatedListState.RepeatedListColumnState.outputSchema()
Get the output schema.
|
ColumnMetadata |
UnionState.UnionColumnState.outputSchema()
Get the output schema.
|
abstract ColumnMetadata |
ColumnState.outputSchema() |
ColumnMetadata |
ColumnState.PrimitiveColumnState.outputSchema()
Get the output schema.
|
ColumnMetadata |
TupleState.MapColumnState.outputSchema() |
ColumnMetadata |
TupleState.DictColumnState.outputSchema() |
ColumnMetadata |
ColumnState.schema() |
ColumnMetadata |
RowSetLoaderImpl.schema() |
| Modifier and Type | Method and Description |
|---|---|
ColumnState |
ContainerState.addColumn(ColumnMetadata columnSchema) |
ObjectWriter |
TupleState.addColumn(TupleWriter tupleWriter,
ColumnMetadata columnSchema) |
ObjectWriter |
UnionState.addMember(ColumnMetadata member) |
ObjectWriter |
ListState.addMember(ColumnMetadata member) |
abstract int |
TupleState.addOutputColumn(ValueVector vector,
ColumnMetadata colSchema) |
int |
TupleState.RowState.addOutputColumn(ValueVector vector,
ColumnMetadata colSchema) |
int |
TupleState.MapState.addOutputColumn(ValueVector vector,
ColumnMetadata colSchema) |
int |
TupleState.DictArrayState.addOutputColumn(ValueVector vector,
ColumnMetadata colSchema) |
ColumnState |
ColumnBuilder.buildColumn(ContainerState parent,
ColumnMetadata columnSchema)
Implementation of the work to add a new column to this tuple given a
schema description of the column.
|
ObjectWriter |
BuildFromSchema.buildColumn(TupleState state,
ColumnMetadata colSchema)
Build a column recursively.
|
ProjectionFilter.ProjResult |
ProjectionFilter.projection(ColumnMetadata columnSchema) |
ProjectionFilter.ProjResult |
ProjectionFilter.ImplicitProjectionFilter.projection(ColumnMetadata col) |
ProjectionFilter.ProjResult |
ProjectionFilter.DirectProjectionFilter.projection(ColumnMetadata col) |
ProjectionFilter.ProjResult |
ProjectionFilter.TypeProjectionFilter.projection(ColumnMetadata col) |
ProjectionFilter.ProjResult |
ProjectionFilter.SchemaProjectionFilter.projection(ColumnMetadata col) |
ProjectionFilter.ProjResult |
ProjectionFilter.CompoundProjectionFilter.projection(ColumnMetadata col) |
AbstractObjectWriter |
RepeatedListState.setChild(ArrayWriter array,
ColumnMetadata columnSchema) |
protected void |
ProjectionFilter.BaseSchemaProjectionFilter.validateColumn(ColumnMetadata schemaCol,
ColumnMetadata readerCol) |
protected void |
ProjectionFilter.BaseSchemaProjectionFilter.validateMap(ColumnMetadata schemaCol) |
static SingleVectorState.SimpleVectorState |
SingleVectorState.vectorState(ColumnMetadata schema,
WriterEvents writer,
ValueVector mainVector) |
| Constructor and Description |
|---|
ProjResult(boolean isProjected,
ColumnMetadata projection) |
ProjResult(boolean isProjected,
ColumnMetadata projection,
ProjectionFilter mapFilter) |
VariableWidthVectorState(ColumnMetadata schema,
WriterEvents writer,
ValueVector mainVector) |
| Modifier and Type | Field and Description |
|---|---|
ColumnMetadata |
MetadataProvider.VectorDescrip.metadata |
protected ColumnMetadata |
BaseTupleModel.BaseColumnModel.schema
Extended schema associated with a column.
|
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
MetadataProvider.metadata(int index,
MaterializedField field) |
ColumnMetadata |
MetadataProvider.MetadataCreator.metadata(int index,
MaterializedField field) |
ColumnMetadata |
MetadataProvider.VariantSchemaCreator.metadata(int index,
MaterializedField field) |
ColumnMetadata |
MetadataProvider.ArraySchemaCreator.metadata(int index,
MaterializedField field) |
ColumnMetadata |
MetadataProvider.MetadataRetrieval.metadata(int index,
MaterializedField field) |
ColumnMetadata |
MetadataProvider.VariantSchemaRetrieval.metadata(int index,
MaterializedField field) |
ColumnMetadata |
MetadataProvider.ArraySchemaRetrieval.metadata(int index,
MaterializedField field) |
ColumnMetadata |
BaseTupleModel.BaseColumnModel.schema() |
ColumnMetadata |
TupleModel.ColumnModel.schema() |
| Modifier and Type | Method and Description |
|---|---|
protected AbstractObjectReader |
ReaderBuilder.buildScalarReader(VectorAccessor va,
ColumnMetadata schema) |
MetadataProvider |
MetadataProvider.childProvider(ColumnMetadata colMetadata) |
MetadataProvider |
MetadataProvider.MetadataCreator.childProvider(ColumnMetadata colMetadata) |
MetadataProvider |
MetadataProvider.VariantSchemaCreator.childProvider(ColumnMetadata colMetadata) |
MetadataProvider |
MetadataProvider.ArraySchemaCreator.childProvider(ColumnMetadata colMetadata) |
MetadataProvider |
MetadataProvider.MetadataRetrieval.childProvider(ColumnMetadata colMetadata) |
MetadataProvider |
MetadataProvider.VariantSchemaRetrieval.childProvider(ColumnMetadata colMetadata) |
MetadataProvider |
MetadataProvider.ArraySchemaRetrieval.childProvider(ColumnMetadata colMetadata) |
static MetadataProvider |
MetadataProvider.MetadataCreator.makeProvider(ColumnMetadata colMetadata) |
static MetadataProvider |
MetadataProvider.MetadataRetrieval.makeProvider(ColumnMetadata colMetadata) |
| Constructor and Description |
|---|
ArraySchemaRetrieval(ColumnMetadata arraySchema) |
BaseColumnModel(ColumnMetadata schema) |
VectorDescrip(MetadataProvider provider,
ColumnMetadata metadata) |
| Modifier and Type | Method and Description |
|---|---|
protected AbstractObjectReader |
HyperReaderBuilder.buildVectorReader(VectorAccessor va,
ColumnMetadata metadata) |
| Modifier and Type | Method and Description |
|---|---|
boolean |
RequestedTupleImpl.enforceProjection(ColumnMetadata columnSchema,
CustomErrorContext errorContext) |
boolean |
ImpliedTupleRequest.enforceProjection(ColumnMetadata columnSchema,
CustomErrorContext errorContext) |
boolean |
RequestedTuple.enforceProjection(ColumnMetadata columnSchema,
CustomErrorContext errorContext) |
static boolean |
Projections.excludeFromWildcard(ColumnMetadata col)
Reports whether the column is a special column which should not be
expanded in a wildcard.
|
static boolean |
ProjectionChecker.isConsistent(RequestedColumn colReq,
ColumnMetadata readCol)
Check if the given read column is consistent with the projection requested for
that column.
|
static boolean |
ProjectionChecker.isConsistent(RequestedTuple tuple,
ColumnMetadata readCol)
Check if the given read column is consistent with the projection requested for
a tuple.
|
boolean |
RequestedTupleImpl.isProjected(ColumnMetadata columnSchema) |
boolean |
ImpliedTupleRequest.isProjected(ColumnMetadata columnSchema) |
boolean |
RequestedTuple.isProjected(ColumnMetadata columnSchema) |
static void |
ProjectionChecker.validateProjection(RequestedColumn colReq,
ColumnMetadata readCol) |
static void |
ProjectionChecker.validateProjection(RequestedColumn colReq,
ColumnMetadata readCol,
CustomErrorContext errorContext)
Perform the column-level projection as described in
ProjectionChecker.isConsistent(RequestedColumn, ColumnMetadata), and raise a
UserException if the column is not consistent with projection. |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
TestDummyWriter.RootWriterFixture.schema() |
ColumnMetadata |
RowSetReaderImpl.schema() |
ColumnMetadata |
RowSetWriterImpl.schema() |
| Modifier and Type | Method and Description |
|---|---|
ColumnConverter.ScalarColumnConverter |
ColumnConverterFactory.buildScalar(ColumnMetadata readerSchema,
ValueWriter writer) |
ColumnConverter |
ColumnConverterFactory.getConverter(TupleMetadata providedSchema,
ColumnMetadata readerSchema,
ObjectWriter writer)
Based on column type, creates corresponding column converter
which holds conversion logic and appropriate writer to set converted data into.
|
| Modifier and Type | Class and Description |
|---|---|
class |
AbstractColumnMetadata
Abstract definition of column metadata.
|
class |
AbstractMapColumnMetadata
Describes a base column type for map, dict, repeated map and repeated dict.
|
class |
DictColumnMetadata |
class |
DynamicColumn
A dynamic column has a name but not a type.
|
class |
MapColumnMetadata
Describes a map and repeated map.
|
class |
PrimitiveColumnMetadata
Primitive (non-map) column.
|
class |
RepeatedListColumnMetadata |
class |
VariantColumnMetadata |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
TupleSchema.add(MaterializedField field) |
ColumnMetadata |
TupleMetadata.add(MaterializedField field)
Add a new column to the schema.
|
ColumnMetadata |
VariantSchema.addType(MaterializedField field) |
ColumnMetadata |
VariantSchema.addType(TypeProtos.MinorType type) |
ColumnMetadata |
VariantMetadata.addType(TypeProtos.MinorType type)
Add any supported type to the variant.
|
ColumnMetadata |
TupleSchema.addView(MaterializedField field) |
ColumnMetadata |
ColumnMetadata.childSchema()
Schema of inner dimension for MULTI_ARRAY columns.
|
ColumnMetadata |
RepeatedListColumnMetadata.childSchema() |
ColumnMetadata |
AbstractColumnMetadata.childSchema() |
ColumnMetadata |
ColumnMetadata.cloneEmpty()
Create an empty version of this column.
|
ColumnMetadata |
MapColumnMetadata.cloneEmpty() |
ColumnMetadata |
RepeatedListColumnMetadata.cloneEmpty() |
ColumnMetadata |
DictColumnMetadata.cloneEmpty() |
ColumnMetadata |
PrimitiveColumnMetadata.cloneEmpty() |
ColumnMetadata |
DynamicColumn.cloneEmpty() |
ColumnMetadata |
VariantColumnMetadata.cloneEmpty() |
static ColumnMetadata |
MetadataUtils.cloneMapWithSchema(ColumnMetadata source,
TupleMetadata members) |
ColumnMetadata |
ColumnMetadata.copy() |
ColumnMetadata |
MapColumnMetadata.copy() |
ColumnMetadata |
RepeatedListColumnMetadata.copy() |
ColumnMetadata |
DictColumnMetadata.copy() |
ColumnMetadata |
PrimitiveColumnMetadata.copy() |
ColumnMetadata |
DynamicColumn.copy() |
ColumnMetadata |
VariantColumnMetadata.copy() |
static ColumnMetadata |
MetadataUtils.diffMap(ColumnMetadata map,
ColumnMetadata other) |
static ColumnMetadata |
MetadataUtils.fromField(MaterializedField field)
Create a column metadata object that holds the given
MaterializedField. |
static ColumnMetadata |
MetadataUtils.fromView(MaterializedField field) |
ColumnMetadata |
DictColumnMetadata.keyColumnMetadata() |
ColumnMetadata |
VariantSchema.listSubtype() |
ColumnMetadata |
VariantMetadata.listSubtype()
Lists are odd creatures: they contain a union if they have more
than one subtype, but are like a nullable repeated type if they
contain only one type.
|
ColumnMetadata |
VariantSchema.member(TypeProtos.MinorType type) |
ColumnMetadata |
VariantMetadata.member(TypeProtos.MinorType type)
Retrieve the virtual column for a given type.
|
static ColumnMetadata |
VariantSchema.memberMetadata(TypeProtos.MinorType type) |
ColumnMetadata |
PrimitiveColumnMetadata.mergeWith(MaterializedField field) |
ColumnMetadata |
TupleSchema.metadata(int index) |
ColumnMetadata |
TupleMetadata.metadata(int index) |
ColumnMetadata |
TupleSchema.metadata(String name) |
ColumnMetadata |
TupleMetadata.metadata(String name) |
static ColumnMetadata |
MetadataUtils.newDecimal(String name,
TypeProtos.DataMode mode,
int precision,
int scale) |
static ColumnMetadata |
MetadataUtils.newDecimal(String name,
TypeProtos.MinorType type,
TypeProtos.DataMode mode,
int precision,
int scale) |
static ColumnMetadata |
MetadataUtils.newDynamic(String name) |
static ColumnMetadata |
MetadataUtils.newMapArray(String name) |
static ColumnMetadata |
MetadataUtils.newMapArray(String name,
TupleMetadata schema) |
ColumnMetadata |
VariantSchema.parent() |
ColumnMetadata |
VariantMetadata.parent()
Return the column that defines this variant structure
|
ColumnMetadata |
TupleMetadata.parent() |
ColumnMetadata |
DictColumnMetadata.valueColumnMetadata() |
static ColumnMetadata |
MetadataUtils.wildcard() |
| Modifier and Type | Method and Description |
|---|---|
Iterator<ColumnMetadata> |
TupleSchema.iterator() |
Collection<ColumnMetadata> |
VariantSchema.members() |
Collection<ColumnMetadata> |
VariantMetadata.members() |
List<ColumnMetadata> |
TupleSchema.toMetadataList() |
List<ColumnMetadata> |
TupleMetadata.toMetadataList()
Returns schema as list of ColumnMetadata objects
which can be used to create JSON schema object.
|
| Modifier and Type | Method and Description |
|---|---|
void |
TupleSchema.add(ColumnMetadata md)
Add a column metadata column created by the caller.
|
SchemaBuilder |
SchemaBuilder.add(ColumnMetadata column) |
int |
TupleSchema.addColumn(ColumnMetadata column) |
void |
RepeatedListBuilder.addColumn(ColumnMetadata column) |
void |
SchemaBuilder.addColumn(ColumnMetadata column) |
void |
TupleBuilder.addColumn(ColumnMetadata column) |
void |
MapBuilder.addColumn(ColumnMetadata column) |
void |
UnionBuilder.addColumn(ColumnMetadata column) |
void |
DictBuilder.addColumn(ColumnMetadata column) |
int |
TupleMetadata.addColumn(ColumnMetadata column) |
void |
VariantSchema.addType(ColumnMetadata col) |
void |
VariantMetadata.addType(ColumnMetadata col)
Add a column for any supported type to the variant.
|
void |
RepeatedListColumnMetadata.childSchema(ColumnMetadata childMetadata) |
static ColumnMetadata |
MetadataUtils.cloneMapWithSchema(ColumnMetadata source,
TupleMetadata members) |
static ColumnMetadata |
MetadataUtils.diffMap(ColumnMetadata map,
ColumnMetadata other) |
String |
TupleSchema.fullName(ColumnMetadata column) |
String |
TupleMetadata.fullName(ColumnMetadata column)
Full name of the column.
|
boolean |
ColumnMetadata.isEquivalent(ColumnMetadata other)
Report whether one column is equivalent to another.
|
boolean |
RepeatedListColumnMetadata.isEquivalent(ColumnMetadata o) |
boolean |
AbstractColumnMetadata.isEquivalent(ColumnMetadata o) |
boolean |
AbstractMapColumnMetadata.isEquivalent(ColumnMetadata o) |
boolean |
PrimitiveColumnMetadata.isEquivalent(ColumnMetadata o) |
boolean |
DynamicColumn.isEquivalent(ColumnMetadata o) |
boolean |
VariantColumnMetadata.isEquivalent(ColumnMetadata o) |
static boolean |
MetadataUtils.isRepeatedList(ColumnMetadata col) |
static boolean |
MetadataUtils.isScalar(ColumnMetadata col) |
static boolean |
MetadataUtils.isWildcard(ColumnMetadata col) |
static RepeatedListColumnMetadata |
MetadataUtils.newRepeatedList(String name,
ColumnMetadata child) |
void |
TupleSchema.replace(ColumnMetadata replaceWith) |
void |
TupleMetadata.replace(ColumnMetadata replaceWith) |
| Modifier and Type | Method and Description |
|---|---|
static TupleSchema |
MetadataUtils.fromColumns(List<ColumnMetadata> columns)
Create a tuple given the list of columns that make up the tuple.
|
| Constructor and Description |
|---|
RepeatedListColumnMetadata(String name,
ColumnMetadata childSchema) |
| Modifier and Type | Method and Description |
|---|---|
static ColumnMetadata |
SchemaExprParser.parseColumn(String column)
Parses string definition of the column and converts it
into
ColumnMetadata instance. |
static ColumnMetadata |
SchemaExprParser.parseColumn(String name,
String type,
TypeProtos.DataMode mode)
Parses given column name, type and mode into
ColumnMetadata instance. |
ColumnMetadata |
SchemaVisitor.ColumnDefVisitor.visitColumn_def(org.apache.drill.exec.record.metadata.schema.parser.SchemaParser.Column_defContext ctx) |
ColumnMetadata |
SchemaVisitor.ColumnVisitor.visitComplex_array_column(org.apache.drill.exec.record.metadata.schema.parser.SchemaParser.Complex_array_columnContext ctx) |
ColumnMetadata |
SchemaVisitor.ColumnVisitor.visitMap_column(org.apache.drill.exec.record.metadata.schema.parser.SchemaParser.Map_columnContext ctx) |
ColumnMetadata |
SchemaVisitor.ColumnVisitor.visitPrimitive_column(org.apache.drill.exec.record.metadata.schema.parser.SchemaParser.Primitive_columnContext ctx) |
ColumnMetadata |
SchemaVisitor.ColumnVisitor.visitSimple_array_column(org.apache.drill.exec.record.metadata.schema.parser.SchemaParser.Simple_array_columnContext ctx) |
ColumnMetadata |
SchemaVisitor.ColumnVisitor.visitStruct_column(org.apache.drill.exec.record.metadata.schema.parser.SchemaParser.Struct_columnContext ctx) |
ColumnMetadata |
SchemaVisitor.ColumnVisitor.visitUnion_column(org.apache.drill.exec.record.metadata.schema.parser.SchemaParser.Union_columnContext ctx) |
| Modifier and Type | Method and Description |
|---|---|
ColumnConverter.ScalarColumnConverter |
AvroColumnConverterFactory.buildScalar(ColumnMetadata readerSchema,
ValueWriter writer) |
| Modifier and Type | Method and Description |
|---|---|
ValueParser |
ExtendedTypeFieldFactory.scalarParserFor(FieldDefn fieldDefn,
ColumnMetadata colSchema)
Infer the extended parser from the provided field type.
|
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
FieldDefn.providedColumn() |
protected ColumnMetadata |
BaseFieldFactory.repeatedListSchemaFor(String key,
int dims,
ColumnMetadata innerArray)
Build up a repeated list column definition given a specification of the
number of dimensions and the JSON type.
|
ColumnMetadata |
FieldDefn.schemaFor(TypeProtos.MinorType type,
boolean isArray) |
| Modifier and Type | Method and Description |
|---|---|
UserException |
JsonLoaderImpl.buildError(ColumnMetadata schema,
UserException.Builder builder) |
UserException |
JsonLoaderImpl.dataConversionError(ColumnMetadata schema,
String tokenType,
String value) |
ObjectWriter |
FieldDefn.fieldWriterFor(ColumnMetadata colSchema) |
UserException |
JsonLoaderImpl.nullDisallowedError(ColumnMetadata schema) |
protected ElementParser |
BaseFieldFactory.objectArrayParserFor(FieldDefn fieldDefn,
ColumnMetadata colSchema,
TupleMetadata providedSchema)
Create a map array column and its associated parsers and listeners
for the given column schema and optional provided schema.
|
protected ElementParser |
BaseFieldFactory.objectParserFor(FieldDefn fieldDefn,
ColumnMetadata colSchema,
TupleMetadata providedSchema)
Create a map column and its associated object value listener for the
given key and optional provided schema.
|
protected ColumnMetadata |
BaseFieldFactory.repeatedListSchemaFor(String key,
int dims,
ColumnMetadata innerArray)
Build up a repeated list column definition given a specification of the
number of dimensions and the JSON type.
|
ValueParser |
FieldFactory.scalarParserFor(FieldDefn fieldDefn,
ColumnMetadata colSchema)
Internal method which allows a custom parser (such as for
extended types) to provide the scalar parser for a provided
schema.
|
ValueParser |
BaseFieldFactory.scalarParserFor(FieldDefn fieldDefn,
ColumnMetadata colSchema) |
ScalarWriter |
FieldDefn.scalarWriterFor(ColumnMetadata colSchema) |
UserException |
JsonLoaderImpl.typeConversionError(ColumnMetadata schema,
String tokenType) |
UserException |
JsonLoaderImpl.typeConversionError(ColumnMetadata schema,
ValueDef valueDef) |
UserException |
JsonLoaderImpl.unsupportedType(ColumnMetadata schema) |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
ScalarListener.schema() |
| Modifier and Type | Method and Description |
|---|---|
static ColumnMetadata |
HiveUtilities.getColumnMetadata(HiveToRelDataTypeConverter dataTypeConverter,
org.apache.hadoop.hive.metastore.api.FieldSchema column)
Converts specified
FieldSchema column into ColumnMetadata. |
static ColumnMetadata |
HiveUtilities.getColumnMetadata(String name,
org.apache.calcite.rel.type.RelDataType relDataType)
Converts specified
RelDataType relDataType into ColumnMetadata. |
| Constructor and Description |
|---|
Column(String catalog,
String schemaName,
String tableName,
String columnName,
ColumnMetadata columnMetadata,
ColumnStatistics<?> columnStatistics,
int index,
boolean isNested) |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
ColumnWriter.schema()
Returns the schema of the column associated with this writer.
|
ColumnMetadata |
ColumnReader.schema() |
| Modifier and Type | Method and Description |
|---|---|
int |
TupleWriter.addColumn(ColumnMetadata column)
Add a column to the tuple (row or map) that backs this writer.
|
ObjectWriter |
VariantWriter.addMember(ColumnMetadata schema) |
ObjectWriter |
VariantWriter.VariantWriterListener.addMember(ColumnMetadata schema) |
static UnsupportedConversionError |
UnsupportedConversionError.nullError(ColumnMetadata schema) |
static UnsupportedConversionError |
UnsupportedConversionError.readError(ColumnMetadata schema,
String javaType) |
static InvalidConversionError |
InvalidConversionError.writeError(ColumnMetadata schema,
Object value) |
static InvalidConversionError |
InvalidConversionError.writeError(ColumnMetadata schema,
Object value,
Exception e) |
static UnsupportedConversionError |
UnsupportedConversionError.writeError(ColumnMetadata schema,
String javaType) |
| Modifier and Type | Field and Description |
|---|---|
protected ColumnMetadata |
BaseScalarReader.schema |
protected ColumnMetadata |
MapReader.schema |
protected ColumnMetadata |
AbstractScalarReader.NullReader.schema |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
ArrayReaderImpl.schema() |
ColumnMetadata |
AbstractObjectReader.schema() |
ColumnMetadata |
OffsetVectorReader.schema() |
ColumnMetadata |
BaseScalarReader.schema() |
ColumnMetadata |
MapReader.schema() |
ColumnMetadata |
AbstractScalarReader.NullReader.schema() |
ColumnMetadata |
DictEntryReader.schema() |
ColumnMetadata |
UnionReaderImpl.schema() |
| Constructor and Description |
|---|
ArrayReaderImpl(ColumnMetadata schema,
VectorAccessor va,
AbstractObjectReader elementReader) |
DictEntryReader(ColumnMetadata schema,
VectorAccessor accessor,
AbstractObjectReader[] readers) |
DictReaderImpl(ColumnMetadata metadata,
VectorAccessor va,
AbstractTupleReader.TupleObjectReader entryObjectReader) |
MapReader(ColumnMetadata schema,
AbstractObjectReader[] readers) |
MapReader(ColumnMetadata schema,
VectorAccessor mapAccessor,
AbstractObjectReader[] readers) |
NullReader(ColumnMetadata schema) |
UnionReaderImpl(ColumnMetadata schema,
VectorAccessor va,
AbstractObjectReader[] variants) |
| Modifier and Type | Field and Description |
|---|---|
protected ColumnMetadata |
MapWriter.mapColumnSchema |
protected ColumnMetadata |
AbstractScalarWriterImpl.schema |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
AbstractArrayWriter.schema() |
ColumnMetadata |
AbstractScalarWriterImpl.schema() |
ColumnMetadata |
MapWriter.schema() |
ColumnMetadata |
AbstractObjectWriter.schema() |
ColumnMetadata |
UnionWriterImpl.schema() |
ColumnMetadata |
DictEntryWriter.schema() |
| Constructor and Description |
|---|
DummyArrayWriter(ColumnMetadata schema,
AbstractObjectWriter elementWriter) |
DummyDictWriter(ColumnMetadata schema,
DictEntryWriter.DictEntryObjectWriter entryObjectWriter) |
DummyScalarWriter(ColumnMetadata schema) |
| Modifier and Type | Method and Description |
|---|---|
ColumnMetadata |
BaseMetadata.getColumn(SchemaPath name) |
ColumnMetadata |
NonInterestingColumnsMetadata.getColumn(SchemaPath name) |
ColumnMetadata |
Metadata.getColumn(SchemaPath name)
Returns metadata description for the specified column
|
| Modifier and Type | Method and Description |
|---|---|
static ColumnMetadata |
SchemaPathUtils.getColumnMetadata(SchemaPath schemaPath,
TupleMetadata schema)
Returns
ColumnMetadata instance obtained from specified TupleMetadata schema which corresponds to
the specified column schema path. |
Copyright © 2021 The Apache Software Foundation. All rights reserved.