Interface TableEnvironmentInternal
-
- All Superinterfaces:
TableEnvironment
- All Known Implementing Classes:
AbstractStreamTableEnvironmentImpl
,StreamTableEnvironmentImpl
,TableEnvironmentImpl
@Internal public interface TableEnvironmentInternal extends TableEnvironment
An internal interface ofTableEnvironment
that 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 CompiledPlan
compilePlan(List<ModifyOperation> operations)
TableResultInternal
executeCachedPlanInternal(CachedPlan cachedPlan)
Execute the givenCachedPlan
and return the execution result.TableResultInternal
executeInternal(List<ModifyOperation> operations)
Execute the given modify operations and return the execution result.TableResultInternal
executeInternal(Operation operation)
Execute the given operation and return the execution result.TableResultInternal
executePlan(InternalPlan plan)
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.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.String
explainPlan(InternalPlan compiledPlan, ExplainDetail... extraDetails)
Table
fromTableSource(TableSource<?> source)
Deprecated.CatalogManager
getCatalogManager()
Returns aCatalogManager
that deals with all catalog objects.OperationTreeBuilder
getOperationTreeBuilder()
Returns aOperationTreeBuilder
that can createQueryOperation
s.Parser
getParser()
Return aParser
that provides methods for parsing a SQL string.void
registerTableSinkInternal(String name, TableSink<?> configuredSink)
Registers an externalTableSink
with already configured field names and field types in thisTableEnvironment
's catalog.void
registerTableSourceInternal(String name, TableSource<?> tableSource)
Registers an externalTableSource
in 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 aParser
that provides methods for parsing a SQL string.- Returns:
- initialized
Parser
.
-
getCatalogManager
CatalogManager getCatalogManager()
Returns aCatalogManager
that deals with all catalog objects.
-
getOperationTreeBuilder
OperationTreeBuilder getOperationTreeBuilder()
Returns aOperationTreeBuilder
that can createQueryOperation
s.
-
fromTableSource
@Deprecated Table fromTableSource(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, TableSource<?> tableSource)
Registers an externalTableSource
in 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 theTableSource
is registered.tableSource
- TheTableSource
to register.
-
registerTableSinkInternal
void registerTableSinkInternal(String name, TableSink<?> configuredSink)
Registers an externalTableSink
with 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.
-
executeCachedPlanInternal
TableResultInternal executeCachedPlanInternal(CachedPlan cachedPlan)
Execute the givenCachedPlan
and 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)
-
-