Package | Description |
---|---|
oracle.spatial.hadoop.vector.data.cmd |
Parsers for parsing data set parameters from command line interface.
|
oracle.spatial.hadoop.vector.mapred.input |
Input format and record readers implementations.
|
oracle.spatial.hadoop.vector.mapred.job |
Contains job drivers.
|
oracle.spatial.hadoop.vector.mapreduce.input |
Input format and record readers implementations (Hadoop new API).
|
oracle.spatial.hadoop.vector.partition |
Classes used to perform spatial partitioning
|
oracle.spatial.hadoop.vector.util |
Contains utility classes used by other components of this API.
|
oracle.spatial.spark.vector.index |
Base definitions and classes for distributed spatial indexes and spatial partitioning algorithms used with spatial RDDs.
|
oracle.spatial.spark.vector.index.quadtree |
QuadTree implementations of DistributedSpatialIndex and SpatialPartitioning
|
oracle.spatial.spark.vector.rdd |
Spatial RDD definitions
|
oracle.spatial.spark.vector.streaming.dstream |
Spatial DStream Defintions
|
Modifier and Type | Method and Description |
---|---|
static void |
CmdArgsParserUtils.getSpatialOperationConfigCmdArgs(SpatialOperationConfig soc, java.util.Map<java.lang.String,java.lang.Object> cmdArgs, boolean includeSpatialconfig)
Converts the properties of the given
SpatialOperationConfig instance of command line arguments |
Modifier and Type | Method and Description |
---|---|
static SpatialOperationConfig |
SpatialIndexInputFormat.getFilterSpatialOperationConfig(Configuration conf)
Gets the
SpatialOperationConfig used to filter records for the given job's configuration. |
static SpatialOperationConfig |
SpatialIndexInputFormat.getFilterSpatialOperationConfig(java.lang.Integer dataSetId, Configuration conf)
Gets the
SpatialOperationConfig used to filter records for the given job's configuration and data set. |
Modifier and Type | Method and Description |
---|---|
static void |
SpatialIndexInputFormat.setFilterSpatialOperationConfig(SpatialOperationConfig spatialOpConf, Configuration conf)
Sets an input-format specific
SpatialOperationConfig . |
static void |
SpatialIndexInputFormat.setFilterSpatialOperationConfig(SpatialOperationConfig spatialOpConf, java.lang.Integer dataSetId, Configuration conf)
Sets an input-format-dataset specific
SpatialOperationConfig . |
Constructor and Description |
---|
SpatialFilterRecordReader(JobConf conf, <any> internalReader, RecordInfoProvider<K,V> riProvider, SpatialOperationConfig spatialOpConf)
Creates a new instance and sets it to use the given internal reader.
|
Modifier and Type | Method and Description |
---|---|
SpatialOperationConfig |
Categorization.getSpatialOperationConfig()
Gets the configuration of the spatial operation to be performed
|
SpatialOperationConfig |
SpatialFilter.getSpatialOperationConfig()
Gets the configuration of the spatial operation to be performed to filter the data
|
SpatialOperationConfig |
SpatialJoin.getSpatialOperationConfig()
Gets the spatial operation configuration used to perform the spatial join
|
Modifier and Type | Method and Description |
---|---|
void |
Categorization.setSpatialOperationConfig(SpatialOperationConfig spatialOperationConfig)
Sets the configuration of the spatial operation to be performed.
|
void |
SpatialFilter.setSpatialOperationConfig(SpatialOperationConfig spatialOperationConfig)
Sets the configuration of the spatial operation to be performed to filter the data.
|
void |
SpatialJoin.setSpatialOperationConfig(SpatialOperationConfig spatialOperationConfig)
Sets the spatial operation configuration used to perform the spatial join
|
Modifier and Type | Method and Description |
---|---|
static SpatialOperationConfig |
SpatialIndexInputFormat.getFilterSpatialOperationConfig(Configuration conf)
Gets the
SpatialOperationConfig used to filter records for the given job's configuration. |
static SpatialOperationConfig |
SpatialIndexInputFormat.getFilterSpatialOperationConfig(java.lang.Integer dataSetId, Configuration conf)
Gets the
SpatialOperationConfig used to filter records for the given job's configuration and data set. |
SpatialOperationConfig |
SpatialFilterInputFormat.getSpatialOperationConfig() |
Modifier and Type | Method and Description |
---|---|
static void |
SpatialIndexInputFormat.setFilterSpatialOperationConfig(SpatialOperationConfig spatialOpConf, Configuration conf)
Sets an input-format specific
SpatialOperationConfig . |
static void |
SpatialIndexInputFormat.setFilterSpatialOperationConfig(SpatialOperationConfig spatialOpConf, java.lang.Integer dataSetId, Configuration conf)
Sets an input-format-dataset specific
SpatialOperationConfig . |
Modifier and Type | Method and Description |
---|---|
static RTree |
PartitioningUtils.indexPartitions(PartitioningResult pr, SpatialOperationConfig spatialOpConf, Configuration conf)
Takes a partitioning result and returns all contained partitions indexed in an r-tree
|
Modifier and Type | Method and Description |
---|---|
static SpatialOperationConfig |
SpatialUtils.createSpatialOperationConfig(JobConf conf)
Deprecated.
Use
SpatialOperationConfig .load() instead. Creates a SpatialOperationConfig out of the job configuration |
Modifier and Type | Method and Description |
---|---|
static boolean |
SpatialUtils.performFilter(JGeometry geom, SpatialOperationConfig spatialOpConf)
Performs the spatial operation described by the
SpatialOperationConfig parameter. |
Constructor and Description |
---|
SpatialOperationConfig(SpatialOperationConfig spatialOpConf)
Creates a new instance copied from another one
|
Modifier and Type | Method and Description |
---|---|
abstract SpatialJavaRDD<T> |
DistributedSpatialIndex.filter(<any> f, SpatialOperationConfig spatialOpConf)
Returns a new spatial RDD containing only the elements that satisfy both, the filtering function and the spatial operation
|
abstract <R> <any> |
DistributedSpatialIndex.flatMap(<any> f, SpatialOperationConfig spatialOpConf)
Returns a new RDD by first spatially filtering the RDD elements using the spatial operation given by spatialOpConf, then a function is applied to all the remaining elements.
|
abstract <T2,R> <any> |
DistributedSpatialIndex.join(SpatialJavaRDD<T2> rdd2, <any> f, SpatialOperationConfig spatialOpConf)
Deprecated.
use spatialJoin Joins records from the current index with records of the passed spatial RDD. The records are joined based on a spatial relationship defined by the given instance of
SpatialOperationConfig . The type of the resulting records is defined by the user-provided lambda function. For each pair of joined records, the lambda function should return one result. If it is desired to return more than one results per pair of joined records or it is desired to exclude a pair from the result, use DistributedSpatialIndex#spatialJoin(SpatialJavaRDD, Function2, SpatialOperationConfig) |
abstract java.util.List<<any>> |
DistributedSpatialIndex.nearestNeighbors(<any> f, int k, SpatialOperationConfig spatialOpConf)
Returns the k elements from the RDD which are closest to the query window defined in spatialOpConf
|
abstract SpatialJavaRDD<T> |
DistributedSpatialIndex.primaryFilter(<any> f, SpatialOperationConfig spatialOpConf)
Returns a new spatial RDD containing the elements which satisfy the filtering lambda function an which are likely to interact with the query window defined in the passes spatial operation configuration.
|
abstract <T2,R> <any> |
DistributedSpatialIndex.spatialJoin(DistributedSpatialIndex<T2> index2, <any> f, SpatialOperationConfig spatialOpConf)
Joins records from the current index with records of the passed spatial index.
|
abstract <T2,R> <any> |
DistributedSpatialIndex.spatialJoin(SpatialJavaRDD<T2> rdd2, <any> f, SpatialOperationConfig spatialOpConf)
Joins records from the current index with records of the passed spatial RDD.
|
Modifier and Type | Method and Description |
---|---|
SpatialJavaRDD<T> |
QuadTreeDistIndex.filter(<any> filterFunc, SpatialOperationConfig spatialOpConf) |
<R> <any> |
QuadTreeDistIndex.flatMap(<any> f, SpatialOperationConfig spatialOpConf) |
<T2,R> <any> |
QuadTreeDistIndex.join(SpatialJavaRDD<T2> rdd2, <any> f, SpatialOperationConfig spatialOpConf) |
java.util.List<<any>> |
QuadTreeDistIndex.nearestNeighbors(<any> f, int k, SpatialOperationConfig spatialOpConf) |
SpatialJavaRDD<T> |
QuadTreeDistIndex.primaryFilter(<any> filterFunc, SpatialOperationConfig spatialOpConf) |
<T2,R> <any> |
QuadTreeDistIndex.spatialJoin(DistributedSpatialIndex<T2> index2, <any> f, SpatialOperationConfig spatialOpConf) |
<T2,R> <any> |
QuadTreeDistIndex.spatialJoin(SpatialJavaRDD<T2> rdd2, <any> f, SpatialOperationConfig spatialOpConf) |
Modifier and Type | Method and Description |
---|---|
SpatialTransformationContext<<any>> |
SpatialJavaPairRDD.createSpatialTransformationContext(SpatialOperationConfig spatialOperationConf)
Creates an instance of
SpatialTransformationContext associated to the given SpatialOperationConfig . |
SpatialTransformationContext<T> |
SpatialJavaRDD.createSpatialTransformationContext(SpatialOperationConfig spatialOperationConf)
Creates an instance of
SpatialTransformationContext associated to the given SpatialOperationConfig . |
SpatialJavaPairRDD<K,V> |
SpatialJavaPairRDD.filter(<any> f, SpatialOperationConfig spatialOpConf)
Returns a new spatial RDD containing only the elements that satisfy both, the filtering lambda function and the spatial operation
|
SpatialJavaRDD<T> |
SpatialJavaRDD.filter(<any> f, SpatialOperationConfig spatialOpConf)
Returns a new spatial RDD containing only the elements that satisfy both, the filtering function and the spatial operation
|
boolean |
SpatialTransformationContext.filter(T record, SpatialOperationConfig spatialOpConf)
Returns if the given record passes the spatial filter specified by the given
SpatialOperationConfig . |
<R> <any> |
SpatialJavaPairRDD.flatMap(<any> f, SpatialOperationConfig spatialOpConf)
Returns a new RDD by first spatially filtering the RDD elements using the spatial operation given by spatialOpConf, a function is applied to all the remaining elements.
|
<R> <any> |
SpatialJavaRDD.flatMap(<any> m, SpatialOperationConfig spatialOpConf)
Returns a new RDD by first spatially filtering the RDD elements using the spatial operation given by spatialOpConf, then a function is applied to all the remaining elements.
|
static boolean |
SpatialTransformationContext.isPreSpatialFiltering(SpatialOperationConfig spatialOpConf) |
java.util.List<<any>> |
SpatialJavaPairRDD.nearestNeighbors(<any> f, int k, SpatialOperationConfig spatialOpConf) |
java.util.List<<any>> |
SpatialJavaRDD.nearestNeighbors(<any> f, int k, SpatialOperationConfig spatialOpConf)
Returns the k elements which are closest to a given query window defined in the give spatial operation configuration
|
Constructor and Description |
---|
KNNPairFlatMapFunction(<any> f, int k, SpatialOperationConfig spatialOpConf, SpatialTransformationContext<T> stCtx) |
SpatialTransformationContext(SparkRecordInfoProvider<T> recordInfoProvider, SpatialOperationConfig spatialOpConf)
Creates a new instance which uses the given
SparkRecordInfoProvider and can filter using the specified SpatialOperationConfig |
Modifier and Type | Method and Description |
---|---|
SpatialTransformationContext<T> |
SpatialJavaDStream.createSpatialTransformationContext(SpatialOperationConfig spatialOperationConf)
Creates an instance of
SpatialTransformationContext associated to the given SpatialOperationConfig . |
SpatialTransformationContext<<any>> |
SpatialJavaPairDStream.createSpatialTransformationContext(SpatialOperationConfig spatialOperationConf)
Creates an instance of
SpatialTransformationContext associated to the given SpatialOperationConfig . |
SpatialJavaDStream<T> |
SpatialJavaDStream.filter(<any> f, SpatialOperationConfig spatialOpConf)
Performs a filter transformation.
|
SpatialJavaPairDStream<K,V> |
SpatialJavaPairDStream.filter(<any> f, SpatialOperationConfig spatialOpConf)
Performs a filter transformation.
|
<U> <any> |
SpatialJavaDStream.flatMap(<any> f, SpatialOperationConfig spatialOpConf)
Returns a new DStream by first spatially filtering the stream elements using the spatial operation given by spatialOpConf, then a flattening function is applied to all the remaining elements.
|
<U> <any> |
SpatialJavaPairDStream.flatMap(<any> f, SpatialOperationConfig spatialOpConf)
Returns a new DStream by first spatially filtering the stream elements using the spatial operation given by spatialOpConf, then a flattening function is applied to all the remaining elements.
|
<any> |
SpatialJavaDStream.nearestNeighbors(<any> f, int k, SpatialOperationConfig spatialOpConf)
Returns a DStream containing one single element with the k elements which are closest to the given query window
|
<any> |
SpatialJavaPairDStream.nearestNeighbors(<any> f, int k, SpatialOperationConfig spatialOpConf)
Returns a DStream containing one single element with the k elements which are closest to the given query window
|
Copyright © 2017 Oracle and/or its affiliates. All Rights Reserved.