Class MaxwellJsonSerializationSchema

  • All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.serialization.SerializationSchema<org.apache.flink.table.data.RowData>

    public class MaxwellJsonSerializationSchema
    extends Object
    implements org.apache.flink.api.common.serialization.SerializationSchema<org.apache.flink.table.data.RowData>
    Serialization schema from Flink Table/SQL internal data structure RowData to maxwell-Json.
    See Also:
    Serialized Form
    • Nested Class Summary

      • Nested classes/interfaces inherited from interface org.apache.flink.api.common.serialization.SerializationSchema

        org.apache.flink.api.common.serialization.SerializationSchema.InitializationContext
    • Constructor Summary

      Constructors 
      Constructor Description
      MaxwellJsonSerializationSchema​(org.apache.flink.table.types.logical.RowType rowType, org.apache.flink.formats.common.TimestampFormat timestampFormat, JsonFormatOptions.MapNullKeyMode mapNullKeyMode, String mapNullKeyLiteral, boolean encodeDecimalAsPlainNumber, boolean ignoreNullFields)  
    • Constructor Detail

      • MaxwellJsonSerializationSchema

        public MaxwellJsonSerializationSchema​(org.apache.flink.table.types.logical.RowType rowType,
                                              org.apache.flink.formats.common.TimestampFormat timestampFormat,
                                              JsonFormatOptions.MapNullKeyMode mapNullKeyMode,
                                              String mapNullKeyLiteral,
                                              boolean encodeDecimalAsPlainNumber,
                                              boolean ignoreNullFields)
    • Method Detail

      • open

        public void open​(org.apache.flink.api.common.serialization.SerializationSchema.InitializationContext context)
                  throws Exception
        Specified by:
        open in interface org.apache.flink.api.common.serialization.SerializationSchema<org.apache.flink.table.data.RowData>
        Throws:
        Exception
      • serialize

        public byte[] serialize​(org.apache.flink.table.data.RowData element)
        Specified by:
        serialize in interface org.apache.flink.api.common.serialization.SerializationSchema<org.apache.flink.table.data.RowData>
      • hashCode

        public int hashCode()
        Overrides:
        hashCode in class Object