Class SerdeContext


  • @Internal
    public class SerdeContext
    extends Object
    A context to allow the store user-defined data within ExecNode serialization and deserialization.
    • Constructor Detail

      • SerdeContext

        public SerdeContext​(Parser parser,
                            org.apache.flink.table.planner.calcite.FlinkContext flinkContext,
                            org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory,
                            org.apache.calcite.sql.SqlOperatorTable operatorTable)
    • Method Detail

      • get

        public static SerdeContext get​(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DatabindContext databindContext)
        Retrieve context from SerializerProvider and DeserializationContext.
      • getParser

        public Parser getParser()
      • getFlinkContext

        public org.apache.flink.table.planner.calcite.FlinkContext getFlinkContext()
      • getTypeFactory

        public org.apache.flink.table.planner.calcite.FlinkTypeFactory getTypeFactory()
      • getOperatorTable

        public org.apache.calcite.sql.SqlOperatorTable getOperatorTable()
      • getRexBuilder

        public org.apache.calcite.rex.RexBuilder getRexBuilder()