org.apache.spark.sql.catalyst

expressions

package expressions

A set of classes that can be used to represent trees of relational expressions. A key goal of the expression library is to hide the details of naming and scoping from developers who want to manipulate trees of relational operators. As such, the library defines a special type of expression, a NamedExpression in addition to the standard collection of expressions.

Standard Expressions

A library of standard expressions (e.g., Add, EqualTo), aggregates (e.g., SUM, COUNT), and other computations (e.g. UDFs). Each expression type is capable of determining its output schema as a function of its children's output schema.

Named Expressions

Some expression are named and thus can be referenced by later operators in the dataflow graph. The two types of named expressions are AttributeReferences and Aliases. AttributeReferences refer to attributes of the input tuple for a given operator and form the leaves of some expression trees. Aliases assign a name to intermediate computations. For example, in the SQL statement SELECT a+b AS c FROM ..., the expressions a and b would be represented by AttributeReferences and c would be represented by an Alias.

During analysis, all named expressions are assigned a globally unique expression id, which can be used for equality comparisons. While the original names are kept around for debugging purposes, they should never be used to check if two attributes refer to the same value, as plan transformations can result in the introduction of naming ambiguity. For example, consider a plan that contains subqueries, both of which are reading from the same table. If an optimization removes the subqueries, scoping information would be destroyed, eliminating the ability to reason about which subquery produced a given attribute.

Evaluation

