Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
static SerdeContext |
get(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DatabindContext databindContext)
Retrieve context from
SerializerProvider and DeserializationContext . |
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() |
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)
public static SerdeContext get(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DatabindContext databindContext)
SerializerProvider
and DeserializationContext
.public Parser getParser()
public ReadableConfig getConfiguration()
public ClassLoader getClassLoader()
public org.apache.flink.table.planner.calcite.FlinkContext getFlinkContext()
public org.apache.flink.table.planner.calcite.FlinkTypeFactory getTypeFactory()
public org.apache.calcite.sql.SqlOperatorTable getOperatorTable()
public org.apache.calcite.rex.RexBuilder getRexBuilder()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.