Kafka
descriptor together
with descriptors for schema and format instead. Descriptors allow for
implementation-agnostic definition of tables. See also
TableEnvironment.connect(ConnectorDescriptor)
.@Deprecated public class Kafka011AvroTableSource extends KafkaAvroTableSource
StreamTableSource
for Kafka 0.11.Modifier and Type | Class and Description |
---|---|
static class |
Kafka011AvroTableSource.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) . |
Constructor and Description |
---|
Kafka011AvroTableSource(String topic,
Properties properties,
org.apache.flink.table.api.TableSchema schema,
Class<? extends org.apache.avro.specific.SpecificRecordBase> record)
Deprecated.
Use table descriptors instead of implementation-specific builders.
|
Modifier and Type | Method and Description |
---|---|
static Kafka011AvroTableSource.Builder |
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) . |
protected FlinkKafkaConsumerBase<Row> |
createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema)
Deprecated.
Creates a version-specific Kafka consumer.
|
void |
setFieldMapping(Map<String,String> fieldMapping)
Deprecated.
Use table descriptors instead of implementation-specific builders.
|
void |
setProctimeAttribute(String proctimeAttribute)
Deprecated.
Use table descriptors instead of implementation-specific builders.
|
void |
setRowtimeAttributeDescriptor(org.apache.flink.table.sources.RowtimeAttributeDescriptor rowtimeAttributeDescriptor)
Deprecated.
Use table descriptors instead of implementation-specific builders.
|
explainSource
equals, getDataStream, getDeserializationSchema, getFieldMapping, getKafkaConsumer, getProctimeAttribute, getProperties, getReturnType, getRowtimeAttributeDescriptors, getTableSchema, hashCode, setRowtimeAttributeDescriptors, setSpecificStartupOffsets, setStartupMode
@Deprecated public Kafka011AvroTableSource(String topic, Properties properties, org.apache.flink.table.api.TableSchema schema, Class<? extends org.apache.avro.specific.SpecificRecordBase> record)
StreamTableSource
using a given SpecificRecord
.topic
- Kafka topic to consume.properties
- Properties for the Kafka consumer.schema
- Schema of the produced table.record
- Avro specific record.@Deprecated public void setFieldMapping(Map<String,String> fieldMapping)
A field mapping is required if the fields of produced tables should be named different than the fields of the Avro record. The key of the provided Map refers to the field of the table schema, the value to the field of the Avro record.
setFieldMapping
in class KafkaTableSource
fieldMapping
- A mapping from schema fields to Avro fields.@Deprecated public void setProctimeAttribute(String proctimeAttribute)
setProctimeAttribute
in class KafkaTableSource
proctimeAttribute
- The name of the field that becomes the processing time field.@Deprecated public void setRowtimeAttributeDescriptor(org.apache.flink.table.sources.RowtimeAttributeDescriptor rowtimeAttributeDescriptor)
rowtimeAttributeDescriptor
- The descriptor of the rowtime attribute.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.@Deprecated public static Kafka011AvroTableSource.Builder builder()
Kafka
descriptor together
with descriptors for schema and format instead. Descriptors allow for
implementation-agnostic definition of tables. See also
TableEnvironment.connect(ConnectorDescriptor)
.Kafka011AvroTableSource
.Kafka011AvroTableSource
.Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.