Modifier and Type | Method and Description |
---|---|
TableSource |
HiveTableFactory.createTableSource(TableSourceFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
static class |
BatchSQLTestProgram.GeneratorTableSource
TableSource for generated data.
|
static class |
StreamSQLTestProgram.GeneratorTableSource
TableSource for generated data.
|
Modifier and Type | Method and Description |
---|---|
protected void |
StreamTableEnvironmentImpl.validateTableSource(TableSource<?> tableSource) |
Modifier and Type | Method and Description |
---|---|
Table |
TableEnvironmentImpl.fromTableSource(TableSource<?> source) |
Table |
TableEnvironmentInternal.fromTableSource(TableSource<?> source)
Deprecated.
|
void |
TableEnvironmentImpl.registerTableSourceInternal(String name,
TableSource<?> tableSource) |
void |
TableEnvironmentInternal.registerTableSourceInternal(String name,
TableSource<?> tableSource)
Registers an external
TableSource in this TableEnvironment 's catalog. |
protected void |
TableEnvironmentImpl.validateTableSource(TableSource<?> tableSource)
Subclasses can override this method to add additional checks.
|
Modifier and Type | Method and Description |
---|---|
Optional<TableSource<T1>> |
ConnectorCatalogTable.getTableSource() |
Modifier and Type | Method and Description |
---|---|
static <T1> TableSchema |
ConnectorCatalogTable.calculateSourceSchema(TableSource<T1> source,
boolean isBatch) |
static <T1> ConnectorCatalogTable<T1,?> |
ConnectorCatalogTable.source(TableSource<T1> source,
boolean isBatch) |
static <T1,T2> ConnectorCatalogTable<T1,T2> |
ConnectorCatalogTable.sourceAndSink(TableSource<T1> source,
TableSink<T2> sink,
boolean isBatch) |
Constructor and Description |
---|
ConnectorCatalogTable(TableSource<T1> tableSource,
TableSink<T2> tableSink,
TableSchema tableSchema,
boolean isBatch) |
Modifier and Type | Method and Description |
---|---|
default TableSource<T> |
StreamTableSourceFactory.createTableSource(Map<String,String> properties)
Deprecated.
Only create a stream table source.
|
default TableSource<T> |
TableSourceFactory.createTableSource(Map<String,String> properties)
Deprecated.
TableSourceFactory.Context contains more information, and already contains table schema too.
Please use TableSourceFactory.createTableSource(Context) instead. |
default TableSource<T> |
TableSourceFactory.createTableSource(ObjectPath tablePath,
CatalogTable table)
Deprecated.
TableSourceFactory.Context contains more information, and already contains table schema too.
Please use TableSourceFactory.createTableSource(Context) instead. |
default TableSource<T> |
TableSourceFactory.createTableSource(TableSourceFactory.Context context)
Deprecated.
Creates and configures a
TableSource based on the given TableSourceFactory.Context . |
static <T> TableSource<T> |
TableFactoryUtil.findAndCreateTableSource(Catalog catalog,
ObjectIdentifier objectIdentifier,
CatalogTable catalogTable,
ReadableConfig configuration,
boolean isTemporary)
Creates a
TableSource from a CatalogTable . |
static <T> TableSource<T> |
TableFactoryUtil.findAndCreateTableSource(TableSourceFactory.Context context)
Returns a table source matching the descriptor.
|
Modifier and Type | Method and Description |
---|---|
TableSource<T> |
TableSourceQueryOperation.getTableSource() |
Constructor and Description |
---|
TableSourceQueryOperation(TableSource<T> tableSource,
boolean isBatch) |
Constructor and Description |
---|
RichTableSourceQueryOperation(ObjectIdentifier identifier,
TableSource<T> tableSource,
org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic) |
Constructor and Description |
---|
BatchExecLegacyTableSourceScan(ReadableConfig tableConfig,
TableSource<?> tableSource,
List<String> qualifiedName,
RowType outputType,
String description) |
Modifier and Type | Field and Description |
---|---|
protected TableSource<?> |
CommonExecLegacyTableSourceScan.tableSource |
Constructor and Description |
---|
CommonExecLegacyTableSourceScan(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
TableSource<?> tableSource,
List<String> qualifiedName,
RowType outputType,
String description) |
Constructor and Description |
---|
StreamExecLegacyTableSourceScan(ReadableConfig tableConfig,
TableSource<?> tableSource,
List<String> qualifiedName,
RowType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
protected List<String> |
FlinkPreparingTableBase.explainSourceAsString(TableSource<?> ts)
Returns the digest of the
TableSource instance. |
Modifier and Type | Class and Description |
---|---|
class |
ArrowTableSource
A
StreamTableSource for serialized arrow record batch data. |
Modifier and Type | Interface and Description |
---|---|
interface |
LookupableTableSource<T>
Deprecated.
This interface will not be supported in the new source design around
DynamicTableSource . Use LookupTableSource instead. See FLIP-95 for more information. |
interface |
StreamTableSource<T>
Deprecated.
This interface has been replaced by
DynamicTableSource . The new interface
produces internal data structures. See FLIP-95 for more information. |
Modifier and Type | Class and Description |
---|---|
class |
CsvTableSource
Deprecated.
The legacy CSV connector has been replaced by
FileSource . It is kept only to
support tests for the legacy connector stack. |
class |
InputFormatTableSource<T>
Deprecated.
This interface has been replaced by
DynamicTableSource . The new interface
produces internal data structures. See FLIP-95 for more information. |
Modifier and Type | Method and Description |
---|---|
TableSource<T> |
LimitableTableSource.applyLimit(long limit)
Deprecated.
Check and push down the limit to the table source.
|
TableSource |
PartitionableTableSource.applyPartitionPruning(List<Map<String,String>> remainingPartitions)
Deprecated.
Applies the remaining partitions to the table source.
|
TableSource<T> |
FilterableTableSource.applyPredicate(List<Expression> predicates)
Deprecated.
Check and pick all predicates this table source can support.
|
TableSource<T> |
ProjectableTableSource.projectFields(int[] fields)
Deprecated.
Creates a copy of the
TableSource that projects its output to the given field
indexes. |
TableSource<T> |
NestedFieldsProjectableTableSource.projectNestedFields(int[] fields,
String[][] nestedFields)
Deprecated.
Creates a copy of the
TableSource that projects its output to the given field
indexes. |
Modifier and Type | Method and Description |
---|---|
static boolean |
TableSourceValidation.hasProctimeAttribute(TableSource<?> tableSource)
Checks if the given
TableSource defines a proctime attribute. |
static boolean |
TableSourceValidation.hasRowtimeAttribute(TableSource<?> tableSource)
Checks if the given
TableSource defines a rowtime attribute. |
static void |
TableSourceValidation.validateTableSource(TableSource<?> tableSource,
TableSchema schema)
Validates a TableSource.
|
Modifier and Type | Method and Description |
---|---|
static int[] |
TypeMappingUtils.computePhysicalIndicesOrTimeAttributeMarkers(TableSource<?> tableSource,
List<TableColumn> logicalColumns,
boolean streamMarkers,
java.util.function.Function<String,String> nameRemapping)
Computes indices of physical fields corresponding to the selected logical fields of a
TableSchema . |
Modifier and Type | Class and Description |
---|---|
class |
PythonInputFormatTableSource
An
InputFormatTableSource created by python 'from_element' method. |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.