package expressions
- Alphabetic
- Public
- All
Type Members
- trait DataFrameAPI extends AnyRef
-
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.
- case class GeometryType(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
- 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
- class InferrableType[T] extends AnyRef
-
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.
- case class ST_3DDistance(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_AddPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_Affine(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_Angle(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
-
case class
ST_Area(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the area measurement of a Geometry.
- case class ST_AreaSpheroid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_AsBinary(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_AsEWKB(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_AsEWKT(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Returns the geometry in EWKT format
- case class ST_AsGML(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_AsGeoJSON(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_AsKML(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_AsText(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_Azimuth(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_Boundary(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_BoundingDiagonal(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
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.
-
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
-
case class
ST_Centroid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return mathematical centroid of a geometry.
- case class ST_ClosestPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_CollectionExtract(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_ConcaveHull(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the concave hull of a Geometry.
-
case class
ST_Contains(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry full contains rightGeometry
-
case class
ST_ConvexHull(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the convex hull of a Geometry.
-
case class
ST_CoordDim(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the number of ddimensions in geometry.
-
case class
ST_CoveredBy(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry is covered by rightGeometry
-
case class
ST_Covers(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry covers rightGeometry
-
case class
ST_Crosses(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry crosses rightGeometry
- case class ST_DWithin(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_Degrees(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
-
case class
ST_Difference(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the difference between geometry A and B
- case class ST_Dimension(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
-
case class
ST_Disjoint(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry is disjoint from rightGeometry
-
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.
- case class ST_DistanceSphere(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_DistanceSpheroid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_Dump(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_DumpPoints(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_EndPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_Envelope(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the bounding rectangle for a Geometry
-
class
ST_Envelope_Aggr extends expressions.Aggregator[Geometry, Geometry, Geometry] with TraitSTAggregateExec
Return the envelope boundary of the entire column
-
case class
ST_Equals(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry is equal to rightGeometry
- case class ST_ExteriorRing(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
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
- case class ST_Force3D(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_Force_2D(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_FrechetDistance(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
- case class ST_GeoHash(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
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.
- case class ST_GeomFromGML(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_GeomFromGeoHash(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_GeomFromGeoJSON(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with CodegenFallback with UserDataGeneratator 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.
- case class ST_GeomFromKML(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
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.
-
case class
ST_GeomFromWKB(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with ImplicitCastInputTypes with CodegenFallback with UserDataGeneratator 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.
-
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.
-
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
- case class ST_GeometryN(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_GeometryType(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_H3CellDistance(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_H3CellIDs(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_H3KRing(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_H3ToGeom(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
- case class ST_HausdorffDistance(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_InteriorRingN(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
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
-
class
ST_Intersection_Aggr extends expressions.Aggregator[Geometry, Geometry, Geometry] with TraitSTAggregateExec
Return the polygon intersection of all Polygon in the given column
-
case class
ST_Intersects(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry full intersects rightGeometry
- case class ST_IsClosed(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_IsCollection(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Returns True if geometry is a collection of geometries
-
case class
ST_IsEmpty(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Test if Geometry is empty geometry.
- case class ST_IsRing(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_IsSimple(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Test if Geometry is simple.
-
case class
ST_IsValid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Test if Geometry is valid.
-
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.
-
case class
ST_Length(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the length measurement of a Geometry
- case class ST_LengthSpheroid(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_LineFromMultiPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Returns the LineString geometry given a MultiPoint geometry
-
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.
-
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.
-
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.
-
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
-
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.
-
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.
-
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.
-
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.
- case class ST_MakeLine(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_MakePoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_MakePolygon(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
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
- case class ST_MinimumBoundingCircle(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_MinimumBoundingRadius(inputExpressions: Seq[Expression]) extends Expression with FoldableExpression with CodegenFallback with Product with Serializable
- case class ST_Multi(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_NDims(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the number of Dimensions in geometry.
-
case class
ST_NPoints(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the number of Points in geometry.
- case class ST_NRings(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_Normalize(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Returns the input geometry in its normalized form.
-
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
- case class ST_NumInteriorRings(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_NumPoints(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_OrderingEquals(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry is order equal to rightGeometry
-
case class
ST_Overlaps(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry overlaps rightGeometry
-
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.
-
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
-
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'
-
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
-
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).
- case class ST_Polygon(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_PolygonFromEnvelope(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return a polygon given minX,minY,maxX,maxY
-
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.
- abstract class ST_Predicate extends Expression with FoldableExpression with ExpectsInputTypes with NullIntolerant
-
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.
- case class ST_RemovePoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_Reverse(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Returns the geometry with vertex order reversed
- case class ST_S2CellIDs(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_SRID(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_SetPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_SetSRID(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
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)
-
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
- case class ST_StartPoint(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_SubDivide(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_SubDivideExplode(children: Seq[Expression]) extends Expression with Generator with CodegenFallback with Product with Serializable
-
case class
ST_SymDifference(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the symmetrical difference between geometry A and B
-
case class
ST_Touches(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry touches rightGeometry
-
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.
- case class ST_Translate(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
-
case class
ST_Union(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Return the union of geometry A and B
-
class
ST_Union_Aggr extends expressions.Aggregator[Geometry, Geometry, Geometry] with TraitSTAggregateExec
Return the polygon union of all Polygon in the given column
- case class ST_VoronoiPolygons(inputExpressions: Seq[Expression]) extends InferredExpression with FoldableExpression with Product with Serializable
-
case class
ST_Within(inputExpressions: Seq[Expression]) extends ST_Predicate with CodegenFallback with Product with Serializable
Test if leftGeometry is full within rightGeometry
- case class ST_X(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
case class
ST_XMax(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Test if returning Max X coordinate value.
-
case class
ST_XMin(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
Test if returning Min X coordinate value.
- case class ST_Y(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_YMax(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_YMin(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
- case class ST_Z(inputExpressions: Seq[Expression]) extends InferredExpression with Product with Serializable
-
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.
-
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.
- trait SerdeAware extends AnyRef
-
trait
TraitSTAggregateExec extends AnyRef
traits for creating Aggregate Function
- trait UserDataGeneratator extends AnyRef
Value Members
- object InferrableFunction extends Serializable
-
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.
- object InferrableRasterTypes
- object InferrableType
- object InferredRasterExpression
- object InferredTypes
- object ST_IsRing extends Serializable
- object implicits
- object st_aggregates extends DataFrameAPI
- object st_constructors extends DataFrameAPI
- object st_functions extends DataFrameAPI
- object st_predicates extends DataFrameAPI