Class SerdeContext
- java.lang.Object
-
- org.apache.flink.table.planner.plan.nodes.exec.serde.SerdeContext
-
-
Constructor Summary
Constructors Constructor Description 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 Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description static SerdeContext
get(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DatabindContext databindContext)
Retrieve context fromSerializerProvider
andDeserializationContext
.ClassLoader
getClassLoader()
ReadableConfig
getConfiguration()
org.apache.flink.table.planner.calcite.FlinkContext
getFlinkContext()
org.apache.calcite.sql.SqlOperatorTable
getOperatorTable()
Parser
getParser()
org.apache.calcite.rex.RexBuilder
getRexBuilder()
org.apache.flink.table.planner.calcite.FlinkTypeFactory
getTypeFactory()
-
-
-
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 fromSerializerProvider
andDeserializationContext
.
-
getParser
public Parser getParser()
-
getConfiguration
public ReadableConfig getConfiguration()
-
getClassLoader
public ClassLoader getClassLoader()
-
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()
-
-