Modifier and Type | Class and Description |
---|---|
class |
DataGenTableSource
A
StreamTableSource that emits generated data rows. |
Modifier and Type | Method and Description |
---|---|
DynamicTableSource |
DataGenTableSource.copy() |
DynamicTableSource |
DataGenTableSourceFactory.createDynamicTableSource(DynamicTableFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
class |
FileSystemTableSource
File system table source.
|
Modifier and Type | Method and Description |
---|---|
DynamicTableSource |
FileSystemTableFactory.createDynamicTableSource(DynamicTableFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
class |
HiveLookupTableSource
Hive Table Source that has lookup ability.
|
class |
HiveTableSource
A TableSource implementation to read data from Hive tables.
|
Modifier and Type | Method and Description |
---|---|
DynamicTableSource |
HiveTableSource.copy() |
DynamicTableSource |
HiveLookupTableSource.copy() |
DynamicTableSource |
HiveDynamicTableFactory.createDynamicTableSource(DynamicTableFactory.Context context) |
Modifier and Type | Interface and Description |
---|---|
interface |
LookupTableSource
A
DynamicTableSource that looks up rows of an external storage system by one or more keys
during runtime. |
interface |
ScanTableSource
A
DynamicTableSource that scans all rows from an external storage system during runtime. |
Modifier and Type | Method and Description |
---|---|
DynamicTableSource |
DynamicTableSource.copy()
Creates a copy of this instance during planning.
|
Modifier and Type | Class and Description |
---|---|
class |
SocketDynamicTableSource
The
SocketDynamicTableSource is used during planning. |
Modifier and Type | Method and Description |
---|---|
DynamicTableSource |
SocketDynamicTableSource.copy() |
DynamicTableSource |
SocketDynamicTableFactory.createDynamicTableSource(DynamicTableFactory.Context context) |
Modifier and Type | Method and Description |
---|---|
DynamicTableSource |
DynamicTableSourceFactory.createDynamicTableSource(DynamicTableFactory.Context context)
Creates a
DynamicTableSource instance from a CatalogTable and additional
context information. |
static DynamicTableSource |
FactoryUtil.createDynamicTableSource(DynamicTableSourceFactory preferredFactory,
ObjectIdentifier objectIdentifier,
ResolvedCatalogTable catalogTable,
Map<String,String> enrichmentOptions,
ReadableConfig configuration,
ClassLoader classLoader,
boolean isTemporary)
Creates a
DynamicTableSource from a CatalogTable . |
static DynamicTableSource |
FactoryUtil.createDynamicTableSource(DynamicTableSourceFactory preferredFactory,
ObjectIdentifier objectIdentifier,
ResolvedCatalogTable catalogTable,
ReadableConfig configuration,
ClassLoader classLoader,
boolean isTemporary)
|
static DynamicTableSource |
FactoryUtil.createTableSource(Catalog catalog,
ObjectIdentifier objectIdentifier,
ResolvedCatalogTable catalogTable,
ReadableConfig configuration,
ClassLoader classLoader,
boolean isTemporary)
|
Modifier and Type | Method and Description |
---|---|
DynamicTableSource |
TestFileSystemTableFactory.createDynamicTableSource(DynamicTableFactory.Context context) |
Modifier and Type | Method and Description |
---|---|
static boolean |
DynamicSourceUtils.changelogNormalizeEnabled(boolean eventTimeSnapshotRequired,
ResolvedSchema resolvedSchema,
DynamicTableSource tableSource,
TableConfig tableConfig)
Returns true if the changelogNormalize should be enabled.
|
static org.apache.calcite.rel.RelNode |
DynamicSourceUtils.convertSourceToRel(boolean isBatchMode,
ReadableConfig config,
FlinkRelBuilder relBuilder,
ContextResolvedTable contextResolvedTable,
org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic,
List<org.apache.calcite.rel.hint.RelHint> hints,
DynamicTableSource tableSource)
Converts a given
DynamicTableSource to a RelNode . |
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 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 void |
DynamicSourceUtils.prepareDynamicSource(String tableDebugName,
ResolvedCatalogTable table,
DynamicTableSource source,
boolean isBatchMode,
ReadableConfig config,
List<SourceAbilitySpec> sourceAbilities)
Prepares the given
DynamicTableSource . |
static void |
DynamicSourceUtils.validateAndApplyMetadata(String tableDebugName,
ResolvedSchema schema,
DynamicTableSource source,
List<SourceAbilitySpec> sourceAbilities) |
Modifier and Type | Method and Description |
---|---|
void |
LimitPushDownSpec.apply(DynamicTableSource tableSource,
SourceAbilityContext context) |
void |
SourceAbilitySpec.apply(DynamicTableSource tableSource,
SourceAbilityContext context)
Apply the ability to the given
DynamicTableSource . |
void |
SourceWatermarkSpec.apply(DynamicTableSource tableSource,
SourceAbilityContext context) |
void |
FilterPushDownSpec.apply(DynamicTableSource tableSource,
SourceAbilityContext context) |
void |
PartitionPushDownSpec.apply(DynamicTableSource tableSource,
SourceAbilityContext context) |
void |
WatermarkPushDownSpec.apply(DynamicTableSource tableSource,
SourceAbilityContext context) |
void |
ProjectPushDownSpec.apply(DynamicTableSource tableSource,
SourceAbilityContext context) |
void |
AggregatePushDownSpec.apply(DynamicTableSource tableSource,
SourceAbilityContext context) |
void |
ReadingMetadataSpec.apply(DynamicTableSource tableSource,
SourceAbilityContext context) |
static SupportsFilterPushDown.Result |
FilterPushDownSpec.apply(List<org.apache.calcite.rex.RexNode> predicates,
DynamicTableSource tableSource,
SourceAbilityContext context) |
static boolean |
AggregatePushDownSpec.apply(RowType inputType,
List<int[]> groupingSets,
List<org.apache.calcite.rel.core.AggregateCall> aggregateCalls,
RowType producedType,
DynamicTableSource tableSource,
SourceAbilityContext context) |
Modifier and Type | Method and Description |
---|---|
void |
DynamicTableSourceSpec.setTableSource(DynamicTableSource tableSource) |
Modifier and Type | Class and Description |
---|---|
class |
TestScanTableSourceWithWatermarkPushDown
A source used to test
SupportsWatermarkPushDown . |
Modifier and Type | Method and Description |
---|---|
DynamicTableSource |
TestScanTableSourceWithWatermarkPushDown.copy() |
DynamicTableSource |
TestScanTableSourceWithWatermarkPushDownFactory.createDynamicTableSource(DynamicTableFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
class |
PythonDynamicTableSource
Implementation of
ScanTableSource for python elements table. |
Modifier and Type | Method and Description |
---|---|
DynamicTableSource |
PythonDynamicTableSource.copy() |
DynamicTableSource |
PythonDynamicTableFactory.createDynamicTableSource(DynamicTableFactory.Context context) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.