Uses of Interface
org.apache.flink.table.api.Table
-
Packages that use Table Package Description org.apache.flink.table.api org.apache.flink.table.api.internal org.apache.flink.table.expressions -
-
Uses of Table in org.apache.flink.table.api
Methods in org.apache.flink.table.api that return Table Modifier and Type Method Description Table
Table. addColumns(org.apache.flink.table.expressions.Expression... fields)
Adds additional columns.Table
Table. addOrReplaceColumns(org.apache.flink.table.expressions.Expression... fields)
Adds additional columns.Table
Table. as(String field, String... fields)
Renames the fields of the expression result.Table
Table. as(org.apache.flink.table.expressions.Expression... fields)
Deprecated.Table
Table. distinct()
Removes duplicate values and returns only distinct (different) values.Table
Table. dropColumns(org.apache.flink.table.expressions.Expression... fields)
Drops existing columns.Table
Table. fetch(int fetch)
Limits a (possibly sorted) result to the first n rows.Table
Table. filter(org.apache.flink.table.expressions.Expression predicate)
Filters out elements that don't pass the filter predicate.Table
Table. flatMap(org.apache.flink.table.expressions.Expression tableFunction)
Performs a flatMap operation with an user-defined table function or built-in table function.Table
TableEnvironment. from(String path)
Reads a registered table and returns the resultingTable
.Table
TableEnvironment. from(TableDescriptor descriptor)
Returns aTable
backed by the givendescriptor
.Table
TableEnvironment. fromValues(Iterable<?> values)
Creates a Table from given collection of objects.default Table
TableEnvironment. fromValues(Object... values)
Creates a Table from given values.Table
TableEnvironment. fromValues(org.apache.flink.table.expressions.Expression... values)
Creates a Table from given values.Table
TableEnvironment. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, Iterable<?> values)
Creates a Table from given collection of objects with a given row type.default Table
TableEnvironment. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, Object... values)
Creates a Table from given collection of objects with a given row type.Table
TableEnvironment. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, org.apache.flink.table.expressions.Expression... values)
Creates a Table from given collection of objects with a given row type.Table
Table. fullOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Joins twoTable
s.Table
Table. intersect(Table right)
Intersects twoTable
s with duplicate records removed.Table
Table. intersectAll(Table right)
Intersects twoTable
s.Table
Table. join(Table right)
Joins twoTable
s.Table
Table. join(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Joins twoTable
s.Table
Table. joinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall)
Joins thisTable
with an user-definedTableFunction
.Table
Table. joinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall, org.apache.flink.table.expressions.Expression joinPredicate)
Joins thisTable
with an user-definedTableFunction
.Table
Table. leftOuterJoin(Table right)
Joins twoTable
s.Table
Table. leftOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Joins twoTable
s.Table
Table. leftOuterJoinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall)
Joins thisTable
with an user-definedTableFunction
.Table
Table. leftOuterJoinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall, org.apache.flink.table.expressions.Expression joinPredicate)
Joins thisTable
with an user-definedTableFunction
.default Table
Table. limit(int fetch)
Limits a (possibly sorted) result to the first n rows.default Table
Table. limit(int offset, int fetch)
Limits a (possibly sorted) result to the first n rows from an offset position.Table
Table. map(org.apache.flink.table.expressions.Expression mapFunction)
Performs a map operation with an user-defined scalar function or built-in scalar function.Table
Table. minus(Table right)
Minus of twoTable
s with duplicate records removed.Table
Table. minusAll(Table right)
Minus of twoTable
s.Table
Table. offset(int offset)
Limits a (possibly sorted) result from an offset position.Table
Table. orderBy(org.apache.flink.table.expressions.Expression... fields)
Sorts the givenTable
.Table
Table. renameColumns(org.apache.flink.table.expressions.Expression... fields)
Renames existing columns.Table
Table. rightOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Joins twoTable
s.Table
TableEnvironment. scan(String... tablePath)
Deprecated.Table
AggregatedTable. select(org.apache.flink.table.expressions.Expression... fields)
Performs a selection operation after an aggregate operation.Table
FlatAggregateTable. select(org.apache.flink.table.expressions.Expression... fields)
Performs a selection operation on a FlatAggregateTable table.Table
GroupedTable. select(org.apache.flink.table.expressions.Expression... fields)
Performs a selection operation on a grouped table.Table
OverWindowedTable. select(org.apache.flink.table.expressions.Expression... fields)
Performs a selection operation on a over windowed table.Table
Table. select(org.apache.flink.table.expressions.Expression... fields)
Performs a selection operation.Table
WindowGroupedTable. select(org.apache.flink.table.expressions.Expression... fields)
Performs a selection operation on a window grouped table.Table
TableEnvironment. sqlQuery(String query)
Evaluates a SQL query on registered tables and returns aTable
object describing the pipeline for further transformations.Table
Table. union(Table right)
Unions twoTable
s with duplicate records removed.Table
Table. unionAll(Table right)
Unions twoTable
s.Table
Table. where(org.apache.flink.table.expressions.Expression predicate)
Filters out elements that don't pass the filter predicate.Methods in org.apache.flink.table.api with parameters of type Table Modifier and Type Method Description StatementSet
StatementSet. addInsert(String targetPath, Table table)
Shorthand forstatementSet.add(table.insertInto(targetPath))
.StatementSet
StatementSet. addInsert(String targetPath, Table table, boolean overwrite)
Shorthand forstatementSet.add(table.insertInto(targetPath, overwrite))
.StatementSet
StatementSet. addInsert(TableDescriptor targetDescriptor, Table table)
Shorthand forstatementSet.add(table.insertInto(targetDescriptor))
.StatementSet
StatementSet. addInsert(TableDescriptor targetDescriptor, Table table, boolean overwrite)
Shorthand forstatementSet.add(table.insertInto(targetDescriptor, overwrite))
.void
TableEnvironment. createTemporaryView(String path, Table view)
Registers aTable
API object as a temporary view similar to SQL temporary views.Table
Table. fullOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Joins twoTable
s.Table
Table. intersect(Table right)
Intersects twoTable
s with duplicate records removed.Table
Table. intersectAll(Table right)
Intersects twoTable
s.Table
Table. join(Table right)
Joins twoTable
s.Table
Table. join(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Joins twoTable
s.Table
Table. leftOuterJoin(Table right)
Joins twoTable
s.Table
Table. leftOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Joins twoTable
s.Table
Table. minus(Table right)
Minus of twoTable
s with duplicate records removed.Table
Table. minusAll(Table right)
Minus of twoTable
s.void
TableEnvironment. registerTable(String name, Table table)
Deprecated.Table
Table. rightOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Joins twoTable
s.Table
Table. union(Table right)
Unions twoTable
s with duplicate records removed.Table
Table. unionAll(Table right)
Unions twoTable
s. -
Uses of Table in org.apache.flink.table.api.internal
Classes in org.apache.flink.table.api.internal that implement Table Modifier and Type Class Description class
TableImpl
Implementation forTable
.Methods in org.apache.flink.table.api.internal that return Table Modifier and Type Method Description Table
TableImpl. addColumns(org.apache.flink.table.expressions.Expression... fields)
Table
TableImpl. addOrReplaceColumns(org.apache.flink.table.expressions.Expression... fields)
Table
TableImpl. as(String field, String... fields)
Table
TableImpl. as(org.apache.flink.table.expressions.Expression... fields)
Table
TableImpl. distinct()
Table
TableImpl. dropColumns(org.apache.flink.table.expressions.Expression... fields)
Table
TableImpl. fetch(int fetch)
Table
TableImpl. filter(org.apache.flink.table.expressions.Expression predicate)
Table
TableImpl. flatMap(org.apache.flink.table.expressions.Expression tableFunction)
Table
TableEnvironmentImpl. from(String path)
Table
TableEnvironmentImpl. from(TableDescriptor descriptor)
Table
TableEnvironmentImpl. fromTableSource(org.apache.flink.table.legacy.sources.TableSource<?> source)
Table
TableEnvironmentInternal. fromTableSource(org.apache.flink.table.legacy.sources.TableSource<?> source)
Deprecated.Table
TableEnvironmentImpl. fromValues(Iterable<?> values)
Table
TableEnvironmentImpl. fromValues(Object... values)
Table
TableEnvironmentImpl. fromValues(org.apache.flink.table.expressions.Expression... values)
Table
TableEnvironmentImpl. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, Iterable<?> values)
Table
TableEnvironmentImpl. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, Object... values)
Table
TableEnvironmentImpl. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, org.apache.flink.table.expressions.Expression... values)
Table
TableImpl. fullOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Table
TableImpl. intersect(Table right)
Table
TableImpl. intersectAll(Table right)
Table
TableImpl. join(Table right)
Table
TableImpl. join(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Table
TableImpl. joinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall)
Table
TableImpl. joinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall, org.apache.flink.table.expressions.Expression joinPredicate)
Table
TableImpl. leftOuterJoin(Table right)
Table
TableImpl. leftOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Table
TableImpl. leftOuterJoinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall)
Table
TableImpl. leftOuterJoinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall, org.apache.flink.table.expressions.Expression joinPredicate)
Table
TableImpl. map(org.apache.flink.table.expressions.Expression mapFunction)
Table
TableImpl. minus(Table right)
Table
TableImpl. minusAll(Table right)
Table
TableImpl. offset(int offset)
Table
TableImpl. orderBy(org.apache.flink.table.expressions.Expression... fields)
Table
TableImpl. renameColumns(org.apache.flink.table.expressions.Expression... fields)
Table
TableImpl. rightOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Table
TableEnvironmentImpl. scan(String... tablePath)
Table
TableImpl. select(org.apache.flink.table.expressions.Expression... fields)
Table
TableEnvironmentImpl. sqlQuery(String query)
Table
TableImpl. union(Table right)
Table
TableImpl. unionAll(Table right)
Table
TableImpl. where(org.apache.flink.table.expressions.Expression predicate)
Methods in org.apache.flink.table.api.internal with parameters of type Table Modifier and Type Method Description StatementSet
StatementSetImpl. addInsert(String targetPath, Table table)
StatementSet
StatementSetImpl. addInsert(String targetPath, Table table, boolean overwrite)
StatementSet
StatementSetImpl. addInsert(TableDescriptor targetDescriptor, Table table)
StatementSet
StatementSetImpl. addInsert(TableDescriptor targetDescriptor, Table table, boolean overwrite)
void
TableEnvironmentImpl. createTemporaryView(String path, Table view)
Table
TableImpl. fullOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
OutType
BaseExpressions. in(Table table)
Returns true if an expression exists in a given table sub-query.Table
TableImpl. intersect(Table right)
Table
TableImpl. intersectAll(Table right)
Table
TableImpl. join(Table right)
Table
TableImpl. join(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Table
TableImpl. leftOuterJoin(Table right)
Table
TableImpl. leftOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Table
TableImpl. minus(Table right)
Table
TableImpl. minusAll(Table right)
void
TableEnvironmentImpl. registerTable(String name, Table table)
Table
TableImpl. rightOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)
Table
TableImpl. union(Table right)
Table
TableImpl. unionAll(Table right)
-
Uses of Table in org.apache.flink.table.expressions
Methods in org.apache.flink.table.expressions with parameters of type Table Modifier and Type Method Description static TableReferenceExpression
ApiExpressionUtils. tableRef(String name, Table table)
-