@Internal public class JsonRowDataDeserializationSchema extends AbstractJsonDeserializationSchema
RowData
.
Deserializes a byte[]
message as a JSON object and reads the specified fields.
Failures during deserialization are forwarded as wrapped IOExceptions.
DeserializationSchema.InitializationContext
failOnMissingField, ignoreParseErrors, objectMapper
Constructor and Description |
---|
JsonRowDataDeserializationSchema(RowType rowType,
TypeInformation<RowData> resultTypeInfo,
boolean failOnMissingField,
boolean ignoreParseErrors,
TimestampFormat timestampFormat) |
Modifier and Type | Method and Description |
---|---|
RowData |
convertToRowData(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.JsonNode message) |
RowData |
deserialize(byte[] message)
Deserializes the byte message.
|
org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.JsonNode |
deserializeToJsonNode(byte[] message) |
equals, getProducedType, hashCode, isEndOfStream, open
clone, finalize, getClass, notify, notifyAll, toString, wait, wait, wait
deserialize
public JsonRowDataDeserializationSchema(RowType rowType, TypeInformation<RowData> resultTypeInfo, boolean failOnMissingField, boolean ignoreParseErrors, TimestampFormat timestampFormat)
public RowData deserialize(@Nullable byte[] message) throws IOException
DeserializationSchema
message
- The message, as a byte array.IOException
public org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.JsonNode deserializeToJsonNode(byte[] message) throws IOException
IOException
public RowData convertToRowData(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.JsonNode message)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.