@PublicEvolving public abstract class Kafka08TableSource extends KafkaTableSource
StreamTableSource
for Kafka 0.8.KafkaTableSource.Builder<T extends KafkaTableSource,B extends KafkaTableSource.Builder>
Constructor and Description |
---|
Kafka08TableSource(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema,
org.apache.flink.table.api.TableSchema schema,
TypeInformation<Row> typeInfo)
Creates a Kafka 0.8
StreamTableSource . |
Modifier and Type | Method and Description |
---|---|
protected FlinkKafkaConsumerBase<Row> |
createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema)
Creates a version-specific Kafka consumer.
|
DeserializationSchema<Row> |
getDeserializationSchema()
Returns the deserialization schema.
|
equals, explainSource, getDataStream, getKafkaConsumer, getProctimeAttribute, getReturnType, getRowtimeAttributeDescriptors, getTableSchema, hashCode, setProctimeAttribute, setRowtimeAttributeDescriptors, setSpecificStartupOffsets, setStartupMode
public Kafka08TableSource(String topic, Properties properties, DeserializationSchema<Row> deserializationSchema, org.apache.flink.table.api.TableSchema schema, TypeInformation<Row> typeInfo)
StreamTableSource
.topic
- Kafka topic to consume.properties
- Properties for the Kafka consumer.deserializationSchema
- Deserialization schema to use for Kafka records.typeInfo
- Type information describing the result type. The field names are used
to parse the JSON file and so are the types.public DeserializationSchema<Row> getDeserializationSchema()
KafkaTableSource
getDeserializationSchema
in class KafkaTableSource
protected FlinkKafkaConsumerBase<Row> createKafkaConsumer(String topic, Properties properties, DeserializationSchema<Row> deserializationSchema)
KafkaTableSource
createKafkaConsumer
in class KafkaTableSource
topic
- Kafka topic to consume.properties
- Properties for the Kafka consumer.deserializationSchema
- Deserialization schema to use for Kafka records.Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.