Package | Description |
---|---|
org.apache.flink.table.api.internal | |
org.apache.flink.table.delegation | |
org.apache.flink.table.operations |
Modifier and Type | Field and Description |
---|---|
protected List<ModifyOperation> |
StatementSetImpl.operations |
Modifier and Type | Method and Description |
---|---|
List<ModifyOperation> |
StatementSetImpl.getOperations() |
Modifier and Type | Method and Description |
---|---|
CompiledPlan |
TableEnvironmentInternal.compilePlan(List<ModifyOperation> operations) |
CompiledPlan |
TableEnvironmentImpl.compilePlan(List<ModifyOperation> operations) |
TableResultInternal |
TableEnvironmentInternal.executeInternal(List<ModifyOperation> operations)
Execute the given modify operations and return the execution result.
|
TableResultInternal |
TableEnvironmentImpl.executeInternal(List<ModifyOperation> operations) |
protected List<org.apache.flink.api.dag.Transformation<?>> |
TableEnvironmentImpl.translate(List<ModifyOperation> modifyOperations) |
Modifier and Type | Method and Description |
---|---|
InternalPlan |
Planner.compilePlan(List<ModifyOperation> modifyOperations) |
List<org.apache.flink.api.dag.Transformation<?>> |
Planner.translate(List<ModifyOperation> modifyOperations)
Converts a relational tree of
ModifyOperation s into a set of runnable Transformation s. |
Modifier and Type | Class and Description |
---|---|
class |
CollectModifyOperation
Special, internal kind of
ModifyOperation that collects the content of QueryOperation to local. |
class |
CreateTableASOperation
Operation to describe a CREATE TABLE AS statement.
|
class |
ExternalModifyOperation
Internal operation used to convert a
Table into a DataStream. |
class |
OutputConversionModifyOperation
Special, internal kind of
ModifyOperation that allows converting a tree of QueryOperation s to a Transformation of given type described with TypeInformation . |
class |
SinkModifyOperation
DML operation that tells to write to a sink.
|
class |
UnregisteredSinkModifyOperation<T>
DML operation that tells to write to the given sink.
|
Modifier and Type | Method and Description |
---|---|
List<ModifyOperation> |
StatementSetOperation.getOperations() |
Constructor and Description |
---|
StatementSetOperation(List<ModifyOperation> operations) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.