@Internal public final class DebeziumJsonDeserializationSchema extends Object implements DeserializationSchema<RowData>
RowData
. The deserialization schema knows Debezium's schema definition and can extract the
database data and convert into RowData
with RowKind
.
Deserializes a byte[]
message as a JSON object and reads the specified fields.
Failures during deserialization are forwarded as wrapped IOExceptions.
DeserializationSchema.InitializationContext
Constructor and Description |
---|
DebeziumJsonDeserializationSchema(RowType rowType,
TypeInformation<RowData> resultTypeInfo,
boolean schemaInclude,
boolean ignoreParseErrors,
TimestampFormat timestampFormatOption) |
Modifier and Type | Method and Description |
---|---|
RowData |
deserialize(byte[] message)
Deserializes the byte message.
|
void |
deserialize(byte[] message,
Collector<RowData> out)
Deserializes the byte message.
|
boolean |
equals(Object o) |
TypeInformation<RowData> |
getProducedType()
Gets the data type (as a
TypeInformation ) produced by this function or input format. |
int |
hashCode() |
boolean |
isEndOfStream(RowData nextElement)
Method to decide whether the element signals the end of the stream.
|
clone, finalize, getClass, notify, notifyAll, toString, wait, wait, wait
open
public DebeziumJsonDeserializationSchema(RowType rowType, TypeInformation<RowData> resultTypeInfo, boolean schemaInclude, boolean ignoreParseErrors, TimestampFormat timestampFormatOption)
public RowData deserialize(byte[] message) throws IOException
DeserializationSchema
deserialize
in interface DeserializationSchema<RowData>
message
- The message, as a byte array.IOException
public void deserialize(byte[] message, Collector<RowData> out) throws IOException
DeserializationSchema
Can output multiple records through the Collector
. Note that number and size of
the produced records should be relatively small. Depending on the source implementation
records can be buffered in memory or collecting records might delay emitting checkpoint
barrier.
deserialize
in interface DeserializationSchema<RowData>
message
- The message, as a byte array.out
- The collector to put the resulting messages.IOException
public boolean isEndOfStream(RowData nextElement)
DeserializationSchema
isEndOfStream
in interface DeserializationSchema<RowData>
nextElement
- The element to test for the end-of-stream signal.public TypeInformation<RowData> getProducedType()
ResultTypeQueryable
TypeInformation
) produced by this function or input format.getProducedType
in interface ResultTypeQueryable<RowData>
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.