Kafka
descriptor together
with descriptors for schema and format instead. Descriptors allow for
implementation-agnostic definition of tables. See also
TableEnvironment.connect(ConnectorDescriptor)
.@Deprecated @Internal public abstract class KafkaAvroTableSource extends KafkaTableSource
StreamTableSource
.
The version-specific Kafka consumers need to extend this class and
override KafkaTableSource.createKafkaConsumer(String, Properties, DeserializationSchema)
}.
Modifier and Type | Class and Description |
---|---|
protected static class |
KafkaAvroTableSource.Builder<T extends KafkaAvroTableSource,B extends KafkaAvroTableSource.Builder>
Deprecated.
Use the
Kafka descriptor together
with descriptors for schema and format instead. Descriptors allow for
implementation-agnostic definition of tables. See also
TableEnvironment.connect(ConnectorDescriptor) . |
Modifier | Constructor and Description |
---|---|
protected |
KafkaAvroTableSource(String topic,
Properties properties,
org.apache.flink.table.api.TableSchema schema,
Class<? extends org.apache.avro.specific.SpecificRecordBase> avroRecordClass)
Deprecated.
Use the
Kafka descriptor together
with descriptors for schema and format instead. Descriptors allow for
implementation-agnostic definition of tables. See also
TableEnvironment.connect(ConnectorDescriptor) . |
Modifier and Type | Method and Description |
---|---|
String |
explainSource()
Deprecated.
|
createKafkaConsumer, equals, getDataStream, getDeserializationSchema, getFieldMapping, getKafkaConsumer, getProctimeAttribute, getProperties, getReturnType, getRowtimeAttributeDescriptors, getTableSchema, hashCode, setFieldMapping, setProctimeAttribute, setRowtimeAttributeDescriptors, setSpecificStartupOffsets, setStartupMode
@Deprecated protected KafkaAvroTableSource(String topic, Properties properties, org.apache.flink.table.api.TableSchema schema, Class<? extends org.apache.avro.specific.SpecificRecordBase> avroRecordClass)
Kafka
descriptor together
with descriptors for schema and format instead. Descriptors allow for
implementation-agnostic definition of tables. See also
TableEnvironment.connect(ConnectorDescriptor)
.StreamTableSource
using a given SpecificRecord
.topic
- Kafka topic to consume.properties
- Properties for the Kafka consumer.schema
- Schema of the produced table.avroRecordClass
- Class of the Avro record that is read from the Kafka topic.public String explainSource()
explainSource
in interface org.apache.flink.table.sources.TableSource<Row>
explainSource
in class KafkaTableSource
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.