Interface TableEnvironmentInternal
-
- All Superinterfaces:
TableEnvironment
- All Known Implementing Classes:
TableEnvironmentImpl
@Internal public interface TableEnvironmentInternal extends TableEnvironment
An internal interface ofTableEnvironmentthat defines extended methods used forTableImpl.Once old planner is removed, this class also can be removed. By then, these methods can be moved into TableEnvironmentImpl.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Default Methods Deprecated Methods Modifier and Type Method Description CompiledPlancompilePlan(List<ModifyOperation> operations)TableResultInternalexecuteCachedPlanInternal(CachedPlan cachedPlan)Execute the givenCachedPlanand return the execution result.TableResultInternalexecuteInternal(List<ModifyOperation> operations)Execute the given modify operations and return the execution result.TableResultInternalexecuteInternal(Operation operation)Execute the given operation and return the execution result.TableResultInternalexecutePlan(InternalPlan plan)default StringexplainInternal(List<Operation> operations, ExplainDetail... extraDetails)Returns the AST of this table and the execution plan to compute the result of this table.StringexplainInternal(List<Operation> operations, ExplainFormat format, ExplainDetail... extraDetails)Returns the AST of this table and the execution plan to compute the result of this table.StringexplainPlan(InternalPlan compiledPlan, ExplainDetail... extraDetails)TablefromTableSource(org.apache.flink.table.legacy.sources.TableSource<?> source)Deprecated.CatalogManagergetCatalogManager()Returns aCatalogManagerthat deals with all catalog objects.OperationTreeBuildergetOperationTreeBuilder()Returns aOperationTreeBuilderthat can createQueryOperations.ParsergetParser()Return aParserthat provides methods for parsing a SQL string.voidregisterTableSinkInternal(String name, org.apache.flink.table.legacy.sinks.TableSink<?> configuredSink)Registers an externalTableSinkwith already configured field names and field types in thisTableEnvironment's catalog.voidregisterTableSourceInternal(String name, org.apache.flink.table.legacy.sources.TableSource<?> tableSource)Registers an externalTableSourcein thisTableEnvironment's catalog.-
Methods inherited from interface org.apache.flink.table.api.TableEnvironment
compilePlanSql, createCatalog, createFunction, createFunction, createFunction, createFunction, createStatementSet, createTable, createTemporaryFunction, createTemporaryFunction, createTemporaryFunction, createTemporarySystemFunction, createTemporarySystemFunction, createTemporarySystemFunction, createTemporaryTable, createTemporaryView, dropFunction, dropTemporaryFunction, dropTemporarySystemFunction, dropTemporaryTable, dropTemporaryView, executePlan, executeSql, explainSql, explainSql, from, from, fromValues, fromValues, fromValues, fromValues, fromValues, fromValues, getCatalog, getCompletionHints, getConfig, getCurrentCatalog, getCurrentDatabase, listCatalogs, listDatabases, listFullModules, listFunctions, listModules, listTables, listTables, listTemporaryTables, listTemporaryViews, listUserDefinedFunctions, listViews, loadModule, loadPlan, registerCatalog, registerFunction, registerTable, scan, sqlQuery, unloadModule, useCatalog, useDatabase, useModules
-
-
-
-
Method Detail
-
getParser
Parser getParser()
Return aParserthat provides methods for parsing a SQL string.- Returns:
- initialized
Parser.
-
getCatalogManager
CatalogManager getCatalogManager()
Returns aCatalogManagerthat deals with all catalog objects.
-
getOperationTreeBuilder
OperationTreeBuilder getOperationTreeBuilder()
Returns aOperationTreeBuilderthat can createQueryOperations.
-
fromTableSource
@Deprecated Table fromTableSource(org.apache.flink.table.legacy.sources.TableSource<?> source)
Deprecated.Creates a table from a table source.- Parameters:
source- table source used as table
-
executeInternal
TableResultInternal executeInternal(List<ModifyOperation> operations)
Execute the given modify operations and return the execution result.- Parameters:
operations- The operations to be executed.- Returns:
- the affected row counts (-1 means unknown).
-
executeInternal
TableResultInternal executeInternal(Operation operation)
Execute the given operation and return the execution result.- Parameters:
operation- The operation to be executed.- Returns:
- the content of the execution result.
-
explainInternal
default String explainInternal(List<Operation> operations, ExplainDetail... extraDetails)
Returns the AST of this table and the execution plan to compute the result of this table.- Parameters:
operations- The operations to be explained.extraDetails- The extra explain details which the explain result should include, e.g. estimated cost, changelog mode for streaming- Returns:
- AST and the execution plan.
-
explainInternal
String explainInternal(List<Operation> operations, ExplainFormat format, ExplainDetail... extraDetails)
Returns the AST of this table and the execution plan to compute the result of this table.- Parameters:
operations- The operations to be explained.format- The output format.extraDetails- The extra explain details which the explain result should include, e.g. estimated cost, changelog mode for streaming- Returns:
- AST and the execution plan.
-
registerTableSourceInternal
void registerTableSourceInternal(String name, org.apache.flink.table.legacy.sources.TableSource<?> tableSource)
Registers an externalTableSourcein thisTableEnvironment's catalog. Registered tables can be referenced in SQL queries.Temporary objects can shadow permanent ones. If a permanent object in a given path exists, it will be inaccessible in the current session. To make the permanent object available again one can drop the corresponding temporary object.
- Parameters:
name- The name under which theTableSourceis registered.tableSource- TheTableSourceto register.
-
registerTableSinkInternal
void registerTableSinkInternal(String name, org.apache.flink.table.legacy.sinks.TableSink<?> configuredSink)
Registers an externalTableSinkwith already configured field names and field types in thisTableEnvironment's catalog. Registered sink tables can be referenced in SQL DML statements.Temporary objects can shadow permanent ones. If a permanent object in a given path exists, it will be inaccessible in the current session. To make the permanent object available again one can drop the corresponding temporary object.
- Parameters:
name- The name under which theTableSinkis registered.configuredSink- The configuredTableSinkto register.
-
executeCachedPlanInternal
TableResultInternal executeCachedPlanInternal(CachedPlan cachedPlan)
Execute the givenCachedPlanand return the execution result.- Parameters:
cachedPlan- The CachedPlan to be executed.- Returns:
- the content of the execution result.
-
compilePlan
@Experimental CompiledPlan compilePlan(List<ModifyOperation> operations)
-
executePlan
@Experimental TableResultInternal executePlan(InternalPlan plan)
-
explainPlan
@Experimental String explainPlan(InternalPlan compiledPlan, ExplainDetail... extraDetails)
-
-