Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y 

A

add(Envelope, Geometry) - Static method in class org.apache.sedona.core.spatialRddTool.StatCalculator
 
add(StatCalculator, Geometry) - Static method in class org.apache.sedona.core.spatialRddTool.StatCalculator
 
addGeometry(Geometry, List<T>) - Method in class org.apache.sedona.core.formatMapper.FormatUtils
 
addMultiGeometry(GeometryCollection, List<T>) - Method in class org.apache.sedona.core.formatMapper.FormatUtils
 
analyze(StorageLevel) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Analyze.
analyze() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Analyze.
analyze(Envelope, Integer) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
 
approximateTotalCount - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
The total number of records.
assignLeafIds() - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
assignPartitionIds() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
assignPartitionLineage() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 

B

boundary() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Deprecated.
Call analyze() instead
boundaryEnvelope - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
The boundary envelope.
BoundaryInputFormat - Class in org.apache.sedona.core.formatMapper.shapefileParser.boundary
 
BoundaryInputFormat() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryInputFormat
 
BoundaryRecordReader - Class in org.apache.sedona.core.formatMapper.shapefileParser.boundary
 
BoundaryRecordReader() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryRecordReader
 
BoundBox - Class in org.apache.sedona.core.formatMapper.shapefileParser.boundary
Created by zongsizhang on 7/6/17.
BoundBox(double[]) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
construct bounds with an array
BoundBox(BoundBox) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
construct by copy other boundbox
BoundBox() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
construct a initial boundBox with all value 0
buildIndex(IndexType, boolean) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Builds the index.

C

calc_partitioner(GridType, int) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Spatial partitioning.
call(Iterator<String>) - Method in class org.apache.sedona.core.formatMapper.EarthdataHDFPointMapper
 
call(Iterator<String>) - Method in class org.apache.sedona.core.formatMapper.FormatMapper
 
call(Integer, Iterator<Pair<U, T>>) - Method in class org.apache.sedona.core.joinJudgement.DuplicatesFilter
 
call(Iterator<U>, Iterator<T>) - Method in class org.apache.sedona.core.joinJudgement.DynamicIndexLookupJudgement
 
call(Iterator<SpatialIndex>, Iterator<U>) - Method in class org.apache.sedona.core.joinJudgement.LeftIndexLookupJudgement
 
call(Iterator<T>, Iterator<U>) - Method in class org.apache.sedona.core.joinJudgement.NestedLoopJudgement
 
call(Iterator<T>, Iterator<SpatialIndex>) - Method in class org.apache.sedona.core.joinJudgement.RightIndexLookupJudgement
 
call(Iterator<T>) - Method in class org.apache.sedona.core.knnJudgement.KnnJudgement
 
call(Iterator<SpatialIndex>) - Method in class org.apache.sedona.core.knnJudgement.KnnJudgementUsingIndex
 
call(T) - Method in class org.apache.sedona.core.rangeJudgement.RangeFilter
 
call(Iterator<SpatialIndex>) - Method in class org.apache.sedona.core.rangeJudgement.RangeFilterUsingIndex
Call.
call(Iterator<String>) - Method in class org.apache.sedona.core.showcase.UserSuppliedLineStringMapper
 
call(Iterator<String>) - Method in class org.apache.sedona.core.showcase.UserSuppliedPointMapper
 
call(Iterator<String>) - Method in class org.apache.sedona.core.showcase.UserSuppliedPolygonMapper
 
call(Iterator<String>) - Method in class org.apache.sedona.core.showcase.UserSuppliedRectangleMapper
 
call(Iterator<T>) - Method in class org.apache.sedona.core.spatialRddTool.IndexBuilder
 
