Modifier and Type | Class and Description |
---|---|
class |
AsyncDynamicTableSink<RequestEntryT extends Serializable>
Abstract wrapper class for
DynamicTableSink with attributes of AsyncSinkBase . |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
BlackHoleTableSinkFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
class |
FileSystemTableSink
File system
DynamicTableSink . |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
FileSystemTableSink.copy() |
DynamicTableSink |
FileSystemTableFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
class |
KinesisFirehoseDynamicSink
Kinesis firehose backed
AsyncDynamicTableSink . |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
KinesisFirehoseDynamicSink.copy() |
DynamicTableSink |
KinesisFirehoseDynamicTableFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
HBase1DynamicTableFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
class |
HBaseDynamicTableSink
HBase table sink implementation.
|
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
HBaseDynamicTableSink.copy() |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
HBase2DynamicTableFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
HBaseDynamicTableSink.copy() |
Modifier and Type | Class and Description |
---|---|
class |
JdbcDynamicTableSink
A
DynamicTableSink for JDBC. |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
JdbcDynamicTableSink.copy() |
DynamicTableSink |
JdbcDynamicTableFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
class |
KinesisDynamicSink
Kinesis backed
AsyncDynamicTableSink . |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
KinesisDynamicSink.copy() |
DynamicTableSink |
KinesisDynamicTableSinkFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
PrintTableSinkFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
UpsertTestDynamicTableSinkFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
class |
HiveTableSink
Table sink to write to Hive tables.
|
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
HiveTableSink.copy() |
DynamicTableSink |
HiveDynamicTableFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
Elasticsearch6DynamicSinkFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
DynamicTableSink |
Elasticsearch7DynamicSinkFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Class and Description |
---|---|
class |
KafkaDynamicSink
A version-agnostic Kafka
DynamicTableSink . |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
KafkaDynamicSink.copy() |
DynamicTableSink |
KafkaDynamicTableFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
DynamicTableSink |
UpsertKafkaDynamicTableFactory.createDynamicTableSink(DynamicTableFactory.Context context) |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
DynamicTableSink.copy()
Creates a copy of this instance during planning.
|
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
DynamicTableSinkFactory.createDynamicTableSink(DynamicTableFactory.Context context)
Creates a
DynamicTableSink instance from a CatalogTable and additional
context information. |
static DynamicTableSink |
FactoryUtil.createDynamicTableSink(DynamicTableSinkFactory preferredFactory,
ObjectIdentifier objectIdentifier,
ResolvedCatalogTable catalogTable,
Map<String,String> enrichmentOptions,
ReadableConfig configuration,
ClassLoader classLoader,
boolean isTemporary)
Creates a
DynamicTableSink from a CatalogTable . |
static DynamicTableSink |
FactoryUtil.createDynamicTableSink(DynamicTableSinkFactory preferredFactory,
ObjectIdentifier objectIdentifier,
ResolvedCatalogTable catalogTable,
ReadableConfig configuration,
ClassLoader classLoader,
boolean isTemporary)
|
static DynamicTableSink |
FactoryUtil.createTableSink(Catalog catalog,
ObjectIdentifier objectIdentifier,
ResolvedCatalogTable catalogTable,
ReadableConfig configuration,
ClassLoader classLoader,
boolean isTemporary)
|
Modifier and Type | Class and Description |
---|---|
class |
CollectDynamicSink
Table sink for
TableResult.collect() . |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
CollectDynamicSink.copy() |
Modifier and Type | Method and Description |
---|---|
static org.apache.calcite.rel.RelNode |
DynamicSinkUtils.convertSinkToRel(FlinkRelBuilder relBuilder,
org.apache.calcite.rel.RelNode input,
SinkModifyOperation sinkModifyOperation,
DynamicTableSink sink)
Converts a given
DynamicTableSink to a RelNode . |
Modifier and Type | Method and Description |
---|---|
void |
SinkAbilitySpec.apply(DynamicTableSink tableSink)
Apply the ability to the given
DynamicTableSink . |
void |
WritingMetadataSpec.apply(DynamicTableSink tableSink) |
void |
OverwriteSpec.apply(DynamicTableSink tableSink) |
void |
PartitioningSpec.apply(DynamicTableSink tableSink) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<Object> |
CommonExecSink.createSinkTransformation(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<RowData> inputTransform,
DynamicTableSink tableSink,
int rowtimeFieldIndex,
boolean upsertMaterialize,
int[] inputUpsertKey) |
Modifier and Type | Method and Description |
---|---|
DynamicTableSink |
DynamicTableSinkSpec.getTableSink(org.apache.flink.table.planner.calcite.FlinkContext context) |
Modifier and Type | Method and Description |
---|---|
void |
DynamicTableSinkSpec.setTableSink(DynamicTableSink tableSink) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.