Packages

package expressions

Ordering
  1. Alphabetic
Visibility
  1. Public
  2. All

Type Members

  1. trait DataFrameAPI extends AnyRef
  2. trait DataframePhysicalFunction extends Expression with PhysicalFunction

    DataframePhysicalFunctions are Functions that will be replaced with a Physical Node for their evaluation.

    DataframePhysicalFunctions are Functions that will be replaced with a Physical Node for their evaluation.

    The physical node will transform the input dataframe into the output dataframe. execute handles conversion of the RDD[InternalRow] to a DataFrame and back. Each DataframePhysicalFunction should implement transformDataframe. The output dataframe should have the same schema as the input dataframe, except for the resultAttrs which should be added to the output dataframe.

  3. trait FoldableExpression extends Expression

    Make expression foldable by constant folding optimizer.

    Make expression foldable by constant folding optimizer. If all children expressions are foldable, then the expression itself is foldable.

  4. case class GeometryType(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  5. case class InferrableFunction(sparkInputTypes: Seq[AbstractDataType], sparkReturnType: DataType, serializer: (Any) ⇒ Any, argExtractorBuilders: Seq[(Expression) ⇒ (InternalRow) ⇒ Any], evaluatorBuilder: (Array[(InternalRow) ⇒ Any]) ⇒ (InternalRow) ⇒ Any) extends Product with Serializable
  6. class InferrableType[T] extends AnyRef
  7. abstract class InferredExpression extends Expression with ImplicitCastInputTypes with SerdeAware with CodegenFallback with FoldableExpression with Serializable

    This is the base class for wrapping Java/Scala functions as a catalyst expression in Spark SQL.

  8. class InferredExpressionException extends Exception

    Custom exception to include the input row and the original exception message.

  9. trait PhysicalFunction extends Expression with ImplicitCastInputTypes with Unevaluable with Serializable

    PhysicalFunctions are Functions that will be replaced with a Physical Node for their evaluation.

    PhysicalFunctions are Functions that will be replaced with a Physical Node for their evaluation.

    execute is the method that will be called in order to evaluate the function. PhysicalFunction is marked non-deterministic to avoid the filter push-down optimization pass which duplicates the PhysicalFunction when pushing down aliased PhysicalFunction calls through a Project operator. Otherwise the PhysicalFunction would be evaluated twice.

  10. case class ST_3DDistance(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  11. case class ST_AddMeasure(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  12. case class ST_AddPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  13. case class ST_Affine(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  14. case class ST_Angle(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  15. case class ST_Area(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the area measurement of a Geometry.

  16. case class ST_AreaSpheroid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  17. case class ST_AsBinary(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  18. case class ST_AsEWKB(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  19. case class ST_AsEWKT(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns the geometry in EWKT format

  20. case class ST_AsGML(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  21. case class ST_AsGeoJSON(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  22. case class ST_AsHEXEWKB(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  23. case class ST_AsKML(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  24. case class ST_AsText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  25. case class ST_Azimuth(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  26. case class ST_BestSRID(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  27. case class ST_BinaryDistanceBandColumn(children: Seq[Expression]) extends Expression with DataframePhysicalFunction with Product with Serializable
  28. case class ST_Boundary(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  29. case class ST_BoundingDiagonal(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  30. case class ST_Buffer(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns a geometry/geography that represents all points whose distance from this Geometry/geography is less than or equal to distance.

  31. case class ST_BuildArea(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns the areal geometry formed by the constituent linework of the input geometry assuming all inner geometries represent holes

  32. case class ST_Centroid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return mathematical centroid of a geometry.

  33. case class ST_ClosestPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  34. case class ST_CollectionExtract(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  35. case class ST_ConcaveHull(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the concave hull of a Geometry.

  36. case class ST_Contains(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry full contains rightGeometry

  37. case class ST_ConvexHull(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the convex hull of a Geometry.

  38. case class ST_CoordDim(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the number of dimensions in geometry.

  39. case class ST_CoveredBy(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry is covered by rightGeometry

  40. case class ST_Covers(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry covers rightGeometry

  41. case class ST_Crosses(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry crosses rightGeometry

  42. case class ST_CrossesDateLine(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  43. case class ST_DBSCAN(children: Seq[Expression]) extends Expression with DataframePhysicalFunction with Product with Serializable
  44. case class ST_DWithin(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  45. case class ST_Degrees(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  46. case class ST_DelaunayTriangles(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  47. case class ST_Difference(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the difference between geometry A and B

  48. case class ST_Dimension(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  49. case class ST_Disjoint(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry is disjoint from rightGeometry

  50. case class ST_Distance(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the distance between two geometries.

    Return the distance between two geometries.

    inputExpressions

    This function takes two geometries and calculates the distance between two objects.

  51. case class ST_DistanceSphere(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  52. case class ST_DistanceSpheroid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  53. case class ST_Dump(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  54. case class ST_DumpPoints(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  55. case class ST_EndPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  56. case class ST_Envelope(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the bounding rectangle for a Geometry

  57. class ST_Envelope_Aggr extends expressions.Aggregator[Geometry, Geometry, Geometry] with TraitSTAggregateExec

    Return the envelope boundary of the entire column

  58. case class ST_Equals(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry is equal to rightGeometry

  59. case class ST_Expand(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  60. case class ST_ExteriorRing(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  61. case class ST_FlipCoordinates(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns a version of the given geometry with X and Y axis flipped.

    Returns a version of the given geometry with X and Y axis flipped.

    inputExpressions

    Geometry

  62. case class ST_Force3D(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  63. case class ST_Force3DM(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  64. case class ST_Force3DZ(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  65. case class ST_Force4D(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  66. case class ST_ForceCollection(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  67. case class ST_ForcePolygonCCW(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  68. case class ST_ForcePolygonCW(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  69. case class ST_ForceRHR(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  70. case class ST_Force_2D(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  71. case class ST_FrechetDistance(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  72. case class ST_GLocal(children: Seq[Expression]) extends Expression with DataframePhysicalFunction with Product with Serializable
  73. case class ST_GeneratePoints(inputExpressions: Seq[Expression], randomSeed: Long) extends Expression with CodegenFallback with ExpectsInputTypes with Nondeterministic with Product with Serializable
  74. case class ST_GeoHash(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  75. case class ST_GeogFromWKT(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Geography from a WKT string

    Return a Geography from a WKT string

    inputExpressions

    This function takes a geometry string and a srid. The string format must be WKT.

  76. case class ST_GeomCollFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  77. case class ST_GeomFromEWKB(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with ImplicitCastInputTypes with CodegenFallback with UserDataGenerator with Product with Serializable
  78. case class ST_GeomFromEWKT(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Geometry from a OGC Extended WKT string

    Return a Geometry from a OGC Extended WKT string

    inputExpressions

    This function takes a geometry string. The string format must be OGC Extended Well-Known text (EWKT) representation.

  79. case class ST_GeomFromGML(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  80. case class ST_GeomFromGeoHash(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  81. case class ST_GeomFromGeoJSON(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with CodegenFallback with UserDataGenerator with Product with Serializable

    Return a Geometry from a GeoJSON string

    Return a Geometry from a GeoJSON string

    inputExpressions

    This function takes 1 parameter which is the geometry string. The string format must be GeoJson.

  82. case class ST_GeomFromKML(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  83. case class ST_GeomFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Geometry from a WKT string

    Return a Geometry from a WKT string

    inputExpressions

    This function takes a geometry string and a srid. The string format must be WKT.

  84. case class ST_GeomFromWKB(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with ImplicitCastInputTypes with CodegenFallback with UserDataGenerator with Product with Serializable

    Return a Geometry from a WKB string

    Return a Geometry from a WKB string

    inputExpressions

    This function takes 1 parameter which is the utf-8 encoded geometry wkb string or the binary wkb array.

  85. case class ST_GeomFromWKT(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Geometry from a WKT string

    Return a Geometry from a WKT string

    inputExpressions

    This function takes a geometry string and a srid. The string format must be WKT.

  86. case class ST_GeometricMedian(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable

    Returns a POINT Computes the approximate geometric median of a MultiPoint geometry using the Weiszfeld algorithm.

    Returns a POINT Computes the approximate geometric median of a MultiPoint geometry using the Weiszfeld algorithm. The geometric median provides a centrality measure that is less sensitive to outlier points than the centroid.

    inputExpressions

    Geometry

  87. case class ST_GeometryFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Geometry from a WKT string.

    Return a Geometry from a WKT string. Alias to ST_GeomFromWKT

    inputExpressions

    This function takes a geometry string and a srid. The string format must be WKT.

  88. case class ST_GeometryN(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  89. case class ST_GeometryType(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  90. case class ST_H3CellDistance(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  91. case class ST_H3CellIDs(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  92. case class ST_H3KRing(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  93. case class ST_H3ToGeom(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  94. case class ST_HasM(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  95. case class ST_HasZ(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  96. case class ST_HausdorffDistance(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  97. case class ST_InteriorRingN(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  98. case class ST_InterpolatePoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  99. case class ST_Intersection(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the intersection shape of two geometries.

    Return the intersection shape of two geometries. The return type is a geometry

  100. class ST_Intersection_Aggr extends expressions.Aggregator[Geometry, Geometry, Geometry] with TraitSTAggregateExec

    Return the polygon intersection of all Polygon in the given column

  101. case class ST_Intersects(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry full intersects rightGeometry

  102. case class ST_IsClosed(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  103. case class ST_IsCollection(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns True if geometry is a collection of geometries

  104. case class ST_IsEmpty(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Test if Geometry is empty geometry.

  105. case class ST_IsPolygonCCW(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  106. case class ST_IsPolygonCW(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  107. case class ST_IsRing(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  108. case class ST_IsSimple(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Test if Geometry is simple.

  109. case class ST_IsValid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Test if Geometry is valid.

  110. case class ST_IsValidDetail(children: Seq[Expression]) extends Expression with ExpectsInputTypes with CodegenFallback with Product with Serializable
  111. case class ST_IsValidReason(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns a text description of the validity of the geometry considering the specified flags.

    Returns a text description of the validity of the geometry considering the specified flags. If flag not specified, it defaults to OGC SFS validity semantics.

    returns

    A string describing the validity of the geometry.

  112. case class ST_IsValidTrajectory(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  113. case class ST_KNN(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Test if leftGeometry is one of the k nearest neighbors (KNN) of rightGeometry based on approximate distance metric.

  114. case class ST_LabelPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  115. case class ST_Length(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the length measurement of a Geometry

  116. case class ST_Length2D(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the length measurement of a Geometry

  117. case class ST_LengthSpheroid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  118. case class ST_LineFromMultiPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns the LineString geometry given a MultiPoint geometry

  119. case class ST_LineFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a line from a string.

    Return a line from a string. The string must be plain string and each coordinate must be separated by a delimiter.

  120. case class ST_LineFromWKB(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with ImplicitCastInputTypes with CodegenFallback with UserDataGenerator with Product with Serializable
  121. case class ST_LineInterpolatePoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns a point interpolated along a line.

    Returns a point interpolated along a line. First argument must be a LINESTRING. Second argument is a Double between 0 and 1 representing fraction of total linestring length the point has to be located.

  122. case class ST_LineLocatePoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns a float between 0 and 1 representing the location of the closest point on a LineString to the given Point, as a fraction of 2d line length.

  123. case class ST_LineMerge(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns a LineString formed by sewing together the constituent line work of a MULTILINESTRING.

    Returns a LineString formed by sewing together the constituent line work of a MULTILINESTRING. Only works for MultiLineString. Using other geometry will return GEOMETRYCOLLECTION EMPTY If the MultiLineString is can't be merged, the original multilinestring is returned

    inputExpressions

    Geometry

  124. case class ST_LineSegments(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  125. case class ST_LineStringFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a linestring from a string.

    Return a linestring from a string. The string must be plain string and each coordinate must be separated by a delimiter.

  126. case class ST_LineSubstring(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a linestring being a substring of the input one starting and ending at the given fractions of total 2d length.

    Return a linestring being a substring of the input one starting and ending at the given fractions of total 2d length. Second and third arguments are Double values between 0 and 1. This only works with LINESTRINGs.

  127. case class ST_LinestringFromWKB(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with ImplicitCastInputTypes with CodegenFallback with UserDataGenerator with Product with Serializable
  128. case class ST_LocalOutlierFactor(children: Seq[Expression]) extends Expression with DataframePhysicalFunction with Product with Serializable
  129. case class ST_LocateAlong(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  130. case class ST_LongestLine(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  131. case class ST_M(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  132. case class ST_MLineFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Geometry from a WKT string

    Return a Geometry from a WKT string

    inputExpressions

    This function takes a geometry string and a srid. The string format must be WKT.

  133. case class ST_MMax(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  134. case class ST_MMin(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  135. case class ST_MPointFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  136. case class ST_MPolyFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Geometry from a WKT string

    Return a Geometry from a WKT string

    inputExpressions

    This function takes a geometry string and a srid. The string format must be WKT.

  137. case class ST_MakeEnvelope(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a polygon given minX,minY,maxX,maxY and optional SRID

  138. case class ST_MakeLine(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  139. case class ST_MakePoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  140. case class ST_MakePointM(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  141. case class ST_MakePolygon(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  142. case class ST_MakeValid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Given an invalid geometry, create a valid representation of the geometry.

    Given an invalid geometry, create a valid representation of the geometry. See: http://lin-ear-th-inking.blogspot.com/2021/05/fixing-invalid-geometry-with-jts.html

  143. case class ST_MaxDistance(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  144. case class ST_MaximumInscribedCircle(children: Seq[Expression]) extends Expression with CodegenFallback with Product with Serializable
  145. case class ST_MinimumBoundingCircle(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  146. case class ST_MinimumBoundingRadius(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with CodegenFallback with Product with Serializable
  147. case class ST_MinimumClearance(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  148. case class ST_MinimumClearanceLine(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  149. case class ST_Multi(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  150. case class ST_NDims(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the number of Dimensions in geometry.

  151. case class ST_NPoints(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the number of Points in geometry.

  152. case class ST_NRings(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  153. case class ST_Normalize(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns the input geometry in its normalized form.

  154. case class ST_NumGeometries(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns the number of Geometries.

    Returns the number of Geometries. If geometry is a GEOMETRYCOLLECTION (or MULTI*) return the number of geometries, for single geometries will return 1

    This method implements the SQL/MM specification. SQL-MM 3: 9.1.4

    inputExpressions

    Geometry

  155. case class ST_NumInteriorRing(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  156. case class ST_NumInteriorRings(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  157. case class ST_NumPoints(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  158. case class ST_OrderingEquals(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry is order equal to rightGeometry

  159. case class ST_Overlaps(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry overlaps rightGeometry

  160. case class ST_Perimeter(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  161. case class ST_Perimeter2D(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  162. case class ST_Point(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Point from X and Y

    Return a Point from X and Y

    inputExpressions

    This function takes 2 parameter which are point x, y.

  163. case class ST_PointFromGeoHash(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  164. case class ST_PointFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a point from a string.

    Return a point from a string. The string must be plain string and each coordinate must be separated by a delimiter.

    inputExpressions

    This function takes 2 parameters. The first parameter is the input geometry string, the second parameter is the delimiter. String format should be similar to CSV/TSV

  165. case class ST_PointFromWKB(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with ImplicitCastInputTypes with CodegenFallback with UserDataGenerator with Product with Serializable
  166. case class ST_PointM(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Point from X, Y, M and srid

    Return a Point from X, Y, M and srid

    inputExpressions

    This function takes 4 parameter which are point x, y, m and srid (default 0).

  167. case class ST_PointN(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns the nth point in the geometry, provided it is a linestring

    Returns the nth point in the geometry, provided it is a linestring

    inputExpressions

    sequence of 2 input arguments, a geometry and a value 'n'

  168. case class ST_PointOnSurface(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns a POINT guaranteed to lie on the surface.

    Returns a POINT guaranteed to lie on the surface.

    inputExpressions

    Geometry

  169. case class ST_PointZ(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a Point from X, Y, Z and srid

    Return a Point from X, Y, Z and srid

    inputExpressions

    This function takes 4 parameter which are point x, y, z and srid (default 0).

  170. case class ST_PointZM(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  171. case class ST_Points(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  172. case class ST_Polygon(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  173. case class ST_PolygonFromEnvelope(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a polygon given minX,minY,maxX,maxY

  174. case class ST_PolygonFromText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return a polygon from a string.

    Return a polygon from a string. The string must be plain string and each coordinate must be separated by a delimiter.

  175. case class ST_Polygonize(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  176. abstract class ST_Predicate extends Expression with FoldableExpression with ExpectsInputTypes with NullIntolerant
  177. case class ST_Project(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  178. case class ST_ReducePrecision(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Reduce the precision of the given geometry to the given number of decimal places

    Reduce the precision of the given geometry to the given number of decimal places

    inputExpressions

    The first arg is a geom and the second arg is an integer scale, specifying the number of decimal places of the new coordinate. The last decimal place will be rounded to the nearest number.

  179. case class ST_Relate(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  180. case class ST_RelateMatch(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  181. case class ST_RemovePoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  182. case class ST_RemoveRepeatedPoints(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  183. case class ST_Reverse(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns the geometry with vertex order reversed

  184. case class ST_Rotate(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  185. case class ST_RotateX(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  186. case class ST_RotateY(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  187. case class ST_S2CellIDs(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  188. case class ST_S2ToGeom(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  189. case class ST_SRID(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  190. case class ST_Scale(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  191. case class ST_ScaleGeom(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  192. case class ST_SetPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  193. case class ST_SetSRID(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  194. case class ST_ShiftLongitude(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  195. case class ST_Simplify(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  196. case class ST_SimplifyPolygonHull(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  197. case class ST_SimplifyPreserveTopology(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Simplifies a geometry and ensures that the result is a valid geometry having the same dimension and number of components as the input, and with the components having the same topological relationship.

    Simplifies a geometry and ensures that the result is a valid geometry having the same dimension and number of components as the input, and with the components having the same topological relationship. The simplification uses a maximum-distance difference algorithm similar to the Douglas-Peucker algorithm.

    inputExpressions

    first arg is geometry second arg is distance tolerance for the simplification(all vertices in the simplified geometry will be within this distance of the original geometry)

  198. case class ST_SimplifyVW(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  199. case class ST_Snap(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  200. case class ST_Split(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Returns a multi-geometry that is the result of splitting the input geometry by the blade geometry

  201. case class ST_StartPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  202. case class ST_SubDivide(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  203. case class ST_SubDivideExplode(children: Seq[Expression]) extends Expression with Generator with CodegenFallback with Product with Serializable
  204. case class ST_SymDifference(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the symmetrical difference between geometry A and B

  205. case class ST_Touches(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry touches rightGeometry

  206. case class ST_Transform(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Given a geometry, sourceEPSGcode, and targetEPSGcode, convert the geometry's Spatial Reference System / Coordinate Reference System.

  207. case class ST_Translate(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  208. case class ST_TriangulatePolygon(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  209. case class ST_UnaryUnion(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  210. case class ST_Union(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the union of geometry A and B

  211. class ST_Union_Aggr extends expressions.Aggregator[Geometry, ListBuffer[Geometry], Geometry]
  212. case class ST_VoronoiPolygons(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
  213. case class ST_WeightedDistanceBandColumn(children: Seq[Expression]) extends Expression with DataframePhysicalFunction with Product with Serializable
  214. case class ST_Within(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable

    Test if leftGeometry is full within rightGeometry

  215. case class ST_X(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  216. case class ST_XMax(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Test if returning Max X coordinate value.

  217. case class ST_XMin(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Test if returning Min X coordinate value.

  218. case class ST_Y(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  219. case class ST_YMax(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  220. case class ST_YMin(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  221. case class ST_Z(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  222. case class ST_ZMax(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the Z maxima of the geometry.

    Return the Z maxima of the geometry.

    inputExpressions

    This function takes a geometry and returns the maximum of all Z-coordinate values.

  223. case class ST_ZMin(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable

    Return the Z minima of the geometry.

    Return the Z minima of the geometry.

    inputExpressions

    This function takes a geometry and returns the minimum of all Z-coordinate values.

  224. case class ST_Zmflag(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
  225. trait SerdeAware extends AnyRef
  226. trait TraitSTAggregateExec extends AnyRef

    traits for creating Aggregate Function

  227. trait UserDataGenerator extends AnyRef

Value Members

  1. object FunctionResolver

    A utility object for resolving functions based on input argument types.

    A utility object for resolving functions based on input argument types. See FunctionResolver.resolveFunction for details.

  2. object InferrableFunction extends Serializable
  3. object InferrableFunctionConverter

    Implicit conversions from Java/Scala functions to InferrableFunction.

    Implicit conversions from Java/Scala functions to InferrableFunction. This should be used in conjunction with InferredExpression to make wrapping Java/Scala functions as catalyst expressions much easier.

  4. object InferrableRasterTypes
  5. object InferrableType
  6. object InferredExpression extends Serializable
  7. object InferredRasterExpression
  8. object InferredTypes
  9. object ST_IsRing extends Serializable
  10. object implicits
  11. object st_aggregates extends DataFrameAPI
  12. object st_constructors extends DataFrameAPI
  13. object st_functions extends DataFrameAPI
  14. object st_predicates extends DataFrameAPI

Ungrouped