Uses of Class
org.apache.flink.table.api.Schema
-
-
Uses of Schema in org.apache.flink.table.api
Methods in org.apache.flink.table.api that return Schema Modifier and Type Method Description Schema
Schema.Builder. build()
Returns an instance of an unresolvedSchema
.static Schema
Schema. derived()
Convenience method for stating explicitly that a schema is empty and should be fully derived by the framework.Methods in org.apache.flink.table.api that return types with arguments of type Schema Modifier and Type Method Description Optional<Schema>
TableDescriptor. getSchema()
Methods in org.apache.flink.table.api with parameters of type Schema Modifier and Type Method Description Schema.Builder
Schema.Builder. fromSchema(Schema unresolvedSchema)
Adopts all members from the given unresolved schema.TableDescriptor.Builder
TableDescriptor.Builder. schema(Schema schema)
Define the schema of theTableDescriptor
.Constructors in org.apache.flink.table.api with parameters of type Schema Constructor Description TableDescriptor(Schema schema, Map<String,String> options, TableDistribution distribution, List<String> partitionKeys, String comment)
-
Uses of Schema in org.apache.flink.table.api.bridge.internal
Methods in org.apache.flink.table.api.bridge.internal with parameters of type Schema Modifier and Type Method Description protected <T> Table
AbstractStreamTableEnvironmentImpl. fromStreamInternal(DataStream<T> dataStream, Schema schema, String viewPath, ChangelogMode changelogMode)
-
Uses of Schema in org.apache.flink.table.api.bridge.java
Methods in org.apache.flink.table.api.bridge.java with parameters of type Schema Modifier and Type Method Description <T> void
StreamTableEnvironment. createTemporaryView(String path, DataStream<T> dataStream, Schema schema)
Creates a view from the givenDataStream
in a given path.Table
StreamTableEnvironment. fromChangelogStream(DataStream<Row> dataStream, Schema schema)
Converts the givenDataStream
of changelog entries into aTable
.Table
StreamTableEnvironment. fromChangelogStream(DataStream<Row> dataStream, Schema schema, ChangelogMode changelogMode)
Converts the givenDataStream
of changelog entries into aTable
.<T> Table
StreamTableEnvironment. fromDataStream(DataStream<T> dataStream, Schema schema)
Converts the givenDataStream
into aTable
.DataStream<Row>
StreamTableEnvironment. toChangelogStream(Table table, Schema targetSchema)
Converts the givenTable
into aDataStream
of changelog entries.DataStream<Row>
StreamTableEnvironment. toChangelogStream(Table table, Schema targetSchema, ChangelogMode changelogMode)
Converts the givenTable
into aDataStream
of changelog entries. -
Uses of Schema in org.apache.flink.table.api.bridge.java.internal
Methods in org.apache.flink.table.api.bridge.java.internal with parameters of type Schema Modifier and Type Method Description <T> void
StreamTableEnvironmentImpl. createTemporaryView(String path, DataStream<T> dataStream, Schema schema)
Table
StreamTableEnvironmentImpl. fromChangelogStream(DataStream<Row> dataStream, Schema schema)
Table
StreamTableEnvironmentImpl. fromChangelogStream(DataStream<Row> dataStream, Schema schema, ChangelogMode changelogMode)
<T> Table
StreamTableEnvironmentImpl. fromDataStream(DataStream<T> dataStream, Schema schema)
DataStream<Row>
StreamTableEnvironmentImpl. toChangelogStream(Table table, Schema targetSchema)
DataStream<Row>
StreamTableEnvironmentImpl. toChangelogStream(Table table, Schema targetSchema, ChangelogMode changelogMode)
-
Uses of Schema in org.apache.flink.table.catalog
Methods in org.apache.flink.table.catalog that return Schema Modifier and Type Method Description Schema
CatalogModel. getInputSchema()
Get the unresolved input schema of the model.Schema
DefaultCatalogModel. getInputSchema()
Schema
DefaultResolvedCatalogModel. getInputSchema()
Schema
CatalogModel. getOutputSchema()
Get the unresolved output schema of the model.Schema
DefaultCatalogModel. getOutputSchema()
Schema
DefaultResolvedCatalogModel. getOutputSchema()
Schema
SchemaTranslator.ConsumingResult. getSchema()
Schema
SchemaTranslator.ProducingResult. getSchema()
default Schema
CatalogBaseTable. getUnresolvedSchema()
Returns the schema of the table or view.Schema
DefaultCatalogMaterializedTable. getUnresolvedSchema()
Schema
DefaultCatalogTable. getUnresolvedSchema()
Schema
ExternalCatalogTable. getUnresolvedSchema()
Schema
QueryOperationCatalogView. getUnresolvedSchema()
Schema
ResolvedCatalogTable. getUnresolvedSchema()
Schema
ResolvedCatalogView. getUnresolvedSchema()
Methods in org.apache.flink.table.catalog with parameters of type Schema Modifier and Type Method Description static SchemaTranslator.ConsumingResult
SchemaTranslator. createConsumingResult(DataTypeFactory dataTypeFactory, TypeInformation<?> inputTypeInfo, Schema declaredSchema)
Converts the givenTypeInformation
and an optional declaredSchema
(possibly incomplete) into the finalSchemaTranslator.ConsumingResult
.static SchemaTranslator.ConsumingResult
SchemaTranslator. createConsumingResult(DataTypeFactory dataTypeFactory, DataType inputDataType, Schema declaredSchema, boolean mergePhysicalSchema)
Converts the givenDataType
and an optional declaredSchema
(possibly incomplete) into the finalSchemaTranslator.ConsumingResult
.static SchemaTranslator.ProducingResult
SchemaTranslator. createProducingResult(ResolvedSchema inputSchema, Schema declaredSchema)
Converts the givenDataType
into the finalSchemaTranslator.ProducingResult
.static CatalogModel
CatalogModel. of(Schema inputSchema, Schema outputSchema, Map<String,String> modelOptions, String comment)
Creates a basic implementation of this interface.static CatalogTable
CatalogTable. of(Schema schema, String comment, List<String> partitionKeys, Map<String,String> options)
Deprecated.Use the builderCatalogTable.newBuilder()
instead.static CatalogTable
CatalogTable. of(Schema schema, String comment, List<String> partitionKeys, Map<String,String> options, Long snapshot)
Deprecated.Use the builderCatalogTable.newBuilder()
instead.static CatalogView
CatalogView. of(Schema schema, String comment, String originalQuery, String expandedQuery, Map<String,String> options)
Creates a basic implementation of this interface.ResolvedSchema
SchemaResolver. resolve(Schema schema)
CatalogMaterializedTable.Builder
CatalogMaterializedTable.Builder. schema(Schema schema)
CatalogTable.Builder
CatalogTable.Builder. schema(Schema schema)
Constructors in org.apache.flink.table.catalog with parameters of type Schema Constructor Description DefaultCatalogMaterializedTable(Schema schema, String comment, List<String> partitionKeys, Map<String,String> options, Long snapshot, String definitionQuery, IntervalFreshness freshness, CatalogMaterializedTable.LogicalRefreshMode logicalRefreshMode, CatalogMaterializedTable.RefreshMode refreshMode, CatalogMaterializedTable.RefreshStatus refreshStatus, String refreshHandlerDescription, byte[] serializedRefreshHandler)
DefaultCatalogModel(Schema inputSchema, Schema outputSchema, Map<String,String> modelOptions, String comment)
DefaultCatalogTable(Schema schema, String comment, List<String> partitionKeys, Map<String,String> options)
DefaultCatalogTable(Schema schema, String comment, List<String> partitionKeys, Map<String,String> options, Long snapshot, TableDistribution distribution)
ExternalCatalogTable(Schema schema)
-
Uses of Schema in org.apache.flink.table.legacy.api
Methods in org.apache.flink.table.legacy.api that return Schema Modifier and Type Method Description Schema
TableSchema. toSchema()
Deprecated.Helps to migrate to the newSchema
class.Schema
TableSchema. toSchema(Map<String,String> comments)
Deprecated.Helps to migrate to the newSchema
class, retain comments when needed. -
Uses of Schema in org.apache.flink.table.planner.operations
Methods in org.apache.flink.table.planner.operations that return Schema Modifier and Type Method Description Schema
SchemaBuilderUtil. build()
Builds and returns aSchema
from the columns, watermark specs, and primary key specified in the builder.Schema
MergeTableAsUtil. mergeSchemas(org.apache.calcite.sql.SqlNodeList sqlColumnList, SqlWatermark sqlWatermark, List<SqlTableConstraint> sqlTableConstraints, ResolvedSchema sourceSchema)
Merges the specified schema with columns, watermark, and constraints with thesourceSchema
.Schema
MergeTableAsUtil. reorderSchema(org.apache.calcite.sql.SqlNodeList sqlColumnList, ResolvedSchema sourceSchema)
Reorders the columns from the source schema based on the columns identifiers list.
-