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 TableTable. addColumns(org.apache.flink.table.expressions.Expression... fields)Adds additional columns.TableTable. addOrReplaceColumns(org.apache.flink.table.expressions.Expression... fields)Adds additional columns.TableTable. as(String field, String... fields)Renames the fields of the expression result.TableTable. as(org.apache.flink.table.expressions.Expression... fields)Deprecated.TableTable. distinct()Removes duplicate values and returns only distinct (different) values.TableTable. dropColumns(org.apache.flink.table.expressions.Expression... fields)Drops existing columns.TableTable. fetch(int fetch)Limits a (possibly sorted) result to the first n rows.TableTable. filter(org.apache.flink.table.expressions.Expression predicate)Filters out elements that don't pass the filter predicate.TableTable. flatMap(org.apache.flink.table.expressions.Expression tableFunction)Performs a flatMap operation with an user-defined table function or built-in table function.TableTableEnvironment. from(String path)Reads a registered table and returns the resultingTable.TableTableEnvironment. from(TableDescriptor descriptor)Returns aTablebacked by the givendescriptor.TableTableEnvironment. fromValues(Iterable<?> values)Creates a Table from given collection of objects.default TableTableEnvironment. fromValues(Object... values)Creates a Table from given values.TableTableEnvironment. fromValues(org.apache.flink.table.expressions.Expression... values)Creates a Table from given values.TableTableEnvironment. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, Iterable<?> values)Creates a Table from given collection of objects with a given row type.default TableTableEnvironment. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, Object... values)Creates a Table from given collection of objects with a given row type.TableTableEnvironment. 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.TableTable. fullOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)Joins twoTables.TableTable. intersect(Table right)Intersects twoTables with duplicate records removed.TableTable. intersectAll(Table right)Intersects twoTables.TableTable. join(Table right)Joins twoTables.TableTable. join(Table right, org.apache.flink.table.expressions.Expression joinPredicate)Joins twoTables.TableTable. joinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall)Joins thisTablewith an user-definedTableFunction.TableTable. joinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall, org.apache.flink.table.expressions.Expression joinPredicate)Joins thisTablewith an user-definedTableFunction.TableTable. leftOuterJoin(Table right)Joins twoTables.TableTable. leftOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)Joins twoTables.TableTable. leftOuterJoinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall)Joins thisTablewith an user-definedTableFunction.TableTable. leftOuterJoinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall, org.apache.flink.table.expressions.Expression joinPredicate)Joins thisTablewith an user-definedTableFunction.default TableTable. limit(int fetch)Limits a (possibly sorted) result to the first n rows.default TableTable. limit(int offset, int fetch)Limits a (possibly sorted) result to the first n rows from an offset position.TableTable. map(org.apache.flink.table.expressions.Expression mapFunction)Performs a map operation with an user-defined scalar function or built-in scalar function.TableTable. minus(Table right)Minus of twoTables with duplicate records removed.TableTable. minusAll(Table right)Minus of twoTables.TableTable. offset(int offset)Limits a (possibly sorted) result from an offset position.TableTable. orderBy(org.apache.flink.table.expressions.Expression... fields)Sorts the givenTable.TableTable. renameColumns(org.apache.flink.table.expressions.Expression... fields)Renames existing columns.TableTable. rightOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)Joins twoTables.TableTableEnvironment. scan(String... tablePath)Deprecated.TableAggregatedTable. select(org.apache.flink.table.expressions.Expression... fields)Performs a selection operation after an aggregate operation.TableFlatAggregateTable. select(org.apache.flink.table.expressions.Expression... fields)Performs a selection operation on a FlatAggregateTable table.TableGroupedTable. select(org.apache.flink.table.expressions.Expression... fields)Performs a selection operation on a grouped table.TableOverWindowedTable. select(org.apache.flink.table.expressions.Expression... fields)Performs a selection operation on a over windowed table.TableTable. select(org.apache.flink.table.expressions.Expression... fields)Performs a selection operation.TableWindowGroupedTable. select(org.apache.flink.table.expressions.Expression... fields)Performs a selection operation on a window grouped table.TableTableEnvironment. sqlQuery(String query)Evaluates a SQL query on registered tables and returns aTableobject describing the pipeline for further transformations.TableTable. union(Table right)Unions twoTables with duplicate records removed.TableTable. unionAll(Table right)Unions twoTables.TableTable. 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 StatementSetStatementSet. addInsert(String targetPath, Table table)Shorthand forstatementSet.add(table.insertInto(targetPath)).StatementSetStatementSet. addInsert(String targetPath, Table table, boolean overwrite)Shorthand forstatementSet.add(table.insertInto(targetPath, overwrite)).StatementSetStatementSet. addInsert(TableDescriptor targetDescriptor, Table table)Shorthand forstatementSet.add(table.insertInto(targetDescriptor)).StatementSetStatementSet. addInsert(TableDescriptor targetDescriptor, Table table, boolean overwrite)Shorthand forstatementSet.add(table.insertInto(targetDescriptor, overwrite)).voidTableEnvironment. createTemporaryView(String path, Table view)Registers aTableAPI object as a temporary view similar to SQL temporary views.voidTableEnvironment. createView(String path, Table view)Registers aTableAPI object as a view similar to SQL views.booleanTableEnvironment. createView(String path, Table view, boolean ignoreIfExists)Registers aTableAPI object as a view similar to SQL views.TableTable. fullOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)Joins twoTables.TableTable. intersect(Table right)Intersects twoTables with duplicate records removed.TableTable. intersectAll(Table right)Intersects twoTables.TableTable. join(Table right)Joins twoTables.TableTable. join(Table right, org.apache.flink.table.expressions.Expression joinPredicate)Joins twoTables.TableTable. leftOuterJoin(Table right)Joins twoTables.TableTable. leftOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)Joins twoTables.TableTable. minus(Table right)Minus of twoTables with duplicate records removed.TableTable. minusAll(Table right)Minus of twoTables.voidTableEnvironment. registerTable(String name, Table table)Deprecated.TableTable. rightOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)Joins twoTables.TableTable. union(Table right)Unions twoTables with duplicate records removed.TableTable. unionAll(Table right)Unions twoTables. -
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 classTableImplImplementation forTable.Methods in org.apache.flink.table.api.internal that return Table Modifier and Type Method Description TableTableImpl. addColumns(org.apache.flink.table.expressions.Expression... fields)TableTableImpl. addOrReplaceColumns(org.apache.flink.table.expressions.Expression... fields)TableTableImpl. as(String field, String... fields)TableTableImpl. as(org.apache.flink.table.expressions.Expression... fields)TableTableImpl. distinct()TableTableImpl. dropColumns(org.apache.flink.table.expressions.Expression... fields)TableTableImpl. fetch(int fetch)TableTableImpl. filter(org.apache.flink.table.expressions.Expression predicate)TableTableImpl. flatMap(org.apache.flink.table.expressions.Expression tableFunction)TableTableEnvironmentImpl. from(String path)TableTableEnvironmentImpl. from(TableDescriptor descriptor)TableTableEnvironmentImpl. fromTableSource(org.apache.flink.table.legacy.sources.TableSource<?> source)TableTableEnvironmentInternal. fromTableSource(org.apache.flink.table.legacy.sources.TableSource<?> source)Deprecated.TableTableEnvironmentImpl. fromValues(Iterable<?> values)TableTableEnvironmentImpl. fromValues(Object... values)TableTableEnvironmentImpl. fromValues(org.apache.flink.table.expressions.Expression... values)TableTableEnvironmentImpl. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, Iterable<?> values)TableTableEnvironmentImpl. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, Object... values)TableTableEnvironmentImpl. fromValues(org.apache.flink.table.types.AbstractDataType<?> rowType, org.apache.flink.table.expressions.Expression... values)TableTableImpl. fullOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)TableTableImpl. intersect(Table right)TableTableImpl. intersectAll(Table right)TableTableImpl. join(Table right)TableTableImpl. join(Table right, org.apache.flink.table.expressions.Expression joinPredicate)TableTableImpl. joinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall)TableTableImpl. joinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall, org.apache.flink.table.expressions.Expression joinPredicate)TableTableImpl. leftOuterJoin(Table right)TableTableImpl. leftOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)TableTableImpl. leftOuterJoinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall)TableTableImpl. leftOuterJoinLateral(org.apache.flink.table.expressions.Expression tableFunctionCall, org.apache.flink.table.expressions.Expression joinPredicate)TableTableImpl. map(org.apache.flink.table.expressions.Expression mapFunction)TableTableImpl. minus(Table right)TableTableImpl. minusAll(Table right)TableTableImpl. offset(int offset)TableTableImpl. orderBy(org.apache.flink.table.expressions.Expression... fields)TableTableImpl. renameColumns(org.apache.flink.table.expressions.Expression... fields)TableTableImpl. rightOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)TableTableEnvironmentImpl. scan(String... tablePath)TableTableImpl. select(org.apache.flink.table.expressions.Expression... fields)TableTableEnvironmentImpl. sqlQuery(String query)TableTableImpl. union(Table right)TableTableImpl. unionAll(Table right)TableTableImpl. 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 StatementSetStatementSetImpl. addInsert(String targetPath, Table table)StatementSetStatementSetImpl. addInsert(String targetPath, Table table, boolean overwrite)StatementSetStatementSetImpl. addInsert(TableDescriptor targetDescriptor, Table table)StatementSetStatementSetImpl. addInsert(TableDescriptor targetDescriptor, Table table, boolean overwrite)voidTableEnvironmentImpl. createTemporaryView(String path, Table view)voidTableEnvironmentImpl. createView(String path, Table view)booleanTableEnvironmentImpl. createView(String path, Table view, boolean ignoreIfExists)TableTableImpl. fullOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)OutTypeBaseExpressions. in(Table table)Returns true if an expression exists in a given table sub-query.TableTableImpl. intersect(Table right)TableTableImpl. intersectAll(Table right)TableTableImpl. join(Table right)TableTableImpl. join(Table right, org.apache.flink.table.expressions.Expression joinPredicate)TableTableImpl. leftOuterJoin(Table right)TableTableImpl. leftOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)TableTableImpl. minus(Table right)TableTableImpl. minusAll(Table right)voidTableEnvironmentImpl. registerTable(String name, Table table)TableTableImpl. rightOuterJoin(Table right, org.apache.flink.table.expressions.Expression joinPredicate)TableTableImpl. union(Table right)TableTableImpl. 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 TableReferenceExpressionApiExpressionUtils. tableRef(String name, Table table)
-