Uses of Interface
org.apache.flink.table.operations.ModifyOperation
-
-
Uses of ModifyOperation in org.apache.flink.table.api.bridge.internal
Methods in org.apache.flink.table.api.bridge.internal with parameters of type ModifyOperation Modifier and Type Method Description protected <T> DataStream<T>
AbstractStreamTableEnvironmentImpl. toStreamInternal(Table table, ModifyOperation modifyOperation)
Method parameters in org.apache.flink.table.api.bridge.internal with type arguments of type ModifyOperation Modifier and Type Method Description void
AbstractStreamTableEnvironmentImpl. attachAsDataStream(List<ModifyOperation> modifyOperations)
-
Uses of ModifyOperation in org.apache.flink.table.api.internal
Fields in org.apache.flink.table.api.internal with type parameters of type ModifyOperation Modifier and Type Field Description protected List<ModifyOperation>
StatementSetImpl. operations
Methods in org.apache.flink.table.api.internal that return types with arguments of type ModifyOperation Modifier and Type Method Description List<ModifyOperation>
StatementSetImpl. getOperations()
Method parameters in org.apache.flink.table.api.internal with type arguments of type ModifyOperation Modifier and Type Method Description CompiledPlan
TableEnvironmentImpl. compilePlan(List<ModifyOperation> operations)
CompiledPlan
TableEnvironmentInternal. compilePlan(List<ModifyOperation> operations)
TableResultInternal
TableEnvironmentImpl. executeInternal(List<ModifyOperation> operations)
TableResultInternal
TableEnvironmentInternal. executeInternal(List<ModifyOperation> operations)
Execute the given modify operations and return the execution result.protected List<Transformation<?>>
TableEnvironmentImpl. translate(List<ModifyOperation> modifyOperations)
-
Uses of ModifyOperation in org.apache.flink.table.delegation
Method parameters in org.apache.flink.table.delegation with type arguments of type ModifyOperation Modifier and Type Method Description InternalPlan
Planner. compilePlan(List<ModifyOperation> modifyOperations)
List<Transformation<?>>
Planner. translate(List<ModifyOperation> modifyOperations)
Converts a relational tree ofModifyOperation
s into a set of runnableTransformation
s. -
Uses of ModifyOperation in org.apache.flink.table.gateway.service.context
Methods in org.apache.flink.table.gateway.service.context that return types with arguments of type ModifyOperation Modifier and Type Method Description List<ModifyOperation>
SessionContext. getStatementSetOperations()
Methods in org.apache.flink.table.gateway.service.context with parameters of type ModifyOperation Modifier and Type Method Description void
SessionContext. addStatementSetOperation(ModifyOperation operation)
-
Uses of ModifyOperation in org.apache.flink.table.operations
Classes in org.apache.flink.table.operations that implement ModifyOperation Modifier and Type Class Description class
CollectModifyOperation
Special, internal kind ofModifyOperation
that collects the content ofQueryOperation
to local.class
CreateTableASOperation
Operation to describe a CREATE TABLE AS statement.class
DeleteFromFilterOperation
The operation for deleting data in a table according to filters directly.class
ExternalModifyOperation
Internal operation used to convert aTable
into a DataStream.class
OutputConversionModifyOperation
Special, internal kind ofModifyOperation
that allows converting a tree ofQueryOperation
s to aTransformation
of given type described withTypeInformation
.class
ReplaceTableAsOperation
Operation to describe a [CREATE OR] REPLACE TABLE AS statement.class
SinkModifyOperation
DML operation that tells to write to a sink.class
StagedSinkModifyOperation
DML operation that tells to write to a sink which implementsSupportsStaging
.class
UnregisteredSinkModifyOperation<T>
DML operation that tells to write to the given sink.Methods in org.apache.flink.table.operations that return types with arguments of type ModifyOperation Modifier and Type Method Description List<ModifyOperation>
StatementSetOperation. getOperations()
Constructor parameters in org.apache.flink.table.operations with type arguments of type ModifyOperation Constructor Description StatementSetOperation(List<ModifyOperation> operations)
-