The result of expressions can be evaluated using the Expression.apply(Row) method.

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. expressions
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. case class Abs(child: Expression) extends UnaryExpression with ExpectsInputTypes with NullIntolerant with Product with Serializable

    A function that get the absolute value of the numeric value.

  2. case class Acos(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  3. case class Add(left: Expression, right: Expression) extends BinaryArithmetic with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  4. case class AddMonths(startDate: Expression, numMonths: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns the date that is num_months after start_date.

  5. abstract class AggregateWindowFunction extends DeclarativeAggregate with WindowFunction

  6. case class Alias(child: Expression, name: String)(exprId: ExprId = NamedExpression.newExprId, qualifier: Option[String] = scala.None, explicitMetadata: Option[Metadata] = scala.None, isGenerated: Boolean = ...) extends UnaryExpression with NamedExpression with Product with Serializable

    Used to assign a new name to a computation.

  7. case class And(left: Expression, right: Expression) extends BinaryOperator with Predicate with Product with Serializable

    Annotations
    @ExpressionDescription()
  8. case class ArrayContains(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Checks if the array (left) has the element (right)

  9. case class Ascii(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns the numeric value of the first character of str.

  10. case class Asin(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  11. case class AssertTrue(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function throws an exception if 'condition' is not true.

  12. case class AtLeastNNonNulls(n: Int, children: Seq[Expression]) extends Expression with Predicate with Product with Serializable

    A predicate that is evaluated to be true if there are at least n non-null and non-NaN values.

  13. case class Atan(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  14. case class Atan2(left: Expression, right: Expression) extends BinaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  15. abstract class Attribute extends LeafExpression with NamedExpression with NullIntolerant

  16. class AttributeEquals extends AnyRef

    Attributes
    protected
  17. class AttributeMap[A] extends Map[Attribute, A] with Serializable

  18. case class AttributeReference(name: String, dataType: DataType, nullable: Boolean = true, metadata: Metadata = ...)(exprId: ExprId = NamedExpression.newExprId, qualifier: Option[String] = scala.None, isGenerated: Boolean = ...) extends Attribute with Unevaluable with Product with Serializable

    A reference to an attribute produced by another operator in the tree.

  19. implicit class AttributeSeq extends Serializable

    Helper functions for working with Seq[Attribute].

  20. class AttributeSet extends Traversable[Attribute] with Serializable

    A Set designed to hold AttributeReference objects, that performs equality checking using expression id instead of standard java equality.

  21. case class BRound(child: Expression, scale: Expression) extends RoundBase with Serializable with ImplicitCastInputTypes with Product

    Round an expression to d decimal places using HALF_EVEN rounding mode, also known as Gaussian rounding or bankers' rounding.

  22. case class Base64(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Converts the argument from binary to a base 64 string.

  23. trait BaseGenericInternalRow extends InternalRow

    An extended version of InternalRow that implements all special getters, toString and equals/hashCode by genericGet.

  24. case class Bin(child: Expression) extends UnaryExpression with Serializable with ImplicitCastInputTypes with Product

    Annotations
    @ExpressionDescription()
  25. abstract class BinaryArithmetic extends BinaryOperator

  26. abstract class BinaryComparison extends BinaryOperator with Predicate

  27. abstract class BinaryExpression extends Expression

    An expression with two inputs and one output.

  28. abstract class BinaryMathExpression extends BinaryExpression with Serializable with ImplicitCastInputTypes

    A binary expression specifically for math functions that take two Doubles as input and returns a Double.

  29. abstract class BinaryOperator extends BinaryExpression with ExpectsInputTypes

    A BinaryExpression that is an operator, with two properties:

  30. case class BitwiseAnd(left: Expression, right: Expression) extends BinaryArithmetic with Product with Serializable

    A function that calculates bitwise and(&) of two numbers.

  31. case class BitwiseNot(child: Expression) extends UnaryExpression with ExpectsInputTypes with Product with Serializable

    A function that calculates bitwise not(~) of a number.

  32. case class BitwiseOr(left: Expression, right: Expression) extends BinaryArithmetic with Product with Serializable

    A function that calculates bitwise or(|) of two numbers.

  33. case class BitwiseXor(left: Expression, right: Expression) extends BinaryArithmetic with Product with Serializable

    A function that calculates bitwise xor of two numbers.

  34. case class BoundReference(ordinal: Int, dataType: DataType, nullable: Boolean) extends LeafExpression with Product with Serializable

    A bound reference points to a specific slot in the input tuple, allowing the actual value to be retrieved more efficiently.

  35. case class CallMethodViaReflection(children: Seq[Expression]) extends Expression with CodegenFallback with Product with Serializable

    An expression that invokes a method on a class via reflection.

  36. case class CaseWhen(branches: Seq[(Expression, Expression)], elseValue: Option[Expression] = scala.None) extends CaseWhenBase with CodegenFallback with Serializable with Product

    Case statements of the form "CASE WHEN a THEN b [WHEN c THEN d]* [ELSE e] END".

  37. abstract class CaseWhenBase extends Expression with Serializable

    Abstract parent class for common logic in CaseWhen and CaseWhenCodegen.

  38. case class CaseWhenCodegen(branches: Seq[(Expression, Expression)], elseValue: Option[Expression] = scala.None) extends CaseWhenBase with Serializable with Product

    CaseWhen expression used when code generation condition is satisfied.

  39. case class Cast(child: Expression, dataType: DataType) extends UnaryExpression with NullIntolerant with Product with Serializable

    Cast the child expression to the target data type.

  40. case class Cbrt(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  41. case class Ceil(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  42. case class CheckOverflow(child: Expression, dataType: DecimalType) extends UnaryExpression with Product with Serializable

    Rounds the decimal to given scale and check whether the decimal can fit in provided precision or not, returns null if not.

  43. case class Coalesce(children: Seq[Expression]) extends Expression with Product with Serializable

    An expression that is evaluated to the first non-null input.

  44. case class Concat(children: Seq[Expression]) extends Expression with ImplicitCastInputTypes with Product with Serializable

    An expression that concatenates multiple input strings into a single string.

  45. case class ConcatWs(children: Seq[Expression]) extends Expression with ImplicitCastInputTypes with Product with Serializable

    An expression that concatenates multiple input strings or array of strings into a single string, using a given separator (the first child).

  46. case class Contains(left: Expression, right: Expression) extends BinaryExpression with StringPredicate with Product with Serializable

    A function that returns true if the string left contains the string right.

  47. case class Conv(numExpr: Expression, fromBaseExpr: Expression, toBaseExpr: Expression) extends TernaryExpression with ImplicitCastInputTypes with Product with Serializable

    Convert a num from one base to another

  48. case class Cos(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  49. case class Cosh(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  50. case class Crc32(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function that computes a cyclic redundancy check value and returns it as a bigint For input of type BinaryType

  51. case class CreateArray(children: Seq[Expression]) extends Expression with Product with Serializable

    Returns an Array containing the evaluation of all children expressions.

  52. case class CreateMap(children: Seq[Expression]) extends Expression with Product with Serializable

    Returns a catalyst Map containing the evaluation of all children expressions as keys and values.

  53. case class CreateNamedStruct(children: Seq[Expression]) extends Expression with CreateNamedStructLike with Product with Serializable

    Creates a struct with the given field names and values

  54. trait CreateNamedStructLike extends Expression

    Common base class for both CreateNamedStruct and CreateNamedStructUnsafe.

  55. case class CreateNamedStructUnsafe(children: Seq[Expression]) extends Expression with CreateNamedStructLike with Product with Serializable

    Creates a struct with the given field names and values.

  56. case class Cube(groupByExprs: Seq[Expression]) extends Expression with GroupingSet with Product with Serializable

  57. case class CumeDist() extends RowNumberLike with SizeBasedWindowFunction with Product with Serializable

    The CumeDist function computes the position of a value relative to all values in the partition.

  58. case class CurrentBatchTimestamp(timestampMs: Long, dataType: DataType) extends LeafExpression with Nondeterministic with CodegenFallback with Product with Serializable

    Expression representing the current batch time, which is used by StreamExecution to 1.

  59. case class CurrentDatabase() extends LeafExpression with Unevaluable with Product with Serializable

    Returns the current database of the SessionCatalog.

  60. case class CurrentDate() extends LeafExpression with CodegenFallback with Product with Serializable

    Returns the current date at the start of query evaluation.

  61. case class CurrentTimestamp() extends LeafExpression with CodegenFallback with Product with Serializable

    Returns the current timestamp at the start of query evaluation.

  62. case class DateAdd(startDate: Expression, days: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Adds a number of days to startdate.

  63. case class DateDiff(endDate: Expression, startDate: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns the number of days from startDate to endDate.

  64. case class DateFormatClass(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  65. case class DateSub(startDate: Expression, days: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Subtracts a number of days to startdate.

  66. case class DayOfMonth(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  67. case class DayOfYear(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  68. case class Decode(bin: Expression, charset: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Decodes the first argument into a String using the provided character set (one of 'US-ASCII', 'ISO-8859-1', 'UTF-8', 'UTF-16BE', 'UTF-16LE', 'UTF-16').

  69. case class DenseRank(children: Seq[Expression]) extends RankLike with Product with Serializable

    The DenseRank function computes the rank of a value in a group of values.

  70. case class Divide(left: Expression, right: Expression) extends BinaryArithmetic with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  71. case class Elt(children: Seq[Expression]) extends Expression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  72. case class Encode(value: Expression, charset: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Encodes the first argument into a BINARY using the provided character set (one of 'US-ASCII', 'ISO-8859-1', 'UTF-8', 'UTF-16BE', 'UTF-16LE', 'UTF-16').

  73. case class EndsWith(left: Expression, right: Expression) extends BinaryExpression with StringPredicate with Product with Serializable

    A function that returns true if the string left ends with the string right.

  74. case class EqualNullSafe(left: Expression, right: Expression) extends BinaryComparison with Product with Serializable

    Annotations
    @ExpressionDescription()
  75. case class EqualTo(left: Expression, right: Expression) extends BinaryComparison with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  76. class EquivalentExpressions extends AnyRef

    This class is used to compute equality of (sub)expression trees.

  77. case class EulerNumber() extends LeafMathExpression with Product with Serializable

    Euler's number.

  78. case class Exists(plan: LogicalPlan, exprId: ExprId = NamedExpression.newExprId) extends SubqueryExpression with Predicate with Unevaluable with Product with Serializable

    The Exists expression checks if a row exists in a subquery given some correlated condition.

  79. case class Exp(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  80. trait ExpectsInputTypes extends Expression

    A trait that gets mixin to define the expected input types of an expression.

  81. case class Explode(child: Expression) extends ExplodeBase with Product with Serializable

    Given an input array produces a sequence of rows for each value in the array.

  82. abstract class ExplodeBase extends UnaryExpression with Generator with CodegenFallback with Serializable

    A base class for Explode and PosExplode

  83. case class Expm1(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  84. case class ExprId(id: Long, jvmId: UUID) extends Product with Serializable

    A globally unique id for a given named expression.

  85. abstract class Expression extends TreeNode[Expression]

    An expression in Catalyst.

  86. class ExpressionDescription extends Annotation with Annotation with ClassfileAnnotation

  87. class ExpressionInfo extends AnyRef

  88. class ExpressionSet extends Set[Expression]

    A Set where membership is determined based on a canonical representation of an Expression (i.

  89. trait ExtractValue extends Expression

  90. case class Factorial(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  91. case class FindInSet(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function that returns the index (1-based) of the given string (left) in the comma- delimited list (right).

  92. final class FixedLengthRowBasedKeyValueBatch extends RowBasedKeyValueBatch

  93. case class Floor(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  94. case class FormatNumber(x: Expression, d: Expression) extends BinaryExpression with ExpectsInputTypes with Product with Serializable

    Formats the number X to a format like '#,###,###.

  95. case class FormatString(children: Expression*) extends Expression with ImplicitCastInputTypes with Product with Serializable

    Returns the input formatted according do printf-style format strings

  96. sealed trait FrameBoundary extends AnyRef

    The trait used to represent the type of a Window Frame Boundary.

  97. sealed trait FrameType extends AnyRef

    The trait used to represent the type of a Window Frame.

  98. case class FromUTCTimestamp(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Given a timestamp, which corresponds to a certain time of day in UTC, returns another timestamp that corresponds to the same time of day in the given timezone.

  99. case class FromUnixTime(sec: Expression, format: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Converts the number of seconds from unix epoch (1970-01-01 00:00:00 UTC) to a string representing the timestamp of that moment in the current system time zone in the given format.

  100. trait Generator extends Expression

    An expression that produces zero or more rows given a single input row.

  101. class GenericInternalRow extends InternalRow with BaseGenericInternalRow

    An internal row implementation that uses an array of objects as the underlying storage.

  102. class GenericRow extends Row

    A row implementation that uses an array of objects as the underlying storage.

  103. class GenericRowWithSchema extends GenericRow

  104. case class GetArrayItem(child: Expression, ordinal: Expression) extends BinaryExpression with ExpectsInputTypes with ExtractValue with Product with Serializable

    Returns the field at ordinal in the Array child.

  105. case class GetArrayStructFields(child: Expression, field: StructField, ordinal: Int, numFields: Int, containsNull: Boolean) extends UnaryExpression with ExtractValue with Product with Serializable

    For a child whose data type is an array of structs, extracts the ordinal-th fields of all array elements, and returns them as a new array.

  106. case class GetJsonObject(json: Expression, path: Expression) extends BinaryExpression with ExpectsInputTypes with CodegenFallback with Product with Serializable

    Extracts json object from a json string based on json path specified, and returns json string of the extracted json object.

  107. case class GetMapValue(child: Expression, key: Expression) extends BinaryExpression with ImplicitCastInputTypes with ExtractValue with Product with Serializable

    Returns the value of key key in Map child.

  108. case class GetStructField(child: Expression, ordinal: Int, name: Option[String] = scala.None) extends UnaryExpression with ExtractValue with Product with Serializable

    Returns the value of fields in the Struct child.

  109. case class GreaterThan(left: Expression, right: Expression) extends BinaryComparison with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  110. case class GreaterThanOrEqual(left: Expression, right: Expression) extends BinaryComparison with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  111. case class Greatest(children: Seq[Expression]) extends Expression with Product with Serializable

    A function that returns the greatest value of all parameters, skipping null values.

  112. case class Grouping(child: Expression) extends Expression with Unevaluable with Product with Serializable

    Indicates whether a specified column expression in a GROUP BY list is aggregated or not.

  113. case class GroupingID(groupByExprs: Seq[Expression]) extends Expression with Unevaluable with Product with Serializable

    GroupingID is a function that computes the level of grouping.

  114. trait GroupingSet extends Expression with CodegenFallback

    A placeholder expression for cube/rollup, which will be replaced by analyzer

  115. abstract class HashExpression[E] extends Expression

    A function that calculates hash value for a group of expressions.

  116. case class Hex(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    If the argument is an INT or binary, hex returns the number as a STRING in hexadecimal format.

  117. case class HiveHash(children: Seq[Expression]) extends HashExpression[Int] with Product with Serializable

    Simulates Hive's hashing function at org.

  118. case class Hour(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  119. case class Hypot(left: Expression, right: Expression) extends BinaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  120. case class If(predicate: Expression, trueValue: Expression, falseValue: Expression) extends Expression with Product with Serializable

    Annotations
    @ExpressionDescription()
  121. case class IfNull(left: Expression, right: Expression, child: Expression) extends UnaryExpression with RuntimeReplaceable with Product with Serializable

    Annotations
    @ExpressionDescription()
  122. trait ImplicitCastInputTypes extends Expression with ExpectsInputTypes

    A mixin for the analyzer to perform implicit type casting using org.apache.spark.sql.catalyst.analysis.TypeCoercion.ImplicitTypeCasts.

  123. case class In(value: Expression, list: Seq[Expression]) extends Expression with Predicate with ImplicitCastInputTypes with Product with Serializable

    Evaluates to true if list contains value.

  124. case class InSet(child: Expression, hset: Set[Any]) extends UnaryExpression with Predicate with Product with Serializable

    Optimized version of In clause, when all filter values of In clause are static.

  125. case class InitCap(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns string, with the first letter of each word in uppercase, all other letters in lowercase.

  126. case class Inline(child: Expression) extends UnaryExpression with Generator with CodegenFallback with Product with Serializable

    Explodes an array of structs into a table.

  127. case class InputFileName() extends LeafExpression with Nondeterministic with Product with Serializable

    Expression that returns the name of the current file being read.

  128. abstract class InterpretedHashFunction extends AnyRef

    Base class for interpreted hash functions.

  129. case class InterpretedMutableProjection(expressions: Seq[Expression]) extends MutableProjection with Product with Serializable

    A MutableProjection that is calculated by calling eval on each of the specified expressions.

  130. class InterpretedOrdering extends Ordering[InternalRow]

    An interpreted row ordering comparator.

  131. class InterpretedProjection extends Projection

    A Projection that is calculated by calling the eval of each of the specified expressions.

  132. case class IsNaN(child: Expression) extends UnaryExpression with Predicate with ImplicitCastInputTypes with Product with Serializable

    Evaluates to true iff it's NaN.

  133. case class IsNotNull(child: Expression) extends UnaryExpression with Predicate with Product with Serializable

    An expression that is evaluated to true if the input is not null.

  134. case class IsNull(child: Expression) extends UnaryExpression with Predicate with Product with Serializable

    An expression that is evaluated to true if the input is null.

  135. class JoinedRow extends InternalRow

    A mutable wrapper that makes two rows appear as a single concatenated row.

  136. case class JsonToStruct(schema: StructType, options: Map[String, String], child: Expression) extends UnaryExpression with CodegenFallback with ExpectsInputTypes with Product with Serializable

    Converts an json input string to a StructType with the specified schema.

  137. case class JsonTuple(children: Seq[Expression]) extends Expression with Generator with CodegenFallback with Product with Serializable

    Annotations
    @ExpressionDescription()
  138. case class Lag(input: Expression, offset: Expression, default: Expression) extends OffsetWindowFunction with Product with Serializable

    The Lag function returns the value of input at the offsetth row before the current row in the window.

  139. case class LastDay(startDate: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns the last day of the month which the date belongs to.

  140. case class Lead(input: Expression, offset: Expression, default: Expression) extends OffsetWindowFunction with Product with Serializable

    The Lead function returns the value of input at the offsetth row after the current row in the window.

  141. abstract class LeafExpression extends Expression

    A leaf expression, i.

  142. abstract class LeafMathExpression extends LeafExpression with CodegenFallback with Serializable

    A leaf expression specifically for math constants.

  143. case class Least(children: Seq[Expression]) extends Expression with Product with Serializable

    A function that returns the least value of all parameters, skipping null values.

  144. case class Length(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function that return the length of the given string or binary expression.

  145. case class LessThan(left: Expression, right: Expression) extends BinaryComparison with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  146. case class LessThanOrEqual(left: Expression, right: Expression) extends BinaryComparison with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  147. case class Levenshtein(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function that return the Levenshtein distance between the two given strings.

  148. case class Like(left: Expression, right: Expression) extends BinaryExpression with StringRegexExpression with Product with Serializable

    Simple RegEx pattern matching function

  149. case class ListQuery(plan: LogicalPlan, exprId: ExprId = NamedExpression.newExprId) extends SubqueryExpression with Unevaluable with Product with Serializable

    A ListQuery expression defines the query which we want to search in an IN subquery expression.

  150. case class Literal(value: Any, dataType: DataType) extends LeafExpression with CodegenFallback with Product with Serializable

    In order to do type checking, use Literal.

  151. case class Log(child: Expression) extends UnaryLogExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  152. case class Log10(child: Expression) extends UnaryLogExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  153. case class Log1p(child: Expression) extends UnaryLogExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  154. case class Log2(child: Expression) extends UnaryLogExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  155. case class Logarithm(left: Expression, right: Expression) extends BinaryMathExpression with Product with Serializable

    Computes the logarithm of a number.

  156. case class Lower(child: Expression) extends UnaryExpression with String2StringExpression with Product with Serializable

    A function that converts the characters of a string to lowercase.

  157. case class MakeDecimal(child: Expression, precision: Int, scale: Int) extends UnaryExpression with Product with Serializable

    Create a Decimal from an unscaled Long value.

  158. case class MapKeys(child: Expression) extends UnaryExpression with ExpectsInputTypes with Product with Serializable

    Returns an unordered array containing the keys of the map.

  159. case class MapValues(child: Expression) extends UnaryExpression with ExpectsInputTypes with Product with Serializable

    Returns an unordered array containing the values of the map.

  160. case class Md5(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function that calculates an MD5 128-bit checksum and returns it as a hex string For input of type BinaryType

  161. case class Minute(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  162. case class MonotonicallyIncreasingID() extends LeafExpression with Nondeterministic with Product with Serializable

    Returns monotonically increasing 64-bit integers.

  163. case class Month(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  164. case class MonthsBetween(date1: Expression, date2: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns number of months between dates date1 and date2.

  165. case class Multiply(left: Expression, right: Expression) extends BinaryArithmetic with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  166. case class Murmur3Hash(children: Seq[Expression], seed: Int) extends HashExpression[Int] with Product with Serializable

    A MurMur3 Hash expression.

  167. final class MutableAny extends MutableValue

  168. final class MutableBoolean extends MutableValue

  169. final class MutableByte extends MutableValue

  170. final class MutableDouble extends MutableValue

  171. final class MutableFloat extends MutableValue

  172. final class MutableInt extends MutableValue

  173. final class MutableLong extends MutableValue

  174. abstract class MutableProjection extends Projection

    Converts a InternalRow to another Row given a sequence of expression that define each column of the new row.

  175. final class MutableShort extends MutableValue

  176. abstract class MutableValue extends Serializable

    A parent class for mutable container objects that are reused when the values are changed, resulting in less garbage.

  177. case class NTile(buckets: Expression) extends RowNumberLike with SizeBasedWindowFunction with Product with Serializable

    The NTile function divides the rows for each window partition into n buckets ranging from 1 to at most n.

  178. case class NaNvl(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    An Expression evaluates to left iff it's not NaN, or evaluates to right otherwise.

  179. trait NamedExpression extends Expression

    An Expression that is named.

  180. case class NextDay(startDate: Expression, dayOfWeek: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns the first date which is later than startDate and named as dayOfWeek.

  181. trait NonSQLExpression extends Expression

    Expressions that don't have SQL representation should extend this trait.

  182. trait Nondeterministic extends Expression

    An expression that is nondeterministic.

  183. case class Not(child: Expression) extends UnaryExpression with Predicate with ImplicitCastInputTypes with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  184. case class NullIf(left: Expression, right: Expression, child: Expression) extends UnaryExpression with RuntimeReplaceable with Product with Serializable

    Annotations
    @ExpressionDescription()
  185. trait NullIntolerant extends AnyRef

    When an expression inherits this, meaning the expression is null intolerant (i.

  186. sealed abstract class NullOrdering extends AnyRef

  187. case class Nvl(left: Expression, right: Expression, child: Expression) extends UnaryExpression with RuntimeReplaceable with Product with Serializable

    Annotations
    @ExpressionDescription()
  188. case class Nvl2(expr1: Expression, expr2: Expression, expr3: Expression, child: Expression) extends UnaryExpression with RuntimeReplaceable with Product with Serializable

    Annotations
    @ExpressionDescription()
  189. abstract class OffsetWindowFunction extends Expression with WindowFunction with Unevaluable with ImplicitCastInputTypes

    An offset window function is a window function that returns the value of the input column offset by a number of rows within the partition.

  190. case class Or(left: Expression, right: Expression) extends BinaryOperator with Predicate with Product with Serializable

    Annotations
    @ExpressionDescription()
  191. case class OuterReference(e: NamedExpression) extends LeafExpression with NamedExpression with Unevaluable with Product with Serializable

    A place holder used to hold a reference that has been resolved to a field outside of the current plan.

  192. case class ParseUrl(children: Seq[Expression]) extends Expression with ExpectsInputTypes with CodegenFallback with Product with Serializable

    Extracts a part from a URL

  193. case class PercentRank(children: Seq[Expression]) extends RankLike with SizeBasedWindowFunction with Product with Serializable

    The PercentRank function computes the percentage ranking of a value in a group of values.

  194. case class Pi() extends LeafMathExpression with Product with Serializable

    Pi.

  195. abstract class PlanExpression[T <: QueryPlan[_]] extends Expression

    An interface for expressions that contain a QueryPlan.

  196. case class Pmod(left: Expression, right: Expression) extends BinaryArithmetic with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  197. case class PosExplode(child: Expression) extends ExplodeBase with Product with Serializable

    Given an input array produces a sequence of rows for each position and value in the array.

  198. case class Pow(left: Expression, right: Expression) extends BinaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  199. case class PreciseTimestamp(child: Expression) extends UnaryExpression with ExpectsInputTypes with Product with Serializable

    Expression used internally to convert the TimestampType to Long without losing precision, i.

  200. trait Predicate extends Expression

    An Expression that returns a boolean value.

  201. trait PredicateHelper extends AnyRef

  202. case class PredicateSubquery(plan: LogicalPlan, children: Seq[Expression] = collection.this.Seq.empty[Nothing], nullAware: Boolean = false, exprId: ExprId = NamedExpression.newExprId) extends SubqueryExpression with Predicate with Unevaluable with Product with Serializable

    A predicate subquery checks the existence of a value in a sub-query.

  203. case class PrettyAttribute(name: String, dataType: DataType = org.apache.spark.sql.types.NullType) extends Attribute with Unevaluable with Product with Serializable

    A place holder used when printing expressions without debugging information such as the expression id or the unresolved indicator.

  204. case class PrintToStderr(child: Expression) extends UnaryExpression with Product with Serializable

    Print the result of an expression to stderr (used for debugging codegen).

  205. abstract class Projection extends (InternalRow) ⇒ InternalRow

    Converts a InternalRow to another Row given a sequence of expression that define each column of the new row.

  206. case class PromotePrecision(child: Expression) extends UnaryExpression with Product with Serializable

    An expression used to wrap the children when promote the precision of DecimalType to avoid promote multiple times.

  207. case class Quarter(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  208. abstract class RDG extends UnaryExpression with ExpectsInputTypes with Nondeterministic

    A Random distribution generating expression.

  209. case class RLike(left: Expression, right: Expression) extends BinaryExpression with StringRegexExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  210. case class Rand(child: Expression) extends RDG with Product with Serializable

    Generate a random column with i.

  211. case class Randn(child: Expression) extends RDG with Product with Serializable

    Generate a random column with i.

  212. case class Rank(children: Seq[Expression]) extends RankLike with Product with Serializable

    The Rank function computes the rank of a value in a group of values.

  213. abstract class RankLike extends AggregateWindowFunction

    A RankLike function is a WindowFunction that changes its value based on a change in the value of the order of the window in which is processed.

  214. case class ReferenceToExpressions(result: Expression, children: Seq[Expression]) extends Expression with Product with Serializable

    A special expression that evaluates BoundReferences by given expressions instead of the input row.

  215. case class RegExpExtract(subject: Expression, regexp: Expression, idx: Expression) extends TernaryExpression with ImplicitCastInputTypes with Product with Serializable

    Extract a specific(idx) group identified by a Java regex.

  216. case class RegExpReplace(subject: Expression, regexp: Expression, rep: Expression) extends TernaryExpression with ImplicitCastInputTypes with Product with Serializable

    Replace all substrings of str that match regexp with rep.

  217. case class Remainder(left: Expression, right: Expression) extends BinaryArithmetic with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  218. case class Rint(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  219. case class Rollup(groupByExprs: Seq[Expression]) extends Expression with GroupingSet with Product with Serializable

  220. case class Round(child: Expression, scale: Expression) extends RoundBase with Serializable with ImplicitCastInputTypes with Product

    Round an expression to d decimal places using HALF_UP rounding mode.

  221. abstract class RoundBase extends BinaryExpression with Serializable with ImplicitCastInputTypes

    Round the child's result to scale decimal place when scale >= 0 or round at integral part when scale < 0.

  222. abstract class RowBasedKeyValueBatch extends MemoryConsumer

  223. case class RowNumber() extends RowNumberLike with Product with Serializable

    The RowNumber function computes a unique, sequential number to each row, starting with one, according to the ordering of rows within the window partition.

  224. abstract class RowNumberLike extends AggregateWindowFunction

  225. trait RuntimeReplaceable extends UnaryExpression with Unevaluable

    An expression that gets replaced at runtime (currently by the optimizer) into a different expression for evaluation.

  226. case class ScalaUDF(function: AnyRef, dataType: DataType, children: Seq[Expression], inputTypes: Seq[DataType] = immutable.this.Nil) extends Expression with ImplicitCastInputTypes with NonSQLExpression with Product with Serializable

    User-defined function.

  227. case class ScalarSubquery(plan: LogicalPlan, children: Seq[Expression] = collection.this.Seq.empty[Nothing], exprId: ExprId = NamedExpression.newExprId) extends SubqueryExpression with Unevaluable with Product with Serializable

    A subquery that will return only one row and one column.

  228. case class Second(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  229. case class Sentences(str: Expression, language: Expression = Literal.apply(""), country: Expression = Literal.apply("")) extends Expression with ImplicitCastInputTypes with CodegenFallback with Product with Serializable

    Splits a string into arrays of sentences, where each sentence is an array of words.

  230. case class Sha1(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function that calculates a sha1 hash value and returns it as a hex string For input of type BinaryType or StringType

  231. case class Sha2(left: Expression, right: Expression) extends BinaryExpression with Serializable with ImplicitCastInputTypes with Product

    A function that calculates the SHA-2 family of functions (SHA-224, SHA-256, SHA-384, and SHA-512) and returns it as a hex string.

  232. case class ShiftLeft(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Bitwise left shift.

  233. case class ShiftRight(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Bitwise (signed) right shift.

  234. case class ShiftRightUnsigned(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Bitwise unsigned right shift, for integer and long data type.

  235. case class Signum(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  236. case class Sin(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  237. case class Sinh(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  238. case class Size(child: Expression) extends UnaryExpression with ExpectsInputTypes with Product with Serializable

    Given an array or map, returns its size.

  239. trait SizeBasedWindowFunction extends AggregateWindowFunction

    A SizeBasedWindowFunction needs the size of the current window for its calculation.

  240. case class SortArray(base: Expression, ascendingOrder: Expression) extends BinaryExpression with ExpectsInputTypes with CodegenFallback with Product with Serializable

    Sorts the input array in ascending / descending order according to the natural ordering of the array elements and returns it.

  241. sealed abstract class SortDirection extends AnyRef

  242. case class SortOrder(child: Expression, direction: SortDirection, nullOrdering: NullOrdering) extends UnaryExpression with Unevaluable with Product with Serializable

    An expression that can be used to sort a tuple.

  243. case class SortPrefix(child: SortOrder) extends UnaryExpression with Product with Serializable

    An expression to generate a 64-bit long prefix used in sorting.

  244. case class SoundEx(child: Expression) extends UnaryExpression with ExpectsInputTypes with Product with Serializable

    A function that return Soundex code of the given string expression.

  245. case class SparkPartitionID() extends LeafExpression with Nondeterministic with Product with Serializable

    Expression that returns the current partition id.

  246. trait SpecializedGetters extends AnyRef

  247. final class SpecificInternalRow extends InternalRow with BaseGenericInternalRow

    A row type that holds an array specialized container objects, of type MutableValue, chosen based on the dataTypes of each column.

  248. case class SpecifiedWindowFrame(frameType: FrameType, frameStart: FrameBoundary, frameEnd: FrameBoundary) extends WindowFrame with Product with Serializable

    A specified Window Frame.

  249. case class Sqrt(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  250. case class Stack(children: Seq[Expression]) extends Expression with Generator with CodegenFallback with Product with Serializable

    Separate v1, .

  251. case class StartsWith(left: Expression, right: Expression) extends BinaryExpression with StringPredicate with Product with Serializable

    A function that returns true if the string left starts with the string right.

  252. trait String2StringExpression extends Expression with ImplicitCastInputTypes

  253. case class StringInstr(str: Expression, substr: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function that returns the position of the first occurrence of substr in the given string.

  254. case class StringLPad(str: Expression, len: Expression, pad: Expression) extends TernaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns str, left-padded with pad to a length of len.

  255. case class StringLocate(substr: Expression, str: Expression, start: Expression) extends TernaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function that returns the position of the first occurrence of substr in given string after position pos.

  256. trait StringPredicate extends Expression with Predicate with ImplicitCastInputTypes

    A base trait for functions that compare two strings, returning a boolean.

  257. case class StringRPad(str: Expression, len: Expression, pad: Expression) extends TernaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns str, right-padded with pad to a length of len.

  258. trait StringRegexExpression extends Expression with ImplicitCastInputTypes

  259. case class StringRepeat(str: Expression, times: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns the string which repeat the given string value n times.

  260. case class StringReverse(child: Expression) extends UnaryExpression with String2StringExpression with Product with Serializable

    Returns the reversed given string.

  261. case class StringSpace(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns a string consisting of n spaces.

  262. case class StringSplit(str: Expression, pattern: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Splits str around pat (pattern is a regular expression).

  263. case class StringToMap(text: Expression, pairDelim: Expression, keyValueDelim: Expression) extends TernaryExpression with CodegenFallback with ExpectsInputTypes with Product with Serializable

    Creates a map after splitting the input text into key/value pairs using delimiters

  264. case class StringTranslate(srcExpr: Expression, matchingExpr: Expression, replaceExpr: Expression) extends TernaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function translate any character in the srcExpr by a character in replaceExpr.

  265. case class StringTrim(child: Expression) extends UnaryExpression with String2StringExpression with Product with Serializable

    A function that trim the spaces from both ends for the specified string.

  266. case class StringTrimLeft(child: Expression) extends UnaryExpression with String2StringExpression with Product with Serializable

    A function that trim the spaces from left end for given string.

  267. case class StringTrimRight(child: Expression) extends UnaryExpression with String2StringExpression with Product with Serializable

    A function that trim the spaces from right end for given string.

  268. case class StructToJson(options: Map[String, String], child: Expression) extends UnaryExpression with CodegenFallback with ExpectsInputTypes with Product with Serializable

    Converts a StructType to a json output string.

  269. abstract class SubqueryExpression extends PlanExpression[LogicalPlan]

    A base interface for expressions that contain a LogicalPlan.

  270. case class Substring(str: Expression, pos: Expression, len: Expression) extends TernaryExpression with ImplicitCastInputTypes with Product with Serializable

    A function that takes a substring of its first argument starting at a given position.

  271. case class SubstringIndex(strExpr: Expression, delimExpr: Expression, countExpr: Expression) extends TernaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns the substring from string str before count occurrences of the delimiter delim.

  272. case class Subtract(left: Expression, right: Expression) extends BinaryArithmetic with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  273. case class Tan(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  274. case class Tanh(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  275. abstract class TernaryExpression extends Expression

    An expression with three inputs and one output.

  276. case class TimeAdd(start: Expression, interval: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Adds an interval to timestamp.

  277. case class TimeSub(start: Expression, interval: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Subtracts an interval from timestamp.

  278. case class TimeWindow(timeColumn: Expression, windowDuration: Long, slideDuration: Long, startTime: Long) extends UnaryExpression with ImplicitCastInputTypes with Unevaluable with NonSQLExpression with Product with Serializable

  279. case class ToDate(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns the date part of a timestamp or string.

  280. case class ToDegrees(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  281. case class ToRadians(child: Expression) extends UnaryMathExpression with Product with Serializable

    Annotations
    @ExpressionDescription()
  282. case class ToUTCTimestamp(left: Expression, right: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Given a timestamp, which corresponds to a certain time of day in the given timezone, returns another timestamp that corresponds to the same time of day in UTC.

  283. case class ToUnixTimestamp(timeExp: Expression, format: Expression) extends UnixTime with Product with Serializable

    Converts time string with given pattern.

  284. case class TruncDate(date: Expression, format: Expression) extends BinaryExpression with ImplicitCastInputTypes with Product with Serializable

    Returns date truncated to the unit specified by the format.

  285. case class UnBase64(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Converts the argument from a base 64 string to BINARY.

  286. abstract class UnaryExpression extends Expression

    An expression with one input and one output.

  287. abstract class UnaryLogExpression extends UnaryMathExpression

  288. abstract class UnaryMathExpression extends UnaryExpression with Serializable with ImplicitCastInputTypes

    A unary expression specifically for math functions.

  289. case class UnaryMinus(child: Expression) extends UnaryExpression with ExpectsInputTypes with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  290. case class UnaryPositive(child: Expression) extends UnaryExpression with ExpectsInputTypes with NullIntolerant with Product with Serializable

    Annotations
    @ExpressionDescription()
  291. trait Unevaluable extends Expression

    An expression that cannot be evaluated.

  292. case class Unhex(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Performs the inverse operation of HEX.

  293. abstract class UnixTime extends BinaryExpression with ExpectsInputTypes

  294. case class UnixTimestamp(timeExp: Expression, format: Expression) extends UnixTime with Product with Serializable

    Converts time string with given pattern.

  295. case class UnresolvedWindowExpression(child: Expression, windowSpec: WindowSpecReference) extends UnaryExpression with Unevaluable with Product with Serializable

  296. final class UnsafeArrayData extends ArrayData

  297. final class UnsafeMapData extends MapData

  298. abstract class UnsafeProjection extends Projection

    A projection that returns UnsafeRow.

  299. final class UnsafeRow extends InternalRow with Externalizable with KryoSerializable

  300. case class UnscaledValue(child: Expression) extends UnaryExpression with Product with Serializable

    Return the unscaled Long value of a Decimal, assuming it fits in a Long.

  301. case class UpCast(child: Expression, dataType: DataType, walkedTypePath: Seq[String]) extends UnaryExpression with Unevaluable with Product with Serializable

    Cast the child expression to the target data type, but will throw error if the cast might truncate, e.

  302. case class Upper(child: Expression) extends UnaryExpression with String2StringExpression with Product with Serializable

    A function that converts the characters of a string to uppercase.

  303. case class UserDefinedGenerator(elementSchema: StructType, function: (Row) ⇒ TraversableOnce[InternalRow], children: Seq[Expression]) extends Expression with Generator with CodegenFallback with Product with Serializable

    A generator that produces its output using the provided lambda function.

  304. case class ValueFollowing(value: Int) extends FrameBoundary with Product with Serializable

    <value> FOLLOWING boundary.

  305. case class ValuePreceding(value: Int) extends FrameBoundary with Product with Serializable

    <value> PRECEDING boundary.

  306. final class VariableLengthRowBasedKeyValueBatch extends RowBasedKeyValueBatch

  307. case class WeekOfYear(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()
  308. case class WindowExpression(windowFunction: Expression, windowSpec: WindowSpecDefinition) extends Expression with Unevaluable with Product with Serializable

  309. sealed trait WindowFrame extends AnyRef

    The trait used to represent the a Window Frame.

  310. trait WindowFunction extends Expression

    A window function is a function that can only be evaluated in the context of a window operator.

  311. sealed trait WindowSpec extends AnyRef

    The trait of the Window Specification (specified in the OVER clause or WINDOW clause) for Window Functions.

  312. case class WindowSpecDefinition(partitionSpec: Seq[Expression], orderSpec: Seq[SortOrder], frameSpecification: WindowFrame) extends Expression with WindowSpec with Unevaluable with Product with Serializable

    The specification for a window function.

  313. case class WindowSpecReference(name: String) extends WindowSpec with Product with Serializable

    A Window specification reference that refers to the WindowSpecDefinition defined under the name name.

  314. final class XXH64 extends AnyRef

  315. case class XxHash64(children: Seq[Expression], seed: Long) extends HashExpression[Long] with Product with Serializable

    A xxHash64 64-bit hash expression.

  316. case class Year(child: Expression) extends UnaryExpression with ImplicitCastInputTypes with Product with Serializable

    Annotations
    @ExpressionDescription()

Value Members

  1. object Ascending extends SortDirection with Product with Serializable

  2. object AttributeMap extends Serializable

    Builds a map that is keyed by an Attribute's expression id.

  3. object AttributeSet extends Serializable

  4. object BinaryArithmetic

  5. object BinaryComparison

  6. object BinaryOperator

  7. object BindReferences extends Logging

  8. object CallMethodViaReflection extends Serializable

  9. object Canonicalize

    Rewrites an expression using rules that are guaranteed preserve the result while attempting to remove cosmetic variations.

  10. object CaseKeyWhen

    Case statements of the form "CASE a WHEN b THEN c [WHEN d THEN e]* [ELSE f] END".

  11. object CaseWhen extends Serializable

    Factory methods for CaseWhen.

  12. object Cast extends Serializable

  13. object CreateStruct extends (Seq[Expression]) ⇒ Expression

    Returns a Row containing the evaluation of all children expressions.

  14. object CurrentRow extends FrameBoundary with Product with Serializable

    CURRENT ROW boundary.

  15. object DecimalLiteral

    Extractor for and other utility methods for decimal literals.

  16. object Descending extends SortDirection with Product with Serializable

  17. val EmptyRow: InternalRow

    Used as input into expressions whose output does not depend on any input value.

  18. object Equality

    An extractor that matches both standard 3VL equality and null-safe equality.

  19. object ExprId extends Serializable

  20. object ExpressionSet

  21. object ExtractValue

  22. object Factorial extends Serializable

  23. object FrameBoundary

    Extractor for making working with frame boundaries easier.

  24. object FromUnsafeProjection

    A projection that could turn UnsafeRow into GenericInternalRow

  25. object Hex extends Serializable

  26. object HiveHashFunction extends InterpretedHashFunction

  27. object IntegerLiteral

    Extractor for retrieving Int literals.

  28. object InterpretedOrdering extends Serializable

  29. object InterpretedPredicate

  30. object Literal extends Serializable

  31. object Murmur3HashFunction extends InterpretedHashFunction

  32. object NamePlaceholder extends LeafExpression with Unevaluable with Product with Serializable

    An expression representing a not yet available attribute name.

  33. object NamedExpression

  34. object NonNullLiteral

    An extractor that matches non-null literal values

  35. object NullsFirst extends NullOrdering with Product with Serializable

  36. object NullsLast extends NullOrdering with Product with Serializable

  37. object ParseUrl extends Serializable

  38. object PredicateSubquery extends Serializable

  39. object Rand extends Serializable

  40. object Randn extends Serializable

  41. object RangeFrame extends FrameType with Product with Serializable

    RangeFrame treats rows in a partition as groups of peers.

  42. object RowFrame extends FrameType with Product with Serializable

    RowFrame treats rows in a partition individually.

  43. object RowOrdering

  44. object ScalarSubquery extends Serializable

  45. object SizeBasedWindowFunction extends Serializable

  46. object SortOrder extends Serializable

  47. object SpecifiedWindowFrame extends Serializable

  48. object StringTranslate extends Serializable

  49. object SubqueryExpression

  50. object TimeWindow extends Serializable

  51. object UnboundedFollowing extends FrameBoundary with Product with Serializable

    UNBOUNDED FOLLOWING boundary.

  52. object UnboundedPreceding extends FrameBoundary with Product with Serializable

    UNBOUNDED PRECEDING boundary.

  53. object UnsafeProjection

  54. object UnspecifiedFrame extends WindowFrame with Product with Serializable

    Used as a place holder when a frame specification is not defined.

  55. object VirtualColumn

  56. object XxHash64Function extends InterpretedHashFunction

  57. package aggregate

  58. package codegen

    A collection of generators that build custom bytecode at runtime for performing the evaluation of catalyst expression.

  59. package objects

  60. package xml

Inherited from AnyRef

Inherited from Any

Ungrouped