Serialized Form
-
Package org.apache.sedona.core.formatMapper
-
Class org.apache.sedona.core.formatMapper.EarthdataHDFPointMapper extends Object implements Serializable
-
Serialized Fields
-
dataFieldName
String dataFieldName
The data field name. -
dataPath
String dataPath
The data path. -
dataPathList
String[] dataPathList
The data path list. -
dataVariableList
String[] dataVariableList
The data variable list. -
dataVariableName
String dataVariableName
The data variable name. -
geolocationField
String geolocationField
The geolocation field. -
increment
int increment
The increment. -
latitudeName
String latitudeName
The latitude name. -
latitudePath
String latitudePath
The latitude path. -
longitudeName
String longitudeName
The longitude name. -
longitudePath
String longitudePath
The longitude path. -
offset
int offset
The offset. -
rootGroupName
String rootGroupName
The root group name. -
switchCoordinateXY
boolean switchCoordinateXY
The switch coordinate XY. By default, longitude is X, latitude is Y -
urlPrefix
String urlPrefix
The url prefix.
-
-
-
Class org.apache.sedona.core.formatMapper.FormatMapper extends org.apache.sedona.common.utils.FormatUtils implements Serializable
-
Class org.apache.sedona.core.formatMapper.LineStringFormatMapper extends FormatMapper implements Serializable
-
Class org.apache.sedona.core.formatMapper.PointFormatMapper extends FormatMapper implements Serializable
-
Class org.apache.sedona.core.formatMapper.PolygonFormatMapper extends FormatMapper implements Serializable
-
Class org.apache.sedona.core.formatMapper.RectangleFormatMapper extends FormatMapper implements Serializable
-
-
Package org.apache.sedona.core.formatMapper.netcdfParser
-
Class org.apache.sedona.core.formatMapper.netcdfParser.SerNetCDFUtils extends Object implements Serializable
-
-
Package org.apache.sedona.core.formatMapper.shapefileParser
-
Class org.apache.sedona.core.formatMapper.shapefileParser.ShapefileRDD extends Object implements Serializable
-
Serialized Fields
-
boundBox
BoundBox boundBox
Deprecated.bounding box. -
PrintShape
org.apache.spark.api.java.function.VoidFunction<org.locationtech.jts.geom.Geometry> PrintShape
Deprecated.The Print shape. -
shapeRDD
org.apache.spark.api.java.JavaRDD<org.locationtech.jts.geom.Geometry> shapeRDD
Deprecated.shape collection.
-
-
-
-
Package org.apache.sedona.core.formatMapper.shapefileParser.boundary
-
Class org.apache.sedona.core.formatMapper.shapefileParser.boundary.BoundBox extends Object implements Serializable
-
Serialized Fields
-
bounds
double[] bounds
bounds of 8 numbers. Xmin, Ymin, Xmax, Ymax, Zmin, Zmax, Mmin, Mmax
-
-
-
-
Package org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf
-
Class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.dbf.FieldDescriptor extends Object implements Serializable
-
Serialized Fields
-
fieldDecimalCount
byte fieldDecimalCount
decimal count. -
fieldLength
int fieldLength
field length. -
fieldName
String fieldName
field name. -
fieldType
byte fieldType
field type.
-
-
-
-
Package org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp
-
Class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.MultiPointParser extends ShapeParser implements Serializable
-
Serialized Fields
-
shapeType
ShapeType shapeType
-
-
-
Class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.PointParser extends ShapeParser implements Serializable
-
Serialized Fields
-
shapeType
ShapeType shapeType
-
-
-
Class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.PolygonParser extends ShapeParser implements Serializable
-
Serialized Fields
-
shapeType
ShapeType shapeType
-
-
-
Class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.PolyLineParser extends ShapeParser implements Serializable
-
Serialized Fields
-
shapeType
ShapeType shapeType
-
-
-
Class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShapeParser extends Object implements Serializable
-
Serialized Fields
-
geometryFactory
org.locationtech.jts.geom.GeometryFactory geometryFactory
The geometry factory.
-
-
-
Class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShpFileParser extends Object implements Serializable
-
Serialized Fields
-
fileLength
long fileLength
length of file in bytes -
reader
org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.ShpFileParser.SafeReader reader
input reader -
remainLength
long remainLength
remain length of bytes to parse
-
-
-
Class org.apache.sedona.core.formatMapper.shapefileParser.parseUtils.shp.TypeUnknownException extends RuntimeException implements Serializable
-
-
Package org.apache.sedona.core.formatMapper.shapefileParser.shapes
-
Class org.apache.sedona.core.formatMapper.shapefileParser.shapes.PrimitiveShape extends Object implements Serializable
-
Class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShapeKey extends Object implements Serializable
-
Serialized Fields
-
index
Long index
record id
-
-
-
Class org.apache.sedona.core.formatMapper.shapefileParser.shapes.ShpRecord extends Object implements Serializable
-
Serialized Fields
-
bytes
org.apache.hadoop.io.BytesWritable bytes
primitive byte contents -
typeID
int typeID
shape type
-
-
-
-
Package org.apache.sedona.core.joinJudgement
-
Class org.apache.sedona.core.joinJudgement.DedupParams extends Object implements Serializable
-
Serialized Fields
-
partitionExtents
List<org.locationtech.jts.geom.Envelope> partitionExtents
-
-
-
Class org.apache.sedona.core.joinJudgement.DuplicatesFilter extends Object implements Serializable
-
Serialized Fields
-
dedupParamsBroadcast
org.apache.spark.broadcast.Broadcast<DedupParams> dedupParamsBroadcast
-
-
-
Class org.apache.sedona.core.joinJudgement.DynamicIndexLookupJudgement extends org.apache.sedona.core.joinJudgement.JudgementBase<T extends org.locationtech.jts.geom.Geometry,U extends org.locationtech.jts.geom.Geometry> implements Serializable
-
Serialized Fields
-
indexType
IndexType indexType
-
joinBuildSide
JoinBuildSide joinBuildSide
-
-
-
Class org.apache.sedona.core.joinJudgement.KnnJoinIndexJudgement extends org.apache.sedona.core.joinJudgement.JudgementBase<T extends org.locationtech.jts.geom.Geometry,U extends org.locationtech.jts.geom.Geometry> implements Serializable
-
Serialized Fields
-
broadcastObjectsTreeIndex
org.apache.spark.broadcast.Broadcast<org.locationtech.jts.index.strtree.STRtree> broadcastObjectsTreeIndex
-
broadcastQueryObjects
org.apache.spark.broadcast.Broadcast<List<T extends org.locationtech.jts.geom.Geometry>> broadcastQueryObjects
-
distanceMetric
DistanceMetric distanceMetric
-
includeTies
boolean includeTies
-
k
int k
-
-
-
Class org.apache.sedona.core.joinJudgement.LeftIndexLookupJudgement extends org.apache.sedona.core.joinJudgement.JudgementBase<T extends org.locationtech.jts.geom.Geometry,U extends org.locationtech.jts.geom.Geometry> implements Serializable
-
Class org.apache.sedona.core.joinJudgement.NestedLoopJudgement extends org.apache.sedona.core.joinJudgement.JudgementBase<T extends org.locationtech.jts.geom.Geometry,U extends org.locationtech.jts.geom.Geometry> implements Serializable
-
Class org.apache.sedona.core.joinJudgement.RightIndexLookupJudgement extends org.apache.sedona.core.joinJudgement.JudgementBase<T extends org.locationtech.jts.geom.Geometry,U extends org.locationtech.jts.geom.Geometry> implements Serializable
-
-
Package org.apache.sedona.core.knnJudgement
-
Class org.apache.sedona.core.knnJudgement.GeometryDistanceComparator extends Object implements Serializable
-
Serialized Fields
-
normalOrder
boolean normalOrder
The normal order. -
queryCenter
T extends org.locationtech.jts.geom.Geometry queryCenter
The query center.
-
-
-
Class org.apache.sedona.core.knnJudgement.KnnJudgement extends Object implements Serializable
-
Serialized Fields
-
k
int k
The k. -
queryCenter
U extends org.locationtech.jts.geom.Geometry queryCenter
The query center.
-
-
-
Class org.apache.sedona.core.knnJudgement.KnnJudgementUsingIndex extends Object implements Serializable
-
Serialized Fields
-
k
int k
The k. -
queryCenter
U extends org.locationtech.jts.geom.Geometry queryCenter
The query center.
-
-
-
-
Package org.apache.sedona.core.monitoring
-
Class org.apache.sedona.core.monitoring.EnvelopeAccumulator extends org.apache.spark.util.AccumulatorV2<org.locationtech.jts.geom.Envelope,org.locationtech.jts.geom.Geometry> implements Serializable
-
Serialized Fields
-
env
org.locationtech.jts.geom.Envelope env
-
gf
org.locationtech.jts.geom.GeometryFactory gf
-
-
-
-
Package org.apache.sedona.core.rangeJudgement
-
Class org.apache.sedona.core.rangeJudgement.JudgementBase extends Object implements Serializable
-
Serialized Fields
-
evaluator
SpatialPredicateEvaluators.SpatialPredicateEvaluator evaluator
-
queryGeometry
U extends org.locationtech.jts.geom.Geometry queryGeometry
-
-
-
Class org.apache.sedona.core.rangeJudgement.RangeFilter extends JudgementBase implements Serializable
-
Class org.apache.sedona.core.rangeJudgement.RangeFilterUsingIndex extends JudgementBase implements Serializable
-
-
Package org.apache.sedona.core.showcase
-
Class org.apache.sedona.core.showcase.Example extends Object implements Serializable
-
Class org.apache.sedona.core.showcase.UserSuppliedLineStringMapper extends Object implements Serializable
-
Serialized Fields
-
actualEndOffset
int actualEndOffset
The actual end offset. -
coordinates
org.locationtech.jts.geom.Coordinate[] coordinates
The coordinates. -
coordinatesList
ArrayList<org.locationtech.jts.geom.Coordinate> coordinatesList
The coordinates list. -
fact
org.locationtech.jts.geom.GeometryFactory fact
The fact. -
linear
org.locationtech.jts.geom.LinearRing linear
The linear. -
lineSplitList
List<String> lineSplitList
The line split list. -
multiSpatialObjects
org.locationtech.jts.geom.MultiPolygon multiSpatialObjects
The multi spatial objects. -
spatialObject
org.locationtech.jts.geom.Geometry spatialObject
The spatial object.
-
-
-
Class org.apache.sedona.core.showcase.UserSuppliedPointMapper extends Object implements Serializable
-
Serialized Fields
-
factory
org.locationtech.jts.geom.GeometryFactory factory
The factory.
-
-
-
Class org.apache.sedona.core.showcase.UserSuppliedPolygonMapper extends Object implements Serializable
-
Serialized Fields
-
actualEndOffset
int actualEndOffset
The actual end offset. -
coordinates
org.locationtech.jts.geom.Coordinate[] coordinates
The coordinates. -
coordinatesList
ArrayList<org.locationtech.jts.geom.Coordinate> coordinatesList
The coordinates list. -
fact
org.locationtech.jts.geom.GeometryFactory fact
The fact. -
linear
org.locationtech.jts.geom.LinearRing linear
The linear. -
lineSplitList
List<String> lineSplitList
The line split list. -
multiSpatialObjects
org.locationtech.jts.geom.MultiPolygon multiSpatialObjects
The multi spatial objects. -
result
List result
The result. -
spatialObject
org.locationtech.jts.geom.Geometry spatialObject
The spatial object.
-
-
-
Class org.apache.sedona.core.showcase.UserSuppliedRectangleMapper extends Object implements Serializable
-
Serialized Fields
-
actualEndOffset
int actualEndOffset
The actual end offset. -
coordinates
org.locationtech.jts.geom.Coordinate[] coordinates
The coordinates. -
coordinatesList
ArrayList<org.locationtech.jts.geom.Coordinate> coordinatesList
The coordinates list. -
fact
org.locationtech.jts.geom.GeometryFactory fact
The fact. -
linear
org.locationtech.jts.geom.LinearRing linear
The linear. -
lineSplitList
List<String> lineSplitList
The line split list. -
multiSpatialObjects
org.locationtech.jts.geom.MultiPolygon multiSpatialObjects
The multi spatial objects. -
spatialObject
org.locationtech.jts.geom.Geometry spatialObject
The spatial object.
-
-
-
-
Package org.apache.sedona.core.spatialOperator
-
Class org.apache.sedona.core.spatialOperator.KNNQuery extends Object implements Serializable
-
Class org.apache.sedona.core.spatialOperator.RangeQuery extends Object implements Serializable
-
-
Package org.apache.sedona.core.spatialPartitioning
-
Class org.apache.sedona.core.spatialPartitioning.BroadcastedSpatialPartitioner extends SpatialPartitioner implements Serializable
-
Serialized Fields
-
bPartitioner
org.apache.spark.broadcast.Broadcast<SpatialPartitioner> bPartitioner
-
-
-
Class org.apache.sedona.core.spatialPartitioning.EqualPartitioning extends Object implements Serializable
-
Serialized Fields
-
-
Class org.apache.sedona.core.spatialPartitioning.FlatGridPartitioner extends SpatialPartitioner implements Serializable
-
Serialized Fields
-
preserveUncontainedGeometries
Boolean preserveUncontainedGeometries
-
-
-
Class org.apache.sedona.core.spatialPartitioning.GenericUniquePartitioner extends SpatialPartitioner implements Serializable
-
Serialized Fields
-
parent
SpatialPartitioner parent
-
-
-
Class org.apache.sedona.core.spatialPartitioning.HilbertPartitioning extends Object implements Serializable
-
Serialized Fields
-
grids
List<org.locationtech.jts.geom.Envelope> grids
The grids. -
splits
int[] splits
The splits.
-
-
-
Class org.apache.sedona.core.spatialPartitioning.IndexedGridPartitioner extends FlatGridPartitioner implements Serializable
-
Serialized Fields
-
index
org.locationtech.jts.index.strtree.STRtree index
-
-
-
Class org.apache.sedona.core.spatialPartitioning.KDB extends PartitioningUtils implements Serializable
-
Class org.apache.sedona.core.spatialPartitioning.KDBTreePartitioner extends SpatialPartitioner implements Serializable
-
Serialized Fields
-
tree
KDB tree
-
-
-
Class org.apache.sedona.core.spatialPartitioning.QuadTreePartitioner extends SpatialPartitioner implements Serializable
-
Serialized Fields
-
quadTree
StandardQuadTree<?> quadTree
-
-
-
Class org.apache.sedona.core.spatialPartitioning.QuadtreePartitioning extends Object implements Serializable
-
Serialized Fields
-
partitionTree
StandardQuadTree<Integer> partitionTree
The Quad-Tree.
-
-
-
Class org.apache.sedona.core.spatialPartitioning.QuadTreeRTPartitioner extends QuadTreePartitioner implements Serializable
-
Serialized Fields
-
extendedQuadTree
ExtendedQuadTree<?> extendedQuadTree
-
-
-
Class org.apache.sedona.core.spatialPartitioning.QuadTreeRTPartitioning extends QuadtreePartitioning implements Serializable
-
Serialized Fields
-
mbrs
HashMap<Integer,List<org.locationtech.jts.geom.Envelope>> mbrs
-
mbrSpatialIndex
org.locationtech.jts.index.strtree.STRtree mbrSpatialIndex
-
sedonaConf
SedonaConf sedonaConf
-
strTree
org.locationtech.jts.index.strtree.STRtree strTree
-
-
-
Class org.apache.sedona.core.spatialPartitioning.RtreePartitioning extends Object implements Serializable
-
Serialized Fields
-
grids
List<org.locationtech.jts.geom.Envelope> grids
The grids.
-
-
-
Class org.apache.sedona.core.spatialPartitioning.SpatialPartitioner extends org.apache.spark.Partitioner implements Serializable
-
Class org.apache.sedona.core.spatialPartitioning.VoronoiPartitioning extends Object implements Serializable
-
Serialized Fields
-
grids
List<org.locationtech.jts.geom.Envelope> grids
The grids.
-
-
-
-
Package org.apache.sedona.core.spatialPartitioning.quadtree
-
Class org.apache.sedona.core.spatialPartitioning.quadtree.ExtendedQuadTree extends PartitioningUtils implements Serializable
-
Serialized Fields
-
boundary
org.locationtech.jts.geom.Envelope boundary
-
expandedBoundaries
HashMap<Integer,List<org.locationtech.jts.geom.Envelope>> expandedBoundaries
-
numPartitions
int numPartitions
-
partitionTree
StandardQuadTree<Integer> partitionTree
-
spatialExpandedBoundaryIndex
org.locationtech.jts.index.strtree.STRtree spatialExpandedBoundaryIndex
-
useNonOverlapped
boolean useNonOverlapped
-
-
-
Class org.apache.sedona.core.spatialPartitioning.quadtree.QuadNode extends Object implements Serializable
-
Serialized Fields
-
element
T element
-
r
QuadRectangle r
-
-
-
Class org.apache.sedona.core.spatialPartitioning.quadtree.QuadRectangle extends Object implements Serializable
-
Class org.apache.sedona.core.spatialPartitioning.quadtree.StandardQuadTree extends PartitioningUtils implements Serializable
-
Serialized Fields
-
level
int level
-
maxItemsPerZone
int maxItemsPerZone
-
maxLevel
int maxLevel
-
nodeNum
int nodeNum
-
nodes
List<QuadNode<T>> nodes
-
regions
StandardQuadTree<T>[] regions
-
zone
QuadRectangle zone
-
-
-
-
Package org.apache.sedona.core.spatialRDD
-
Class org.apache.sedona.core.spatialRDD.CircleRDD extends SpatialRDD<org.apache.sedona.common.geometryObjects.Circle> implements Serializable
-
Class org.apache.sedona.core.spatialRDD.LineStringRDD extends SpatialRDD<org.locationtech.jts.geom.LineString> implements Serializable
-
Class org.apache.sedona.core.spatialRDD.PointRDD extends SpatialRDD<org.locationtech.jts.geom.Point> implements Serializable
-
Class org.apache.sedona.core.spatialRDD.PolygonRDD extends SpatialRDD<org.locationtech.jts.geom.Polygon> implements Serializable
-
Class org.apache.sedona.core.spatialRDD.RectangleRDD extends SpatialRDD<org.locationtech.jts.geom.Polygon> implements Serializable
-
Class org.apache.sedona.core.spatialRDD.SpatialRDD extends Object implements Serializable
-
Serialized Fields
-
approximateTotalCount
long approximateTotalCount
The total number of records. -
boundaryEnvelope
org.locationtech.jts.geom.Envelope boundaryEnvelope
The boundary envelope. -
CRStransformation
boolean CRStransformation
The CR stransformation. -
fieldNames
List<String> fieldNames
-
indexedRawRDD
org.apache.spark.api.java.JavaRDD<org.locationtech.jts.index.SpatialIndex> indexedRawRDD
The indexed raw RDD. -
indexedRDD
org.apache.spark.api.java.JavaRDD<org.locationtech.jts.index.SpatialIndex> indexedRDD
The indexed RDD. -
neighborSampleNumber
int neighborSampleNumber
The neighbor sample number. -
partitioner
SpatialPartitioner partitioner
-
rawSpatialRDD
org.apache.spark.api.java.JavaRDD<T extends org.locationtech.jts.geom.Geometry> rawSpatialRDD
The raw spatial RDD. -
sampleNumber
int sampleNumber
The sample number. -
schema
org.apache.spark.sql.types.StructType schema
-
sourceEpsgCode
String sourceEpsgCode
The source epsg code. -
spatialPartitionedRDD
org.apache.spark.api.java.JavaRDD<T extends org.locationtech.jts.geom.Geometry> spatialPartitionedRDD
The spatial partitioned RDD. -
targetEpgsgCode
String targetEpgsgCode
The target epgsg code.
-
-
-
-
Package org.apache.sedona.core.spatialRddTool
-
Class org.apache.sedona.core.spatialRddTool.IndexBuilder extends Object implements Serializable
-
Serialized Fields
-
indexType
IndexType indexType
-
-
-
Class org.apache.sedona.core.spatialRddTool.StatCalculator extends Object implements Serializable
-
Serialized Fields
-
boundary
org.locationtech.jts.geom.Envelope boundary
-
count
long count
-
-
-
-
Package org.apache.sedona.core.utils
-
Class org.apache.sedona.core.utils.SedonaConf extends Object implements Serializable
-
Serialized Fields
-
autoBroadcastJoinThreshold
long autoBroadcastJoinThreshold
-
datasetBoundary
org.locationtech.jts.geom.Envelope datasetBoundary
-
DBSCANIncludeOutliers
Boolean DBSCANIncludeOutliers
-
fallbackPartitionNum
int fallbackPartitionNum
-
includeTieBreakersInKNNJoins
boolean includeTieBreakersInKNNJoins
-
indexType
IndexType indexType
-
joinApproximateTotalCount
long joinApproximateTotalCount
-
joinBuildSide
JoinBuildSide joinBuildSide
-
joinGridType
GridType joinGridType
-
joinSpartitionDominantSide
JoinSpartitionDominantSide joinSpartitionDominantSide
-
spatialJoinOptimizationMode
SpatialJoinOptimizationMode spatialJoinOptimizationMode
-
useIndex
boolean useIndex
-
-
-
-
Package org.apache.sedona.core.wrapper
-
Class org.apache.sedona.core.wrapper.UniqueGeometry extends org.locationtech.jts.geom.Geometry implements Serializable
-
-
Package org.apache.sedona.sql.datasources.osmpbf.build
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Fileformat.Blob extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
lzmaData_
proto4.ByteString lzmaData_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
oBSOLETEBzip2Data_
proto4.ByteString oBSOLETEBzip2Data_
-
raw_
proto4.ByteString raw_
-
rawSize_
int rawSize_
-
zlibData_
proto4.ByteString zlibData_
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Fileformat.BlobHeader extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
datasize_
int datasize_
-
indexdata_
proto4.ByteString indexdata_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
type_
Object type_
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.ChangeSet extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
id_
long id_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.DenseInfo extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
changeset_
proto4.Internal.LongList changeset_
-
changesetMemoizedSerializedSize
int changesetMemoizedSerializedSize
-
memoizedIsInitialized
byte memoizedIsInitialized
-
timestamp_
proto4.Internal.LongList timestamp_
-
timestampMemoizedSerializedSize
int timestampMemoizedSerializedSize
-
uid_
proto4.Internal.IntList uid_
-
uidMemoizedSerializedSize
int uidMemoizedSerializedSize
-
userSid_
proto4.Internal.IntList userSid_
-
userSidMemoizedSerializedSize
int userSidMemoizedSerializedSize
-
version_
proto4.Internal.IntList version_
-
versionMemoizedSerializedSize
int versionMemoizedSerializedSize
-
visible_
proto4.Internal.BooleanList visible_
-
visibleMemoizedSerializedSize
int visibleMemoizedSerializedSize
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.DenseNodes extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
denseinfo_
Osmformat.DenseInfo denseinfo_
-
id_
proto4.Internal.LongList id_
-
idMemoizedSerializedSize
int idMemoizedSerializedSize
-
keysVals_
proto4.Internal.IntList keysVals_
-
keysValsMemoizedSerializedSize
int keysValsMemoizedSerializedSize
-
lat_
proto4.Internal.LongList lat_
-
latMemoizedSerializedSize
int latMemoizedSerializedSize
-
lon_
proto4.Internal.LongList lon_
-
lonMemoizedSerializedSize
int lonMemoizedSerializedSize
-
memoizedIsInitialized
byte memoizedIsInitialized
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.HeaderBBox extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
bottom_
long bottom_
-
left_
long left_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
right_
long right_
-
top_
long top_
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.HeaderBlock extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bbox_
Osmformat.HeaderBBox bbox_
-
bitField0_
int bitField0_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
optionalFeatures_
proto4.LazyStringArrayList optionalFeatures_
-
osmosisReplicationBaseUrl_
Object osmosisReplicationBaseUrl_
-
osmosisReplicationSequenceNumber_
long osmosisReplicationSequenceNumber_
-
osmosisReplicationTimestamp_
long osmosisReplicationTimestamp_
-
requiredFeatures_
proto4.LazyStringArrayList requiredFeatures_
-
source_
Object source_
-
writingprogram_
Object writingprogram_
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.Info extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
changeset_
long changeset_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
timestamp_
long timestamp_
-
uid_
int uid_
-
userSid_
int userSid_
-
version_
int version_
-
visible_
boolean visible_
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.Node extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
id_
long id_
-
info_
Osmformat.Info info_
-
keys_
proto4.Internal.IntList keys_
-
keysMemoizedSerializedSize
int keysMemoizedSerializedSize
-
lat_
long lat_
-
lon_
long lon_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
vals_
proto4.Internal.IntList vals_
-
valsMemoizedSerializedSize
int valsMemoizedSerializedSize
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.PrimitiveBlock extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
dateGranularity_
int dateGranularity_
-
granularity_
int granularity_
-
latOffset_
long latOffset_
-
lonOffset_
long lonOffset_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
primitivegroup_
List<Osmformat.PrimitiveGroup> primitivegroup_
-
stringtable_
Osmformat.StringTable stringtable_
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.PrimitiveGroup extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
changesets_
List<Osmformat.ChangeSet> changesets_
-
dense_
Osmformat.DenseNodes dense_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
nodes_
List<Osmformat.Node> nodes_
-
relations_
List<Osmformat.Relation> relations_
-
ways_
List<Osmformat.Way> ways_
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.Relation extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
id_
long id_
-
info_
Osmformat.Info info_
-
keys_
proto4.Internal.IntList keys_
-
keysMemoizedSerializedSize
int keysMemoizedSerializedSize
-
memids_
proto4.Internal.LongList memids_
-
memidsMemoizedSerializedSize
int memidsMemoizedSerializedSize
-
memoizedIsInitialized
byte memoizedIsInitialized
-
rolesSid_
proto4.Internal.IntList rolesSid_
-
rolesSidMemoizedSerializedSize
int rolesSidMemoizedSerializedSize
-
types_
List<Integer> types_
-
typesMemoizedSerializedSize
int typesMemoizedSerializedSize
-
vals_
proto4.Internal.IntList vals_
-
valsMemoizedSerializedSize
int valsMemoizedSerializedSize
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.StringTable extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
memoizedIsInitialized
byte memoizedIsInitialized
-
s_
proto4.Internal.ProtobufList<proto4.ByteString> s_
-
-
Class org.apache.sedona.sql.datasources.osmpbf.build.Osmformat.Way extends proto4.GeneratedMessage implements Serializable
- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
id_
long id_
-
info_
Osmformat.Info info_
-
keys_
proto4.Internal.IntList keys_
-
keysMemoizedSerializedSize
int keysMemoizedSerializedSize
-
memoizedIsInitialized
byte memoizedIsInitialized
-
refs_
proto4.Internal.LongList refs_
-
refsMemoizedSerializedSize
int refsMemoizedSerializedSize
-
vals_
proto4.Internal.IntList vals_
-
valsMemoizedSerializedSize
int valsMemoizedSerializedSize
-
-
-
Package org.apache.sedona.viz.core
-
Class org.apache.sedona.viz.core.ColoringRule extends Object implements Serializable
-
Class org.apache.sedona.viz.core.GlobalParameter extends Object implements Serializable
-
Serialized Fields
-
colorAlpha
int colorAlpha
The color alpha. -
coloringRule
ColoringRule coloringRule
The coloring rule. -
controlColorChannel
Color controlColorChannel
The control color channel. -
datasetBoundary
org.locationtech.jts.geom.Envelope datasetBoundary
The dataset boundary. -
drawOutlineOnly
boolean drawOutlineOnly
The draw outline only. -
filterRadius
int filterRadius
The filter radius. -
maxPartitionTreeLevel
int maxPartitionTreeLevel
The max partition tree level. -
maxPixelWeight
int maxPixelWeight
The max pixel weight. -
minTreeLevel
int minTreeLevel
The min tree level. -
overwriteExistingImages
boolean overwriteExistingImages
The overwrite existing images. -
partitionIntervalX
double partitionIntervalX
The partition interval X. -
partitionIntervalY
double partitionIntervalY
The partition interval Y. -
partitionsOnSingleAxis
int partitionsOnSingleAxis
The partitions on single axis. -
photoFilter
PhotoFilter photoFilter
The photo filter. -
resolutionX
int resolutionX
The resolution X. -
resolutionY
int resolutionY
The resolution Y. -
reverseSpatialCoordinate
boolean reverseSpatialCoordinate
The reverse spatial coordinate. -
samplingFraction
double samplingFraction
The sample amount. -
useInverseRatioForControlColorChannel
boolean useInverseRatioForControlColorChannel
The use inverse ratio for control color channel. -
useUserSuppliedResolution
boolean useUserSuppliedResolution
The use user supplied resolution.
-
-
-
Class org.apache.sedona.viz.core.ImageGenerator extends Object implements Serializable
-
Class org.apache.sedona.viz.core.ImageSerializableWrapper extends Object implements Serializable
-
Serialization Methods
-
readObject
private void readObject(ObjectInputStream in) throws IOException, ClassNotFoundException
Read object.- Throws:
IOException
- Signals that an I/O exception has occurred.ClassNotFoundException
- the class not found exception
-
writeObject
private void writeObject(ObjectOutputStream out) throws IOException
Write object.- Throws:
IOException
- Signals that an I/O exception has occurred.
-
-
-
Class org.apache.sedona.viz.core.VisualizationOperator extends Object implements Serializable
-
Serialized Fields
-
blue
int blue
The blue. -
colorAlpha
int colorAlpha
The color alpha. -
colorizeOption
ColorizeOption colorizeOption
The colorize option. -
controlColorChannel
Color controlColorChannel
The control color channel. -
datasetBoundary
org.locationtech.jts.geom.Envelope datasetBoundary
The dataset boundary. -
distributedRasterColorMatrix
org.apache.spark.api.java.JavaPairRDD<Pixel,Integer> distributedRasterColorMatrix
The distributed raster color matrix. -
distributedRasterCountMatrix
org.apache.spark.api.java.JavaPairRDD<Pixel,Double> distributedRasterCountMatrix
The distributed raster count matrix. -
distributedRasterImage
org.apache.spark.api.java.JavaPairRDD<Integer,ImageSerializableWrapper> distributedRasterImage
The distributed raster image. -
distributedVectorColors
org.apache.spark.api.java.JavaPairRDD<Object,Color> distributedVectorColors
The distributed vector colors. -
distributedVectorImage
org.apache.spark.api.java.JavaPairRDD<Integer,String> distributedVectorImage
The distributed vector image. -
distributedVectorObjects
org.apache.spark.api.java.JavaPairRDD<Object,Double> distributedVectorObjects
The distributed vector objects. -
green
int green
The green. -
hasBeenSpatialPartitioned
boolean hasBeenSpatialPartitioned
The has been spatial partitioned. -
maxPixelCount
Double maxPixelCount
The max pixel count. -
onlyDrawOutline
boolean onlyDrawOutline
The only draw outline. -
parallelPhotoFilter
boolean parallelPhotoFilter
The parallel photo filter. -
parallelRenderImage
boolean parallelRenderImage
The parallel render image. -
partitionIntervalX
int partitionIntervalX
The partition interval X. -
partitionIntervalY
int partitionIntervalY
The partition interval Y. -
partitionX
int partitionX
The partition X. -
partitionY
int partitionY
The partition Y. -
PhotoFilterConvolutionMatrix
Double[][] PhotoFilterConvolutionMatrix
The Photo filter convolution matrix. -
photoFilterRadius
int photoFilterRadius
The photo filter radius. -
rasterImage
BufferedImage rasterImage
The raster image. -
red
int red
The red. -
resolutionX
int resolutionX
The resolution X. -
resolutionY
int resolutionY
The resolution Y. -
reverseSpatialCoordinate
boolean reverseSpatialCoordinate
The reverse spatial coordinate. -
useInverseRatioForControlColorChannel
boolean useInverseRatioForControlColorChannel
The use inverse ratio for control color channel. -
vectorImage
List<String> vectorImage
The vector image.
-
-
-
Class org.apache.sedona.viz.core.VisualizationPartitioner extends org.apache.spark.Partitioner implements Serializable
-
Serialized Fields
-
partitionIntervalX
int partitionIntervalX
The partition interval Y. -
partitionIntervalY
int partitionIntervalY
The partition interval Y. -
partitionX
int partitionX
The partition interval Y. -
partitionY
int partitionY
The partition interval Y. -
resolutionX
int resolutionX
The partition interval Y. -
resolutionY
int resolutionY
The partition interval Y.
-
-
-
-
Package org.apache.sedona.viz.extension.coloringRule
-
Class org.apache.sedona.viz.extension.coloringRule.LinearFunction extends ColoringRule implements Serializable
-
Class org.apache.sedona.viz.extension.coloringRule.PiecewiseFunction extends ColoringRule implements Serializable
-
-
Package org.apache.sedona.viz.extension.imageGenerator
-
Class org.apache.sedona.viz.extension.imageGenerator.SedonaVizImageGenerator extends ImageGenerator implements Serializable
-
-
Package org.apache.sedona.viz.extension.visualizationEffect
-
Class org.apache.sedona.viz.extension.visualizationEffect.ChoroplethMap extends VisualizationOperator implements Serializable
-
Class org.apache.sedona.viz.extension.visualizationEffect.HeatMap extends VisualizationOperator implements Serializable
-
Class org.apache.sedona.viz.extension.visualizationEffect.ScatterPlot extends VisualizationOperator implements Serializable
-
-
Package org.apache.sedona.viz.utils
-
Class org.apache.sedona.viz.utils.Pixel extends org.locationtech.jts.geom.Point implements Serializable
-
Serialized Fields
-
currentPartitionId
int currentPartitionId
The current partition id. -
isDuplicate
boolean isDuplicate
The is duplicate. -
resolutionX
int resolutionX
The resolution X. -
resolutionY
int resolutionY
The resolution Y.
-
-
-
Class org.apache.sedona.viz.utils.RasterizationUtils extends Object implements Serializable
-