static ApiExpression |
Expressions.$(String name) |
Creates an unresolved reference to a table's column.
|
static ApiExpression |
Expressions.and(Object predicate0,
Object predicate1,
Object... predicates) |
Boolean AND in three-valued logic.
|
static ApiExpression |
Expressions.array(Object head,
Object... tail) |
Creates an array of literals.
|
static ApiExpression |
Expressions.atan2(Object y,
Object x) |
Calculates the arc tangent of a given coordinate.
|
static ApiExpression |
Expressions.call(Class<? extends org.apache.flink.table.functions.UserDefinedFunction> function,
Object... arguments) |
A call to an unregistered, inline function.
|
static ApiExpression |
Expressions.call(String path,
Object... arguments) |
A call to a function that will be looked up in a catalog.
|
static ApiExpression |
Expressions.call(org.apache.flink.table.functions.UserDefinedFunction function,
Object... arguments) |
A call to an unregistered, inline function.
|
static ApiExpression |
Expressions.callSql(String sqlExpression) |
A call to a SQL expression.
|
static ApiExpression |
Expressions.coalesce(Object... args) |
Returns the first argument that is not NULL.
|
static ApiExpression |
Expressions.col(String name) |
Creates an unresolved reference to a table's column.
|
static ApiExpression |
Expressions.concat(Object string,
Object... strings) |
Returns the string that results from concatenating the arguments.
|
static ApiExpression |
Expressions.concatWs(Object separator,
Object string,
Object... strings) |
Returns the string that results from concatenating the arguments and separator.
|
static ApiExpression |
Expressions.convertTz(Object dateStr,
Object tzFrom,
Object tzTo) |
Converts a datetime dateStr (with default ISO timestamp format 'yyyy-MM-dd HH:mm:ss') from
time zone tzFrom to time zone tzTo.
|
static ApiExpression |
Expressions.currentDatabase() |
Return the current database, the return type of this expression is DataTypes.STRING() .
|
static ApiExpression |
Expressions.currentDate() |
Returns the current SQL date in local time zone, the return type of this expression is DataTypes.DATE() .
|
static ApiExpression |
Expressions.currentTime() |
Returns the current SQL time in local time zone, the return type of this expression is DataTypes.TIME() .
|
static ApiExpression |
Expressions.currentTimestamp() |
Returns the current SQL timestamp in local time zone, the return type of this expression is
DataTypes.TIMESTAMP_WITH_LOCAL_TIME_ZONE() .
|
static ApiExpression |
Expressions.currentWatermark(Object rowtimeAttribute) |
Returns the current watermark for the given rowtime attribute, or NULL if no common
watermark of all upstream operations is available at the current operation in the pipeline.
|
static ApiExpression |
Expressions.dateFormat(Object timestamp,
Object format) |
Formats a timestamp as a string using a specified format.
|
static ApiExpression |
Expressions.e() |
Returns a value that is closer than any other value to e.
|
static ApiExpression |
Expressions.fromUnixtime(Object unixtime) |
Converts unix timestamp (seconds since '1970-01-01 00:00:00' UTC) to datetime string in the
"yyyy-MM-dd HH:mm:ss" format.
|
static ApiExpression |
Expressions.fromUnixtime(Object unixtime,
Object format) |
Converts unix timestamp (seconds since '1970-01-01 00:00:00' UTC) to datetime string in the
given format.
|
static ApiExpression |
Expressions.ifThenElse(Object condition,
Object ifTrue,
Object ifFalse) |
Ternary conditional operator that decides which of two other expressions should be evaluated
based on a evaluated boolean condition.
|
static ApiExpression |
Expressions.jsonArray(org.apache.flink.table.api.JsonOnNull onNull,
Object... values) |
Builds a JSON array string from a list of values.
|
static ApiExpression |
Expressions.jsonArrayAgg(org.apache.flink.table.api.JsonOnNull onNull,
Object itemExpr) |
Builds a JSON object string by aggregating items into an array.
|
static ApiExpression |
Expressions.jsonObject(org.apache.flink.table.api.JsonOnNull onNull,
Object... keyValues) |
Builds a JSON object string from a list of key-value pairs.
|
static ApiExpression |
Expressions.jsonObjectAgg(org.apache.flink.table.api.JsonOnNull onNull,
Object keyExpr,
Object valueExpr) |
Builds a JSON object string by aggregating key-value expressions into a single JSON object.
|
static ApiExpression |
Expressions.jsonString(Object value) |
Serializes a value into JSON.
|
static ApiExpression |
Expressions.lit(Object v) |
Creates a SQL literal.
|
static ApiExpression |
Expressions.lit(Object v,
org.apache.flink.table.types.DataType dataType) |
Creates a SQL literal of a given DataType .
|
static ApiExpression |
Expressions.localTime() |
Returns the current SQL time in local time zone, the return type of this expression is DataTypes.TIME() , this is a synonym for Expressions.currentTime() .
|
static ApiExpression |
Expressions.localTimestamp() |
Returns the current SQL timestamp in local time zone, the return type of this expression is
DataTypes.TIMESTAMP() .
|
static ApiExpression |
Expressions.log(Object value) |
Calculates the logarithm of the given value.
|
static ApiExpression |
Expressions.log(Object base,
Object value) |
Calculates the logarithm of the given value to the given base.
|
static ApiExpression |
Expressions.map(Object key,
Object value,
Object... tail) |
Creates a map of expressions.
|
static ApiExpression |
Expressions.mapFromArrays(Object key,
Object value) |
Creates a map from an array of keys and an array of values.
|
static ApiExpression |
Expressions.negative(Object v) |
Returns negative numeric.
|
static ApiExpression |
Expressions.not(Object expression) |
Inverts a given boolean expression.
|
static ApiExpression |
Expressions.nullOf(org.apache.flink.api.common.typeinfo.TypeInformation<?> typeInfo) |
Deprecated.
|
static ApiExpression |
Expressions.nullOf(org.apache.flink.table.types.DataType dataType) |
Returns a null literal value of a given data type.
|
static ApiExpression |
Expressions.or(Object predicate0,
Object predicate1,
Object... predicates) |
Boolean OR in three-valued logic.
|
static ApiExpression |
Expressions.pi() |
Returns a value that is closer than any other value to pi.
|
static ApiExpression |
Expressions.rand() |
Returns a pseudorandom double value between 0.0 (inclusive) and 1.0 (exclusive).
|
static ApiExpression |
Expressions.rand(Object seed) |
Returns a pseudorandom double value between 0.0 (inclusive) and 1.0 (exclusive) with a
initial seed.
|
static ApiExpression |
Expressions.randInteger(Object bound) |
Returns a pseudorandom integer value between 0 (inclusive) and the specified value
(exclusive).
|
static ApiExpression |
Expressions.randInteger(Object seed,
Object bound) |
Returns a pseudorandom integer value between 0 (inclusive) and the specified value
(exclusive) with a initial seed.
|
static ApiExpression |
Expressions.range(int start,
int end) |
Indicates an index based range, which can be used in columns selection.
|
static ApiExpression |
Expressions.range(String start,
String end) |
Indicates a range from 'start' to 'end', which can be used in columns selection.
|
static ApiExpression |
Expressions.row(Object head,
Object... tail) |
Creates a row of expressions.
|
static ApiExpression |
Expressions.rowInterval(Long rows) |
Creates an interval of rows.
|
static ApiExpression |
Expressions.sourceWatermark() |
Source watermark declaration for Schema .
|
static ApiExpression |
Expressions.temporalOverlaps(Object leftTimePoint,
Object leftTemporal,
Object rightTimePoint,
Object rightTemporal) |
Determines whether two anchored time intervals overlap.
|
static ApiExpression |
Expressions.timestampDiff(org.apache.flink.table.expressions.TimePointUnit timePointUnit,
Object timePoint1,
Object timePoint2) |
Returns the (signed) number of TimePointUnit between timePoint1 and timePoint2.
|
protected ApiExpression |
ApiExpression.toApiSpecificExpression(org.apache.flink.table.expressions.Expression expression) |
|
static ApiExpression |
Expressions.toDate(Object dateStr) |
Converts the given date string with format 'yyyy-MM-dd' to DataTypes.DATE() .
|
static ApiExpression |
Expressions.toDate(Object dateStr,
Object format) |
Converts the date string with the specified format to DataTypes.DATE() .
|
static ApiExpression |
Expressions.toTimestamp(Object timestampStr) |
Converts the given date time string with format 'yyyy-MM-dd HH:mm:ss' under the 'UTC+0' time
zone to DataTypes.TIMESTAMP() .
|
static ApiExpression |
Expressions.toTimestamp(Object timestampStr,
Object format) |
Converts the given time string with the specified format under the 'UTC+0' time zone to
DataTypes.TIMESTAMP() .
|
static ApiExpression |
Expressions.toTimestampLtz(Object numericEpochTime,
Object precision) |
Converts a numeric type epoch time to DataTypes.TIMESTAMP_LTZ(int) .
|
static ApiExpression |
Expressions.unixTimestamp() |
Gets the current unix timestamp in seconds.
|
static ApiExpression |
Expressions.unixTimestamp(Object timestampStr) |
Converts the given date time string with format 'yyyy-MM-dd HH:mm:ss' to unix timestamp (in
seconds), using the time zone specified in the table config.
|
static ApiExpression |
Expressions.unixTimestamp(Object timestampStr,
Object format) |
Converts the given date time string with the specified format to unix timestamp (in seconds),
using the specified timezone in table config.
|
static ApiExpression |
Expressions.uuid() |
Returns an UUID (Universally Unique Identifier) string (e.g.,
"3d3c68f7-f608-473f-b60c-b0c44ad4cc4e") according to RFC 4122 type 4 (pseudo randomly
generated) UUID.
|
static ApiExpression |
Expressions.withAllColumns() |
Creates an expression that selects all columns.
|
static ApiExpression |
Expressions.withColumns(Object head,
Object... tail) |
Creates an expression that selects a range of columns.
|
static ApiExpression |
Expressions.withoutColumns(Object head,
Object... tail) |
Creates an expression that selects all columns except for the given range of columns.
|