carryInputData - Variable in class org.apache.sedona.core.formatMapper.FormatUtils
The carry input data.
CircleRDD - Class in org.apache.sedona.core.spatialRDD
The Class CircleRDD.
CircleRDD(JavaRDD<Circle>) - Constructor for class org.apache.sedona.core.spatialRDD.CircleRDD
Instantiates a new circle RDD.
CircleRDD(JavaRDD<Circle>, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.CircleRDD
Instantiates a new circle RDD.
CircleRDD(SpatialRDD, Double) - Constructor for class org.apache.sedona.core.spatialRDD.CircleRDD
Instantiates a new circle RDD.
close() - Method in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
close() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryRecordReader
 
close() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameRecordReader
 
close() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.CombineShapeReader
 
close() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.DbfFileReader
 
close() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeFileReader
 
combine(StatCalculator, StatCalculator) - Static method in class org.apache.sedona.core.spatialRddTool.StatCalculator
 
combine(Envelope, Envelope) - Static method in class org.apache.sedona.core.spatialRddTool.StatCalculator
 
CombineShapeReader - Class in org.apache.sedona.core.formatMapper.shapefileParser.shapes
 
CombineShapeReader() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.shapes.CombineShapeReader
 
compare(T, T) - Method in class org.apache.sedona.core.knnJudgement.GeometryDistanceComparator
 
computeHValue(int, int, int) - Static method in class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning
Compute H value.
contains(double, double) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
contains(QuadRectangle) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
copyBounds() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
return a copy of bounds
count() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileRDD
Deprecated.
Count.
countWithoutDuplicates() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Count without duplicates.
countWithoutDuplicatesSPRDD() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Count without duplicates SPRDD.
create(SpatialPredicate) - Static method in class org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators
 
createFromHValues(int[], int) - Method in class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning
Creates the from H values.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeInputFormat
 
CRSTransform(String, String, boolean) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
CRS transform.
CRSTransform(String, String) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
CRS transform.
CRStransformation - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
The CR stransformation.
CRSTransformation - Class in org.apache.sedona.core.utils
The Class CRSTransformation.
CRSTransformation() - Constructor for class org.apache.sedona.core.utils.CRSTransformation
 

D

DbfFileReader - Class in org.apache.sedona.core.formatMapper.shapefileParser.shapes
 
DbfFileReader() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.shapes.DbfFileReader
 
DbfParseUtil - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf
 
DbfParseUtil() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
 
DedupParams - Class in org.apache.sedona.core.joinJudgement
Contains information necessary to activate de-dup logic in sub-classes of JudgementBase.
DedupParams(List<Envelope>) - Constructor for class org.apache.sedona.core.joinJudgement.DedupParams
 
deserialize(Input, GeometryFactory) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeSerde
 
deserialize(byte[], GeometryFactory) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeSerde
 
distanceJoin(SpatialRDD<T>, CircleRDD, JoinQuery.JoinParams) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Note: INTERNAL FUNCTION.
DistanceJoinQuery(SpatialRDD<T>, CircleRDD, boolean, SpatialPredicate) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Inner joins two sets of geometries, where the query windows are circles (aka.
DistanceJoinQuery(SpatialRDD<T>, CircleRDD, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Deprecated.
DistanceJoinQuery(SpatialRDD<T>, CircleRDD, JoinQuery.JoinParams) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
 
DistanceJoinQueryCountByKey(SpatialRDD<T>, CircleRDD, boolean, SpatialPredicate) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
DistanceJoinQueryCountByKey(SpatialRDD<T>, CircleRDD, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Deprecated.
DistanceJoinQueryCountByKey(SpatialRDD<T>, CircleRDD, JoinQuery.JoinParams) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
 
DistanceJoinQueryFlat(SpatialRDD<T>, CircleRDD, boolean, SpatialPredicate) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Inner joins two sets of geometries, where the query windows are circles (aka.
DistanceJoinQueryFlat(SpatialRDD<T>, CircleRDD, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Deprecated.
DistanceJoinQueryFlat(SpatialRDD<T>, CircleRDD, JoinQuery.JoinParams) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
 
DOUBLE_LENGTH - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant DOUBLE_LENGTH.
dropElements() - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
dropElements() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
DuplicatesFilter<U extends org.locationtech.jts.geom.Geometry,T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.joinJudgement
Provides optional de-dup logic.
DuplicatesFilter(Broadcast<DedupParams>) - Constructor for class org.apache.sedona.core.joinJudgement.DuplicatesFilter
 
DynamicIndexLookupJudgement<T extends org.locationtech.jts.geom.Geometry,U extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.joinJudgement
 
DynamicIndexLookupJudgement(SpatialPredicate, IndexType, JoinBuildSide, Metric, Metric, Metric, Metric) - Constructor for class org.apache.sedona.core.joinJudgement.DynamicIndexLookupJudgement
 

E

EarthdataHDFPointMapper - Class in org.apache.sedona.core.formatMapper
The Class EarthdataHDFPointMapper.
EarthdataHDFPointMapper(int, int, String, String[], String, boolean) - Constructor for class org.apache.sedona.core.formatMapper.EarthdataHDFPointMapper
Instantiates a new earthdata HDF point mapper.
EarthdataHDFPointMapper(int, int, String, String[], String) - Constructor for class org.apache.sedona.core.formatMapper.EarthdataHDFPointMapper
Instantiates a new earthdata HDF point mapper.
EarthdataHDFPointMapper(int, int, String, String[], String, boolean, String) - Constructor for class org.apache.sedona.core.formatMapper.EarthdataHDFPointMapper
Instantiates a new earthdata HDF point mapper.
EarthdataHDFPointMapper(int, int, String, String[], String, String) - Constructor for class org.apache.sedona.core.formatMapper.EarthdataHDFPointMapper
Instantiates a new earthdata HDF point mapper.
EarthdataMapperRunnableExample - Class in org.apache.sedona.core.showcase
The Class EarthdataMapperRunnableExample.
EarthdataMapperRunnableExample() - Constructor for class org.apache.sedona.core.showcase.EarthdataMapperRunnableExample
 
elapsedSince(long) - Static method in class org.apache.sedona.core.utils.TimeUtils
 
endOffset - Variable in class org.apache.sedona.core.formatMapper.FormatUtils
The end offset.
EqualPartitioning - Class in org.apache.sedona.core.spatialPartitioning
The Class EqualPartitioning.
EqualPartitioning(List<Envelope>) - Constructor for class org.apache.sedona.core.spatialPartitioning.EqualPartitioning
 
EqualPartitioning(Envelope, int) - Constructor for class org.apache.sedona.core.spatialPartitioning.EqualPartitioning
Instantiates a new equal partitioning.
equals(Object) - Method in class org.apache.sedona.core.spatialPartitioning.FlatGridPartitioner
 
equals(Object) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
equals(Object) - Method in class org.apache.sedona.core.spatialPartitioning.QuadTreePartitioner
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.ContainsEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.ContainsEvaluator
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.CoveredByEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.CoveredByEvaluator
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.CoversEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.CoversEvaluator
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.CrossesEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.CrossesEvaluator
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.EqualsEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.EqualsEvaluator
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.IntersectsEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.IntersectsEvaluator
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.OverlapsEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.OverlapsEvaluator
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.SpatialPredicateEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.SpatialPredicateEvaluator
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.TouchesEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.TouchesEvaluator
 
eval(Geometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.WithinEvaluator
 
eval(PreparedGeometry, Geometry) - Method in interface org.apache.sedona.core.spatialOperator.SpatialPredicateEvaluators.WithinEvaluator
 
Example - Class in org.apache.sedona.core.showcase
The Class Example.
Example() - Constructor for class org.apache.sedona.core.showcase.Example
 
EXPECT_FILE_CODE - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
Consts for .shp file
EXPECT_FILE_VERSION - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant EXPECT_FILE_VERSION.

F

factory - Variable in class org.apache.sedona.core.formatMapper.FormatUtils
The factory.
fetchLeafZones() - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
fetchLeafZones() - Method in class org.apache.sedona.core.spatialPartitioning.PartitioningUtils
 
fetchLeafZones() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
FIELD_DESCRIPTOR_TERMINATOR - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
Consts for .dbf file
FIELD_NAME_LENGTH - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant FIELD_NAME_LENGTH.
FieldDescriptor - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf
The Class FieldDescriptor.
FieldDescriptor() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor
 
FieldnameInputFormat - Class in org.apache.sedona.core.formatMapper.shapefileParser.fieldname
 
FieldnameInputFormat() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameInputFormat
 
FieldnameRecordReader - Class in org.apache.sedona.core.formatMapper.shapefileParser.fieldname
 
FieldnameRecordReader() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameRecordReader
 
fieldNames - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
 
FILE_END_FLAG - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant FILE_END_FLAG.
FileDataSplitter - Enum in org.apache.sedona.core.enums
The Enum FileDataSplitter.
filePath - Variable in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
fileStatus - Variable in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
findLeafNodes(Envelope) - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
findZones(QuadRectangle) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
FlatGridPartitioner - Class in org.apache.sedona.core.spatialPartitioning
 
FlatGridPartitioner(GridType, List<Envelope>) - Constructor for class org.apache.sedona.core.spatialPartitioning.FlatGridPartitioner
 
FlatGridPartitioner(List<Envelope>) - Constructor for class org.apache.sedona.core.spatialPartitioning.FlatGridPartitioner
 
flipCoordinates() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
 
flush() - Method in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
forceGrowUp(int) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
FormatMapper<T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.formatMapper
 
FormatMapper(int, int, FileDataSplitter, boolean, GeometryType) - Constructor for class org.apache.sedona.core.formatMapper.FormatMapper
Instantiates a new format mapper.
FormatMapper(FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.FormatMapper
Instantiates a new format mapper.
FormatMapper(FileDataSplitter, boolean, GeometryType) - Constructor for class org.apache.sedona.core.formatMapper.FormatMapper
This format mapper is used in SedonaSQL.
FormatUtils<T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.formatMapper
This format mapper is isolated on purpose for the sake of sharing across Spark and Flink
FormatUtils(int, int, FileDataSplitter, boolean, GeometryType) - Constructor for class org.apache.sedona.core.formatMapper.FormatUtils
Instantiates a new format mapper.
FormatUtils(FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.FormatUtils
Instantiates a new format mapper.
FormatUtils(FileDataSplitter, boolean, GeometryType) - Constructor for class org.apache.sedona.core.formatMapper.FormatUtils
This format mapper is used in SedonaSQL.
fromActiveSession() - Static method in class org.apache.sedona.core.utils.SedonaConf
 
fromByteBuffer(ByteBuffer) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeReaderFactory
 
fromInput(Input) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeReaderFactory
 
fsURI - Variable in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 

G

geoJSONReader - Variable in class org.apache.sedona.core.formatMapper.FormatUtils
 
GeoJsonReader - Class in org.apache.sedona.core.formatMapper
 
GeoJsonReader() - Constructor for class org.apache.sedona.core.formatMapper.GeoJsonReader
 
GeometryDistanceComparator<T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.knnJudgement
The Class GeometryDistanceComparator.
GeometryDistanceComparator(T, boolean) - Constructor for class org.apache.sedona.core.knnJudgement.GeometryDistanceComparator
Instantiates a new geometry distance comparator.
geometryFactory - Variable in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeParser
The geometry factory.
geometryFactory - Static variable in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileRDD
Deprecated.
The geometry factory.
GeometrySerde - Class in org.apache.sedona.core.geometryObjects
Provides methods to efficiently serialize and deserialize geometry types.
GeometrySerde() - Constructor for class org.apache.sedona.core.geometryObjects.GeometrySerde
 
geometryToLineString(SpatialRDD) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
convert geometry rdd to
geometryToPoint(SpatialRDD) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
convert geometry rdd to
geometryToPolygon(SpatialRDD) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
convert geometry rdd to
GeometryType - Enum in org.apache.sedona.core.enums
The Enum GeometryType.
geometryType - Variable in class org.apache.sedona.core.formatMapper.FormatUtils
 
getAllZones() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
getAttributes() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.PrimitiveShape
 
getAutoBroadcastJoinThreshold() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getBoundary() - Method in class org.apache.sedona.core.spatialRddTool.StatCalculator
 
getBoundBox(JavaSparkContext, String) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileRDD
Deprecated.
read and merge bound boxes of all shapefiles user input, if there is no, leave BoundBox null;
getBuildSide(String) - Static method in enum org.apache.sedona.core.enums.JoinBuildSide
 
getBytes() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShpRecord
 
getCenterLineStringRDDAsSpatialRDD() - Method in class org.apache.sedona.core.spatialRDD.CircleRDD
Gets the center line string RDD as spatial RDD.
getCenterPointAsSpatialRDD() - Method in class org.apache.sedona.core.spatialRDD.CircleRDD
Gets the center point as spatial RDD.
getCenterPolygonAsSpatialRDD() - Method in class org.apache.sedona.core.spatialRDD.CircleRDD
Gets the center polygon as spatial RDD.
getCenterRectangleRDDAsSpatialRDD() - Method in class org.apache.sedona.core.spatialRDD.CircleRDD
Gets the center rectangle RDD as spatial RDD.
getCount() - Method in class org.apache.sedona.core.spatialRddTool.StatCalculator
 
getCRStransformation() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Gets the CR stransformation.
getCurrentKey() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryRecordReader
 
getCurrentKey() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameRecordReader
 
getCurrentKey() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.CombineShapeReader
 
getCurrentKey() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.DbfFileReader
 
getCurrentKey() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeFileReader
 
getCurrentValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryRecordReader
 
getCurrentValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameRecordReader
 
getCurrentValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.CombineShapeReader
 
getCurrentValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.DbfFileReader
 
getCurrentValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeFileReader
 
getDataAsym(Array, int, int, int, int) - Static method in class org.apache.sedona.core.formatMapper.netcdfParser.SerNetCDFUtils
Gets the data from asymmetric mapping.
getDatasetBoundary() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getDataSym(Array, int, int) - Static method in class org.apache.sedona.core.formatMapper.netcdfParser.SerNetCDFUtils
Gets the data from symmetric mapping.
getDedupParams() - Method in class org.apache.sedona.core.spatialPartitioning.FlatGridPartitioner
 
getDedupParams() - Method in class org.apache.sedona.core.spatialPartitioning.KDBTreePartitioner
 
getDedupParams() - Method in class org.apache.sedona.core.spatialPartitioning.QuadTreePartitioner
 
getDedupParams() - Method in class org.apache.sedona.core.spatialPartitioning.SpatialPartitioner
 
getDelimiter() - Method in enum org.apache.sedona.core.enums.FileDataSplitter
Gets the delimiter.
getDimensionSize(NetcdfDataset, String) - Static method in class org.apache.sedona.core.formatMapper.netcdfParser.SerNetCDFUtils
Gets the size of a dimension of a NetCDF file.
getElements(QuadRectangle) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
getEnvelope() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
getExtent() - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
getFallbackPartitionNum() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getFieldDecimalCount() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor
Gets the field decimal count.
getFieldDescriptors() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
 
getFieldLength() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor
Gets the field length.
getFieldName() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor
Gets the field name.
getFieldType() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor
Gets the field type.
getFileDataSplitter(String) - Static method in enum org.apache.sedona.core.enums.FileDataSplitter
Gets the file data splitter.
getGeometryType(String) - Static method in enum org.apache.sedona.core.enums.GeometryType
Gets the GeometryType.
getGrids() - Method in class org.apache.sedona.core.spatialPartitioning.EqualPartitioning
Gets the grids.
getGrids() - Method in class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning
Gets the grids.
getGrids() - Method in class org.apache.sedona.core.spatialPartitioning.RtreePartitioning
Gets the grids.
getGrids() - Method in class org.apache.sedona.core.spatialPartitioning.SpatialPartitioner
 
getGrids() - Method in class org.apache.sedona.core.spatialPartitioning.VoronoiPartitioning
Gets the grids.
getGridType(String) - Static method in enum org.apache.sedona.core.enums.GridType
Gets the grid type.
getGridType() - Method in class org.apache.sedona.core.spatialPartitioning.SpatialPartitioner
 
getId() - Method in enum org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeType
return the shape type id.
getIndex() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeKey
 
getIndexType(String) - Static method in enum org.apache.sedona.core.enums.IndexType
Gets the index type.
getIndexType() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getItemCount() - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
getJoinApproximateTotalCount() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getJoinBuildSide() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getJoinGridType() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getJoinSparitionDominantSide(String) - Static method in enum org.apache.sedona.core.enums.JoinSparitionDominantSide
 
getJoinSparitionDominantSide() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getKeys(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.EqualPartitioning
 
getKeys(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
getKeys(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.PartitioningUtils
 
getKeys(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
getLastModified() - Method in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
getLeafId() - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
getLineStringRDD() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileRDD
Deprecated.
Gets the line string RDD.
getMMax() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
get max M
getMMin() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
get min M
getNetCDF2DArray(NetcdfDataset, String) - Static method in class org.apache.sedona.core.formatMapper.netcdfParser.SerNetCDFUtils
Extracts a variable's data from a NetCDF.
getParentZone(int, int, int) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
getParser(GeometryFactory) - Method in enum org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeType
generate a parser according to current shape type.
getPartition(Object) - Method in class org.apache.sedona.core.spatialPartitioning.SpatialPartitioner
 
getPartitionBounds() - Method in class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning
Gets the partition bounds.
getPartitioner(List<Geometry>, GridType, Envelope, int) - Static method in class org.apache.sedona.core.spatialPartitioning.PartitioningUtils
 
getPartitioner(Envelope, int) - Static method in class org.apache.sedona.core.spatialPartitioning.PartitioningUtils
If the user only provides boundary and numPartitions, use equal grids.
getPartitioner() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
 
getPartitionExtents() - Method in class org.apache.sedona.core.joinJudgement.DedupParams
 
getPartitionTree() - Method in class org.apache.sedona.core.spatialPartitioning.QuadtreePartitioning
 
getPointRDD() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileRDD
Deprecated.
Gets the point RDD.
getPolygonRDD() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileRDD
Deprecated.
Gets the polygon RDD.
getPrimitiveRecord() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.PrimitiveShape
 
getProgress() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryRecordReader
 
getProgress() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameRecordReader
 
getProgress() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
 
getProgress() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShpFileParser
get current progress of parsing records.
getProgress() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.CombineShapeReader
 
getProgress() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.DbfFileReader
 
getProgress() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeFileReader
 
getRawSpatialRDD() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Gets the raw spatial RDD.
getSampleNumber() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
 
getSampleNumbers(int, long, int) - Static method in class org.apache.sedona.core.utils.RDDSampleUtils
Returns the number of samples to take to partition the RDD into specified number of partitions.
getShape(GeometryFactory) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.PrimitiveShape
 
getShapeRDD() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileRDD
Deprecated.
Gets the shape RDD.
getSourceEpsgCode() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Gets the source epsg code.
getSpatialJoinOptimizationMode(String) - Static method in enum org.apache.sedona.core.enums.SpatialJoinOptimizationMode
 
getSpatialJoinOptimizationMode() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getSplits(JobContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryInputFormat
get and combine all splits of .shp files
getSplits(JobContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameInputFormat
get and combine all splits of .shp files
getSplits(JobContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeInputFormat
 
getTargetEpgsgCode() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Gets the target epgsg code.
getTotalNumLeafNode() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
getType(int) - Static method in enum org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeType
return the corresponding ShapeType instance by int id.
getType() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShpRecord
 
getTypeID() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShpRecord
 
getUniqueId() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
getUseIndex() - Method in class org.apache.sedona.core.utils.SedonaConf
 
getXMax() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
get max X
getXMin() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
get min X
getYMax() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
get max Y
getYMin() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
get min Y
getZMax() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
get max Z
getZMin() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
get min Z
getZone() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
getZone(int, int) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
Find the zone that fully contains this query point
gridID(Envelope, Envelope, int[]) - Static method in class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning
Grid ID.
grids - Variable in class org.apache.sedona.core.spatialPartitioning.SpatialPartitioner
 
GridType - Enum in org.apache.sedona.core.enums
The Enum GridType.
gridType - Variable in class org.apache.sedona.core.spatialPartitioning.SpatialPartitioner
 

H

hashCode() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
HDFSRandomAccessFile - Class in org.apache.sedona.core.formatMapper.netcdfParser
 
HDFSRandomAccessFile(String, String) - Constructor for class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
HDFSRandomAccessFile(String, String, int) - Constructor for class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
HEAD_BOX_NUM - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant HEAD_BOX_NUM.
HEAD_EMPTY_NUM - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant HEAD_EMPTY_NUM.
HEAD_FILE_LENGTH_16BIT - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant HEAD_FILE_LENGTH_16BIT.
height - Variable in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
hfile - Variable in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
HilbertPartitioning - Class in org.apache.sedona.core.spatialPartitioning
 
HilbertPartitioning(List<Envelope>, Envelope, int) - Constructor for class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning
Instantiates a new hilbert partitioning.

I

IndexBuilder<T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.spatialRddTool
 
IndexBuilder(IndexType) - Constructor for class org.apache.sedona.core.spatialRddTool.IndexBuilder
 
indexedRawRDD - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
The indexed raw RDD.
indexedRDD - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
The indexed RDD.
IndexSerde - Class in org.locationtech.jts.index.quadtree
Provides methods to efficiently serialize and deserialize the index.
IndexSerde() - Constructor for class org.locationtech.jts.index.quadtree.IndexSerde
 
IndexSerde - Class in org.locationtech.jts.index.strtree
Provides methods to efficiently serialize and deserialize the index.
IndexSerde() - Constructor for class org.locationtech.jts.index.strtree.IndexSerde
 
IndexType - Enum in org.apache.sedona.core.enums
The Enum IndexType.
indexType - Variable in class org.apache.sedona.core.spatialOperator.JoinQuery.JoinParams
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.CombineShapeReader
cut the combined split into FileSplit for .shp, .shx and .dbf
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.DbfFileReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeFileReader
 
insert(Envelope) - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
insert(QuadRectangle, T) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
INT_LENGTH - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant INT_LENGTH.
inverse(SpatialPredicate) - Static method in enum org.apache.sedona.core.spatialOperator.SpatialPredicate
Get inverse predicate of given spatial predicate
isDone() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
 
isLeaf() - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
isLeaf() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
isSplitable(JobContext, Path) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryInputFormat
enforce isSplitable to be false so that super.getSplits() combine all files as one split.
isSplitable(JobContext, Path) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameInputFormat
enforce isSplitable to be false so that super.getSplits() combine all files as one split.
isSplitable(JobContext, Path) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeInputFormat
enforce isSplitable() to return false so that every getSplits() only return one InputSplit
isSupported() - Method in enum org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeType
return whether the shape type is supported by Sedona

J

JoinBuildSide - Enum in org.apache.sedona.core.enums
The enumerator type of JoinQuery JoinBuildSide.
joinBuildSide - Variable in class org.apache.sedona.core.spatialOperator.JoinQuery.JoinParams
 
JoinParams(boolean, SpatialPredicate, IndexType, JoinBuildSide) - Constructor for class org.apache.sedona.core.spatialOperator.JoinQuery.JoinParams
 
JoinParams(boolean, SpatialPredicate) - Constructor for class org.apache.sedona.core.spatialOperator.JoinQuery.JoinParams
 
JoinParams(boolean, boolean) - Constructor for class org.apache.sedona.core.spatialOperator.JoinQuery.JoinParams
Deprecated.
JoinParams(boolean, boolean, IndexType, JoinBuildSide) - Constructor for class org.apache.sedona.core.spatialOperator.JoinQuery.JoinParams
Deprecated.
JoinQuery - Class in org.apache.sedona.core.spatialOperator
 
JoinQuery() - Constructor for class org.apache.sedona.core.spatialOperator.JoinQuery
 
JoinQuery.JoinParams - Class in org.apache.sedona.core.spatialOperator
 
JoinSparitionDominantSide - Enum in org.apache.sedona.core.enums
 
JudgementBase<U extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.rangeJudgement
 
JudgementBase(U, SpatialPredicate) - Constructor for class org.apache.sedona.core.rangeJudgement.JudgementBase
Instantiates a new range filter using index.
JudgementBase(U, boolean, boolean) - Constructor for class org.apache.sedona.core.rangeJudgement.JudgementBase
Instantiates a new range filter using index.

K

KDB - Class in org.apache.sedona.core.spatialPartitioning
see https://en.wikipedia.org/wiki/K-D-B-tree
KDB(int, int, Envelope) - Constructor for class org.apache.sedona.core.spatialPartitioning.KDB
 
KDB.Visitor - Interface in org.apache.sedona.core.spatialPartitioning
 
KDBTreePartitioner - Class in org.apache.sedona.core.spatialPartitioning
 
KDBTreePartitioner(KDB) - Constructor for class org.apache.sedona.core.spatialPartitioning.KDBTreePartitioner
 
KnnJudgement<U extends org.locationtech.jts.geom.Geometry,T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.knnJudgement
The Class GeometryKnnJudgement.
KnnJudgement(U, int) - Constructor for class org.apache.sedona.core.knnJudgement.KnnJudgement
Instantiates a new geometry knn judgement.
KnnJudgementUsingIndex<U extends org.locationtech.jts.geom.Geometry,T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.knnJudgement
The Class KnnJudgementUsingIndex.
KnnJudgementUsingIndex(U, int) - Constructor for class org.apache.sedona.core.knnJudgement.KnnJudgementUsingIndex
Instantiates a new knn judgement using index.
KNNQuery - Class in org.apache.sedona.core.spatialOperator
The Class KNNQuery.
KNNQuery() - Constructor for class org.apache.sedona.core.spatialOperator.KNNQuery
 

L

LeftIndexLookupJudgement<T extends org.locationtech.jts.geom.Geometry,U extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.joinJudgement
 
LeftIndexLookupJudgement(SpatialPredicate) - Constructor for class org.apache.sedona.core.joinJudgement.LeftIndexLookupJudgement
 
length() - Method in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
lineage - Variable in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
LineStringFormatMapper - Class in org.apache.sedona.core.formatMapper
 
LineStringFormatMapper(FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.LineStringFormatMapper
Instantiates a new line string format mapper.
LineStringFormatMapper(Integer, Integer, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.LineStringFormatMapper
Instantiates a new line string format mapper.
LineStringRDD - Class in org.apache.sedona.core.spatialRDD
The Class LineStringRDD.
LineStringRDD() - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaRDD<LineString>) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaRDD<LineString>, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, FlatMapFunction) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FlatMapFunction) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaRDD<LineString>, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaRDD<LineString>, String, String, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Integer, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FileDataSplitter, boolean, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, FlatMapFunction, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FlatMapFunction, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaRDD<LineString>, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Integer, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FileDataSplitter, boolean, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, FlatMapFunction, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FlatMapFunction, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaRDD<LineString>, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Integer, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FileDataSplitter, boolean, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, Integer, FlatMapFunction, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
LineStringRDD(JavaSparkContext, String, FlatMapFunction, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.LineStringRDD
Instantiates a new line string RDD.
loadDFSNetCDFDataSet(String, String, Integer) - Static method in class org.apache.sedona.core.formatMapper.netcdfParser.SerNetCDFUtils
Loads a NetCDF Dataset from HDFS.
loadNetCDFDataSet(String) - Static method in class org.apache.sedona.core.formatMapper.netcdfParser.SerNetCDFUtils
Loads a NetCDF Dataset from a URL.
locationMapping(double, double, double) - Static method in class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning
Location mapping.

M

main(String[]) - Static method in class org.apache.sedona.core.showcase.EarthdataMapperRunnableExample
The main method.
main(String[]) - Static method in class org.apache.sedona.core.showcase.Example
The main method.
match(Geometry, Geometry) - Method in class org.apache.sedona.core.rangeJudgement.JudgementBase
 
mergeBoundBox(BoundBox, BoundBox) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
calculate the union of two bound box
MinimumBoundingRectangle() - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Deprecated.
MultiPointParser - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
MultiPointParser(GeometryFactory) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.MultiPointParser
create a parser that can abstract a MultiPoint from input source with given GeometryFactory.

N

NestedLoopJudgement<T extends org.locationtech.jts.geom.Geometry,U extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.joinJudgement
 
NestedLoopJudgement(SpatialPredicate) - Constructor for class org.apache.sedona.core.joinJudgement.NestedLoopJudgement
 
nextKeyValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundaryRecordReader
 
nextKeyValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.fieldname.FieldnameRecordReader
 
nextKeyValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.CombineShapeReader
 
nextKeyValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.DbfFileReader
 
nextKeyValue() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeFileReader
 
numBytesRecord - Variable in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
number of bytes per record
numPartitions() - Method in class org.apache.sedona.core.spatialPartitioning.FlatGridPartitioner
 
numPartitions() - Method in class org.apache.sedona.core.spatialPartitioning.KDBTreePartitioner
 
numPartitions() - Method in class org.apache.sedona.core.spatialPartitioning.QuadTreePartitioner
 
numRecord - Variable in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
number of record get from header
numRecordRead - Variable in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
number of records already read.

O

org.apache.sedona.core.enums - package org.apache.sedona.core.enums
 
org.apache.sedona.core.formatMapper - package org.apache.sedona.core.formatMapper
 
org.apache.sedona.core.formatMapper.netcdfParser - package org.apache.sedona.core.formatMapper.netcdfParser
 
org.apache.sedona.core.formatMapper.shapefileParser - package org.apache.sedona.core.formatMapper.shapefileParser
 
org.apache.sedona.core.formatMapper.shapefileParser.boundary - package org.apache.sedona.core.formatMapper.shapefileParser.boundary
 
org.apache.sedona.core.formatMapper.shapefileParser.fieldname - package org.apache.sedona.core.formatMapper.shapefileParser.fieldname
 
org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf - package org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf
 
org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp - package org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
org.apache.sedona.core.formatMapper.shapefileParser.shapes - package org.apache.sedona.core.formatMapper.shapefileParser.shapes
 
org.apache.sedona.core.geometryObjects - package org.apache.sedona.core.geometryObjects
 
org.apache.sedona.core.joinJudgement - package org.apache.sedona.core.joinJudgement
 
org.apache.sedona.core.knnJudgement - package org.apache.sedona.core.knnJudgement
 
org.apache.sedona.core.rangeJudgement - package org.apache.sedona.core.rangeJudgement
 
org.apache.sedona.core.serde - package org.apache.sedona.core.serde
 
org.apache.sedona.core.showcase - package org.apache.sedona.core.showcase
 
org.apache.sedona.core.spatialOperator - package org.apache.sedona.core.spatialOperator
 
org.apache.sedona.core.spatialPartitioning - package org.apache.sedona.core.spatialPartitioning
 
org.apache.sedona.core.spatialPartitioning.quadtree - package org.apache.sedona.core.spatialPartitioning.quadtree
 
org.apache.sedona.core.spatialRDD - package org.apache.sedona.core.spatialRDD
 
org.apache.sedona.core.spatialRddTool - package org.apache.sedona.core.spatialRddTool
 
org.apache.sedona.core.utils - package org.apache.sedona.core.utils
 
org.locationtech.jts.index.quadtree - package org.locationtech.jts.index.quadtree
 
org.locationtech.jts.index.strtree - package org.locationtech.jts.index.strtree
 
otherAttributes - Variable in class org.apache.sedona.core.formatMapper.FormatUtils
Non-spatial attributes in each input row will be concatenated to a tab separated string

P

parseFileHead(DataInputStream) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
parse header of .dbf file and draw information for next step
parsePrimitiveRecord(DataInputStream) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
draw raw byte array of effective record
parseRecordHeadID() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShpFileParser
abstract id number from record header
parseRecordPrimitiveContent() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShpFileParser
abstract information from record header and then copy primitive bytes data of record to a primitive record.
parseRecordPrimitiveContent(int) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShpFileParser
abstract information from record header and then copy primitive bytes data of record to a primitive record.
parseShape(ShapeReader) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.MultiPointParser
abstract a MultiPoint shape.
parseShape(ShapeReader) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.PointParser
abstract a Point shape.
parseShape(ShapeReader) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.PolygonParser
abstract abstract a Polygon shape.
parseShape(ShapeReader) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.PolyLineParser
abstract a Polyline shape.
parseShape(ShapeReader) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeParser
parse the shape to a geometry.
parseShapeFileHead() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShpFileParser
extract and validate information from .shp file header
partitionId - Variable in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
PartitioningUtils - Class in org.apache.sedona.core.spatialPartitioning
 
PartitioningUtils() - Constructor for class org.apache.sedona.core.spatialPartitioning.PartitioningUtils
 
placeObject(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.EqualPartitioning
 
placeObject(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.FlatGridPartitioner
 
placeObject(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.KDB
 
placeObject(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.KDBTreePartitioner
 
placeObject(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.PartitioningUtils
 
placeObject(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
placeObject(Geometry) - Method in class org.apache.sedona.core.spatialPartitioning.QuadTreePartitioner
 
placeObject(T) - Method in class org.apache.sedona.core.spatialPartitioning.SpatialPartitioner
Given a geometry, returns a list of partitions it overlaps.
PointFormatMapper - Class in org.apache.sedona.core.formatMapper
 
PointFormatMapper(FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.PointFormatMapper
Instantiates a new point format mapper.
PointFormatMapper(Integer, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.PointFormatMapper
Instantiates a new point format mapper.
PointParser - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
PointParser(GeometryFactory) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.PointParser
create a parser that can abstract a Point from input source with given GeometryFactory.
PointRDD - Class in org.apache.sedona.core.spatialRDD
The Class PointRDD.
PointRDD() - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaRDD<Point>) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaRDD<Point>, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FlatMapFunction) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FlatMapFunction) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaRDD<Point>, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaRDD<Point>, String, String, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Integer, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FileDataSplitter, boolean, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FlatMapFunction, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FlatMapFunction, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaRDD<Point>, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Integer, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FileDataSplitter, boolean, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FlatMapFunction, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FlatMapFunction, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaRDD<Point>, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Integer, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FileDataSplitter, boolean, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, Integer, FlatMapFunction, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PointRDD(JavaSparkContext, String, FlatMapFunction, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PointRDD
Instantiates a new point RDD.
PolygonFormatMapper - Class in org.apache.sedona.core.formatMapper
 
PolygonFormatMapper(FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.PolygonFormatMapper
Instantiates a new polygon format mapper.
PolygonFormatMapper(Integer, Integer, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.PolygonFormatMapper
Instantiates a new polygon format mapper.
PolygonParser - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
PolygonParser(GeometryFactory) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.PolygonParser
create a parser that can abstract a Polygon from input source with given GeometryFactory.
PolygonRDD - Class in org.apache.sedona.core.spatialRDD
The Class PolygonRDD.
PolygonRDD() - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaRDD<Polygon>) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaRDD<Polygon>, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, FlatMapFunction) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FlatMapFunction) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaRDD<Polygon>, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaRDD<Polygon>, String, String, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Integer, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FileDataSplitter, boolean, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, FlatMapFunction, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FlatMapFunction, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaRDD<Polygon>, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Integer, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FileDataSplitter, boolean, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, FlatMapFunction, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FlatMapFunction, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaRDD<Polygon>, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, Integer, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, Integer, FileDataSplitter, boolean, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FileDataSplitter, boolean, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, Integer, FlatMapFunction, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonRDD(JavaSparkContext, String, FlatMapFunction, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.PolygonRDD
Instantiates a new polygon RDD.
PolygonUnion() - Method in class org.apache.sedona.core.spatialRDD.PolygonRDD
Polygon union.
PolyLineParser - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
PolyLineParser(GeometryFactory) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.PolyLineParser
create a parser that can abstract a MultiPolyline from input source with given GeometryFactory.
PrimitiveShape - Class in org.apache.sedona.core.formatMapper.shapefileParser.shapes
 
PrimitiveShape(ShpRecord) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.shapes.PrimitiveShape
 
primitiveToAttributes(DataInputStream) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
abstract attributes from primitive bytes according to field descriptors.
primitiveToAttributes(ByteBuffer) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.DbfParseUtil
abstract attributes from primitive bytes according to field descriptors.

Q

QuadNode<T> - Class in org.apache.sedona.core.spatialPartitioning.quadtree
 
QuadRectangle - Class in org.apache.sedona.core.spatialPartitioning.quadtree
 
QuadRectangle(Envelope) - Constructor for class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
QuadRectangle(double, double, double, double) - Constructor for class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
QuadTreePartitioner - Class in org.apache.sedona.core.spatialPartitioning
 
QuadTreePartitioner(StandardQuadTree<? extends Geometry>) - Constructor for class org.apache.sedona.core.spatialPartitioning.QuadTreePartitioner
 
QuadtreePartitioning - Class in org.apache.sedona.core.spatialPartitioning
 
QuadtreePartitioning(List<Envelope>, Envelope, int) - Constructor for class org.apache.sedona.core.spatialPartitioning.QuadtreePartitioning
Instantiates a new Quad-Tree partitioning.
QuadtreePartitioning(List<Envelope>, Envelope, int, int) - Constructor for class org.apache.sedona.core.spatialPartitioning.QuadtreePartitioning
 

R

RangeFilter<U extends org.locationtech.jts.geom.Geometry,T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.rangeJudgement
 
RangeFilter(U, SpatialPredicate) - Constructor for class org.apache.sedona.core.rangeJudgement.RangeFilter
 
RangeFilter(U, boolean, boolean) - Constructor for class org.apache.sedona.core.rangeJudgement.RangeFilter
 
RangeFilterUsingIndex<U extends org.locationtech.jts.geom.Geometry,T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.rangeJudgement
 
RangeFilterUsingIndex(U, SpatialPredicate) - Constructor for class org.apache.sedona.core.rangeJudgement.RangeFilterUsingIndex
 
RangeFilterUsingIndex(U, boolean, boolean) - Constructor for class org.apache.sedona.core.rangeJudgement.RangeFilterUsingIndex
 
RangeQuery - Class in org.apache.sedona.core.spatialOperator
The Class RangeQuery.
RangeQuery() - Constructor for class org.apache.sedona.core.spatialOperator.RangeQuery
 
rawSpatialRDD - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
The raw spatial RDD.
RDDSampleUtils - Class in org.apache.sedona.core.utils
The Class RDDSampleUtils.
RDDSampleUtils() - Constructor for class org.apache.sedona.core.utils.RDDSampleUtils
 
read(Kryo, Input, Class) - Method in class org.apache.sedona.core.geometryObjects.GeometrySerde
 
read(Kryo, Input, Class) - Method in class org.apache.sedona.core.geometryObjects.SpatialIndexSerde
 
read(Kryo, Input) - Method in class org.locationtech.jts.index.quadtree.IndexSerde
 
read(Kryo, Input) - Method in class org.locationtech.jts.index.strtree.IndexSerde
 
read_(long, byte[], int, int) - Method in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
readBoundBox(JavaSparkContext, String) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
read and merge bound boxes of all shapefiles user input, if there is no, leave BoundBox null;
readByte() - Method in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeReader
 
readCoordinates(String) - Method in class org.apache.sedona.core.formatMapper.FormatUtils
 
readCoordinates(ShapeReader, int) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeParser
read numPoints of coordinates from input source.
readDouble() - Method in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeReader
 
readFieldNames(JavaSparkContext, String) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
 
readGeoJSON(String) - Method in class org.apache.sedona.core.formatMapper.FormatUtils
 
readGeoJsonPropertyNames(String) - Static method in class org.apache.sedona.core.formatMapper.FormatUtils
 
readGeometry(String) - Method in class org.apache.sedona.core.formatMapper.FormatUtils
 
readInt() - Method in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeReader
 
readOffsets(ShapeReader, int, int) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeParser
 
readPropertyNames(String) - Method in class org.apache.sedona.core.formatMapper.FormatUtils
 
readToByteChannel(WritableByteChannel, long, long) - Method in class org.apache.sedona.core.formatMapper.netcdfParser.HDFSRandomAccessFile
 
readToGeometryRDD(JavaSparkContext, String) - Static method in class org.apache.sedona.core.formatMapper.GeoJsonReader
Read a SpatialRDD from a file.
readToGeometryRDD(JavaSparkContext, String, boolean, boolean) - Static method in class org.apache.sedona.core.formatMapper.GeoJsonReader
Read a SpatialRDD from a file.
readToGeometryRDD(JavaRDD) - Static method in class org.apache.sedona.core.formatMapper.GeoJsonReader
Read a SpatialRDD from a string type rdd.
readToGeometryRDD(JavaRDD, boolean, boolean) - Static method in class org.apache.sedona.core.formatMapper.GeoJsonReader
Read a SpatialRDD from a string type rdd.
readToGeometryRDD(JavaSparkContext, String) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
read shapefile in inputPath with default GeometryFactory and return an RDD of Geometry.
readToGeometryRDD(JavaSparkContext, String, GeometryFactory) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
read shapefile in inputPath with customized GeometryFactory and return an RDD of Geometry.
readToGeometryRDD(JavaSparkContext, String, int, boolean, boolean) - Static method in class org.apache.sedona.core.formatMapper.WkbReader
Read a SpatialRDD from a file.
readToGeometryRDD(JavaRDD, int, boolean, boolean) - Static method in class org.apache.sedona.core.formatMapper.WkbReader
Read a SpatialRDD from a string type rdd.
readToGeometryRDD(JavaSparkContext, String, int, boolean, boolean) - Static method in class org.apache.sedona.core.formatMapper.WktReader
Read a SpatialRDD from a file.
readToGeometryRDD(JavaRDD, int, boolean, boolean) - Static method in class org.apache.sedona.core.formatMapper.WktReader
Read a SpatialRDD from a string type rdd.
readToLineStringRDD(JavaSparkContext, String) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
read shapefile and return as an LineStringRDD
readToLineStringRDD(JavaSparkContext, String, GeometryFactory) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
read shapefile with customized GeometryFactory and return as an LineStringRDD
readToPointRDD(JavaSparkContext, String) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
read shapefile and return as an PointRDD
readToPointRDD(JavaSparkContext, String, GeometryFactory) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
read shapefile with customized GeometryFactory and return as an PointRDD
readToPolygonRDD(JavaSparkContext, String) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
read shapefile and return as an PolygonRDD
readToPolygonRDD(JavaSparkContext, String, GeometryFactory) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
read shapefile with customized GeometryFactory and return as an PolygonRDD
readWkb(String) - Method in class org.apache.sedona.core.formatMapper.FormatUtils
 
readWkt(String) - Method in class org.apache.sedona.core.formatMapper.FormatUtils
 
RECORD_DELETE_FLAG - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant RECORD_DELETE_FLAG.
RECORD_EXIST_FLAG - Static variable in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeFileConst
The Constant RECORD_EXIST_FLAG.
RectangleFormatMapper - Class in org.apache.sedona.core.formatMapper
 
RectangleFormatMapper(FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.RectangleFormatMapper
Instantiates a new rectangle format mapper.
RectangleFormatMapper(Integer, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.formatMapper.RectangleFormatMapper
Instantiates a new rectangle format mapper.
RectangleRDD - Class in org.apache.sedona.core.spatialRDD
Deprecated.
RectangleRDD() - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaRDD<Polygon>) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaRDD<Polygon>, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FileDataSplitter, boolean) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FlatMapFunction) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FlatMapFunction) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaRDD<Polygon>, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaRDD<Polygon>, String, String, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Integer, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FileDataSplitter, boolean, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FlatMapFunction, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FlatMapFunction, Envelope, Integer) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaRDD<Polygon>, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Integer, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FileDataSplitter, boolean, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FlatMapFunction, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FlatMapFunction, StorageLevel) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaRDD<Polygon>, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, Integer, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FileDataSplitter, boolean, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FileDataSplitter, boolean, Integer, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FileDataSplitter, boolean, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, Integer, FlatMapFunction, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
RectangleRDD(JavaSparkContext, String, FlatMapFunction, StorageLevel, String, String) - Constructor for class org.apache.sedona.core.spatialRDD.RectangleRDD
Deprecated.
Instantiates a new rectangle RDD.
REGION_NE - Static variable in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
REGION_NW - Static variable in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
REGION_SE - Static variable in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
REGION_SELF - Static variable in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
REGION_SW - Static variable in class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
registerClasses(Kryo) - Method in class org.apache.sedona.core.serde.SedonaKryoRegistrator
 
resolveSpatialPredicate(boolean, boolean) - Static method in class org.apache.sedona.core.rangeJudgement.JudgementBase
 
RightIndexLookupJudgement<T extends org.locationtech.jts.geom.Geometry,U extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.joinJudgement
 
RightIndexLookupJudgement(SpatialPredicate) - Constructor for class org.apache.sedona.core.joinJudgement.RightIndexLookupJudgement
 
RtreePartitioning - Class in org.apache.sedona.core.spatialPartitioning
The Class RtreePartitioning.
RtreePartitioning(List<Envelope>, int) - Constructor for class org.apache.sedona.core.spatialPartitioning.RtreePartitioning
Instantiates a new rtree partitioning.

S

saveAsGeoJSON(String) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Save as geo JSON.
saveAsWKB(String) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Save as WKB.
saveAsWKT(String) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Save as WKT
sc - Static variable in class org.apache.sedona.core.showcase.EarthdataMapperRunnableExample
The sc.
sc - Static variable in class org.apache.sedona.core.showcase.Example
The sc.
SedonaConf - Class in org.apache.sedona.core.utils
 
SedonaConf(RuntimeConfig) - Constructor for class org.apache.sedona.core.utils.SedonaConf
 
SedonaKryoRegistrator - Class in org.apache.sedona.core.serde
 
SedonaKryoRegistrator() - Constructor for class org.apache.sedona.core.serde.SedonaKryoRegistrator
 
serialize(Geometry) - Static method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeSerde
 
SerNetCDFUtils - Class in org.apache.sedona.core.formatMapper.netcdfParser
The Class SerNetCDFUtils.
SerNetCDFUtils() - Constructor for class org.apache.sedona.core.formatMapper.netcdfParser.SerNetCDFUtils
 
set(int, double) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
set tuple at i with value
setAttributes(String) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.PrimitiveShape
 
setFieldDecimalCount(byte) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor
Sets the field decimal count.
setFieldLength(int) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor
Sets the field length.
setFieldName(String) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor
Sets the field name.
setFieldType(byte) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor
Sets the field type.
setIndex(long) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeKey
 
setMMax(double) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
set max M
setMMin(double) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
set min M
setRawSpatialRDD(JavaRDD<T>) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Sets the raw spatial RDD.
setSampleNumber(int) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Sets the sample number.
setXMax(double) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
set max X
setXMin(double) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
set min X
setYMax(double) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
set max Y
setYMin(double) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
set min Y
setZMax(double) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
set max Z
setZMin(double) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
set min Z
ShapeFileConst - Interface in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
The Interface ShapeFileConst.
ShapefileRDD - Class in org.apache.sedona.core.formatMapper.shapefileParser
Deprecated.
ShapefileRDD(JavaSparkContext, String) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileRDD
Deprecated.
ShapefileRDD.
ShapefileReader - Class in org.apache.sedona.core.formatMapper.shapefileParser
 
ShapefileReader() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileReader
 
ShapeFileReader - Class in org.apache.sedona.core.formatMapper.shapefileParser.shapes
 
ShapeFileReader() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeFileReader
empty constructor
ShapeFileReader(int[]) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeFileReader
constructor with index
ShapeInputFormat - Class in org.apache.sedona.core.formatMapper.shapefileParser.shapes
 
ShapeInputFormat() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeInputFormat
 
ShapeKey - Class in org.apache.sedona.core.formatMapper.shapefileParser.shapes
 
ShapeKey() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeKey
 
ShapeParser - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
ShapeParser(GeometryFactory) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeParser
Instantiates a new shape parser.
ShapeReader - Interface in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
ShapeReaderFactory - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
ShapeReaderFactory() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeReaderFactory
 
ShapeSerde - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
Provides methods to efficiently serialize and deserialize geometry types using shapefile format developed by ESRI.
ShapeSerde() - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeSerde
 
ShapeType - Enum in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
ShpFileParser - Class in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
 
ShpFileParser(FSDataInputStream) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShpFileParser
create a new shape file parser with a input source that is instance of DataInputStream
ShpRecord - Class in org.apache.sedona.core.formatMapper.shapefileParser.shapes
 
ShpRecord(byte[], int) - Constructor for class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShpRecord
create a ShpRecord with primitive bytes and shape type id we abstract from .shp file
skip(int) - Method in interface org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeReader
 
sourceEpsgCode - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
The source epsg code.
SpatialIndexSerde - Class in org.apache.sedona.core.geometryObjects
Provides methods to efficiently serialize and deserialize spatialIndex types.
SpatialIndexSerde() - Constructor for class org.apache.sedona.core.geometryObjects.SpatialIndexSerde
 
SpatialIndexSerde(GeometrySerde) - Constructor for class org.apache.sedona.core.geometryObjects.SpatialIndexSerde
 
spatialJoin(SpatialRDD<U>, SpatialRDD<T>, JoinQuery.JoinParams) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Note: INTERNAL FUNCTION.
SpatialJoinOptimizationMode - Enum in org.apache.sedona.core.enums
 
SpatialJoinQuery(SpatialRDD<T>, SpatialRDD<U>, boolean, SpatialPredicate) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Inner joins two sets of geometries on specified spatial predicate.
SpatialJoinQuery(SpatialRDD<T>, SpatialRDD<U>, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Deprecated.
SpatialJoinQuery(SpatialRDD<T>, SpatialRDD<U>, JoinQuery.JoinParams) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
 
SpatialJoinQueryCountByKey(SpatialRDD<T>, SpatialRDD<U>, boolean, SpatialPredicate) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
SpatialJoinQueryCountByKey(SpatialRDD<T>, SpatialRDD<U>, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Deprecated.
SpatialJoinQueryCountByKey(SpatialRDD<T>, SpatialRDD<U>, JoinQuery.JoinParams) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
 
SpatialJoinQueryFlat(SpatialRDD<T>, SpatialRDD<U>, boolean, SpatialPredicate) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Inner joins two sets of geometries on specified spatial predicate.
SpatialJoinQueryFlat(SpatialRDD<T>, SpatialRDD<U>, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
Deprecated.
SpatialJoinQueryFlat(SpatialRDD<T>, SpatialRDD<U>, JoinQuery.JoinParams) - Static method in class org.apache.sedona.core.spatialOperator.JoinQuery
 
SpatialKnnQuery(SpatialRDD<T>, U, Integer, boolean) - Static method in class org.apache.sedona.core.spatialOperator.KNNQuery
Spatial knn query.
spatialPartitionedRDD - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
The spatial partitioned RDD.
SpatialPartitioner - Class in org.apache.sedona.core.spatialPartitioning
 
SpatialPartitioner(GridType, List<Envelope>) - Constructor for class org.apache.sedona.core.spatialPartitioning.SpatialPartitioner
 
spatialPartitioning(GridType) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
 
spatialPartitioning(GridType, int) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
 
spatialPartitioning(SpatialPartitioner) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
 
spatialPartitioning(List<Envelope>) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Deprecated.
Use spatialPartitioning(SpatialPartitioner partitioner)
spatialPartitioning(StandardQuadTree) - Method in class org.apache.sedona.core.spatialRDD.SpatialRDD
Deprecated.
Use spatialPartitioning(SpatialPartitioner partitioner)
spatialPredicate - Variable in class org.apache.sedona.core.spatialOperator.JoinQuery.JoinParams
 
SpatialPredicate - Enum in org.apache.sedona.core.spatialOperator
Spatial predicates for range queries and join queries.
SpatialPredicateEvaluators - Class in org.apache.sedona.core.spatialOperator
 
SpatialPredicateEvaluators.ContainsEvaluator - Interface in org.apache.sedona.core.spatialOperator
 
SpatialPredicateEvaluators.CoveredByEvaluator - Interface in org.apache.sedona.core.spatialOperator
 
SpatialPredicateEvaluators.CoversEvaluator - Interface in org.apache.sedona.core.spatialOperator
 
SpatialPredicateEvaluators.CrossesEvaluator - Interface in org.apache.sedona.core.spatialOperator
 
SpatialPredicateEvaluators.EqualsEvaluator - Interface in org.apache.sedona.core.spatialOperator
 
SpatialPredicateEvaluators.IntersectsEvaluator - Interface in org.apache.sedona.core.spatialOperator
 
SpatialPredicateEvaluators.OverlapsEvaluator - Interface in org.apache.sedona.core.spatialOperator
 
SpatialPredicateEvaluators.SpatialPredicateEvaluator - Interface in org.apache.sedona.core.spatialOperator
SpatialPredicateEvaluator for evaluating spatial predicates, it also works as a trait which will be mixed into org.apache.sedona.core.joinJudgement.JoinConditionMatcher.
SpatialPredicateEvaluators.TouchesEvaluator - Interface in org.apache.sedona.core.spatialOperator
 
SpatialPredicateEvaluators.WithinEvaluator - Interface in org.apache.sedona.core.spatialOperator
 
SpatialRangeQuery(SpatialRDD<T>, U, SpatialPredicate, boolean) - Static method in class org.apache.sedona.core.spatialOperator.RangeQuery
Spatial range query.
SpatialRangeQuery(SpatialRDD<T>, Envelope, SpatialPredicate, boolean) - Static method in class org.apache.sedona.core.spatialOperator.RangeQuery
Spatial range query.
SpatialRangeQuery(SpatialRDD<T>, U, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.RangeQuery
Deprecated.
SpatialRangeQuery(SpatialRDD<T>, Envelope, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.RangeQuery
Deprecated.
SpatialRangeQuery(Envelope, SpatialRDD<T>, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.RangeQuery
Deprecated.
SpatialRangeQuery(U, SpatialRDD<T>, boolean, boolean) - Static method in class org.apache.sedona.core.spatialOperator.RangeQuery
Deprecated.
SpatialRDD<T extends org.locationtech.jts.geom.Geometry> - Class in org.apache.sedona.core.spatialRDD
The Class SpatialRDD.
SpatialRDD() - Constructor for class org.apache.sedona.core.spatialRDD.SpatialRDD
 
splits - Variable in class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning
The splits.
splitter - Variable in class org.apache.sedona.core.formatMapper.FormatUtils
The splitter.
StandardQuadTree<T> - Class in org.apache.sedona.core.spatialPartitioning.quadtree
 
StandardQuadTree(QuadRectangle, int) - Constructor for class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
StandardQuadTree(QuadRectangle, int, int, int) - Constructor for class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree
 
startOffset - Variable in class org.apache.sedona.core.formatMapper.FormatUtils
The start offset.
StatCalculator - Class in org.apache.sedona.core.spatialRddTool
 
StatCalculator(Envelope, long) - Constructor for class org.apache.sedona.core.spatialRddTool.StatCalculator
 

T

targetEpgsgCode - Variable in class org.apache.sedona.core.spatialRDD.SpatialRDD
The target epgsg code.
testCRSTransformationSpatialRangeQuery() - Static method in class org.apache.sedona.core.showcase.Example
Test CRS transformation spatial range query.
testCRSTransformationSpatialRangeQueryUsingIndex() - Static method in class org.apache.sedona.core.showcase.Example
Test CRS transformation spatial range query using index.
testDistanceJoinQuery() - Static method in class org.apache.sedona.core.showcase.Example
Test spatial join query.
testDistanceJoinQueryUsingIndex() - Static method in class org.apache.sedona.core.showcase.Example
Test spatial join query using index.
testLoadShapefileIntoPolygonRDD() - Static method in class org.apache.sedona.core.showcase.Example
 
testSpatialJoinQuery() - Static method in class org.apache.sedona.core.showcase.Example
Test spatial join query.
testSpatialJoinQueryUsingIndex() - Static method in class org.apache.sedona.core.showcase.Example
Test spatial join query using index.
testSpatialKnnQuery() - Static method in class org.apache.sedona.core.showcase.Example
Test spatial knn query.
testSpatialKnnQueryUsingIndex() - Static method in class org.apache.sedona.core.showcase.Example
Test spatial knn query using index.
testSpatialRangeQuery() - Static method in class org.apache.sedona.core.showcase.EarthdataMapperRunnableExample
Test spatial range query.
testSpatialRangeQuery() - Static method in class org.apache.sedona.core.showcase.Example
Test spatial range query.
testSpatialRangeQueryUsingIndex() - Static method in class org.apache.sedona.core.showcase.EarthdataMapperRunnableExample
Test spatial range query using index.
testSpatialRangeQueryUsingIndex() - Static method in class org.apache.sedona.core.showcase.Example
Test spatial range query using index.
TimeUtils - Class in org.apache.sedona.core.utils
 
TimeUtils() - Constructor for class org.apache.sedona.core.utils.TimeUtils
 
toString() - Method in class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox
convert bounds array to string
toString() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadNode
 
toString() - Method in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
toString() - Method in class org.apache.sedona.core.utils.SedonaConf
 
Transform(String, String, Point) - Static method in class org.apache.sedona.core.utils.CRSTransformation
Transform.
Transform(String, String, Polygon) - Static method in class org.apache.sedona.core.utils.CRSTransformation
Transform.
Transform(String, String, Envelope) - Static method in class org.apache.sedona.core.utils.CRSTransformation
Transform.
Transform(String, String, T) - Static method in class org.apache.sedona.core.utils.CRSTransformation
 
traverse(KDB.Visitor) - Method in class org.apache.sedona.core.spatialPartitioning.KDB
Traverses the tree top-down breadth-first and calls the visitor for each node.
TypeUnknownException - Exception in org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
The Class TypeUnknownException.
TypeUnknownException(int) - Constructor for exception org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.TypeUnknownException
create an exception indicates that the shape type number we get from .shp file is valid

U

updateEnvelope(Envelope, Envelope) - Static method in class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning
Update envelope.
useIndex - Variable in class org.apache.sedona.core.spatialOperator.JoinQuery.JoinParams
 
UserSuppliedLineStringMapper - Class in org.apache.sedona.core.showcase
The Class UserSuppliedLineStringMapper.
UserSuppliedLineStringMapper() - Constructor for class org.apache.sedona.core.showcase.UserSuppliedLineStringMapper
 
UserSuppliedPointMapper - Class in org.apache.sedona.core.showcase
 
UserSuppliedPointMapper() - Constructor for class org.apache.sedona.core.showcase.UserSuppliedPointMapper
 
UserSuppliedPolygonMapper - Class in org.apache.sedona.core.showcase
The Class UserSuppliedPolygonMapper.
UserSuppliedPolygonMapper() - Constructor for class org.apache.sedona.core.showcase.UserSuppliedPolygonMapper
 
UserSuppliedRectangleMapper - Class in org.apache.sedona.core.showcase
The Class UserSuppliedRectangleMapper.
UserSuppliedRectangleMapper() - Constructor for class org.apache.sedona.core.showcase.UserSuppliedRectangleMapper
 

V

valueOf(String) - Static method in enum org.apache.sedona.core.enums.FileDataSplitter
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sedona.core.enums.GeometryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sedona.core.enums.GridType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sedona.core.enums.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sedona.core.enums.JoinBuildSide
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sedona.core.enums.JoinSparitionDominantSide
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sedona.core.enums.SpatialJoinOptimizationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.sedona.core.spatialOperator.SpatialPredicate
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.sedona.core.enums.FileDataSplitter
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sedona.core.enums.GeometryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sedona.core.enums.GridType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sedona.core.enums.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sedona.core.enums.JoinBuildSide
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sedona.core.enums.JoinSparitionDominantSide
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sedona.core.enums.SpatialJoinOptimizationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.sedona.core.spatialOperator.SpatialPredicate
Returns an array containing the constants of this enum type, in the order they are declared.
visit(KDB) - Method in interface org.apache.sedona.core.spatialPartitioning.KDB.Visitor
Visits a single node of the tree
VoronoiPartitioning - Class in org.apache.sedona.core.spatialPartitioning
The Class VoronoiPartitioning.
VoronoiPartitioning(List<Envelope>, int) - Constructor for class org.apache.sedona.core.spatialPartitioning.VoronoiPartitioning
Instantiates a new voronoi partitioning.

W

width - Variable in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
WkbReader - Class in org.apache.sedona.core.formatMapper
 
WkbReader() - Constructor for class org.apache.sedona.core.formatMapper.WkbReader
 
wktReader - Variable in class org.apache.sedona.core.formatMapper.FormatUtils
 
WktReader - Class in org.apache.sedona.core.formatMapper
 
WktReader() - Constructor for class org.apache.sedona.core.formatMapper.WktReader
 
write(DataOutput) - Method in class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeKey
 
write(Kryo, Output, Object) - Method in class org.apache.sedona.core.geometryObjects.GeometrySerde
 
write(Kryo, Output, Object) - Method in class org.apache.sedona.core.geometryObjects.SpatialIndexSerde
 
write(Kryo, Output, Quadtree) - Method in class org.locationtech.jts.index.quadtree.IndexSerde
 
write(Kryo, Output, STRtree) - Method in class org.locationtech.jts.index.strtree.IndexSerde
 

X

x - Variable in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 

Y

y - Variable in class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y 
Skip navigation links

Copyright © 2023 The Apache Software Foundation. All rights reserved.