Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
TableResult.getResolvedSchema()
Returns the schema of the result.
|
ResolvedSchema |
Table.getResolvedSchema()
Returns the resolved schema of this table.
|
ResolvedSchema |
Schema.resolve(SchemaResolver resolver)
Resolves the given
Schema to a validated ResolvedSchema . |
Modifier and Type | Method and Description |
---|---|
static TableSchema |
TableSchema.fromResolvedSchema(ResolvedSchema resolvedSchema)
Deprecated.
Helps to migrate to the new
ResolvedSchema to old API methods. |
Schema.Builder |
Schema.Builder.fromResolvedSchema(ResolvedSchema resolvedSchema)
Adopts all members from the given resolved schema.
|
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
TableResultImpl.getResolvedSchema() |
ResolvedSchema |
TableImpl.getResolvedSchema() |
Modifier and Type | Method and Description |
---|---|
TableResultImpl.Builder |
TableResultImpl.Builder.schema(ResolvedSchema resolvedSchema)
Specifies schema of the execution result.
|
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
ContextResolvedTable.getResolvedSchema() |
ResolvedSchema |
ResolvedCatalogTable.getResolvedSchema() |
ResolvedSchema |
ResolvedCatalogBaseTable.getResolvedSchema()
Returns a fully resolved and validated
ResolvedSchema . |
ResolvedSchema |
ResolvedCatalogView.getResolvedSchema() |
static ResolvedSchema |
ResolvedSchema.of(Column... columns)
Shortcut for a resolved schema of only columns.
|
static ResolvedSchema |
ResolvedSchema.of(List<Column> columns)
Shortcut for a resolved schema of only columns.
|
static ResolvedSchema |
ResolvedSchema.physical(List<String> columnNames,
List<DataType> columnDataTypes)
Shortcut for a resolved schema of only physical columns.
|
static ResolvedSchema |
ResolvedSchema.physical(String[] columnNames,
DataType[] columnDataTypes)
Shortcut for a resolved schema of only physical columns.
|
ResolvedSchema |
SchemaResolver.resolve(Schema schema) |
Modifier and Type | Method and Description |
---|---|
static SchemaTranslator.ProducingResult |
SchemaTranslator.createProducingResult(DataTypeFactory dataTypeFactory,
ResolvedSchema inputSchema,
AbstractDataType<?> targetDataType)
Converts the given
DataType into the final SchemaTranslator.ProducingResult . |
static SchemaTranslator.ProducingResult |
SchemaTranslator.createProducingResult(ResolvedSchema inputSchema,
Schema declaredSchema)
Converts the given
DataType into the final SchemaTranslator.ProducingResult . |
Constructor and Description |
---|
ResolvedCatalogTable(CatalogTable origin,
ResolvedSchema resolvedSchema) |
ResolvedCatalogView(CatalogView origin,
ResolvedSchema resolvedSchema) |
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
ResultDescriptor.getResultSchema() |
Constructor and Description |
---|
ResultDescriptor(String resultId,
ResolvedSchema resultSchema,
boolean isMaterialized,
ReadableConfig config,
RowDataToStringConverter rowDataToStringConverter) |
Modifier and Type | Field and Description |
---|---|
static ResolvedSchema |
HiveServer2Schemas.GET_CATALOGS_SCHEMA
|
static ResolvedSchema |
HiveServer2Schemas.GET_COLUMNS_SCHEMA
|
static ResolvedSchema |
HiveServer2Schemas.GET_FUNCTIONS_SCHEMA
|
static ResolvedSchema |
HiveServer2Schemas.GET_PRIMARY_KEYS_SCHEMA
|
static ResolvedSchema |
HiveServer2Schemas.GET_SCHEMAS_SCHEMA
|
static ResolvedSchema |
HiveServer2Schemas.GET_TABLE_TYPES_SCHEMA
|
static ResolvedSchema |
HiveServer2Schemas.GET_TABLES_SCHEMA
|
static ResolvedSchema |
HiveServer2Schemas.GET_TYPE_INFO_SCHEMA
|
Modifier and Type | Method and Description |
---|---|
static org.apache.hive.service.rpc.thrift.TRowSet |
ThriftObjectConversions.toTRowSet(org.apache.hive.service.rpc.thrift.TProtocolVersion version,
ResolvedSchema schema,
List<RowData> data)
Similar to
SerDeUtils.toThriftPayload(Object, ObjectInspector, int) that converts the
returned Rows to JSON string. |
static org.apache.hive.service.rpc.thrift.TTableSchema |
ThriftObjectConversions.toTTableSchema(ResolvedSchema schema)
Similar logic in the
org.apache.hive.service.cli.ColumnDescriptor . |
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
SqlGatewayService.getOperationResultSchema(SessionHandle sessionHandle,
OperationHandle operationHandle)
Get the result schema for the specified Operation.
|
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
ResultSet.getResultSchema()
The schema of the data.
|
Constructor and Description |
---|
ResultSet(ResultSet.ResultType resultType,
Long nextToken,
ResolvedSchema resultSchema,
List<RowData> data) |
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
SqlGatewayServiceImpl.getOperationResultSchema(SessionHandle sessionHandle,
OperationHandle operationHandle) |
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
OperationManager.getOperationResultSchema(OperationHandle operationHandle)
Get the
ResolvedSchema of the operation. |
ResolvedSchema |
OperationManager.Operation.getResultSchema() |
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
ResultFetcher.getResultSchema() |
Constructor and Description |
---|
ResultFetcher(OperationHandle operationHandle,
ResolvedSchema resultSchema,
CloseableIterator<RowData> resultRows) |
ResultFetcher(OperationHandle operationHandle,
ResolvedSchema resultSchema,
List<RowData> rows) |
Modifier and Type | Method and Description |
---|---|
static RowType |
DynamicSourceUtils.createProducedType(ResolvedSchema schema,
DynamicTableSource source)
Returns the
DataType that a source should produce as the input into the runtime. |
static List<Column.MetadataColumn> |
DynamicSourceUtils.createRequiredMetadataColumns(ResolvedSchema schema,
DynamicTableSource source)
Returns a list of required metadata columns.
|
static List<Column.MetadataColumn> |
DynamicSourceUtils.extractMetadataColumns(ResolvedSchema schema) |
static boolean |
DynamicSourceUtils.isSourceChangeEventsDuplicate(ResolvedSchema resolvedSchema,
DynamicTableSource tableSource,
TableConfig tableConfig)
Returns true if the table source produces duplicate change events.
|
static boolean |
DynamicSourceUtils.isUpsertSource(ResolvedSchema resolvedSchema,
DynamicTableSource tableSource)
Returns true if the table is an upsert source.
|
static org.apache.calcite.rel.RelNode |
DynamicSinkUtils.validateSchemaAndApplyImplicitCast(org.apache.calcite.rel.RelNode query,
ResolvedSchema sinkSchema,
String tableDebugName,
DataTypeFactory dataTypeFactory,
org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory)
Checks if the given query can be written into the given sink's table schema.
|
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
InternalDataStreamQueryOperation.getResolvedSchema()
Deprecated.
|
ResolvedSchema |
PlannerQueryOperation.getResolvedSchema() |
Constructor and Description |
---|
InternalDataStreamQueryOperation(ObjectIdentifier identifier,
DataStream<E> dataStream,
int[] fieldIndices,
ResolvedSchema resolvedSchema,
boolean[] fieldNullables,
org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static ResolvedSchema |
DataTypeUtils.expandCompositeTypeToSchema(DataType dataType)
Expands a composite
DataType to a corresponding ResolvedSchema . |
Modifier and Type | Method and Description |
---|---|
ResolvedSchema |
FieldInfoUtils.TypeInfoSchema.toResolvedSchema() |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.