public class Kafka08TableSourceSinkFactory extends KafkaTableSourceSinkFactoryBase
Kafka08TableSource
.Constructor and Description |
---|
Kafka08TableSourceSinkFactory() |
Modifier and Type | Method and Description |
---|---|
protected KafkaTableSinkBase |
createKafkaTableSink(TableSchema schema,
String topic,
Properties properties,
Optional<FlinkKafkaPartitioner<Row>> partitioner,
SerializationSchema<Row> serializationSchema)
Constructs the version-specific Kafka table sink.
|
protected KafkaTableSourceBase |
createKafkaTableSource(TableSchema schema,
Optional<String> proctimeAttribute,
List<RowtimeAttributeDescriptor> rowtimeAttributeDescriptors,
Map<String,String> fieldMapping,
String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema,
StartupMode startupMode,
Map<KafkaTopicPartition,Long> specificStartupOffsets)
Constructs the version-specific Kafka table source.
|
protected String |
kafkaVersion()
Returns the Kafka version.
|
protected boolean |
supportsKafkaTimestamps()
True if the Kafka source supports Kafka timestamps, false otherwise.
|
createStreamTableSink, createStreamTableSource, requiredContext, supportedProperties
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
createTableSource
createTableSource
createTableSink
createTableSink
protected String kafkaVersion()
KafkaTableSourceSinkFactoryBase
kafkaVersion
in class KafkaTableSourceSinkFactoryBase
protected boolean supportsKafkaTimestamps()
KafkaTableSourceSinkFactoryBase
supportsKafkaTimestamps
in class KafkaTableSourceSinkFactoryBase
protected KafkaTableSourceBase createKafkaTableSource(TableSchema schema, Optional<String> proctimeAttribute, List<RowtimeAttributeDescriptor> rowtimeAttributeDescriptors, Map<String,String> fieldMapping, String topic, Properties properties, DeserializationSchema<Row> deserializationSchema, StartupMode startupMode, Map<KafkaTopicPartition,Long> specificStartupOffsets)
KafkaTableSourceSinkFactoryBase
createKafkaTableSource
in class KafkaTableSourceSinkFactoryBase
schema
- Schema of the produced table.proctimeAttribute
- Field name of the processing time attribute.rowtimeAttributeDescriptors
- Descriptor for a rowtime attributefieldMapping
- Mapping for the fields of the table schema to
fields of the physical returned type.topic
- Kafka topic to consume.properties
- Properties for the Kafka consumer.deserializationSchema
- Deserialization schema for decoding records from Kafka.startupMode
- Startup mode for the contained consumer.specificStartupOffsets
- Specific startup offsets; only relevant when startup
mode is StartupMode.SPECIFIC_OFFSETS
.protected KafkaTableSinkBase createKafkaTableSink(TableSchema schema, String topic, Properties properties, Optional<FlinkKafkaPartitioner<Row>> partitioner, SerializationSchema<Row> serializationSchema)
KafkaTableSourceSinkFactoryBase
createKafkaTableSink
in class KafkaTableSourceSinkFactoryBase
schema
- Schema of the produced table.topic
- Kafka topic to consume.properties
- Properties for the Kafka consumer.partitioner
- Partitioner to select Kafka partition for each item.Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.