Modifier and Type | Class and Description |
---|---|
class |
AbstractDeserializationSchema<T>
The deserialization schema describes how to turn the byte messages delivered by certain
data sources (for example Apache Kafka) into data types (Java/Scala objects) that are
processed by Flink.
|
class |
SimpleStringSchema
Very simple serialization schema for strings.
|
class |
TypeInformationSerializationSchema<T>
A serialization and deserialization schema that uses Flink's serialization stack to
transform typed from and to byte arrays.
|
Modifier and Type | Class and Description |
---|---|
class |
AvroRowDeserializationSchema
Deserialization schema from Avro bytes over
SpecificRecord to Row . |
Modifier and Type | Class and Description |
---|---|
class |
JsonNodeDeserializationSchema
DeserializationSchema that deserializes a JSON String into an ObjectNode.
|
class |
JsonRowDeserializationSchema
Deserialization schema from JSON to Flink types.
|
Modifier and Type | Method and Description |
---|---|
DeserializationSchema<Row> |
Kafka011TableSource.getDeserializationSchema() |
DeserializationSchema<Row> |
Kafka010TableSource.getDeserializationSchema() |
DeserializationSchema<Row> |
Kafka09TableSource.getDeserializationSchema() |
DeserializationSchema<Row> |
Kafka08TableSource.getDeserializationSchema() |
protected abstract DeserializationSchema<Row> |
KafkaTableSource.getDeserializationSchema()
Returns the deserialization schema.
|
Modifier and Type | Method and Description |
---|---|
protected FlinkKafkaConsumerBase<Row> |
Kafka011JsonTableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka011TableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka011AvroTableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka010TableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka010AvroTableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka010JsonTableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka09JsonTableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka09AvroTableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka09TableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka08AvroTableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka08TableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected FlinkKafkaConsumerBase<Row> |
Kafka08JsonTableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema) |
protected abstract FlinkKafkaConsumerBase<Row> |
KafkaTableSource.createKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema)
Creates a version-specific Kafka consumer.
|
protected FlinkKafkaConsumerBase<Row> |
KafkaTableSource.getKafkaConsumer(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema)
Returns a version-specific Kafka consumer with the start position configured.
|
Constructor and Description |
---|
FlinkKafkaConsumer010(List<String> topics,
DeserializationSchema<T> deserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.10.x
|
FlinkKafkaConsumer010(Pattern subscriptionPattern,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.10.x.
|
FlinkKafkaConsumer010(String topic,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.10.x.
|
FlinkKafkaConsumer011(List<String> topics,
DeserializationSchema<T> deserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.11.x
|
FlinkKafkaConsumer011(Pattern subscriptionPattern,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.11.x.
|
FlinkKafkaConsumer011(String topic,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.11.x.
|
FlinkKafkaConsumer08(List<String> topics,
DeserializationSchema<T> deserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.8.x
|
FlinkKafkaConsumer08(Pattern subscriptionPattern,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.8.x.
|
FlinkKafkaConsumer08(String topic,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.8.x.
|
FlinkKafkaConsumer081(String topic,
DeserializationSchema<T> valueDeserializer,
Properties props)
|
FlinkKafkaConsumer082(String topic,
DeserializationSchema<T> valueDeserializer,
Properties props)
|
FlinkKafkaConsumer09(List<String> topics,
DeserializationSchema<T> deserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.9.x
|
FlinkKafkaConsumer09(Pattern subscriptionPattern,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.9.x.
|
FlinkKafkaConsumer09(String topic,
DeserializationSchema<T> valueDeserializer,
Properties props)
Creates a new Kafka streaming source consumer for Kafka 0.9.x .
|
Kafka010TableSource(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema,
org.apache.flink.table.api.TableSchema schema,
TypeInformation<Row> typeInfo)
Creates a Kafka 0.10
StreamTableSource . |
Kafka011TableSource(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema,
org.apache.flink.table.api.TableSchema schema,
TypeInformation<Row> typeInfo)
Creates a Kafka 0.11
StreamTableSource . |
Kafka08TableSource(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema,
org.apache.flink.table.api.TableSchema schema,
TypeInformation<Row> typeInfo)
Creates a Kafka 0.8
StreamTableSource . |
Kafka09TableSource(String topic,
Properties properties,
DeserializationSchema<Row> deserializationSchema,
org.apache.flink.table.api.TableSchema schema,
TypeInformation<Row> typeInfo)
Creates a Kafka 0.9
StreamTableSource . |
Modifier and Type | Field and Description |
---|---|
protected DeserializationSchema<OUT> |
RMQSource.schema |
Constructor and Description |
---|
RMQSource(RMQConnectionConfig rmqConnectionConfig,
String queueName,
boolean usesCorrelationId,
DeserializationSchema<OUT> deserializationSchema)
Creates a new RabbitMQ source.
|
RMQSource(RMQConnectionConfig rmqConnectionConfig,
String queueName,
DeserializationSchema<OUT> deserializationSchema)
Creates a new RabbitMQ source with at-least-once message processing guarantee when
checkpointing is enabled.
|
Modifier and Type | Class and Description |
---|---|
class |
KafkaEventSchema
The serialization schema for the
KafkaEvent type. |
Modifier and Type | Class and Description |
---|---|
class |
EventDeSerializer
A serializer and deserializer for the
Event type. |
Modifier and Type | Interface and Description |
---|---|
interface |
DeserializationSchema<T>
Deprecated.
Use
DeserializationSchema instead. |
Modifier and Type | Class and Description |
---|---|
class |
JSONDeserializationSchema
Deprecated.
Please use
JsonNodeDeserializationSchema in the "flink-json" module. |
Constructor and Description |
---|
KeyedDeserializationSchemaWrapper(DeserializationSchema<T> deserializationSchema) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.