Modifier and Type | Method and Description |
---|---|
protected TableSchema |
HiveTableSource.getProducedTableSchema() |
protected TableSchema |
HiveTableSource.getTableSchema() |
Constructor and Description |
---|
HiveWriterFactory(org.apache.hadoop.mapred.JobConf jobConf,
Class hiveOutputFormatClz,
org.apache.hadoop.hive.metastore.api.SerDeInfo serDeInfo,
TableSchema schema,
String[] partitionColumns,
Properties tableProperties,
HiveShim hiveShim,
boolean isCompressed) |
Modifier and Type | Method and Description |
---|---|
TableSchema |
StreamSQLTestProgram.GeneratorTableSource.getTableSchema() |
TableSchema |
BatchSQLTestProgram.GeneratorTableSource.getTableSchema() |
Modifier and Type | Method and Description |
---|---|
TableSchema |
TableSchema.Builder.build()
Returns a
TableSchema instance. |
TableSchema |
TableSchema.copy()
Deprecated.
Returns a deep copy of the table schema.
|
static TableSchema |
TableSchema.fromResolvedSchema(ResolvedSchema resolvedSchema)
Deprecated.
Helps to migrate to the new
ResolvedSchema to old API methods. |
static TableSchema |
TableSchema.fromTypeInfo(TypeInformation<?> typeInfo)
Deprecated.
This method will be removed soon. Use
DataTypes to declare types. |
default TableSchema |
Table.getSchema()
Deprecated.
This method has been deprecated as part of FLIP-164.
TableSchema has been
replaced by two more dedicated classes Schema and ResolvedSchema . Use
Schema for declaration in APIs. ResolvedSchema is offered by the
framework after resolution and validation. |
default TableSchema |
TableResult.getTableSchema()
Deprecated.
This method has been deprecated as part of FLIP-164.
TableSchema has been
replaced by two more dedicated classes Schema and ResolvedSchema . Use
Schema for declaration in APIs. ResolvedSchema is offered by the
framework after resolution and validation. |
Modifier and Type | Method and Description |
---|---|
static <T1> TableSchema |
ConnectorCatalogTable.calculateSourceSchema(TableSource<T1> source,
boolean isBatch) |
TableSchema |
AbstractCatalogView.getSchema() |
TableSchema |
AbstractCatalogTable.getSchema() |
default TableSchema |
ResolvedCatalogBaseTable.getSchema()
Deprecated.
This method returns the deprecated
TableSchema class. The old class was a
hybrid of resolved and unresolved schema information. It has been replaced by the new
ResolvedSchema which is resolved by the framework and accessible via ResolvedCatalogBaseTable.getResolvedSchema() . |
default TableSchema |
CatalogBaseTable.getSchema()
Deprecated.
This method returns the deprecated
TableSchema class. The old class was a
hybrid of resolved and unresolved schema information. It has been replaced by the new
Schema which is always unresolved and will be resolved by the framework later. |
Modifier and Type | Method and Description |
---|---|
static Map<String,String> |
CatalogTableImpl.removeRedundant(Map<String,String> properties,
TableSchema schema,
List<String> partitionKeys)
Deprecated.
Construct catalog table properties from
CatalogTableImpl.toProperties() . |
Constructor and Description |
---|
AbstractCatalogTable(TableSchema tableSchema,
List<String> partitionKeys,
Map<String,String> options,
String comment) |
AbstractCatalogTable(TableSchema tableSchema,
Map<String,String> options,
String comment) |
AbstractCatalogView(String originalQuery,
String expandedQuery,
TableSchema schema,
Map<String,String> options,
String comment) |
CatalogTableImpl(TableSchema tableSchema,
List<String> partitionKeys,
Map<String,String> properties,
String comment)
Deprecated.
|
CatalogTableImpl(TableSchema tableSchema,
Map<String,String> properties,
String comment)
Deprecated.
|
CatalogViewImpl(String originalQuery,
String expandedQuery,
TableSchema schema,
Map<String,String> properties,
String comment)
Deprecated.
|
ConnectorCatalogTable(TableSource<T1> tableSource,
TableSink<T2> tableSink,
TableSchema tableSchema,
boolean isBatch) |
Modifier and Type | Method and Description |
---|---|
static TableSchema |
HiveTableUtil.createTableSchema(HiveConf hiveConf,
org.apache.hadoop.hive.metastore.api.Table hiveTable,
HiveMetastoreClientWrapper client,
HiveShim hiveShim) |
static TableSchema |
HiveTableUtil.createTableSchema(List<org.apache.hadoop.hive.metastore.api.FieldSchema> cols,
List<org.apache.hadoop.hive.metastore.api.FieldSchema> partitionKeys,
Set<String> notNullColumns,
UniqueConstraint primaryKey)
Create a Flink's TableSchema from Hive table's columns and partition keys.
|
Modifier and Type | Method and Description |
---|---|
static List<org.apache.hadoop.hive.metastore.api.FieldSchema> |
HiveTableUtil.createHiveColumns(TableSchema schema)
Create Hive columns from Flink TableSchema.
|
Modifier and Type | Method and Description |
---|---|
static TableSchema |
SchemaValidator.deriveTableSinkSchema(DescriptorProperties properties)
Deprecated.
This method combines two separate concepts of table schema and field mapping.
This should be split into two methods once we have support for the corresponding
interfaces (see FLINK-9870).
|
TableSchema |
DescriptorProperties.getTableSchema(String key)
Deprecated.
Returns a table schema under the given existing key.
|
Modifier and Type | Method and Description |
---|---|
Optional<TableSchema> |
DescriptorProperties.getOptionalTableSchema(String key)
Deprecated.
Returns a table schema under the given key if it exists.
|
Modifier and Type | Method and Description |
---|---|
void |
DescriptorProperties.putTableSchema(String key,
TableSchema schema)
Deprecated.
Adds a table schema under the given key.
|
Schema |
Schema.schema(TableSchema schema)
Deprecated.
Sets the schema with field names and the types.
|
Modifier and Type | Method and Description |
---|---|
static TableSchema |
TableFormatFactoryBase.deriveSchema(Map<String,String> properties)
Deprecated.
Finds the table schema that can be used for a format schema (without time attributes and
generated columns).
|
Modifier and Type | Method and Description |
---|---|
static TableSchema |
OperationConverterUtils.changeColumn(TableSchema oldSchema,
String oldName,
TableColumn newTableColumn,
boolean first,
String after) |
Modifier and Type | Method and Description |
---|---|
static TableSchema |
OperationConverterUtils.changeColumn(TableSchema oldSchema,
String oldName,
TableColumn newTableColumn,
boolean first,
String after) |
Modifier and Type | Method and Description |
---|---|
TableSchema |
ArrowTableSource.getTableSchema() |
Modifier and Type | Method and Description |
---|---|
TableSchema |
CsvTableSink.getTableSchema()
Deprecated.
|
default TableSchema |
TableSink.getTableSchema()
Deprecated.
Returns the schema of the consumed table.
|
Modifier and Type | Method and Description |
---|---|
TableSchema |
CsvTableSource.getTableSchema()
Deprecated.
|
TableSchema |
TableSource.getTableSchema()
Deprecated.
Table schema is a logical description of a table and should not be part of the
physical TableSource. Define schema when registering a Table either in DDL or in
TableEnvironment#connect(...) . |
Modifier and Type | Method and Description |
---|---|
static List<LogicalType> |
CsvTableSourceFactoryBase.getFieldLogicalTypes(TableSchema schema)
Deprecated.
|
static void |
TableSourceValidation.validateTableSource(TableSource<?> tableSource,
TableSchema schema)
Validates a TableSource.
|
Modifier and Type | Method and Description |
---|---|
static TableSchema |
TableSchemaUtils.checkOnlyPhysicalColumns(TableSchema schema)
Throws an exception if the given
TableSchema contains any non-physical columns. |
static TableSchema |
TableSchemaUtils.dropConstraint(TableSchema oriSchema,
String constraintName)
Creates a new schema but drop the constraint with given name.
|
static TableSchema |
TableSchemaUtils.getPhysicalSchema(TableSchema tableSchema)
Return
TableSchema which consists of all physical columns. |
Modifier and Type | Method and Description |
---|---|
static TableSchema.Builder |
TableSchemaUtils.builderWithGivenSchema(TableSchema oriSchema)
Creates a builder with given table schema.
|
static TableSchema |
TableSchemaUtils.checkOnlyPhysicalColumns(TableSchema schema)
Throws an exception if the given
TableSchema contains any non-physical columns. |
static boolean |
TableSchemaUtils.containsPhysicalColumnsOnly(TableSchema schema)
Returns true if there are only physical columns in the given
TableSchema . |
static TableSchema |
TableSchemaUtils.dropConstraint(TableSchema oriSchema,
String constraintName)
Creates a new schema but drop the constraint with given name.
|
static TableSchema |
TableSchemaUtils.getPhysicalSchema(TableSchema tableSchema)
Return
TableSchema which consists of all physical columns. |
static int[] |
TableSchemaUtils.getPrimaryKeyIndices(TableSchema schema)
Returns the field indices of primary key in the physical columns of this schema (not include
computed columns or metadata columns).
|
Modifier and Type | Method and Description |
---|---|
TableSchema |
PythonInputFormatTableSource.getTableSchema() |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.