Modifier and Type | Field and Description |
---|---|
protected FunctionCatalog |
TableEnvironmentImpl.functionCatalog |
Constructor and Description |
---|
TableEnvironmentImpl(CatalogManager catalogManager,
ModuleManager moduleManager,
TableConfig tableConfig,
Executor executor,
FunctionCatalog functionCatalog,
Planner planner,
boolean isStreamingMode) |
Constructor and Description |
---|
StreamTableEnvironmentImpl(CatalogManager catalogManager,
ModuleManager moduleManager,
FunctionCatalog functionCatalog,
TableConfig tableConfig,
StreamExecutionEnvironment executionEnvironment,
Planner planner,
Executor executor,
boolean isStreamingMode) |
Constructor and Description |
---|
FunctionCatalogOperatorTable(FunctionCatalog functionCatalog,
org.apache.flink.table.calcite.FlinkTypeFactory typeFactory) |
Modifier and Type | Field and Description |
---|---|
FunctionCatalog |
ExecutionContext.SessionState.functionCatalog |
Modifier and Type | Method and Description |
---|---|
static ExecutionContext.SessionState |
ExecutionContext.SessionState.of(CatalogManager catalogManager,
ModuleManager moduleManager,
FunctionCatalog functionCatalog) |
Modifier and Type | Method and Description |
---|---|
Planner |
PlannerFactory.create(Map<String,String> properties,
Executor executor,
TableConfig tableConfig,
FunctionCatalog functionCatalog,
CatalogManager catalogManager)
Creates a corresponding
Planner . |
Modifier and Type | Method and Description |
---|---|
Planner |
StreamPlannerFactory.create(Map<String,String> properties,
Executor executor,
TableConfig tableConfig,
FunctionCatalog functionCatalog,
CatalogManager catalogManager) |
Constructor and Description |
---|
PlanningConfigurationBuilder(TableConfig tableConfig,
FunctionCatalog functionCatalog,
org.apache.calcite.jdbc.CalciteSchema rootSchema,
org.apache.flink.table.expressions.ExpressionBridge<org.apache.flink.table.expressions.PlannerExpression> expressionBridge) |
Constructor and Description |
---|
FunctionCatalogOperatorTable(FunctionCatalog functionCatalog,
org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory) |
Modifier and Type | Method and Description |
---|---|
Planner |
BlinkPlannerFactory.create(Map<String,String> properties,
Executor executor,
TableConfig tableConfig,
FunctionCatalog functionCatalog,
CatalogManager catalogManager) |
Constructor and Description |
---|
PlannerContext(TableConfig tableConfig,
FunctionCatalog functionCatalog,
CatalogManager catalogManager,
org.apache.calcite.jdbc.CalciteSchema rootSchema,
List<org.apache.calcite.plan.RelTraitDef> traitDefs) |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.