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 Kafka011JsonTableSource extends KafkaJsonTableSource
StreamTableSource
for Kafka 0.11.Modifier and Type | Class and Description |
---|---|
static class |
Kafka011JsonTableSource.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 |
---|
Kafka011JsonTableSource(String topic,
Properties properties,
org.apache.flink.table.api.TableSchema tableSchema,
org.apache.flink.table.api.TableSchema jsonSchema)
Deprecated.
Use table descriptors instead of implementation-specific builders.
|
Modifier and Type | Method and Description |
---|---|
static Kafka011JsonTableSource.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 |
setFailOnMissingField(boolean failOnMissingField)
Deprecated.
Use table descriptors instead of implementation-specific builders.
|
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 Kafka011JsonTableSource(String topic, Properties properties, org.apache.flink.table.api.TableSchema tableSchema, org.apache.flink.table.api.TableSchema jsonSchema)
StreamTableSource
.topic
- Kafka topic to consume.properties
- Properties for the Kafka consumer.tableSchema
- The schema of the table.jsonSchema
- The schema of the JSON messages to decode from Kafka.@Deprecated public void setFailOnMissingField(boolean failOnMissingField)
setFailOnMissingField
in class KafkaJsonTableSource
failOnMissingField
- Flag that specifies the TableSource behavior in case of missing fields.@Deprecated public void setFieldMapping(Map<String,String> fieldMapping)
setFieldMapping
in class KafkaTableSource
fieldMapping
- The mapping from table schema fields to JSON schema 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 Kafka011JsonTableSource.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)
.Kafka011JsonTableSource
.Kafka011JsonTableSource
.Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.