@Internal public class JsonRowDataSerializationSchema extends Object implements org.apache.flink.api.common.serialization.SerializationSchema<org.apache.flink.table.data.RowData>
Serializes the input Flink object into a JSON string and converts it into byte[].
Result byte[] messages can be deserialized using JsonRowDataDeserializationSchema or JsonParserRowDataDeserializationSchema.
| Constructor and Description |
|---|
JsonRowDataSerializationSchema(org.apache.flink.table.types.logical.RowType rowType,
org.apache.flink.formats.common.TimestampFormat timestampFormat,
JsonFormatOptions.MapNullKeyMode mapNullKeyMode,
String mapNullKeyLiteral,
boolean encodeDecimalAsPlainNumber,
boolean ignoreNullFields) |
| Modifier and Type | Method and Description |
|---|---|
boolean |
equals(Object o) |
int |
hashCode() |
void |
open(org.apache.flink.api.common.serialization.SerializationSchema.InitializationContext context) |
byte[] |
serialize(org.apache.flink.table.data.RowData row) |
public JsonRowDataSerializationSchema(org.apache.flink.table.types.logical.RowType rowType,
org.apache.flink.formats.common.TimestampFormat timestampFormat,
JsonFormatOptions.MapNullKeyMode mapNullKeyMode,
String mapNullKeyLiteral,
boolean encodeDecimalAsPlainNumber,
boolean ignoreNullFields)
public void open(org.apache.flink.api.common.serialization.SerializationSchema.InitializationContext context)
throws Exception
open in interface org.apache.flink.api.common.serialization.SerializationSchema<org.apache.flink.table.data.RowData>Exceptionpublic byte[] serialize(org.apache.flink.table.data.RowData row)
serialize in interface org.apache.flink.api.common.serialization.SerializationSchema<org.apache.flink.table.data.RowData>Copyright © 2014–2025 The Apache Software Foundation. All rights reserved.