Uses of Interface
org.apache.flink.table.expressions.Expression
-
Packages that use Expression Package Description org.apache.flink.table.api org.apache.flink.table.catalog org.apache.flink.table.expressions org.apache.flink.table.functions org.apache.flink.table.legacy.sources -
-
Uses of Expression in org.apache.flink.table.api
Methods in org.apache.flink.table.api that return Expression Modifier and Type Method Description ExpressionSchema.UnresolvedComputedColumn. getExpression()ExpressionSchema.UnresolvedWatermarkSpec. getWatermarkExpression()Methods in org.apache.flink.table.api with parameters of type Expression Modifier and Type Method Description Schema.BuilderSchema.Builder. columnByExpression(String columnName, Expression expression)Declares a computed column that is appended to this schema.Schema.BuilderSchema.Builder. watermark(String columnName, Expression watermarkExpression)Declares that the given column should serve as an event-time (i.e. rowtime) attribute and specifies a corresponding watermark strategy as an expression.Constructors in org.apache.flink.table.api with parameters of type Expression Constructor Description UnresolvedComputedColumn(String columnName, Expression expression)UnresolvedComputedColumn(String columnName, Expression expression, String comment)UnresolvedWatermarkSpec(String columnName, Expression watermarkExpression) -
Uses of Expression in org.apache.flink.table.catalog
Method parameters in org.apache.flink.table.catalog with type arguments of type Expression Modifier and Type Method Description List<CatalogPartitionSpec>Catalog. listPartitionsByFilter(ObjectPath tablePath, List<Expression> filters)Get CatalogPartitionSpec of partitions by expression filters in the table. -
Uses of Expression in org.apache.flink.table.expressions
Subinterfaces of Expression in org.apache.flink.table.expressions Modifier and Type Interface Description interfaceResolvedExpressionExpression that has been fully resolved and validated.Classes in org.apache.flink.table.expressions that implement Expression Modifier and Type Class Description classAggregateExpressionResolved and validated expression for calling an aggregate function.classCallExpressionResolved and validated call expression for calling a function.classFieldReferenceExpressionA reference to a field in an input.classNestedFieldReferenceExpressionA reference to a nested field in an input.classSqlCallExpressionA call to a SQL expression.classTypeLiteralExpressionExpression that wrapsDataTypeas a literal.classValueLiteralExpressionExpression for constant literal values.Methods in org.apache.flink.table.expressions that return types with arguments of type Expression Modifier and Type Method Description List<Expression>AggregateExpression. getChildren()List<Expression>CallExpression. getChildren()List<Expression>Expression. getChildren()List<Expression>FieldReferenceExpression. getChildren()List<Expression>NestedFieldReferenceExpression. getChildren()List<Expression>SqlCallExpression. getChildren()List<Expression>TypeLiteralExpression. getChildren()List<Expression>ValueLiteralExpression. getChildren()Methods in org.apache.flink.table.expressions with parameters of type Expression Modifier and Type Method Description protected abstract TExpressionDefaultVisitor. defaultMethod(Expression expression)static <V> Optional<V>ExpressionUtils. extractValue(Expression expression, Class<V> targetClass)Extracts the value (excluding null) of a given class from an expression assuming it is aValueLiteralExpression.static StringExpressionUtils. stringValue(Expression expression)TExpressionDefaultVisitor. visit(Expression other)RExpressionVisitor. visit(Expression other) -
Uses of Expression in org.apache.flink.table.functions
Methods in org.apache.flink.table.functions with parameters of type Expression Modifier and Type Method Description SpecializedFunction.ExpressionEvaluatorSpecializedFunction.ExpressionEvaluatorFactory. createEvaluator(Expression expression, DataType outputDataType, DataTypes.Field... args)Creates a serializable factory that can be passed into aUserDefinedFunctionfor evaluating anExpressionduring runtime. -
Uses of Expression in org.apache.flink.table.legacy.sources
Methods in org.apache.flink.table.legacy.sources that return Expression Modifier and Type Method Description ExpressionFieldComputer. getExpression(ResolvedFieldReference[] fieldAccesses)Deprecated.Returns theExpressionthat computes the value of the field.Method parameters in org.apache.flink.table.legacy.sources with type arguments of type Expression Modifier and Type Method Description TableSource<T>FilterableTableSource. applyPredicate(List<Expression> predicates)Deprecated.Check and pick all predicates this table source can support.
-