Uses of Interface
org.apache.flink.api.common.serialization.DeserializationSchema
-
-
Uses of DeserializationSchema in org.apache.flink.api.common.serialization
Classes in org.apache.flink.api.common.serialization that implement DeserializationSchema Modifier and Type Class 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. -
Uses of DeserializationSchema in org.apache.flink.connector.file.table
Constructors in org.apache.flink.connector.file.table with parameters of type DeserializationSchema Constructor Description DeserializationSchemaAdapter(DeserializationSchema<RowData> deserializationSchema)
-
Uses of DeserializationSchema in org.apache.flink.connector.testutils.formats
Methods in org.apache.flink.connector.testutils.formats with parameters of type DeserializationSchema Modifier and Type Method Description static void
SchemaTestUtils. open(DeserializationSchema<?> schema)
Opens the given schema with a mock initialization context. -
Uses of DeserializationSchema in org.apache.flink.connector.upserttest.sink
Methods in org.apache.flink.connector.upserttest.sink with parameters of type DeserializationSchema Modifier and Type Method Description static <K,V>
Map<K,V>UpsertTestFileUtil. readRecords(BufferedInputStream bis, DeserializationSchema<K> keyDeserializationSchema, DeserializationSchema<V> valueDeserializationSchema)
Reads records that were written using theUpsertTestSinkWriter
from the given InputStream and converts them using the providedDeserializationSchema
s.static <K,V>
Map<K,V>UpsertTestFileUtil. readRecords(File file, DeserializationSchema<K> keyDeserializationSchema, DeserializationSchema<V> valueDeserializationSchema)
Reads records that were written using theUpsertTestSinkWriter
from the given File and converts them using the providedDeserializationSchema
s. -
Uses of DeserializationSchema in org.apache.flink.formats.avro
Classes in org.apache.flink.formats.avro that implement DeserializationSchema Modifier and Type Class Description class
AvroDeserializationSchema<T>
Deserialization schema that deserializes from Avro binary format.class
AvroRowDataDeserializationSchema
Deserialization schema from Avro bytes toRowData
.class
AvroRowDeserializationSchema
Deserialization schema from Avro bytes toRow
.class
RegistryAvroDeserializationSchema<T>
Deserialization schema that deserializes from Avro format usingSchemaCoder
.Methods in org.apache.flink.formats.avro that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
AvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Constructors in org.apache.flink.formats.avro with parameters of type DeserializationSchema Constructor Description AvroRowDataDeserializationSchema(DeserializationSchema<org.apache.avro.generic.GenericRecord> nestedSchema, AvroToRowDataConverters.AvroToRowDataConverter runtimeConverter, TypeInformation<RowData> typeInfo)
Creates a Avro deserialization schema for the given logical type. -
Uses of DeserializationSchema in org.apache.flink.formats.avro.registry.confluent
Classes in org.apache.flink.formats.avro.registry.confluent that implement DeserializationSchema Modifier and Type Class Description class
ConfluentRegistryAvroDeserializationSchema<T>
Deserialization schema that deserializes from Avro binary format usingSchemaCoder
that uses Confluent Schema Registry.Methods in org.apache.flink.formats.avro.registry.confluent that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
RegistryAvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.formats.avro.registry.confluent.debezium
Classes in org.apache.flink.formats.avro.registry.confluent.debezium that implement DeserializationSchema Modifier and Type Class Description class
DebeziumAvroDeserializationSchema
Deserialization schema from Debezium Avro to Flink Table/SQL internal data structureRowData
.Methods in org.apache.flink.formats.avro.registry.confluent.debezium that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
DebeziumAvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.formats.csv
Classes in org.apache.flink.formats.csv that implement DeserializationSchema Modifier and Type Class Description class
CsvRowDataDeserializationSchema
Deserialization schema from CSV to Flink Table & SQL internal data structures.class
CsvRowDeserializationSchema
Deserialization schema from CSV to Flink types.Methods in org.apache.flink.formats.csv that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
CsvFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.formats.json
Classes in org.apache.flink.formats.json that implement DeserializationSchema Modifier and Type Class Description class
AbstractJsonDeserializationSchema
Deserialization schema from JSON to Flink Table/SQL internal data structureRowData
.class
JsonDeserializationSchema<T>
DeserializationSchema that deserializes a JSON String.class
JsonParserRowDataDeserializationSchema
Tool class used to convert fields fromJsonParser
toRowData
which has a higher parsing efficiency.class
JsonRowDataDeserializationSchema
Deserialization schema from JSON to Flink Table/SQL internal data structureRowData
.class
JsonRowDeserializationSchema
Deserialization schema from JSON to Flink types.Methods in org.apache.flink.formats.json that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
JsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.formats.json.canal
Classes in org.apache.flink.formats.json.canal that implement DeserializationSchema Modifier and Type Class Description class
CanalJsonDeserializationSchema
Deserialization schema from Canal JSON to Flink Table/SQL internal data structureRowData
.Methods in org.apache.flink.formats.json.canal that return DeserializationSchema Modifier and Type Method Description DeserializationSchema<RowData>
CanalJsonDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType physicalDataType, int[][] projections)
Methods in org.apache.flink.formats.json.canal that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
CanalJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.formats.json.debezium
Classes in org.apache.flink.formats.json.debezium that implement DeserializationSchema Modifier and Type Class Description class
DebeziumJsonDeserializationSchema
Deserialization schema from Debezium JSON to Flink Table/SQL internal data structureRowData
.Methods in org.apache.flink.formats.json.debezium that return DeserializationSchema Modifier and Type Method Description DeserializationSchema<RowData>
DebeziumJsonDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType physicalDataType, int[][] projections)
Methods in org.apache.flink.formats.json.debezium that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
DebeziumJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.formats.json.maxwell
Classes in org.apache.flink.formats.json.maxwell that implement DeserializationSchema Modifier and Type Class Description class
MaxwellJsonDeserializationSchema
Deserialization schema from Maxwell JSON to Flink Table/SQL internal data structureRowData
.Methods in org.apache.flink.formats.json.maxwell that return DeserializationSchema Modifier and Type Method Description DeserializationSchema<RowData>
MaxwellJsonDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType physicalDataType, int[][] projections)
Methods in org.apache.flink.formats.json.maxwell that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
MaxwellJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.formats.json.ogg
Classes in org.apache.flink.formats.json.ogg that implement DeserializationSchema Modifier and Type Class Description class
OggJsonDeserializationSchema
Deserialization schema from Ogg JSON to Flink Table/SQL internal data structureRowData
.Methods in org.apache.flink.formats.json.ogg that return DeserializationSchema Modifier and Type Method Description DeserializationSchema<RowData>
OggJsonDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType physicalDataType)
Methods in org.apache.flink.formats.json.ogg that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
OggJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.formats.protobuf
Methods in org.apache.flink.formats.protobuf that return DeserializationSchema Modifier and Type Method Description DeserializationSchema<RowData>
PbDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType producedDataType)
Methods in org.apache.flink.formats.protobuf that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
PbFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.formats.protobuf.deserialize
Classes in org.apache.flink.formats.protobuf.deserialize that implement DeserializationSchema Modifier and Type Class Description class
PbRowDataDeserializationSchema
Deserialization schema from Protobuf to Flink types. -
Uses of DeserializationSchema in org.apache.flink.formats.raw
Classes in org.apache.flink.formats.raw that implement DeserializationSchema Modifier and Type Class Description class
RawFormatDeserializationSchema
Deserialization schema from raw (byte based) value to Flink Table/SQL internal data structureRowData
.Methods in org.apache.flink.formats.raw that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
RawFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DeserializationSchema in org.apache.flink.streaming.examples.statemachine.kafka
Classes in org.apache.flink.streaming.examples.statemachine.kafka that implement DeserializationSchema Modifier and Type Class Description class
EventDeSerializationSchema
A serializer and deserializer for theEvent
type. -
Uses of DeserializationSchema in org.apache.flink.table.examples.java.connectors
Classes in org.apache.flink.table.examples.java.connectors that implement DeserializationSchema Modifier and Type Class Description class
ChangelogCsvDeserializer
TheChangelogCsvDeserializer
contains a simple parsing logic for converting bytes intoRow
ofInteger
andString
with aRowKind
.Methods in org.apache.flink.table.examples.java.connectors that return DeserializationSchema Modifier and Type Method Description DeserializationSchema<RowData>
ChangelogCsvFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType producedDataType)
Methods in org.apache.flink.table.examples.java.connectors that return types with arguments of type DeserializationSchema Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
ChangelogCsvFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Constructors in org.apache.flink.table.examples.java.connectors with parameters of type DeserializationSchema Constructor Description SocketSource(String hostname, int port, byte byteDelimiter, DeserializationSchema<RowData> deserializer)
Constructor parameters in org.apache.flink.table.examples.java.connectors with type arguments of type DeserializationSchema Constructor Description SocketDynamicTableSource(String hostname, int port, byte byteDelimiter, DecodingFormat<DeserializationSchema<RowData>> decodingFormat, DataType producedDataType)
-