Skip navigation links
Oracle Big Data Spatial and Graph
Vector Analysis Java API Reference
Release 3 (3.0) E74607-08
A B C D E F G H I J K L M N O P Q R S T U V W 

A

abortJob(JobContext, State) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
abortTask(TaskAttemptContext, Path) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
AbstractCompositeInputFormat<K,V> - Interface in oracle.spatial.hadoop.vector.mapred.input
 
AbstractInputDataSet - Interface in oracle.spatial.hadoop.vector.data
Base interface to represent an input data set.
AbstractSpatialHierarchicalMapper<K,V,W> - Class in oracle.spatial.hadoop.vector.mapred
Base mapper class used to catalog records into hierarchy layers.
AbstractSpatialHierarchicalMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
AbstractSpatialHierarchicalMapper<K,V,W> - Class in oracle.spatial.hadoop.vector.mapreduce
Base mapper class used to catalog records into hierarchy layers.
AbstractSpatialHierarchicalMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
accept(Path) - Method in class oracle.spatial.hadoop.vector.util.FileNamePathFilter
 
acceptsCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.FileInputDataSetCmdArgsParser
 
acceptsCmdArgs(CmdArgsParser, Configuration) - Method in interface oracle.spatial.hadoop.vector.data.cmd.InputDataSetCmdArgsParser
Returns true if the implementation can create an instance of AbstractInputDataSet given the command line arguments encapsulated by argsp
acceptsCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.MultiInputDataSetCmdArgsParser
 
acceptsCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.NoSQLInputCmdArgsParser
 
acceptsCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.SimpleInputDataSetCmdArgsParser
 
acceptsCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.SpatialIndexInputDataSetCmdArgsParser
 
acceptsDataSet(D) - Method in interface oracle.spatial.hadoop.vector.data.conf.DataSetConfigurator
Returns true if the current configurator can configure the given data set
acceptsDataSet(AbstractInputDataSet) - Method in class oracle.spatial.hadoop.vector.data.conf.FileInputDataSetConfigurator
 
acceptsDataSet(AbstractInputDataSet) - Method in class oracle.spatial.hadoop.vector.data.conf.MultiInputDataSetConfigurator
 
acceptsDataSet(AbstractInputDataSet) - Method in class oracle.spatial.hadoop.vector.data.conf.NoSQLInputDataSetConfigurator
 
acceptsDataSet(AbstractInputDataSet) - Method in class oracle.spatial.hadoop.vector.data.conf.SimpleInputDataSetConfigurator
 
acceptsDataSet(AbstractInputDataSet) - Method in class oracle.spatial.hadoop.vector.data.conf.SpatialIndexInputDataSetConfigurator
 
AdapterInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
This input format works as an adapter for subclasses of the new API' org.apache.hadoop.mapreduce.lib.input.FileInputFormat
AdapterInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.AdapterInputFormat
 
add(double[]) - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfo
Adds a point to the partition
addCachedArchive(Path, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
Adds an archive to the distributed cache
addCachedArchive(Path, String, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
addCachedArchive(Path, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
Adds an archive to the distributed cache
addCachedArchive(Path, String, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
addCachedFile(Path, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
Adds a file to the distributed cache
addCachedFile(Path, String, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
addCachedFile(Path, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
Adds a file to the distributed cache
addCachedFile(Path, String, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
addClusterMember(RecordInfo, double[]) - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.CriterionFunction
Adds the data and point of an individual cluster member.
addClusterMember(RecordInfo, double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.EuclideanDistanceCriterionFunction
 
addClusterMember(RecordInfo, double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.SquaredErrorCriterionFunction
 
addExtraFields(Configuration) - Static method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
Returns true if geojson's properties will be added as extra fields in the index, false otherwise
addExtraFields(Configuration) - Static method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
Returns true if shapefile's attributes will be added as extra fields in the index, false otherwise
addField(String, Object) - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Adds a field to the record info
addInputDataSet(AbstractInputDataSet) - Method in class oracle.spatial.hadoop.vector.data.MultiInputDataSet
Adds an input data set
addInputDataSet(InputDataSet) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
addInputDataSets(List<AbstractInputDataSet>) - Method in class oracle.spatial.hadoop.vector.data.MultiInputDataSet
Adds all the data sets from the list
addLevel(int, String, String, String) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
Adds a level to the hierarchy.
addMbr(double[], double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
addMemberPoint(double[]) - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.ClusterShapeGenerator
Adds the point of a cluster member.
addMemberPoint(double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ConvexHullClusterShapeGenerator
 
addMemberPoint(double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.DummyClusterShapeGenerator
 
addParam(String, Number) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
addParsers(List<InputDataSetCmdArgsParser>) - Method in class oracle.spatial.hadoop.vector.data.cmd.DynamicInputDataSetCmdArgsParserHandler
Adds all the parsers at the end of the parsers chain
addPath(Path) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation
Deprecated.
 
addQueryRecord(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSQueryRequester
 
addQueryRecord(String) - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSQueryRequester
Adds a text record to the query
addQueryRecord(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSQueryRequester
 
addSRIDToGeoJSON(String, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Returns a GeoJSON string made from the given json string and the given SRID
addSRIDToGeoJSON(ObjectMapper, JsonNode, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
 
addTargetEntries(String[]) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Adds an array of keys from NoSQL entries (key-value pairs) to be included in a RecordInfo passed as a value to a job's mapper.
addTargetEntry(String, Class<? extends NoSQLEntryProcessor>) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Adds a key from a NoSQL entry (key-value pair )to be included in a RecordInfo passed as a value to a job's mapper.
anyInteract(JGeometry, JGeometry, Boolean, Double) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
Performs an anyInteract test between two geometries
append(String) - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
appendConfigurator(InputDataSetConfigurator) - Method in class oracle.spatial.hadoop.vector.data.conf.DynamicInputDataSetConfiguratorHandler
Adds a configurator to the end of the configurators chain.
appendConfigurators(List<InputDataSetConfigurator>) - Method in class oracle.spatial.hadoop.vector.data.conf.DynamicInputDataSetConfiguratorHandler
Adds all the configurators to the end of the configurators chain.
appendNameValue(String, String) - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
appendOptionalNameValue(String, String) - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
appendOR() - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
appendParser(InputDataSetCmdArgsParser) - Method in class oracle.spatial.hadoop.vector.data.cmd.DynamicInputDataSetCmdArgsParserHandler
Adds a parser at the end of the parsers chain
apply(T, U, V) - Method in interface oracle.spatial.spark.vector.sql.udf.util.TriFunction
Call method for three parameters UDFs
ARG_BATCH_SIZE - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the batch size property
ARG_CLUSTERS_POINTS - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_CONSISTENCY - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the consistency property
ARG_CRIT_FUN_CLASS - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_DEFAULT_ENTRY_PROCESSOR - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the default NoSQLEntryProcessor implementation
ARG_DELETE_CLUSTER_FILES - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_DEPTH - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the depth property
ARG_ENTRY_GROUPER - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the entry grouper class property
ARG_FORMATTER_CLASS - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the formatter class property
ARG_K - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_KVSTORE_HOSTS - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the list of NoSQL service hosts
ARG_KVSTORE_NAME - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for a KV store name
ARG_KVSTORE_SECURITY - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the security properties file property
ARG_MAX_ITERATIONS - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_MAX_MEMBER_DISTANCE - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_PARENT_KEY - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the parent key property
ARG_PARTITION_READER - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the partition reader property
ARG_RESULT_ENTRIES - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the list of result entries property
ARG_SECURITY_PROPS - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the security properties file property
ARG_SHAPE_GEN_CLASS - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_SUB_RANGE - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the sub range property
ARG_TIME_OUT - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the time out property
ARG_TIME_OUT_UNIT - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Command line argument for the time out unit
asComplexValue(Map<String, Object>, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
asFieldName(String, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
asGeometry(JGeometry, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
asGeometry(JGeometry) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
asNameValue(String, Object, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
asNameValueList(Map<String, Object>, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
asSimpleValue(Object, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
asText(String, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 

B

BaseCompositeInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
 
BaseCompositeInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
BaseJob<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
Defines the basic parameters and validations for vector jobs
BaseJob() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
BaseWrapperInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
BaseWrapperInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
BasicSparkRecordInfoProvider<V> - Class in oracle.spatial.spark.vector
Abstract class which implements the SRID setter and getter methods from SparkRecordInfoProvider
BasicSparkRecordInfoProvider() - Constructor for class oracle.spatial.spark.vector.BasicSparkRecordInfoProvider
 
BasicSparkRecordInfoProvider(int) - Constructor for class oracle.spatial.spark.vector.BasicSparkRecordInfoProvider
Creates a new instance with the given SRID
beforeClusterCenterUpdated(int, double[], double, long) - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.CriterionFunction
Sets the current cluster and its state before the cluster point is updated.
beforeClusterCenterUpdated(int, double[], double, long) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.EuclideanDistanceCriterionFunction
 
beforeClusterCenterUpdated(int, double[], double, long) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.SquaredErrorCriterionFunction
 
BinMapper<K,V> - Class in oracle.spatial.hadoop.vector.binning.mapred
A subclass of Mapper that maps input records to bins.
BinMapper() - Constructor for class oracle.spatial.hadoop.vector.binning.mapred.BinMapper
 
BinMapper<K,V> - Class in oracle.spatial.hadoop.vector.binning.mapreduce
A subclass of Mapper that maps input records to bins.
BinMapper() - Constructor for class oracle.spatial.hadoop.vector.binning.mapreduce.BinMapper
 
Binning<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
This class can be used to run or configure a job for performing spatial binning.
Binning() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.Binning
 
Binning<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.job
 
Binning() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.Binning
 
BinningAlg - Interface in oracle.spatial.hadoop.vector.binning
Represents an algorithm to perform spatial binning.
BinningCommonMapper<K,V> - Class in oracle.spatial.hadoop.vector.binning
Maps input records to bins.
BinningCommonMapper() - Constructor for class oracle.spatial.hadoop.vector.binning.BinningCommonMapper
 
BinningCommonReducer - Class in oracle.spatial.hadoop.vector.binning
Processes reduce groups containing records mapped to a bin.
BinningCommonReducer() - Constructor for class oracle.spatial.hadoop.vector.binning.BinningCommonReducer
 
BinningConfig - Class in oracle.spatial.hadoop.vector.binning
Holds the configuration for creating spatial binning.
BinningConfig() - Constructor for class oracle.spatial.hadoop.vector.binning.BinningConfig
 
BinningConfig.BinShape - Enum in oracle.spatial.hadoop.vector.binning
The shape of the cells to be generated
BinningFactory - Class in oracle.spatial.hadoop.vector.binning
Class used to create a BinningAlg implementation based on the configuration
BinningFactory() - Constructor for class oracle.spatial.hadoop.vector.binning.BinningFactory
 
BinReducer - Class in oracle.spatial.hadoop.vector.binning.mapred
A subclass of Reducer that collects all the records assigned to a bin.
BinReducer() - Constructor for class oracle.spatial.hadoop.vector.binning.mapred.BinReducer
 
BinReducer - Class in oracle.spatial.hadoop.vector.binning.mapreduce
A subclass of Reducer that collects all the records assigned to a bin.
BinReducer() - Constructor for class oracle.spatial.hadoop.vector.binning.mapreduce.BinReducer
 
BinUtils - Class in oracle.spatial.hadoop.vector.binning
Contains helper methods for spatial binning
BinUtils() - Constructor for class oracle.spatial.hadoop.vector.binning.BinUtils
 
BOUNDARIES - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
The dimensions boundaries of the spatial data.
BUFFER_ARCT - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The arc tolerance for geodetic arc densification.
BUFFER_IFLAT - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The Flattening from CS parameters.
BUFFER_SMA - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The Semi Major Axis for the Datum used in the CS of the input.
BUFFER_WIDTH - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The buffer width used in buffering operations
BufferMapper - Class in oracle.spatial.hadoop.vector.mapred
A mapper implementation that generates a buffer for each record containing a geometry.
BufferMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.BufferMapper
 
buildClustersFilePath(Path, int) - Static method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Gets the path where the results of the given iteration can be stored
buildGeometry(String) - Static method in class oracle.spatial.spark.vector.sql.udf.util.SparkUDFUtils
Builds the jGeometry for the geojson

C

cache() - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Persist the index' internal RDD with the default storage level
cache() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
calculateNumReduceTasks(Path, Configuration) - Static method in class oracle.spatial.hadoop.vector.partition.PartitioningUtils
Calculates how many reduce tasks are needed to process the partitions defined in a partitioning result file
calculateNumReduceTasks(PartitioningResult) - Static method in class oracle.spatial.hadoop.vector.partition.PartitioningUtils
Calculates how many reduce tasks are needed to process the partitions defined in a partitioning result file
call(Iterator<T>) - Method in class oracle.spatial.spark.vector.rdd.KNNPairFlatMapFunction
 
call(String, String, BigDecimal) - Method in class oracle.spatial.spark.vector.sql.udf.function.STAnyInteract
Execution call for AnyInteract UDF
call(String, BigDecimal) - Method in class oracle.spatial.spark.vector.sql.udf.function.STArea
Execution call for Area UDF
call(String) - Method in class oracle.spatial.spark.vector.sql.udf.function.STAsWKB
Execution call for AsWKB UDF
call(String) - Method in class oracle.spatial.spark.vector.sql.udf.function.STAsWKT
Execution call for AsWKT UDF
call(String, Integer, BigDecimal) - Method in class oracle.spatial.spark.vector.sql.udf.function.STBuffer
Execution call for Buffer UDF
call(String, String, BigDecimal) - Method in class oracle.spatial.spark.vector.sql.udf.function.STContains
Execution call for Contains UDF
call(String) - Method in class oracle.spatial.spark.vector.sql.udf.function.STConvexHull
Execution call for ConvexHull UDF
call(String, String, BigDecimal) - Method in class oracle.spatial.spark.vector.sql.udf.function.STDistance
Execution call for Distance UDF
call(String) - Method in class oracle.spatial.spark.vector.sql.udf.function.STEnvelope
Execution call for Envelope UDF
call(String, String, BigDecimal) - Method in class oracle.spatial.spark.vector.sql.udf.function.STInside
Execution call for Inside UDF
call(String, BigDecimal) - Method in class oracle.spatial.spark.vector.sql.udf.function.STLength
Execution call for Length UDF
call(String, Integer) - Method in class oracle.spatial.spark.vector.sql.udf.function.STSimplify
Execution call for Simplify UDF
call(String, Integer) - Method in class oracle.spatial.spark.vector.sql.udf.function.STSimplifyVW
Execution call for SimplifyVW UDF
call(String, BigDecimal) - Method in class oracle.spatial.spark.vector.sql.udf.function.STVolume
Execution call for Volume UDF
call(T, Integer) - Method in class oracle.spatial.spark.vector.sql.udf.types.STGeometry
Function call to create geometries in geojson format
call(T) - Method in class oracle.spatial.spark.vector.util.FlatMapFunctionAdapter
 
call(<any>, T) - Static method in class oracle.spatial.spark.vector.util.FlatMapFunctionAdapter
 
Categorization<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
This class can be used to run or configure a job for categorizing records of an input dataset into features of a hierarchical dataset.
Categorization() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.Categorization
 
Categorization<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.job
This class can be used to run or configure a job for categorizing records of an input dataset into features of a hierarchical dataset.
Categorization() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.Categorization
 
checkOutputSpecs(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
 
cleanupJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
clear() - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.ClusterShapeGenerator
Clears the current status.
clear() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ConvexHullClusterShapeGenerator
 
clear() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.DummyClusterShapeGenerator
 
clear() - Method in class oracle.spatial.hadoop.vector.data.cmd.DynamicInputDataSetCmdArgsParserHandler
Removes all the parsers from the parsers chain
clear() - Method in class oracle.spatial.hadoop.vector.data.conf.DynamicInputDataSetConfiguratorHandler
Removes all the configurators from the configurators chain
clear() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSQueryRequester
 
clear() - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSQueryRequester
Clears the current query
clear() - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSQueryRequester
 
clear() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Clears all the information held by the current instance.
clear() - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Removes all the information from the record info.
clearFields() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Clears the extra fields (names and values)
clearFields() - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Removes all the fields from the record info
clearInputDataSets() - Method in class oracle.spatial.hadoop.vector.data.MultiInputDataSet
Removes all the input data set from the current container
close() - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyDataIndexReader
Closes the reader
close() - Method in class oracle.spatial.hadoop.vector.mapred.HierarchicalCountReducer
 
close() - Method in class oracle.spatial.hadoop.vector.mapred.input.InputSplitInputFormat.InputSplitRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultiRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.mapred.SpatialIndexingMapper
 
close() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileRecordReaderAdapter
 
close() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.InputSplitInputFormat.InputSplitRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileRecordReader
 
close() - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
closeGroup() - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
closeNameComplexValue() - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
closeNestedBlock() - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
ClusterCenterReducer - Class in oracle.spatial.hadoop.vector.cluster.kmeans.mapred
A subclass of Reducer that updates a cluster center based on its members locations, determines if the cluster center converges and emits the updated cluster information.
ClusterCenterReducer() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.ClusterCenterReducer
 
clusterCenterUpdated(double[]) - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.CriterionFunction
Sets the updated cluster center point
clusterCenterUpdated(double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.EuclideanDistanceCriterionFunction
 
clusterCenterUpdated(double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.SquaredErrorCriterionFunction
 
ClusterInfo - Class in oracle.spatial.hadoop.vector.cluster.kmeans
Writable class that contains information of a single cluster.
ClusterInfo() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Creates a new instance
ClusterInfo(ClusterInfo) - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Creates a new instanced with the same information than another ClusterInfo
ClusterMembershipMapper<K,V> - Class in oracle.spatial.hadoop.vector.cluster.kmeans.mapred
A subclass of Mapper that maps each input record to its closest cluster center.
Emitted key and value are a ClusterInfo instance containing the cluster information and a RecordInfo instance containing the information of the record mapped to the cluster.
ClusterMembershipMapper() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.ClusterMembershipMapper
 
CLUSTERS_FILE_PREFIX - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
The file name prefix of the intermediate clusters file generated between iterations
ClusterShapeGenerator - Interface in oracle.spatial.hadoop.vector.cluster.kmeans
Component used to generate a cluster shape in the reduce phase when the cluster center is updated.
CmdArgs - Class in oracle.spatial.hadoop.vector.util
Contains constants for some common command line arguments
CmdArgs() - Constructor for class oracle.spatial.hadoop.vector.util.CmdArgs
 
CmdArgsParser - Class in oracle.spatial.hadoop.vector.util
A command line input parser used internally by the vector API
CmdArgsParser(String[]) - Constructor for class oracle.spatial.hadoop.vector.util.CmdArgsParser
Creates a new instance with the given arguments
CmdArgsParserUtils - Class in oracle.spatial.hadoop.vector.data.cmd
Contains utility methods for parsing command line parameters for input data sets
CmdArgsParserUtils() - Constructor for class oracle.spatial.hadoop.vector.data.cmd.CmdArgsParserUtils
 
CmdOptionsBuilder - Class in oracle.spatial.hadoop.vector.data.cmd
Utility class used internally to generate command line argument descriptions.
CmdOptionsBuilder() - Constructor for class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.join.mapred.JoinOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.join.mapreduce.JoinOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapred.output.MergeFileOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapred.output.MergeJsonFileOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapred.output.MultipleJsonOutputMergeOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapred.output.MultipleOutputMergeOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapred.output.SpatialIndexOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.MergeFileOutputCommiter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.MergeJsonFileOutputCommiter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.MultipleJsonOutputMergeOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.MultipleOutputMergeOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.SpatialIndexOutputCommitter
 
commitJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
commitTask(TaskAttemptContext, Path) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
compare(WritableComparable, WritableComparable) - Method in class oracle.spatial.hadoop.vector.join.JoinGroupGroupComparator
 
compare(WritableComparable, WritableComparable) - Method in class oracle.spatial.hadoop.vector.join.JoinGroupKeyComparator
 
compare(LongWritable, LongWritable) - Static method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
 
compare(WritableComparable, WritableComparable) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroupGroupComparator
 
compare(WritableComparable, WritableComparable) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroupKeyComparator
 
compareTo(JoinGroupWritable) - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
 
compareTo(HilbertValueGroup) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
 
compareTo(PartitionInfoWritable) - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfoWritable
 
CompositeInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
Abstract InputFormat which uses another InputFormat (internalInputFormat) to read data and allows adding additional functionality such as filtering the data.
CompositeInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
 
compute2DPolygonCentroid(double[], double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
compute2DPolygonCentroid(double[], int) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
CONF_AGGR_FIELDS - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: a comma separated list of numeric field values to be aggregated.
CONF_BATCH_SIZE - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the batch size
CONF_CELL_HEIGHT - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: The height of the cells as a double value
CONF_CELL_SHAPE - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: the shape of the cells.
CONF_CELL_WIDTH - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: The width of the cells as a double value
CONF_CLUSTERS_FILE - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Job configuration: the name of the file that will contain the clusters information between iterations
CONF_CONSISTENCY - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the consistency
CONF_CRIT_FUN_CLASS - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Job configuration: the CriterionFunction implementation class that should be used
CONF_CRIT_FUN_TERMINATION_VALUE - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Job configuration: the minimum double value used to determine if a criterion function is converging
CONF_DATA_SET_TAGS - Static variable in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsInputFormat
 
CONF_DEFAULT_ENTRY_PROCESSOR - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the default implementation of NoSQLEntryProcessor
CONF_DEFAULT_FILTER_OPERATION - Static variable in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
Default spatial operation to be performed when there is not a SpatialOperationConfig set.
CONF_DEPTH - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the depth
CONF_DS_INPUT_FORMAT_PREFIX - Static variable in class oracle.spatial.hadoop.vector.DistributedDataSet
 
CONF_DS_KEYS_PREFIX - Static variable in class oracle.spatial.hadoop.vector.DistributedDataSet
 
CONF_DS_LEN_PREFIX - Static variable in class oracle.spatial.hadoop.vector.DistributedDataSet
 
CONF_DS_PATHS_PREFIX - Static variable in class oracle.spatial.hadoop.vector.DistributedDataSet
 
CONF_DS_RI_PROVIDER_PREFIX - Static variable in class oracle.spatial.hadoop.vector.DistributedDataSet
 
CONF_DS_SPATIAL_CONF_PREFIX - Static variable in class oracle.spatial.hadoop.vector.DistributedDataSet
 
CONF_ENTRY_GROUPER - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the NoSQLEntryGrouper class
CONF_ENV_IS_REPO_LOC - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Job configuration: boolean value that specifies whether the service location refers to a repository (true) or to a whole MVS directory (false)
CONF_ENV_OVERWRITE_PERSIST_SERV_LOC - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Job configuration: boolean value that specifies whether LocalMVSConfig.CONF_ENV_PERSIST_SERV_LOC should be overwritten by the content pointed by MVSConfig.CONF_SERVCE_LOCATION (true) or not (false)
CONF_ENV_PERSIST_SERV_LOC - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Job configuration: the name of the HDFS path where the MVS directory should be saved.
CONF_ENV_REBUILD_INDEX - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Job configuration: boolean value indicating if the MVS directory index should be rebuilt (true) or not (false).
CONF_FORMATTER_CLASS - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the formatter class
CONF_GRID_COLS - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: The number of columns in the grid as an integer number.
CONF_GRID_MAX_X - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: The maximum x ordinate value of the grid as a double value
CONF_GRID_MAX_Y - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: The maximum y ordinate value of the grid as a double value
CONF_GRID_MIN_X - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: The minimum x ordinate value of the grid as a double value
CONF_GRID_MIN_Y - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: The minimum y ordinate value of the grid as a double value
CONF_GRID_ROWS - Static variable in class oracle.spatial.hadoop.vector.binning.BinningConfig
Job configuration: The number of rows in the grid as an integer number.
CONF_INCLUDED_EXTRA_FIELDS - Static variable in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexTextInputFormat
 
CONF_INPUT_FORMAT - Static variable in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter
 
CONF_INPUT_FORMAT_FILTER_READERS - Static variable in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialFilterInputFormat
 
CONF_K - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Job configuration: the number of cluster to generate as an integer value
CONF_KVSTORE_HOSTS - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the list of KV store hosts
CONF_KVSTORE_NAME - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the KV store name
CONF_KVSTORE_SECURITY - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the security properties file
CONF_MATCH_COUNTRY - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Job configuration: a country name used as a context for searches
CONF_MATCH_LAYERS - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Job configuration: a comma separated list of layers used by MVSuggest to perform searches
CONF_MAX_MEMBER_DISTANCE - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Maximum distance between a cluster center and a cluster member.
CONF_MAX_QUERY_RECORDS - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Job configuration: an integer number defining the maximum number of records sent to MVSuggest by each request.
CONF_NON_GEODETIC_FILTER - Static variable in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
Boolean job configuration value.
CONF_PARENT_KEY - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the KV store name
CONF_PARTITION_READER - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the partition reader
CONF_PROVIDE_TEMPLATES - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Job configuration: boolean value that specified whether or not the MVSuggest implementation should keep the templates content in memory.
CONF_RECORD_INFO_LOCATION_FIELD - Static variable in interface oracle.spatial.hadoop.vector.LocalizableRecordInfoProvider
 
CONF_REMOVE_PART_FILES - Static variable in class oracle.spatial.hadoop.vector.mapred.output.MergeFileOutputCommitter
Job configuration: boolean value that specifies whether the part files are removed or not.
CONF_REMOVE_PART_FILES - Static variable in class oracle.spatial.hadoop.vector.mapred.output.MergeJsonFileOutputCommitter
Job configuration: boolean value that specifies whether the part files are removed or not.
CONF_REMOVE_PART_FILES - Static variable in class oracle.spatial.hadoop.vector.mapreduce.output.MergeFileOutputCommiter
Job configuration: boolean value that specifies whether the part files are removed or not.
CONF_REMOVE_PART_FILES - Static variable in class oracle.spatial.hadoop.vector.mapreduce.output.MergeJsonFileOutputCommiter
Job configuration: boolean value that specifies whether the part files are removed or not.
CONF_RESPONCE_SPATIAL_CONTENT - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Job configuration: the type of spatial content returned by MVSuggest.
CONF_RESULT_ENTRIES - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the result entry list
CONF_RESULT_FILE_NAME - Static variable in class oracle.spatial.hadoop.vector.mapred.output.MergeFileOutputCommitter
Job configuration: the name of the resulting merged file
CONF_RESULT_FILE_NAME - Static variable in class oracle.spatial.hadoop.vector.mapred.output.MergeJsonFileOutputCommitter
Job configuration: the name of the resulting merged file
CONF_RESULT_FILE_NAME - Static variable in class oracle.spatial.hadoop.vector.mapreduce.output.MergeFileOutputCommiter
Job configuration: the name of the resulting merged file
CONF_RESULT_FILE_NAME - Static variable in class oracle.spatial.hadoop.vector.mapreduce.output.MergeJsonFileOutputCommiter
Job configuration: the name of the resulting merged file
CONF_SAMPLER - Static variable in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelector
Deprecated.
 
CONF_SERVCE_LOCATION - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Job configuration: the MVSuggest location.
CONF_SERVICE_INTERFACE - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Job configuration: the type of MVSuggest interface.
CONF_SHAPE_GEN_CLASS - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Job configuration: the ClusterShapeGenerator implementation class used
CONF_SUB_RANGE - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the minor key subrange
CONF_TAGS_REMOVED - Static variable in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsInputFormat
 
CONF_TIME_OUT - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the time out
CONF_TIME_OUT_UNIT - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Configuration property name for the time out unit
CONFIG_NAMEDOUTPUT_TO_MERGEDNAME_RELATION - Static variable in class oracle.spatial.hadoop.vector.mapred.output.MultipleOutputMergeOutputCommitter
Job configuration: a comma-separated list of assignments in the form namedOutput=finalMergedFileName
CONFIG_NAMEDOUTPUT_TO_MERGEDNAME_RELATION - Static variable in class oracle.spatial.hadoop.vector.mapreduce.output.MultipleOutputMergeOutputCommitter
Job configuration: a comma-separated list of assignments in the form namedOutput=finalMergedFileName
ConfigParams - Class in oracle.spatial.hadoop.vector.util
Contains names of common job configuration parameters used by different components of the API
ConfigParams() - Constructor for class oracle.spatial.hadoop.vector.util.ConfigParams
 
ConfigurationStorable - Interface in oracle.spatial.hadoop.vector
An implementer should be able of saving and loading its stated from a job Configuration
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.binning.mapred.BinMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.binning.mapred.BinReducer
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.ClusterCenterReducer
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.ClusterMembershipMapper
 
configure(D, Configuration) - Method in interface oracle.spatial.hadoop.vector.data.conf.DataSetConfigurator
Setups the given data set using the given job's configuration
configure(AbstractInputDataSet, Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.FileInputDataSetConfigurator
 
configure(AbstractInputDataSet, Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.InputDataSetConfiguratorHandler
Looks for a configurator suited for the input data set and calls the InputDataSetConfigurator#configure(AbstractInputDataSet, Configuration) if found.
configure(AbstractInputDataSet, Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.MultiInputDataSetConfigurator
 
configure(AbstractInputDataSet, Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.NoSQLInputDataSetConfigurator
 
configure(AbstractInputDataSet, Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.SimpleInputDataSetConfigurator
 
configure(AbstractInputDataSet, Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.SpatialIndexInputDataSetConfigurator
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.join.mapred.JoinMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.join.mapred.JoinPartitioner
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.join.mapred.JoinReducer
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.BufferMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.HierarchicalCountReducer
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.IndexedSpatialFilterMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.AdapterInputFormat
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.FileSplitInputFormat
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Validates and adds the current parameters to the job configuration
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Validates and adds the current parameters to the job configuration
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialFilter
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService.MVSMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService.SuggestServiceReducer
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.MVSHierachicalCountMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialFilterMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialFilterOutputMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialIndexingMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.Binning
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.Categorization
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.KMeansClustering
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.MBR
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.Partitioning
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialFilter
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialIndexing
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialJoin
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.partition.mapred.HilbertValueMapper
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.partition.mapred.HilbertValueReducer
 
consumeLastRequestTime() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSHelper
Gets the last request time and sets the time to zero so if it is called again before execution other request it will always return zero.
containsInputDataSet(AbstractInputDataSet) - Method in class oracle.spatial.hadoop.vector.data.MultiInputDataSet
Returns true if the given input data set is contained
containsTemplates() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
Tells whether the templates JSON contents are contained
ConvexHullClusterShapeGenerator - Class in oracle.spatial.hadoop.vector.cluster.kmeans
Generates clusters shapes as hexagons
ConvexHullClusterShapeGenerator() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.ConvexHullClusterShapeGenerator
 
count() - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Returns the number of elements in the index
count() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
count() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
 
createBinning(Configuration) - Static method in class oracle.spatial.hadoop.vector.binning.BinningFactory
Creates a BinningAlg based on the job configuration
createHexagonFromCircle(double, double, double, int) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
createHexagonFromCircle(double, double, double, double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
createHierarchyCountRecord(String, long) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Generates a count result in JSON format.
createHierarchyInfo(Configuration) - Static method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
Returns an initialized, empty (no content in hierarchy levels) instance of a HierarchyInfo implementation contained in the configuration.
createIndex(JavaSparkContext, SpatialJavaRDD<T>, SpatialPartitioningConfiguration) - Static method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Spatially index a spatial RDD using the specified DistributedSpatialIndex implementing class
createInputDataSet(String[]) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
 
createInternalInputFormat(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
createInternalInputFormat(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
createInternalInputFormat(JobContext) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
 
createKey() - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonRecordReader
 
createKey() - Method in class oracle.spatial.hadoop.vector.mapred.input.InputSplitInputFormat.InputSplitRecordReader
 
createKey() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultiRecordReader
 
createKey() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterRecordReader
 
createKey() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
 
createKey() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
createKey() - Method in class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLRecordReader
 
createKey() - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileRecordReader
 
createLocallyIndexedRDD(SpatialJavaPairRDD<PartitionKey, T>) - Static method in class oracle.spatial.spark.vector.index.local.LocalIndex
Returns a pair RDD where each is value is an r-tree containing all the elements contained in a partition
createMapRedOutputKey(String, String) - Static method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
Creates a key for the given hierarchy level name, feature id which can be used as an output key by a mapper and then read from a reducer
createMVSService(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSServiceFactory
Creates a new MVSService instance based on the job configuration parameter MVSConfig.CONF_SERVICE_INTERFACE.
createPartitioner(List<SpatialPartition>) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreePartitioning
 
createPartitioner(List<SpatialPartition>) - Method in interface oracle.spatial.spark.vector.index.SpatialPartitioning
Creates a SpatialPartitioner based on the given spatial partitions
createPartitionsToReducersMap(PartitioningResult, int) - Static method in class oracle.spatial.hadoop.vector.partition.PartitioningUtils
Maps partitions to reduce tasks so the reduce tasks contain approximately the same number of elements to process
createQueryRequester() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
createQueryRequester() - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSService
Creates an instance of MVSQueryRequester used to send match requests
createQueryRequester() - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
createRecordInfoLoader(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoaderFactory
 
createRecordInfoProvider(Class<? extends RecordInfoProvider<?, ?>>, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
createRecordInfoProvider(Class<? extends RecordInfoProvider<?, ?>>, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.PointKeyInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.InputSplitInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.JGeometryKeyInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialFilterInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialIndexInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
 
createRILoader(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoaderFactory
Creates a new RecordInfoLoader instance based on the job's configuration
createSpatialDataFrame(SQLContext, List<String>) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Creates data frame based on the SpatialJavaRDD.
createSpatialIndexFilter(SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
createSpatialRDDFromQuery(JavaSparkContext, JDBCUtils.ConnectionSupplier, String, SparkRecordInfoProvider<ResultSet>) - Static method in class oracle.spatial.spark.vector.util.JDBCUtils
Creates a Spatial RDD given a SQL query to a database.
createSpatialRDDFromQuery(JavaSparkContext, JDBCUtils.ConnectionSupplier, String, SparkRecordInfoProvider<ResultSet>, long) - Static method in class oracle.spatial.spark.vector.util.JDBCUtils
Creates a Spatial RDD given a SQL query to a database.
createSpatialRDDFromTable(JavaSparkContext, JDBCUtils.ConnectionSupplier, String, List<String>, SparkRecordInfoProvider<ResultSet>) - Static method in class oracle.spatial.spark.vector.util.JDBCUtils
Creates a Spatial RDD given the name of a table and the fields to be selected.
createSpatialRDDFromTable(JavaSparkContext, JDBCUtils.ConnectionSupplier, String, List<String>, SparkRecordInfoProvider<ResultSet>, long) - Static method in class oracle.spatial.spark.vector.util.JDBCUtils
Creates a Spatial RDD given the name of a table and the fields to be selected.
createSpatialTransformationContext(SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Creates an instance of SpatialTransformationContext associated to the given SpatialOperationConfig.
createSpatialTransformationContext() - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Creates an instance of SpatialTransformationContext
createSpatialTransformationContext() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
createSpatialTransformationContext(SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
createSpatialTransformationContext(SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Creates an instance of SpatialTransformationContext associated to the given SpatialOperationConfig.
createSpatialTransformationContext() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Creates an instance of SpatialTransformationContext
createSpatialTransformationContext(SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Creates an instance of SpatialTransformationContext associated to the given SpatialOperationConfig.
createSpatialTransformationContext() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Creates an instance of SpatialTransformationContext
createSpatialTransformationContext(SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Creates an instance of SpatialTransformationContext associated to the given SpatialOperationConfig.
createSpatialTransformationContext() - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Creates an instance of SpatialTransformationContext
createSpatialTransformationContext(SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
Creates an instance of SpatialTransformationContext associated to the given SpatialOperationConfig.
createSpatialTransformationContext() - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
Creates an instance of SpatialTransformationContext
createValue() - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonRecordReader
 
createValue() - Method in class oracle.spatial.hadoop.vector.mapred.input.InputSplitInputFormat.InputSplitRecordReader
 
createValue() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultiRecordReader
 
createValue() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterRecordReader
 
createValue() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
 
createValue() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
createValue() - Method in class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLRecordReader
 
createValue() - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileRecordReader
 
CriterionFunction - Interface in oracle.spatial.hadoop.vector.cluster.kmeans
Represents a criterion function used to determine if a cluster algorithm has finished during the cluster center update phase at reduce time.

D

DATA_SET_INPUT_STR - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
 
DATA_SET_LENGTH - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
 
DATA_SET_PATH - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
 
DATA_SET_TYPE - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
 
DataSetConfigurator<D extends IODataSet> - Interface in oracle.spatial.hadoop.vector.data.conf
Defines the interface of a data set configurator.
DBFReader - Class in oracle.spatial.hadoop.vector.shapefile
DBF files reader.
DBFReader(InputStream, InputStream) - Constructor for class oracle.spatial.hadoop.vector.shapefile.DBFReader
Construct an object out of the specified shapefile's DBF file input stream and of the optional CPG file input stream.
DBFReader(InputStream) - Constructor for class oracle.spatial.hadoop.vector.shapefile.DBFReader
Construct an object out of the specified shapefile's DBF file input stream.
DEFAULT_ENTRY_GROUPER_CLASS - Static variable in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
De default implementation of NoSQLEntryGrouper used when the property NoSQLConfiguration.CONF_ENTRY_GROUPER is not set
DEFAULT_REPOSITORY_NAME - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
 
deletePathSafely(Path, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
deserialize(Writable) - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonSerDe
 
deserialize(Writable) - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonToWKTSerDe
 
deserialize(Writable) - Method in class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileSerDe
 
DIMENSIONS - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
The number of dimensions of the spatial data
DistributedDataSet - Class in oracle.spatial.hadoop.vector
A validated, normalized and ready to be distributed version of InputDataSet.
DistributedDataSet() - Constructor for class oracle.spatial.hadoop.vector.DistributedDataSet
Creates a new instance
DistributedDataSet(int) - Constructor for class oracle.spatial.hadoop.vector.DistributedDataSet
Creates a new instance with an id
DistributedSpatialIndex<T> - Class in oracle.spatial.spark.vector.index
A distributed spatial index for a spatial RDD.
DistributedSpatialIndex(Class<T>) - Constructor for class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Creates an empty instance which will accept spatial RDDs of the given generic type
DoubleArrayWritable() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.MBR.DoubleArrayWritable
 
DummyClusterShapeGenerator - Class in oracle.spatial.hadoop.vector.cluster.kmeans
An implementation of ClusterShapeGenerator that produces no shape.
DummyClusterShapeGenerator() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.DummyClusterShapeGenerator
 
DummyReporter - Class in oracle.spatial.hadoop.vector.util
A mock reporter implementation
DummyReporter() - Constructor for class oracle.spatial.hadoop.vector.util.DummyReporter
 
DynaAdminHierarchyInfo - Class in oracle.spatial.hadoop.vector.hierarchy.impl
An implementation of HierarchyInfo that can be configured to represent a hierarchy structure using the MVSuggest administrative boundary catalogs.
DynaAdminHierarchyInfo() - Constructor for class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
Creates a new empty instance
DynamicInputDataSetCmdArgsParserHandler - Class in oracle.spatial.hadoop.vector.data.cmd
An implementation of InputDataSetCmdArgsParserHandler whose parsers chain can be set dynamically by adding instances of InputDataSetCmdArgsParser
DynamicInputDataSetCmdArgsParserHandler() - Constructor for class oracle.spatial.hadoop.vector.data.cmd.DynamicInputDataSetCmdArgsParserHandler
 
DynamicInputDataSetConfiguratorHandler - Class in oracle.spatial.hadoop.vector.data.conf
A subclass of InputDataSetConfiguratorHandler which can be configured dynamically by adding its InputDataSetConfigurator instances.
DynamicInputDataSetConfiguratorHandler() - Constructor for class oracle.spatial.hadoop.vector.data.conf.DynamicInputDataSetConfiguratorHandler
 

E

EMPTY_RESULT - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
 
EMPTY_STR - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
EmptyFileOutputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.output
 
EmptyFileOutputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.output.EmptyFileOutputFormat
 
enrich(JGeometry) - Method in interface oracle.spatial.spark.vector.geoenrichment.GeoEnricher
Returns spatial features related to the given geometry
enrich(JGeometry) - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONGeoEnricher
 
enrich(<any>, GeoEnricher) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Associates records from the current spatial RDD to spatial features using an instance of GeoEnricher
enrich(<any>, GeoEnricher) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Associates records from the current spatial RDD to spatial features using an instance of GeoEnricher
enrich(<any>, GeoEnricher) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Associates records from the current spatial DStream to spatial features using an instance of GeoEnricher
enrich(<any>, GeoEnricher) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
Associates records from the current spatial DStream to spatial features using an instance of GeoEnricher
environmentCleanup(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
environmentCleanup(Configuration) - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSService
Performs cleanning tasks like removing temporal file.
environmentCleanup(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
environmentSetup(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
environmentSetup(Configuration) - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSService
Performs the necessary setup before running a job.
environmentSetup(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
equals(Object) - Method in class oracle.spatial.hadoop.vector.JGeometryWritable
 
equals(Object) - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
 
equals(Object) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
 
equals(Object) - Method in class oracle.spatial.hadoop.vector.RecordInfo
 
equals(Object) - Method in class oracle.spatial.spark.vector.index.PartitionKey
 
equals(Object) - Method in class oracle.spatial.spark.vector.index.PartitionKeyBasedPartitioner
 
equals(Object) - Method in class oracle.spatial.spark.vector.index.SpatialPartition
 
equals(Object) - Method in class oracle.spatial.spark.vector.SparkRecordInfo
 
EuclideanDistanceCriterionFunction - Class in oracle.spatial.hadoop.vector.cluster.kmeans
A CriterionFunction implementation based on the uclidian distance between the last two cluster centers.
EuclideanDistanceCriterionFunction() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.EuclideanDistanceCriterionFunction
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Area
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKB
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKT
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Buffer
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_ConvexHull
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Envelope
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Length
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Simplify
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_SimplifyVW
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Volume
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
evaluate(DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
expandMbr(double[], double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
EXTRA_FIELD_DS_ID - Static variable in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
 

F

F_FEAT_GEOMETRIES - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEAT_GEOMETRY - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEAT_ID - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEAT_PROPS - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEAT_TYPE - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEATCOLL_ATTR_NAMES - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEATCOLL_ATTR_TYPES - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEATCOLL_BBOX - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEATCOLL_CR - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEATCOLL_FEATURES - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEATCOLL_GEODETIC - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEATCOLL_NAME - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEATCOLL_SRS - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_FEATCOLL_TYPE - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_GEOM_COORDS - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
F_GEOM_TYPE - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
FAILED_ITERATION - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans.KMeansIterationResult
 
FastJGeometryKryoSerializer - Class in oracle.spatial.spark.vector.serialization
Custom Kryo Serializer for the class oracle.spatial.util.RStarTree
FastJGeometryKryoSerializer() - Constructor for class oracle.spatial.spark.vector.serialization.FastJGeometryKryoSerializer
 
Feature - Class in oracle.spatial.hadoop.vector.geojson
An object representation of a GeoJSON feature collection's feature
Feature() - Constructor for class oracle.spatial.hadoop.vector.geojson.Feature
 
FEATURE_PROPS_ELEM_COUNT - Static variable in class oracle.spatial.hadoop.vector.partition.PartitioningResult
 
FeatureCollection - Class in oracle.spatial.hadoop.vector.geojson
Object representation of a GeoJSON feature collection.
FeatureCollection() - Constructor for class oracle.spatial.hadoop.vector.geojson.FeatureCollection
 
FileInputDataSet - Class in oracle.spatial.hadoop.vector.data
Represents a file based data set.
FileInputDataSet() - Constructor for class oracle.spatial.hadoop.vector.data.FileInputDataSet
 
FileInputDataSetCmdArgsParser - Class in oracle.spatial.hadoop.vector.data.cmd
An implementation of InputDataSetCmdArgsParser to parse command line arguments for input data sets of type FileInputDataSet
FileInputDataSetCmdArgsParser() - Constructor for class oracle.spatial.hadoop.vector.data.cmd.FileInputDataSetCmdArgsParser
 
FileInputDataSetConfigurator - Class in oracle.spatial.hadoop.vector.data.conf
Base configurator for FileInputDataSet instances.
FileInputDataSetConfigurator() - Constructor for class oracle.spatial.hadoop.vector.data.conf.FileInputDataSetConfigurator
 
FileInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapred
An implementation of FileInputDataSetConfigurator for the old Hadoop API
FileInputDataSetConfiguratorImpl() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapred.FileInputDataSetConfiguratorImpl
 
FileInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapreduce
An implementation of FileInputDataSetConfigurator for the new Hadoop API
FileInputDataSetConfiguratorImpl() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapreduce.FileInputDataSetConfiguratorImpl
 
FileInputFormatAdapter<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
FileInputFormatAdapter() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter
 
FileInputFormatAdapter.FileRecordReaderAdapter<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
FileInputFormatAdapter.FileSplitAdapter - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
FileNamePathFilter - Class in oracle.spatial.hadoop.vector.util
A path filter that uses a pattern
FileNamePathFilter() - Constructor for class oracle.spatial.hadoop.vector.util.FileNamePathFilter
 
FileRecordReaderAdapter(<any>) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileRecordReaderAdapter
 
FileSplitAdapter() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileSplitAdapter
 
FileSplitAdapter(InputSplit, Path, long, long, String[], String[]) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileSplitAdapter
 
FileSplitAdapter(InputSplit, Path, long, long, String[]) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileSplitAdapter
 
FileSplitInputFormat - Class in oracle.spatial.hadoop.vector.mapred.input
A CompositeInputFormat that only provides the source FileSplits as its values so mapreduce components can read the data directly using its internal input format.
FileSplitInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.FileSplitInputFormat
 
FileSplitInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
FileSplitInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat
 
FileSplitInputFormat.FileSplitRecordReader - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
FileSplitRecordInfoLoader<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
 
FileSplitRecordInfoLoader(JobConf) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.FileSplitRecordInfoLoader
Creates a new instance.
FileSplitRecordInfoLoader<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input.recordinfo
The basic implementation of RecordInfoLoader.
FileSplitRecordInfoLoader() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
FileSplitRecordReader() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
FileUtils - Class in oracle.spatial.hadoop.vector.util
Provides common operations related to files and used internally by components of this API.
FileUtils() - Constructor for class oracle.spatial.hadoop.vector.util.FileUtils
 
filter(<any>) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Returns a new spatial RDD containing only the elements that satisfy the filtering function
filter(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Returns a new spatial RDD containing only the elements that satisfy both, the filtering function and the spatial operation
filter(<any>) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
filter(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
filter(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Returns a new spatial RDD containing only the elements that satisfy both, the filtering lambda function and the spatial operation
filter(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Returns a new spatial RDD containing only the elements that satisfy both, the filtering function and the spatial operation
filter(T) - Method in class oracle.spatial.spark.vector.rdd.SpatialTransformationContext
Returns true if the given record passes the spatial filter specified by the current SpatialOperationConfig if any.
filter(T, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.rdd.SpatialTransformationContext
Returns if the given record passes the spatial filter specified by the given SpatialOperationConfig.
filter(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Performs a filter transformation.
filter(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
Performs a filter transformation.
findCachedArchivePath(String, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
findCachedArchivePath(String, JobContext) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
findCachedArchivePath(String, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
Searches a file by its name in the distributed cache
findCachedFilePath(String, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
findCachedFilePath(String, JobContext) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
findCachedFilePath(String, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
Searches an archive by its name in the distributed cache
findParentRecords(Text, RecordInfoArrayWritable) - Method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyDataIndexReader
Finds the given parent's children records.
findRepository(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
findSpatialIndexMetadata(String, Path, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
Searches the metadata file for the given index name
findType() - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonStreamParser
Returns true if an object of the specified type is found, false otherwise.
finishLoading() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
Finishes the current loading and closes any resource.
finishLoading() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
finishLoading() - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
When called, stops reading the current split
flatMap(<any>) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Returns a new RDD by first applying a function to all elements of this index, and then flattening the results.
flatMap(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
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.
flatMap(<any>) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
flatMap(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
flatMap(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
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.
flatMap(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
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.
flatMap(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
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.
flatMap(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
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.
flatMap(<any>) - Static method in class oracle.spatial.spark.vector.util.FunctionAdapters
 
FlatMapFunctionAdapter<T,R> - Class in oracle.spatial.spark.vector.util
 
FlatMapFunctionAdapter(<any>) - Constructor for class oracle.spatial.spark.vector.util.FlatMapFunctionAdapter
 
FlatMapIterator<T,R> - Class in oracle.spatial.spark.vector.util
 
FlatMapIterator(Iterator<T>, <any>) - Constructor for class oracle.spatial.spark.vector.util.FlatMapIterator
 
fromDStream(<any>, SparkRecordInfoProvider<T>) - Static method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Creates a spatial JavaDStream from an existing DStream
fromJavaDStream(<any>, SparkRecordInfoProvider<T>, Class<T>) - Static method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Creates a spatial JavaDStream from an existing JavaDStream
fromJavaDStream(<any>, SparkRecordInfoProvider<T>) - Static method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Creates a spatial JavaDStream which records are of type SparkRecordInfo
fromJavaPairDStream(<any>, SparkRecordInfoProvider<<any>>, Class<K>, Class<V>) - Static method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
Creates a new spatial pair DStream from an existing JavaPairDStream
fromJavaPairRDD(<any>, SparkRecordInfoProvider<<any>>, Class<K>, Class<V>) - Static method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Creates a new spatial RDD from an existing JavaPairRDD
fromJavaRDD(<any>, SparkRecordInfoProvider<T>, Class<T>) - Static method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Creates a spatial RDD from the given java rdd.
fromJavaRDD(<any>, SparkRecordInfoProvider<T>) - Static method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Creates a spatial RDD of type SparkRecordInfo from the given rdd.
fromOrdinal(int) - Static method in enum oracle.spatial.hadoop.vector.util.SpatialOperation
Gets the enum value associated to the given ordinal
fromRDD(<any>, SparkRecordInfoProvider<T>) - Static method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Creates a spatial RDD from the given rdd.
FullInputDataSetCmdArgsParserHandler - Class in oracle.spatial.hadoop.vector.data.cmd
FullInputDataSetCmdArgsParserHandler(Configuration) - Constructor for class oracle.spatial.hadoop.vector.data.cmd.FullInputDataSetCmdArgsParserHandler
 
FullInputDataSetConfiguratorHandler - Class in oracle.spatial.hadoop.vector.data.conf.mapred
FullInputDataSetConfiguratorHandler() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapred.FullInputDataSetConfiguratorHandler
 
FullInputDataSetConfiguratorHandler - Class in oracle.spatial.hadoop.vector.data.conf.mapreduce
FullInputDataSetConfiguratorHandler() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapreduce.FullInputDataSetConfiguratorHandler
 
FunctionAdapters - Class in oracle.spatial.spark.vector.util
 
FunctionAdapters() - Constructor for class oracle.spatial.spark.vector.util.FunctionAdapters
 
FunctionExecutor - Class in oracle.spatial.spark.vector.sql.udf.function
Helps in the process of Spark SQL UDFs execution
FunctionExecutor() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.FunctionExecutor
 

G

generateBinTemplate(DataOutputStream, String, BinningConfig, int, boolean) - Static method in class oracle.spatial.hadoop.vector.binning.BinUtils
Generates a bin template in JSON format.
generateBinTemplate(Path, String, Configuration) - Static method in class oracle.spatial.hadoop.vector.binning.BinUtils
Generates a bin template in JSON format.
generatePartitioningResult(Path, SpatialConfig, Configuration) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueBasedPartitioner
Creates partitions and generates a partitioning result file.
generateShape() - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.ClusterShapeGenerator
Generates the current cluster shape.
generateShape() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ConvexHullClusterShapeGenerator
 
generateShape() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.DummyClusterShapeGenerator
 
genFeature(String, JGeometry, Map<String, Object>, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
genFeature(String, JGeometry, Map<String, Object>) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
genFeature(RecordInfo, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
genFeatureCollectionHeader(String, int, boolean, double[], Map<String, String>) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
genFeatureCollectionHeader(String, int, boolean, double[], Map<String, String>, StringBuilder) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
GeoAreaInfo - Class in oracle.spatial.hadoop.vector.mvsuggest
This class contains information regarding a single feature from a layer template indexed by MVSuggest.
GeoAreaInfo(String, String, JGeometry) - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.GeoAreaInfo
Construct a GeoAreaInfo with the file, featureId and pointGeometry.
GEODETIC - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
Whether the spatial data is geodetic or not
GEODETIC - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Whether the current geometries can be considered geodetic or not
GeoEnricher - Interface in oracle.spatial.spark.vector.geoenrichment
Component used to find features related to a given geometry.
GeoJson2JGeometry(String, int) - Static method in class oracle.spatial.hadoop.vector.mvsuggest.SimpleGeoJsonParser
Returns a JGeometry from the provided Json string and srid
GeoJson2JGeometry(JsonParser, int) - Static method in class oracle.spatial.hadoop.vector.mvsuggest.SimpleGeoJsonParser
Returns a JGeometry from a provided JsonParser Needs the current token to be the start of the geometry object, for a newly created parser, call nextToken() before calling this
GeoJsonGen - Class in oracle.spatial.hadoop.vector.util
Provides convenient methods to generate JSON fragments.
GeoJsonGen(JsonGenerator) - Constructor for class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
GeoJSONGeoEnricher - Class in oracle.spatial.spark.vector.geoenrichment
An implementation of GeoEnricher which looks for spatial features from a hierarchy of spatial data layers defined as GeoJSON files.
GeoJSONGeoEnricher(String, GeoJSONSpatialLayerHierarchyConfiguration, Configuration) - Constructor for class oracle.spatial.spark.vector.geoenrichment.GeoJSONGeoEnricher
Creates a new instance
GeoJsonHiveRecordInfoProvider - Class in oracle.spatial.hadoop.vector.hive.json
Implementation of oracle.spatial.hadoop.vector.hive.HiveRecordInfoProvider to read GeoJSON features.
GeoJsonHiveRecordInfoProvider() - Constructor for class oracle.spatial.hadoop.vector.hive.json.GeoJsonHiveRecordInfoProvider
 
GeoJsonInputFormat - Class in oracle.spatial.hadoop.vector.geojson.mapred
org.apache.hadoop.mapred.FileInputFormat for GeoJSON text files.
GeoJsonInputFormat() - Constructor for class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonInputFormat
 
GeoJsonInputFormat - Class in oracle.spatial.hadoop.vector.geojson.mapreduce
FileInputFormat for GeoJSON text files.
GeoJsonInputFormat() - Constructor for class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonInputFormat
 
GeoJsonParseType - Enum in oracle.spatial.hadoop.vector.geojson
Defines values for the different GeoJSON parsing types.
GeoJsonRecordInfoProvider - Class in oracle.spatial.hadoop.vector.geojson
RecordInfoProvider for GeoJSON text files.
GeoJsonRecordInfoProvider() - Constructor for class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
Creates a new instance
GeoJsonRecordInfoProvider - Class in oracle.spatial.spark.vector.recordinfoprovider
SparkRecordInfoProvider for GeoJSON text files.
GeoJsonRecordInfoProvider() - Constructor for class oracle.spatial.spark.vector.recordinfoprovider.GeoJsonRecordInfoProvider
 
GeoJsonRecordInfoProvider(List<String>, int, int) - Constructor for class oracle.spatial.spark.vector.recordinfoprovider.GeoJsonRecordInfoProvider
Create a GeoJsonRecordInfoProvider
GeoJsonRecordReader - Class in oracle.spatial.hadoop.vector.geojson.mapred
org.apache.hadoop.mapred.RecordReader for GeoJSON text files.
GeoJsonRecordReader(JobConf, FileSplit, GeoJsonParseType) - Constructor for class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonRecordReader
Creates a new instance.
GeoJsonRecordReader - Class in oracle.spatial.hadoop.vector.geojson.mapreduce
RecordReader for GeoJSON text files.
GeoJsonRecordReader(GeoJsonParseType) - Constructor for class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
Creates a new instance.
GeoJsonSerDe - Class in oracle.spatial.hadoop.vector.hive.json
This SerDe can be used to read data in GeoJSON format.
GeoJsonSerDe() - Constructor for class oracle.spatial.hadoop.vector.hive.json.GeoJsonSerDe
 
GeoJSONSpatialLayerDescriptor - Class in oracle.spatial.spark.vector.geoenrichment
Describes a spatial data layer.
GeoJSONSpatialLayerDescriptor(String, String) - Constructor for class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
Creates a new instance
GeoJSONSpatialLayerDescriptor(String, String, String) - Constructor for class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
Creates a new instance
GeoJSONSpatialLayerDescriptor(String, String, String, String) - Constructor for class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
Creates a new instance
GeoJSONSpatialLayerHierarchyConfiguration - Class in oracle.spatial.spark.vector.geoenrichment
Contains the configuration used by a GeoJSONGeoEnricher.
GeoJSONSpatialLayerHierarchyConfiguration(GeoJSONSpatialLayerDescriptor[], int, double) - Constructor for class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerHierarchyConfiguration
Creates a new instance
GeoJsonStreamParser - Class in oracle.spatial.hadoop.vector.geojson
A stream GeoJSON parser used to read GeoJSON records.
GeoJsonStreamParser(InputStream, GeoJsonParseType) - Constructor for class oracle.spatial.hadoop.vector.geojson.GeoJsonStreamParser
Create a new instance
GeoJSONTextRecordInfoProvider - Class in oracle.spatial.spark.vector.recordinfoprovider
An implementation of SparkRecordInfoProvider which can extract spatial information and properties from GeoJSON features
GeoJSONTextRecordInfoProvider() - Constructor for class oracle.spatial.spark.vector.recordinfoprovider.GeoJSONTextRecordInfoProvider
Creates a new instance
GeoJSONTextRecordInfoProvider(int) - Constructor for class oracle.spatial.spark.vector.recordinfoprovider.GeoJSONTextRecordInfoProvider
Creates a new instance.
GeoJSONTextRecordInfoProvider(int, List<String>) - Constructor for class oracle.spatial.spark.vector.recordinfoprovider.GeoJSONTextRecordInfoProvider
Creates a new instance.
GeoJsonToWKTSerDe - Class in oracle.spatial.hadoop.vector.hive.json
This SerDe can be used to read data in GeoJSON format and set the geometry column in WKT format.
GeoJsonToWKTSerDe() - Constructor for class oracle.spatial.hadoop.vector.hive.json.GeoJsonToWKTSerDe
 
GEOMETRY_ATTRIBUTE - Static variable in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
The name of the geometry attribute.
GEOMETRY_ATTRIBUTE - Static variable in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
The name of the geometry attribute.
GeometryParamHelper - Class in oracle.spatial.hadoop.vector.hive.function
Provides some internal helpful functions used by the Hive API to handle geometries.
GeometryParamHelper(PrimitiveObjectInspector, int) - Constructor for class oracle.spatial.hadoop.vector.hive.function.GeometryParamHelper
 
GeometryParamHelper - Class in oracle.spatial.spark.vector.sql.udf.function
Helps to prevent the construction of jGeometry objects from GeoJson when the parameter in UDFs is constant in the query
GeometryParamHelper() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.GeometryParamHelper
 
geomToString(JGeometry) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
get() - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfoWritable
Gets the current partition
get(String) - Method in class oracle.spatial.hadoop.vector.util.TaggedConfiguration
 
get(String, String) - Method in class oracle.spatial.hadoop.vector.util.TaggedConfiguration
 
get(String) - Method in class oracle.spatial.hadoop.vector.util.TaggedJobConf
 
get(String, String) - Method in class oracle.spatial.hadoop.vector.util.TaggedJobConf
 
get() - Method in interface oracle.spatial.spark.vector.util.JDBCUtils.ConnectionSupplier
 
getAggrFields() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Gets the name of the fields to be aggregated
getAnonymousArgs() - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
 
getArg(String) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Returns the string value of the given argument.
getArg(String, String) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Returns the string value of the given argument.
getArrayArg(String, boolean, String[]) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the string array value of an argument
getAttrNames() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the names of the attributes contained in the features
getAttrTypes() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the types of the attributes contained in the features
getBaseInputFormatClass() - Method in interface oracle.spatial.hadoop.vector.data.conf.InputDataSetConfigurator
Gets the InputFormat super class supported by this configurator.
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapred.FileInputDataSetConfiguratorImpl
 
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapred.MultiInputDataSetConfiguratorImpl
 
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapred.NoSQLInputDataSetConfiguratorImpl
 
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapred.SimpleInputDataSetConfiguratorImpl
 
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapred.SpatialIndexInputDataSetConfiguratorImpl
 
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapreduce.FileInputDataSetConfiguratorImpl
 
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapreduce.MultiInputDataSetConfiguratorImpl
 
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapreduce.NoSQLInputDataSetConfiguratorImpl
 
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapreduce.SimpleInputDataSetConfiguratorImpl
 
getBaseInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.conf.mapreduce.SpatialIndexInputDataSetConfiguratorImpl
 
getBatchSize() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Gets the current batch size
getBbox() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the bounding box
getBestFittingInputDataSetType(SpatialIndexInputDataSet) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
Converts the given input data set to the most general class possible.
getBestFittingInputDataSetType(FileInputDataSet) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
Converts the given input data set to the most general class possible.
getBinConf() - Method in class oracle.spatial.hadoop.vector.mapred.job.Binning
Gets the binning configuration
getBinningConfig() - Method in interface oracle.spatial.hadoop.vector.binning.BinningAlg
Gets the binning configuration
getBinningConfig() - Method in class oracle.spatial.hadoop.vector.binning.HexBinningAlg
 
getBinningConfig() - Method in class oracle.spatial.hadoop.vector.binning.RectBinningAlg
 
getBooleanArg(String, boolean, Boolean) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the boolean value of an argument
getBooleanArrayArg(String, boolean, boolean[]) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the boolean array value of an argument
getBoundaries() - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Gets the minimum and maximum values for each dimension in the form dim1Min,dim2Min,dim1Max,dim2Max
getBounds() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets the dimensions minimum of maximum values
getBytesRead() - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonStreamParser
Returns the bytes that have been read
getCell(double, double, int[]) - Method in interface oracle.spatial.hadoop.vector.binning.BinningAlg
Gets the row and column of the cell that contains the given point.
getCell(long, int[]) - Method in interface oracle.spatial.hadoop.vector.binning.BinningAlg
Gets the row and column of the cell with the given id
getCell(double, double, int[]) - Method in class oracle.spatial.hadoop.vector.binning.HexBinningAlg
 
getCell(long, int[]) - Method in class oracle.spatial.hadoop.vector.binning.HexBinningAlg
 
getCell(double, double, int[]) - Method in class oracle.spatial.hadoop.vector.binning.RectBinningAlg
 
getCell(long, int[]) - Method in class oracle.spatial.hadoop.vector.binning.RectBinningAlg
 
getCellHeight() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Gets the height of the cells
getCellId(int[]) - Method in interface oracle.spatial.hadoop.vector.binning.BinningAlg
Gets the id of the cell represented by the given row and column
getCellId(int[]) - Method in class oracle.spatial.hadoop.vector.binning.HexBinningAlg
 
getCellId(int[]) - Method in class oracle.spatial.hadoop.vector.binning.RectBinningAlg
 
getCellMbr(int[], double[]) - Method in interface oracle.spatial.hadoop.vector.binning.BinningAlg
Gets the minimum bounding box of the given cell's row and column
getCellMbr(int[], double[]) - Method in class oracle.spatial.hadoop.vector.binning.HexBinningAlg
 
getCellMbr(int[], double[]) - Method in class oracle.spatial.hadoop.vector.binning.RectBinningAlg
 
getCellOrdinates(int[], double[]) - Method in interface oracle.spatial.hadoop.vector.binning.BinningAlg
Gets the ordinates of the given cell
getCellOrdinates(int[], double[]) - Method in class oracle.spatial.hadoop.vector.binning.HexBinningAlg
 
getCellOrdinates(int[], double[]) - Method in class oracle.spatial.hadoop.vector.binning.RectBinningAlg
 
getCellOrdinatesLength() - Method in interface oracle.spatial.hadoop.vector.binning.BinningAlg
Gets the number of ordinates that contains any cell created by this algorithm
getCellOrdinatesLength() - Method in class oracle.spatial.hadoop.vector.binning.HexBinningAlg
 
getCellOrdinatesLength() - Method in class oracle.spatial.hadoop.vector.binning.RectBinningAlg
 
getCellWidth() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Gets the width of the cells
getCentroid(JGeometry, double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
getClassArg(String, boolean, Class<?>) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the class value of an argument
getClusters() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans.KMeansIterationResult
Gets the last clusters information
getClustersPoints() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Gets the initial clusters points
getCmdArgs(AbstractInputDataSet, Map<String, Object>) - Method in class oracle.spatial.hadoop.vector.data.cmd.FileInputDataSetCmdArgsParser
 
getCmdArgs(AbstractInputDataSet, Map<String, Object>) - Method in interface oracle.spatial.hadoop.vector.data.cmd.InputDataSetCmdArgsParser
Converts the current input data set properties to command line parameters which are added to the passed cmdArgs map.
getCmdArgs(AbstractInputDataSet, Map<String, Object>, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.InputDataSetCmdArgsParserHandler
Gets the command line arguments used to get the current state of the given input data set
getCmdArgs(AbstractInputDataSet, Map<String, Object>) - Method in class oracle.spatial.hadoop.vector.data.cmd.MultiInputDataSetCmdArgsParser
 
getCmdArgs(AbstractInputDataSet, Map<String, Object>) - Method in class oracle.spatial.hadoop.vector.data.cmd.NoSQLInputCmdArgsParser
 
getCmdArgs(AbstractInputDataSet, Map<String, Object>) - Method in class oracle.spatial.hadoop.vector.data.cmd.SimpleInputDataSetCmdArgsParser
 
getCmdArgs(AbstractInputDataSet, Map<String, Object>) - Method in class oracle.spatial.hadoop.vector.data.cmd.SpatialIndexInputDataSetCmdArgsParser
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.data.cmd.FileInputDataSetCmdArgsParser
 
getCmdOptions() - Method in interface oracle.spatial.hadoop.vector.data.cmd.InputDataSetCmdArgsParser
Gets a descriptive text about the parameters expected
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.data.cmd.MultiInputDataSetCmdArgsParser
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.data.cmd.NoSQLInputCmdArgsParser
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.data.cmd.SimpleInputDataSetCmdArgsParser
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.data.cmd.SpatialIndexInputDataSetCmdArgsParser
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets a description of the arguments expected from command line.
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialFilter
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService
 
getCmdOptionsWithInputDataSets() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets a descriptive text about the parameters expected by the job plus a description of the supported input data set types
getCollectionName() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the feature collection name
getCommaSeparatedPaths() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation
Deprecated.
 
getComment() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
getCommittedTaskPath(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
getConf() - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
 
getConf() - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonInputFormat
 
getConf() - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonInputFormat
 
getConf() - Method in class oracle.spatial.hadoop.vector.join.mapreduce.JoinPartitioner
 
getConf() - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
getConf() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
getConf() - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
 
getConf() - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
 
getConf() - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
 
getConfiguration() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Gets the current job configuration
getConfiguratorHandler() - Method in class oracle.spatial.hadoop.vector.data.conf.MultiInputDataSetConfigurator
Gets a configurator handler used to configure the data sets contained in a MultiInputDataSet
getConfigurators(Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.DynamicInputDataSetConfiguratorHandler
 
getConfigurators(Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.InputDataSetConfiguratorHandler
Gets a collection of InputDataSetConfigurator instances supported by this handler.
getConfiguredInstance(JobConf) - Static method in class oracle.spatial.hadoop.vector.mvsuggest.MVSHelper
Creates a MVSHelper instance using the current job configuration
getConsistency() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
getConvergentClusters() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans.KMeansIterationResult
Sets the last clusters information
getCopyright() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the copyright value
getCounter(Enum<?>) - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
getCounter(String, String) - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
getCPGFilesPath(JobConf) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
Returns the optional CPG files path.
getCPGFilesPath(Configuration) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
Returns the optional CPG files path.
getCriterionFunctionValue() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Gets the criterion function value generated the last time the cluster was updated
getCriterionFunctionValue() - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.CriterionFunction
Gets the new criterion function value calculated using the updated cluster center point
getCriterionFunctionValue() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.EuclideanDistanceCriterionFunction
 
getCriterionFunctionValue() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.SquaredErrorCriterionFunction
 
getCritetionFunctionClass() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Gets the CriterionFunction subclass to be used
getCurrentCmdArgs(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Returns the current driver properties in a map where each key-value is a name and value of a command line argument.
getCurrentCmdArgs(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
getCurrentCmdArgs(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
 
getCurrentCmdArgs(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
getCurrentCmdArgs(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
getCurrentCmdArgs(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialFilter
 
getCurrentCmdArgs(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
getCurrentCmdArgs(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
getCurrentCmdArgs(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService
 
getCurrentCmdArgsAsString(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Returns the current driver properties as a space-separated list of name=value elements.
getCurrentKey() - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
 
getCurrentKey() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileRecordReaderAdapter
 
getCurrentKey() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
getCurrentKey() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.InputSplitInputFormat.InputSplitRecordReader
 
getCurrentKey() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLRecordReader
 
getCurrentKey() - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileRecordReader
 
getCurrentRecordInfo() - Method in class oracle.spatial.hadoop.vector.SpatialIndexRecordInfoProvider
 
getCurrentValue() - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
 
getCurrentValue() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileRecordReaderAdapter
 
getCurrentValue() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
getCurrentValue() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.InputSplitInputFormat.InputSplitRecordReader
 
getCurrentValue() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLRecordReader
 
getCurrentValue() - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileRecordReader
 
getCurrReader() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
getCurrReader() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
getCurrReader() - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Gets the current reader
getDataSetId() - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
Gets the id of the data set associated to the current partition
getDataSetId() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation
Deprecated.
 
getDataSetLength() - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
Gets the approximate length of the current data set
getDBFFilesPath(JobConf) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
Returns the optional DBF files path.
getDBFFilesPath(Configuration) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
Returns the optional DBF files path.
getDefaultRepository() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
getDefaultWorkFile(TaskAttemptContext, String) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
 
getDelegateRecordReader(FileSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
Creates a record reader instance.
getDelegateRecordReader(FileSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.FileSplitInputFormat
 
getDelegateRecordReader(FileSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
 
getDepth() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
getDesc_default_repository() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
getDesc_repository_list() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
getDesc_uri() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
getDescriptors() - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerHierarchyConfiguration
Gets the descriptors of the spatial data layers of this configuration
getDimensions(Configuration) - Static method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
Returns the geometries dimensions.
getDimensions(JsonNode) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
 
getDimensions() - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Gets the number of dimensions of the geometries
getDimensions() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets the number of spatial dimensions of the indexed data
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AnyInteract
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Area
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKB
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKT
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Buffer
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Contains
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_ConvexHull
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Distance
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Envelope
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Inside
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Length
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Simplify
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_SimplifyVW
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Volume
 
getDisplayString(String[]) - Method in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
getDistributedSpatialIndexClass() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
 
getDistributedSpatialIndexClass() - Method in interface oracle.spatial.spark.vector.index.SpatialPartitioningConfiguration
Gets the type of DistributedSpatialIndex this configuration is meant for.
getDoubleArg(String, boolean, Double) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the double value of an argument
getDoubleArrayArg(String, boolean, double[]) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the double array value of an argument
getElemCount() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
Gets the number of elements contained in the local spatial index
getElementCount() - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Gets the total number of the number of elements in all the partitions.
getEntriesIds(int) - Method in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
Gets the ids of all the elements in the given hierarchy level
getEntriesIds(int) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
 
getEntryGeometry(int, String) - Method in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
Gets the geometry of the specified entry in the given hierarchy level
getEntryGeometry(int, String) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
 
getEntryGrouperClass() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Gets the NoSQLEntryGrouper subclass which is in charge of grouping key-value pairs into a single record
getEntryProcessor(String) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Gets the entry processor assigned to process a NoSQL key-value pair identified by the given minor key.
getExtraFieldNames() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets a set of all the extra field names contained in the spatial index
getExtraFields(Map<String, String>) - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
 
getExtraFields(Map<String, String>) - Method in interface oracle.spatial.hadoop.vector.RecordInfoProvider
If the current record contains other fields different to id and geometry that are desired to be stored for fast access, they should be returned here by adding them to the passed map.
getExtraFields(Map<String, String>) - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
 
getExtraFields(Map<String, String>) - Method in class oracle.spatial.hadoop.vector.SpatialIndexRecordInfoProvider
 
getFeatureId() - Method in class oracle.spatial.hadoop.vector.mvsuggest.GeoAreaInfo
Returns the feature id.
getFeatureInfo(String, String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
Gets the information of the feature identified by the layer name and feature id.
getFeatures() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the collection's features
getField(String) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Gets the value of an extra field
getField(String) - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Returns a field with the given name
getFieldData(int, byte[]) - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Returns the value string for the ith field in the given record.
getFieldName(int) - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Returns the name for the ith field of records in this file.
getFieldNames() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Gets the names of all the extra fields contained
getFields() - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Gets a map containing the current fields if any
getFieldType(int) - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Returns the type for the ith field in a record.
getFile() - Method in class oracle.spatial.hadoop.vector.mvsuggest.GeoAreaInfo
Returns the feature template file name.
getFileName() - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
 
getFilterSpatialOperationConfig(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
Gets the SpatialOperationConfig used to filter records for the given job's configuration.
getFilterSpatialOperationConfig(Integer, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
Gets the SpatialOperationConfig used to filter records for the given job's configuration and data set.
getFilterSpatialOperationConfig(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialIndexInputFormat
Gets the SpatialOperationConfig used to filter records for the given job's configuration.
getFilterSpatialOperationConfig(Integer, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialIndexInputFormat
Gets the SpatialOperationConfig used to filter records for the given job's configuration and data set.
getFittingInputSplit(JobConf, <any>, InputSplit) - Static method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
Returns an instance of an InputSplit subclass appropriate for the given InputFormat.
getFittingInputSplit(JobContext, <any>, InputSplit) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Returns an instance of an InputSplit subclass appropriate for the given InputFormat.
getFormatterClassName() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
getGeoJsonTypesToParse(JobConf) - Static method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonInputFormat
Returns the GeoJSON parsing type
getGeoJsonTypesToParse(Configuration) - Static method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonInputFormat
Returns the GeoJSON parsing type
getGeom() - Method in class oracle.spatial.hadoop.vector.geojson.Feature
Gets the feature geometry
getGeom() - Method in interface oracle.spatial.spark.vector.geoenrichment.SpatialFeature
Returns the feature's geometry
getGeometry() - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
 
getGeometry(DeferredObject) - Method in class oracle.spatial.hadoop.vector.hive.function.GeometryParamHelper
 
getGeometry() - Method in interface oracle.spatial.hadoop.vector.hive.HiveRecordInfoProvider
Gets the geometry of the current record or null if the record does not have spatial information.
getGeometry() - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonHiveRecordInfoProvider
 
getGeometry() - Method in class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileHiveRecordInfoProvider
 
getGeometry() - Method in class oracle.spatial.hadoop.vector.JGeometryWritable
Gets the current JGeometry instance
getGeometry() - Method in class oracle.spatial.hadoop.vector.mvsuggest.GeoAreaInfo
Returns the feature geometry.
getGeometry() - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfo
Gets the partition geometry
getGeometry() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Gets the geometry associated to the source record
getGeometry() - Method in interface oracle.spatial.hadoop.vector.RecordInfoProvider
Gets the geometry of the current record
getGeometry() - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
 
getGeometry() - Method in class oracle.spatial.hadoop.vector.SpatialIndexRecordInfoProvider
 
getGeometry() - Method in class oracle.spatial.spark.vector.index.local.RRecord
Gets the current geometry.
getGeometry(T) - Method in class oracle.spatial.spark.vector.rdd.SpatialTransformationContext
Gets the geometry of the given record
getGeometry(T) - Method in class oracle.spatial.spark.vector.rdd.StatefulSpatialTransformationContext
Gets the geometry of the given record
getGeometry() - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Gets the current geometry or null if there is not spatial information
getGeometry() - Method in class oracle.spatial.spark.vector.sql.udf.function.GeometryParamHelper
Obtained jGeometry object based on STGeometry geojson input
getGlobalSpatialConfig(MultiInputDataSet, boolean) - Static method in class oracle.spatial.hadoop.vector.data.conf.MultiInputDataSetConfigurator
Gets the common spatial configuration between all the input data sets contained in the given MultiInputDataSet instance
getGridColumns() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Gets the number of columns in the grid
getGridMbr() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Gets the minimum bounding box of the grid
getGridRows() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Gets the number of rows in the grid
getGroupId() - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
Gets the current group id
getHierarchyDataPaths() - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Gets the paths to hierarchy data catalogs.
getHierarchyIndexPath() - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Gets the HDFS path where the hierarchy data index is located or should be placed once it is generated
getHierarchyInfoClass() - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Gets the HierarchyInfo implementing class which describes the current hierarchy
getHierarchyLevelsNames(HierarchyInfo) - Static method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
 
getHilbertKey(double[]) - Method in class oracle.spatial.hadoop.vector.util.HilbertValueCoDec
Gets the hilbert key for the given point.
getHilbertValue() - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
Gets the hilbert value
getId() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Gets the cluster id
getId() - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Gets the data set id
getId() - Method in class oracle.spatial.hadoop.vector.geojson.Feature
Gets the feature id
getId() - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
 
getId() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Tenants
 
getId() - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfo
Gets the partition id
getId() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Gets the id used to identify the source record
getId() - Method in interface oracle.spatial.hadoop.vector.RecordInfoProvider
Gets the id of the current record
getId() - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
 
getId() - Method in class oracle.spatial.hadoop.vector.SpatialIndexRecordInfoProvider
 
getId() - Method in interface oracle.spatial.spark.vector.geoenrichment.SpatialFeature
Gets the feature's unique identifier
getInClustersPath() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Gets the path where the input cluster information is located
getIndex() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
Gets the path of the local spatial index
getIndex() - Method in class oracle.spatial.spark.vector.index.PartitionKey
Gets the index of the referenced partition
getIndexCount() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets the number of local indexes
getIndexFiles() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets a list of the metadata of each local index
getIndexFilesPath(JobConf) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
Returns the index files path.
getIndexFilesPath(Configuration) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
Returns the index files path.
getIndexMetadataDir() - Method in class oracle.spatial.hadoop.vector.data.SpatialIndexInputDataSet
Gets the directory where the spatial index metadata can be found for this data set
getIndexMetadataDir() - Method in class oracle.spatial.hadoop.vector.mapred.job.IndexedInputBaseJob
Gets the path to the directory where the index metadata is located
getIndexName() - Method in class oracle.spatial.hadoop.vector.data.SpatialIndexInputDataSet
Gets the data set spatial index name
getIndexName() - Method in class oracle.spatial.hadoop.vector.mapred.job.IndexedInputBaseJob
Gets the name of the spatial index to be used as input
getIndexName() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
Gets the index name
getIndexName() - Method in class oracle.spatial.hadoop.vector.RTreeWritable
Gets the index name
getIndexName() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets the spatial index name
getIndexPath() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets the path of the whole spatial index
getInitialKPoints(int) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.InitialKPointsGenerator
Gets k points from the initial array of points
getInput() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets the job input string
getInputDataSet() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets the current input data set
getInputDataSetDescription() - Method in class oracle.spatial.hadoop.vector.data.cmd.FileInputDataSetCmdArgsParser
 
getInputDataSetDescription() - Method in interface oracle.spatial.hadoop.vector.data.cmd.InputDataSetCmdArgsParser
Gets a description of the input data set created by the current parser implementation
getInputDataSetDescription() - Method in class oracle.spatial.hadoop.vector.data.cmd.MultiInputDataSetCmdArgsParser
 
getInputDataSetDescription() - Method in class oracle.spatial.hadoop.vector.data.cmd.NoSQLInputCmdArgsParser
 
getInputDataSetDescription() - Method in class oracle.spatial.hadoop.vector.data.cmd.SimpleInputDataSetCmdArgsParser
 
getInputDataSetDescription() - Method in class oracle.spatial.hadoop.vector.data.cmd.SpatialIndexInputDataSetCmdArgsParser
 
getInputDataSetLocations(AbstractInputDataSet) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
Gets the location(s) of the given input data set when the location is available.
getInputDataSets() - Method in class oracle.spatial.hadoop.vector.data.MultiInputDataSet
Returns a list of all the contained input data sets
getInputFormat() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation
Deprecated.
 
getInputFormat() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialFilterInputFormat
 
getInputFormatClass() - Method in interface oracle.spatial.hadoop.vector.data.AbstractInputDataSet
Gets the InputFormat class used to read the input data set
getInputFormatClass() - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
getInputFormatClass() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets the input format used to read the input data
getInputs() - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
getInputSplit() - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
getInputSplitForInputFormat(Class<<any>>, InputSplit, Configuration) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
Returns the type of InputSplit expected by the given InputFormat class
getInputString() - Method in class oracle.spatial.hadoop.vector.data.FileInputDataSet
Gets the location of the data set's files as a string.
getInstance(JobConf) - Static method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoaderFactory
Gets the only factory instance.
getInstance(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoaderFactory
 
getInstance() - Static method in class oracle.spatial.hadoop.vector.mvsuggest.MVSServiceFactory
Gets an instance of MVSServiceFactory
getIntArg(String, boolean, Integer) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the integer value of an argument
getIntArrayArg(String, boolean, int[]) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the integer array value of an argument
getInternalInputFormat(JobConf) - Method in interface oracle.spatial.hadoop.vector.mapred.input.AbstractCompositeInputFormat
 
getInternalInputFormat(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.AdapterInputFormat
Gets an instance of the class set as the internal input format
getInternalInputFormat(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
getInternalInputFormat(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
Gets an instance of the class set as the internal input format
getInternalInputFormat(Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
getInternalInputFormat(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Gets an instance of the class set as the internal input format
getInternalInputFormatClass(JobConf) - Static method in class oracle.spatial.hadoop.vector.mapred.input.AdapterInputFormat
Gets the internal input format type which is used to actually read the data.
getInternalInputFormatClass(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
getInternalInputFormatClass(JobConf) - Static method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
Gets the internal input format type which is used to actually read the data.
getInternalInputFormatClass(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
getInternalInputFormatClass(JobContext) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Gets the internal input format type which is used to actually read the data.
getIntersectingMBR(double[], double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
getIteration() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Gets the current iteration number
getJarClass() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
getJdbc_datasource() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Tenants
 
getJobAttemptPath(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
getJsonQueryWindow() - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
Gets the query window as a geometry in GeoJSON format
getK() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Gets the number of clusters
getKey() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
Gets the last read record's key
getKey() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
getKey() - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Gets the current record's key
getKeys() - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Gets the keys that identify every path of the data set
getKeyType() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Gets the type of the RDD's keys
getKeyType() - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
Gets the type of the RDD's keys
getKVConfiguration() - Method in interface oracle.spatial.hadoop.vector.nosql.NoSQLContext
Gets the current NoSQLConfiguration
getKVConfiguration() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLContextImpl
 
getKvHosts() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
Gets the KV hosts locations
getKVHosts() - Method in interface oracle.spatial.hadoop.vector.nosql.NoSQLContext
Gets the current KV hosts
getKVHosts() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLContextImpl
 
getKvSecurityProps() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
getKvStoreHosts() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Gets an array containing the KV store hosts locations
getKvStoreName() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Gets the current KV store name
getKvStoreSecurityFile() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
getLayers() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
getLayers() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
Gets the names of all the contained layers
getLayers() - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSService
Gets the layers indexed by MVSuggest
getLayers() - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
getLength() - Method in interface oracle.spatial.hadoop.vector.data.AbstractInputDataSet
Gets the length (in bytes) of the data set
getLength() - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
getLength() - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Gets the data set length in bytes
getLength() - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
getLength() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
getLength() - Method in class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLInputSplit
 
getLength() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
 
getLength() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Gets the length in bytes of the source record
getLevel() - Method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyDataIndexReader
Gets the hierarchy level of the current index
getLevelName(int) - Method in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
Gets the name which identifies the given hierarchy level number.
getLevelName(int) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
 
getLevelNumber(String) - Method in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
Gets the number of the hierarchy level identified by the given name
getLevelNumber(String) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
 
getLoadHierarchyFromLevel(HierarchyInfo, Configuration) - Static method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
Gets the value of the configuration parameter ConfigParams.HIERARCHY_LOAD_MIN_LEVEL.
getLoadHierarchyToLevel(HierarchyInfo, Configuration) - Static method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
Gets the value of the configuration parameter ConfigParams.HIERARCHY_LOAD_MAX_LEVEL.
getLocationField() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
getLocationField(RecordInfoProvider, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
getLocationField(RecordInfoProvider<K, V>, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
Gets the location field name which is the RecordInfo's field containing the the location text that can be sent to MVSuggest.
getLocationField() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
getLocationField(RecordInfoProvider<K, V>, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
Gets the location field name which is the RecordInfo's field containing the the location text that can be sent to MVSuggest.
getLocationField() - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Gets the location field
getLocations() - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
getLocations() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
getLocations() - Method in class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLInputSplit
 
getLocations() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
 
getLocationServiceField() - Method in interface oracle.spatial.hadoop.vector.LocalizableRecordInfoProvider
Gets the name of the field containing text with location information.
getLongArg(String, boolean, Long) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the long value of an argument
getLongArrayArg(String, boolean, long[]) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Gets the long array value of an argument
getMapredInputFormat(JobConf, Class<?>) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
Checks if the given class is an org.apache.hadoop.mapred.InputFormat or an org.apache.hadoop.mapreduce.lib.input.FileInputFormat and returns the appropriate adapter if needed.
getMapRedOutputKeyComponents(String) - Static method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
Gets the components for a hierarchy level-feature id key created using the method HierarchyHelper.createMapRedOutputKey(String, String)
getMatchCountry() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Gets a country name used as context when performing a search
getMatchLayers() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Gets the layer names used to narrow MVS searches
getMaxIterations() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Gets the maximum number of iterations allowed
getMaxPartitionCount() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Gets the maximum number of partitions to be generated
getMaxPartitionSize() - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Gets the size of the partition containing the maximum number of elements
getMaxQuadTreeDepth() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Gets the maximum number of levels contained by the generated QuadTree
getMaxQueryRecords() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Gets the maximum number of records contained in a request to MVSuggest.
getMaxRecordsPerPartition() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Gets the maximum number of RDD elements per partition
getMbr() - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfo
Gets the partition minimum bounding rectangle
getMbr() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets the MBR of the whole indexed data
getMbr() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
Gets the minimum bounding box of the indexed data
getMBR() - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Returns the minimum bounding rectangle, that is, the rectangle enclosing all the data from the current index
getMBR() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
getMbr() - Method in class oracle.spatial.spark.vector.index.SpatialPartition
Gets the partition's minimum bounding rectangle
getMBR() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Gets the minimum bounding rectangle of the RDD
getMBR() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Gets the minimum bounding rectangle of the RDD
getMBRWithTolerance(JGeometry, SpatialConfig) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
getMemberCount() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Gets the number of members contained by the cluster
getMer() - Method in class oracle.spatial.spark.vector.index.local.RRecord
 
getMetadataDir() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
Gets the directory where the index metadata will be stored
getMinPartitionSize() - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Gets the size of the partition containing the minimum number of elements
getMinRecordsPerPartition() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Gets the minimum number of RDD elements per partition
getMultipleInputDataSetsParams(String) - Static method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
getMvsConf() - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService
Gets the MVSuggest configuration
getMvsConfig() - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Gets the MVSuggest configuration
getMvsConfig() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
Gets the current MVSuggest configuration if any
getMVSConfig() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
getMVSConfig() - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSService
Gets the MVSuggest configuration bean
getMVSConfig() - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
getName() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
getName() - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
 
getNamedToMergedOutMap(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.output.MultipleOutputMergeOutputCommitter
 
getNamedToMergedOutMap(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.output.MultipleOutputMergeOutputCommitter
 
getNestedSplit() - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
getNestedSplit() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
getNode(JsonNode, String[][]) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Searches a JSON node given a root node and group of paths where the searched node could be.
getNode(JsonNode, String[]) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Searches a JSON node given a root node and the path of the searched node.
getNoSQLConfig() - Method in class oracle.spatial.hadoop.vector.data.NoSQLInputDataSet
Gets the NoSQL configuration
getNumberOfFields() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Gets the number of extra fields contained by this instance.
getNumberOfLevels() - Method in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
Gets the total number of hierarchy levels
getNumberOfLevels() - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
 
getObjectInspector() - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonSerDe
 
getObjectInspector() - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonToWKTSerDe
 
getObjectInspector() - Method in class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileSerDe
 
getOffset() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Gets the position in file of the source record as an offset in bytes.
getOperation() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
Gets the operation used to filter records
getOperation() - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
getOrdinal() - Method in enum oracle.spatial.hadoop.vector.util.SpatialOperation
Gets the ordinal value of the current enum value
getOrdinates() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Gets the ordinates of the cluster center point
getOrds() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.PointWritable
Gets the point ordinates array
getOutput() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets the job output path
getOutput() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
getOutputCommitter(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
 
getOutputFormat(Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
Gets an instance of the wrapped output format
getOutputFormatClass(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
Gets the wrapped OutputFormat class
getParam(String) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
getParam(String, Number) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
getParams() - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
getParentId(int, String) - Method in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
Gets the id of the parent of the given entry
getParentId(int, String) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
 
getParentKey() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Gets the major key used to select NoSQL entries
getParentRefField() - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
 
getParentRefFieldMapping() - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
 
getParserHandler() - Method in class oracle.spatial.hadoop.vector.data.cmd.MultiInputDataSetCmdArgsParser
Gets the current instance of InputDataSetCmdArgsParserHandler
getParsers(Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.DynamicInputDataSetCmdArgsParserHandler
 
getParsers(Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.InputDataSetCmdArgsParserHandler
Gets the current parsers chain
getPartition() - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
Gets the partition object containing the partition information
getPartition(JoinGroupWritable, RecordInfo, int) - Method in class oracle.spatial.hadoop.vector.join.mapred.JoinPartitioner
 
getPartition(JoinGroupWritable, RecordInfo, int) - Method in class oracle.spatial.hadoop.vector.join.mapreduce.JoinPartitioner
 
getPartition(Object) - Method in class oracle.spatial.spark.vector.index.PartitionKeyBasedPartitioner
 
getPartitionCount() - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Gets the number of partitions.
getPartitionedPaths() - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Gets the paths of the sources that were partitioned.
getPartitionedRDD() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreePartitioning
 
getPartitionedRDD() - Method in interface oracle.spatial.spark.vector.index.SpatialPartitioning
Gets the current spatially partitioned spatial RDD
getPartitioner() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreePartitioning
 
getPartitioner() - Method in interface oracle.spatial.spark.vector.index.SpatialPartitioning
Gets the SpatialPartitioner instance used to generated the partitioned RDD
getPartitioningResultPath() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
Sets the location of a previously generated partitioning result file for the input data sets
getPartitions() - Method in class oracle.spatial.spark.vector.index.PartitionKeyBasedPartitioner
 
getPartitions() - Method in class oracle.spatial.spark.vector.index.SpatialPartitioner
Gets the partitions used to partition an RDD
getPartitionSet() - Method in interface oracle.spatial.hadoop.vector.nosql.NoSQLContext
Gets the current NoSQL partition sets being read
getPartitionSet() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLContextImpl
 
getPartitionSets() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
Gets the partitions in this split
getPartitionsPath() - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
getPath() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Gets the path (as a String) to the file containing the source record
getPathLength(FileStatus, FileSystem) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
getPathLength(Path, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
getPaths() - Method in class oracle.spatial.hadoop.vector.data.FileInputDataSet
Gets the paths where the data set files are located
getPaths(String, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
 
getPersistentServiceLocation() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Gets the path where the MVS folder should be saved in HDFS.
getPoint(long) - Method in class oracle.spatial.hadoop.vector.util.HilbertValueCoDec
Gets a point from a hilbert value
getPoint(double, double, double, double, boolean, double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
getPointDistance(double[], double[], int) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
getPointDistance(double, double, double, double) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
getPos() - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.mapred.input.InputSplitInputFormat.InputSplitRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.mapred.input.KeyPosSubSplitRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultiRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileRecordReader
 
getPositionInMainFile() - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileStreamParser
Returns the bytes position in the main file.
getPreviousIndexes() - Method in class oracle.spatial.spark.vector.index.PartitionKey
Gets an array of partitions indexes which also contain the RDD element this key is associated with.
getProgress() - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapred.input.InputSplitInputFormat.InputSplitRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultiRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileRecordReaderAdapter
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.InputSplitInputFormat.InputSplitRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
getProperties() - Method in class oracle.spatial.hadoop.vector.geojson.Feature
Gets the feature properties
getProperties() - Method in interface oracle.spatial.spark.vector.geoenrichment.SpatialFeature
Gets the feature's properties, if any
getQueryRecordsCount() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSQueryRequester
 
getQueryRecordsCount() - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSQueryRequester
Gets the number of records in the query
getQueryRecordsCount() - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSQueryRequester
 
getQueryWindow() - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
Gets the query window used in the spatial operation
getRddSize() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Gets the size of the RDD to be partitioned/indexed.
getRecord(int) - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Retrieves the nth record in the file.
getRecordInfo(RecordInfoProvider<?, ?>, RecordInfo, Map<String, String>) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
getRecordInfo(T) - Method in class oracle.spatial.spark.vector.rdd.SpatialTransformationContext
Gets a SparkRecordInfo containing information from the give record.
getRecordInfo(T) - Method in class oracle.spatial.spark.vector.rdd.StatefulSpatialTransformationContext
Gets a SparkRecordInfo containing information from the give record.
getRecordInfo(Text, SparkRecordInfo) - Method in class oracle.spatial.spark.vector.recordinfoprovider.GeoJsonRecordInfoProvider
 
getRecordInfo(String, SparkRecordInfo) - Method in class oracle.spatial.spark.vector.recordinfoprovider.GeoJSONTextRecordInfoProvider
 
getRecordInfo(MapWritable, SparkRecordInfo) - Method in class oracle.spatial.spark.vector.recordinfoprovider.ShapeFileRecordInfoProvider
 
getRecordInfo(V, SparkRecordInfo) - Method in interface oracle.spatial.spark.vector.SparkRecordInfoProvider
Extracts spatial and other required data from the value input parameter and sets the extracted data to the recordInfo output parameter
getRecordInfoProvider(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
getRecordInfoProvider(RecordInfoProvider<K, V>, JobConf) - Static method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
Gets an instance of the specified RecordInfoProvider implementation
getRecordInfoProvider() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
Gets an instance of the RecordInfoProvider class currently set in the job configuration
getRecordInfoProvider(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
getRecordInfoProvider() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
getRecordInfoProvider() - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Gets the current RecordInfoProvider instance
getRecordInfoProvider() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialFilterInputFormat
 
getRecordInfoProvider(RecordInfoProvider<K, V>, JobContext) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Gets an instance of the specified RecordInfoProvider implementation
getRecordInfoProvider() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Gets the RDD's SparkRecordInfoProvider instance
getRecordInfoProvider() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Gets the RDD's SparkRecordInfoProvider instance
getRecordInfoProvider() - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Returns the current stream's SparkRecordInfoProvider instance
getRecordInfoProvider() - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
Gets the RDD's SparkRecordInfoProvider instance
getRecordInfoProviderClass() - Method in interface oracle.spatial.hadoop.vector.data.AbstractInputDataSet
Gets the RecordInfoProvider class used to extract required information from the key-value pairs provided by the InputFormat.
getRecordInfoProviderClass() - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
getRecordInfoProviderClass(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
getRecordInfoProviderClass(JobConf) - Static method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
Gets the class of the RecordInfoProvider implementation
getRecordInfoProviderClass() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets the RecordInfoProvider class used to interpret input records.
getRecordInfoProviderClass(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
getRecordInfoProviderClass(JobContext) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Gets the class of the RecordInfoProvider implementation
getRecordNode() - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
Returns the org.codehaus.jackson.JsonNode of the record.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.PointKeyInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.AdapterInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.InputSplitInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.JGeometryKeyInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexTextInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
 
getRecordSize() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Gets the average record size
getRecordValue() - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
Returns the map record value.
getRecordWriter(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.EmptyFileOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
 
getRepository_list() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
getRepositoryName() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Gets the name of the repository folder name in an MVS location
getRequiredArg(String) - Method in class oracle.spatial.hadoop.vector.util.CmdArgsParser
Validates that the given argument exists and returns its string value.
getResponseSpatialContentType() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Gets the type of spatial content returned by MVSuggest when a match is found.
getSample(Class<? extends <any>>, Class<? extends RecordInfoProvider<K, V>>, String, Configuration) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.KMeansSampler
Gets a sample of points from the input data set.
getSample(AbstractInputDataSet, InputDataSetConfiguratorHandler, Configuration) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.KMeansSampler
Gets a sample of points from the input data set.
getSample(Class<? extends <any>>, Class<? extends RecordInfoProvider<K, V>>, String, Configuration) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansSampler
Gets a sample of points from the input data set.
getSample(AbstractInputDataSet, InputDataSetConfiguratorHandler, Configuration) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansSampler
Gets a sample of points from the input data set.
getSample(AbstractInputDataSet, InputDataSetConfiguratorHandler, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialSampler
 
getSample(AbstractInputDataSet, InputDataSetConfiguratorHandler, Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialSampler
 
getSampleSplits(InputSplit[]) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelector
Deprecated.
 
getSampleSplits(Collection<org.apache.hadoop.mapreduce.InputSplit>) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelector
Deprecated.
 
getSamplingFraction() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Gets the sampling fraction used for sampling the RDD for calculating partitions.
getSamplingRatio() - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
Gets the ratio of the sample size to the input data size
getSamplingRatio() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
Gets the ratio of the sample size to the input data size used to sample when a partitioning result file is not set
getSerDeStats() - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonSerDe
 
getSerDeStats() - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonToWKTSerDe
 
getSerDeStats() - Method in class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileSerDe
 
getSerializedClass() - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonSerDe
 
getSerializedClass() - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonToWKTSerDe
 
getSerializedClass() - Method in class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileSerDe
 
getServiceInterfaceType() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Gets the MVSuggest interface type
getServiceLocation() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Gets the MVS service location.
getShape() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Gets the shape of the cells
getShape() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
 
getShapeGeneratorClass() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Gets the ClusterShapeGenerator subclass to be used
getSize() - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfo
Gets the number of points in the partition
getSpanForIndex(JGeometry, double[][]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
getSpanForIndex(JGeometry, double[][], SpatialConfig, boolean) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
getSpanForIndex(JGeometry, double[][], Double) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
getSpatialConfig() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Gets the current spatial configuration
getSpatialConfig() - Method in interface oracle.spatial.hadoop.vector.data.AbstractInputDataSet
Gets the spatial configuration of the data set which defines the spatial features of the data set such as SRID, dimensions and boundaries.
getSpatialConfig() - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
getSpatialConfig() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets the spatial configuration that describes the geometries in the input data.
getSpatialConfigCmdArgs(SpatialConfig, Map<String, Object>) - Static method in class oracle.spatial.hadoop.vector.data.cmd.CmdArgsParserUtils
Converts the properties of the given SpatialConfig instance to command line parameters
getSpatialIndexMetadata(String, String, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
 
getSpatialIndexPath(SpatialIndexMetadata) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
 
getSpatialLayerName() - Method in interface oracle.spatial.spark.vector.geoenrichment.SpatialFeature
Returns the name of the spatial data layer that contains the feature
getSpatiallyIndexedSplitFilter() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialFilterInputFormat
 
getSpatialOperationConfig() - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Gets the configuration of the spatial operation to be performed
getSpatialOperationConfig() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialFilter
Gets the configuration of the spatial operation to be performed to filter the data
getSpatialOperationConfig() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
Gets the spatial operation configuration used to perform the spatial join
getSpatialOperationConfig() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialFilterInputFormat
 
getSpatialOperationConfigCmdArgs(SpatialOperationConfig, Map<String, Object>, boolean) - Static method in class oracle.spatial.hadoop.vector.data.cmd.CmdArgsParserUtils
Converts the properties of the given SpatialOperationConfig instance of command line arguments
getSpatialPartitioningClass() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
 
getSpatialPartitioningClass() - Method in interface oracle.spatial.spark.vector.index.SpatialPartitioningConfiguration
Gets the type of SpatialPartitioning algorithm this configuration is meant for.
getSplit() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileSplitAdapter
 
getSplits(JobConf, int) - Method in class oracle.spatial.hadoop.vector.mapred.input.AdapterInputFormat
 
getSplits(JobConf, int) - Method in class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
getSplits(JobConf, int) - Method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
 
getSplits(JobConf, int) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsInputFormat
 
getSplits(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
getSplits(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter
 
getSplits(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsInputFormat
 
getSplits(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
 
getSplits(JobConf, int) - Method in class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLInputFormat
 
getSplits(JobContext) - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputFormat
 
getSrc() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
Gets the path of the source indexed data
getSrid() - Static method in class oracle.spatial.hadoop.vector.geojson.Feature
 
getSrid(Configuration) - Static method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
Returns the SRID.
getSrid() - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonHiveRecordInfoProvider
Returns the SRID.
getSrid() - Method in class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileHiveRecordInfoProvider
Returns the SRID.
getSrid() - Method in class oracle.spatial.hadoop.vector.RTreeWritable
Gets the SRID
getSrid(Configuration) - Static method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
Returns the SRID.
getSrid() - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Gets the SRS id of the geometries involved in the spatial operation
getSrid() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets the SRID of the indexed data
getSrid() - Method in class oracle.spatial.spark.vector.BasicSparkRecordInfoProvider
 
getSrid() - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerHierarchyConfiguration
Gets the spatial reference system id
getSRID() - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
 
getSRID() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
getSrid() - Method in class oracle.spatial.spark.vector.recordinfoprovider.GeoJsonRecordInfoProvider
 
getSrid() - Method in class oracle.spatial.spark.vector.recordinfoprovider.ShapeFileRecordInfoProvider
 
getSrid() - Method in interface oracle.spatial.spark.vector.SparkRecordInfoProvider
Gets the SRID of the geometries returned by getRecordInfo
getSrs() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the spatial reference system of the geometries in the collection
getSubRange() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
getTag() - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
getTag() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
getTargetEntries() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
getTaskAttemptPath(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
getTemplate(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
getTemplate(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
Gets the template JSON content of the specified layer.
getTemplate(String) - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSService
Gets the template content for a single layer
getTemplate(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
getTenants_list() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
getTenants_repository() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
getTextValue(JsonNode) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Gets a text value of a JSON node containing either, text or numbers
getTimeOut() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
getTimeOutUnit() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
getTolerance() - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Gets the tolerance used in the spatial operation
getTolerance() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets the tolerance that should be used with the indexed data
getTolerance() - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerHierarchyConfiguration
Returns the tolerance used when performing spatial operations
getTolerance() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
 
getTolerance() - Method in interface oracle.spatial.spark.vector.index.SpatialPartitioningConfiguration
 
getTotalElemCount() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Gets the number of indexed records
getTree() - Method in class oracle.spatial.hadoop.vector.RTreeWritable
Gets the current tree
getTrimmed(String) - Method in class oracle.spatial.hadoop.vector.util.TaggedConfiguration
 
getTrimmed(String) - Method in class oracle.spatial.hadoop.vector.util.TaggedJobConf
 
getType() - Method in class oracle.spatial.hadoop.vector.geojson.Feature
Gets the feature type
getType() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the feature collection type.
getType() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Gets the type of the records in the RDD
getType() - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Returns the type of the records in this stream
getUri() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
getUserInputString() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
 
getValue() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
Gets the last read record's value
getValue() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
getValue() - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Gets the current record's value
getValue() - Method in class oracle.spatial.spark.vector.index.local.RRecord
Gets the current value
getValueType() - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Gets the type of the RDD's values
getValueType() - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
Gets the type of the RDD's values
getWorkDirPath() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Gets the path where the mapreduce output is stored at each iteration
getWorkPath() - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
getWrapperOutputCommitter(OutputCommitter, JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
Gets an instance of the WrapperOutputCommitter
getWrapperOutputCommitterClass(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
Gets the WrapperOutputCommitter that contains the final output committer
group(KeyValueVersion, KeyValueVersion, NoSQLContext) - Method in interface oracle.spatial.hadoop.vector.nosql.NoSQLEntryGrouper
Returns true if the two given entries belong to the same record
group(KeyValueVersion, KeyValueVersion, NoSQLContext) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLMajorKeyEntryGrouper
 

H

hashCode() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
 
hashCode() - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
 
hashCode() - Method in class oracle.spatial.spark.vector.index.PartitionKey
 
hashCode() - Method in class oracle.spatial.spark.vector.index.SpatialPartition
 
hashCode() - Method in class oracle.spatial.spark.vector.SparkRecordInfo
 
hasNext() - Method in class oracle.spatial.hadoop.vector.mapred.input.KeyPosRecordInfoLoader
 
hasNext() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
hasNext() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
hasNext() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.KeyPosFileSplitRecordInfoLoader
 
hasNext() - Method in class oracle.spatial.spark.vector.util.FlatMapIterator
 
hasNext() - Method in class oracle.spatial.spark.vector.util.LazyIterator
 
HexBinningAlg - Class in oracle.spatial.hadoop.vector.binning
An implementation of BinningAlg for generating spatial binning with hexagonal cells
HexBinningAlg(BinningConfig) - Constructor for class oracle.spatial.hadoop.vector.binning.HexBinningAlg
Creates a new instance of HexBinningAlg
HierarchicalCountReducer - Class in oracle.spatial.hadoop.vector.mapred
A reducer that takes the output generated by SpatialHierarchicalCountMapper and creates a different output for each hierarchy level.
HierarchicalCountReducer() - Constructor for class oracle.spatial.hadoop.vector.mapred.HierarchicalCountReducer
 
HierarchicalCountReducer - Class in oracle.spatial.hadoop.vector.mapreduce
A reducer that takes the output generated by SpatialHierarchicalCountMapper and creates a different output for each hierarchy level.
HierarchicalCountReducer() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.HierarchicalCountReducer
 
HIERARCHY_DATA_PATHS - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
A comma-separated list of paths of different hierarchy level templates
HIERARCHY_INDEX_PATH - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
The path where a hierarchy index will be stored or can be found.
HIERARCHY_INFO - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
A HierarchyInfo subclass used to describe a hierarchical data set
HIERARCHY_INFO_CLASS - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The current HierarchyInfo class implementation.
HIERARCHY_LOAD_MAX_LEVEL - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The maximum hierarchy level that should be loaded.
HIERARCHY_LOAD_MIN_LEVEL - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The minimum hierarchy level that should be loaded.
HIERARCHY_SEARCH_MULTIPLE_LEVELS - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Tells whether spatial searches must performed only in the maximum level loaded (false) or if the search should continue in lower level numbers (or upper levels if the hierarchy is thought as a tree)
HierarchyDataIndexReader - Class in oracle.spatial.hadoop.vector.hierarchy
Class used to read a hierarchy level data index.
HierarchyDataIndexReader(int, String, Configuration) - Constructor for class oracle.spatial.hadoop.vector.hierarchy.HierarchyDataIndexReader
Creates a new reader for the specified hierarchy level index.
HierarchyDataIndexReader(Path, int, JobConf) - Constructor for class oracle.spatial.hadoop.vector.hierarchy.HierarchyDataIndexReader
Creates a new reader for the specified hierarchy level index.
HierarchyDataIndexWriter - Class in oracle.spatial.hadoop.vector.hierarchy
Class used to create and write an index for hierarchy data.
HierarchyDataIndexWriter(HierarchyInfo, Path, JobConf) - Constructor for class oracle.spatial.hadoop.vector.hierarchy.HierarchyDataIndexWriter
Creates a new instance and sets the HierarchyInfo which contains the hierarchy to be indexed and the path where the generated indices will be stored.
HierarchyHelper - Class in oracle.spatial.hadoop.vector.hierarchy
Provides convenience methods used internally to manage hierarchical catalogs -related tasks
HierarchyHelper() - Constructor for class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
 
HierarchyInfo - Interface in oracle.spatial.hadoop.vector.hierarchy
Represents a hierarchical catalog.
HilbertValueBasedPartitioner - Class in oracle.spatial.hadoop.vector.partition
 
HilbertValueBasedPartitioner(Path, Path[], long, double, long) - Constructor for class oracle.spatial.hadoop.vector.partition.HilbertValueBasedPartitioner
Creates a new instance
HilbertValueBasedPartitioner(Path, String[], long, double, long) - Constructor for class oracle.spatial.hadoop.vector.partition.HilbertValueBasedPartitioner
Creates a new instance
HilbertValueCoDec - Class in oracle.spatial.hadoop.vector.util
Converts from points to hilbert values and vice versa
HilbertValueCoDec(double[][], int[]) - Constructor for class oracle.spatial.hadoop.vector.util.HilbertValueCoDec
Creates a new instance
HilbertValueGroup - Class in oracle.spatial.hadoop.vector.partition
Writable class that holds a hilbert value and a group id.
HilbertValueGroup() - Constructor for class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
Creates a new instance
HilbertValueGroup(long, long) - Constructor for class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
Creates a new instance
HilbertValueGroupGroupComparator - Class in oracle.spatial.hadoop.vector.partition
Groups keys of type HilbertValueGroup by their group id.
HilbertValueGroupKeyComparator - Class in oracle.spatial.hadoop.vector.partition
Compares HilbertValueGroup instances by group id and the by hilbert value.
HilbertValueMapper - Class in oracle.spatial.hadoop.vector.partition.mapred
Calculates a hilbert value for every point of each input record geometry.
HilbertValueMapper() - Constructor for class oracle.spatial.hadoop.vector.partition.mapred.HilbertValueMapper
 
HilbertValueMapper - Class in oracle.spatial.hadoop.vector.partition.mapreduce
Calculates a hilbert value for every point of each input record geometry.
HilbertValueMapper() - Constructor for class oracle.spatial.hadoop.vector.partition.mapreduce.HilbertValueMapper
 
HilbertValueReducer - Class in oracle.spatial.hadoop.vector.partition.mapred
Generates a sorted list of hilbert-value/point pairs.
HilbertValueReducer() - Constructor for class oracle.spatial.hadoop.vector.partition.mapred.HilbertValueReducer
 
HilbertValueReducer - Class in oracle.spatial.hadoop.vector.partition.mapreduce
Generates a sorted list of hilbert-value/point pairs.
HilbertValueReducer() - Constructor for class oracle.spatial.hadoop.vector.partition.mapreduce.HilbertValueReducer
 
HiveRecordInfoProvider - Interface in oracle.spatial.hadoop.vector.hive
An implementation of this interface is used to extract the geometry information from a Hive table's field representing a geometry.
HiveUDFRegister - Class in oracle.spatial.spark.vector.util
 
HiveUDFRegister() - Constructor for class oracle.spatial.spark.vector.util.HiveUDFRegister
 

I

improveQueryWindow(SpatialOperationConfig) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
incrCounter(Enum<?>, long) - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
incrCounter(String, String, long) - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
index() - Method in class oracle.spatial.spark.vector.index.SpatialPartition
 
INDEX_MAP_FILE - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
Boolean parameter.
INDEX_METADATA_DIR - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
The path to the directory where the spatial index metadata is stored
INDEX_NAME - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
A spatial index name
IndexedInputBaseJob<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
Base implementation for jobs which accept a spatial index as input.
IndexedInputBaseJob() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.IndexedInputBaseJob
Creates a new instance
IndexedSpatialFilterMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapred
Reads a local spatial index and takes all the records that satisfy the spatial operation and query window specified in the job configuration
IndexedSpatialFilterMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.IndexedSpatialFilterMapper
 
IndexedSpatialFilterMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce
Reads a local spatial index and takes all the records that satisfy the spatial operation and query window specified in the job configuration
IndexedSpatialFilterMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.IndexedSpatialFilterMapper
 
indexPartitions(PartitioningResult, SpatialOperationConfig, Configuration) - Static method in class oracle.spatial.hadoop.vector.partition.PartitioningUtils
Takes a partitioning result and returns all contained partitions indexed in an r-tree
init(CommonContext) - Method in class oracle.spatial.hadoop.vector.binning.BinningCommonMapper
 
init(CommonContext) - Method in class oracle.spatial.hadoop.vector.binning.BinningCommonReducer
 
init(CommonContext) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansCommonMapper
 
init(CommonContext) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansCommonReducer
 
init(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelector
Deprecated.
 
init(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
init(JobContext) - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Initializes the loader.
init(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
init(String, String[]) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
init(String, String[]) - Method in interface oracle.spatial.hadoop.vector.mvsuggest.LocationService
Initialize the service with the specified server URL.
init(Configuration) - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSService
Initializes a single instance per task.
init(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
init(String, String[]) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
init(NoSQLConfiguration) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLBaseEntryProcessor
 
init(NoSQLConfiguration) - Method in interface oracle.spatial.hadoop.vector.nosql.NoSQLEntryGrouper
Initializes the current entry grouper using the given NoSQLConfiguration
init(NoSQLConfiguration) - Method in interface oracle.spatial.hadoop.vector.nosql.NoSQLEntryProcessor
Initializes the current processor using the given NoSQLConfiguration
init(NoSQLConfiguration) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLGeoJSONEntryProcessor
 
init(NoSQLConfiguration) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLMajorKeyEntryGrouper
 
initialize(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
 
initialize(Configuration) - Method in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
This method is called always once a new instance is created.
initialize(Configuration) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Area
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKB
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKT
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Buffer
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_ConvexHull
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Envelope
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Length
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Simplify
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_SimplifyVW
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Volume
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
initialize(Configuration, Properties) - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonSerDe
 
initialize(Configuration, Properties) - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonToWKTSerDe
 
initialize(Configuration, Properties) - Method in class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileSerDe
 
initialize(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
initialize(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileRecordReaderAdapter
 
initialize(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.InputSplitInputFormat.InputSplitRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileRecordReader
 
InitialKPointsGenerator - Class in oracle.spatial.hadoop.vector.cluster.kmeans
Generates the initial k centers used as the input for the KMeans algorithm based on a sample of points from the input data set.
InitialKPointsGenerator(PointWritable[]) - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.InitialKPointsGenerator
Creates a new instance
INPUT - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
The input data path as a path, a comma-separated list of paths or a path pattern
INPUT_FORMAT - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
A subclass of InputFormat used to read the input data
INPUT_FORMAT - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
 
INPUT_LIST - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
Multiples input data sets specified in the following format: { {input_path1 inputFormatClass1 recordInfoProviderClass1} {input_path2 inputFormatClass2 recordInfoProviderClass2} ...
InputDataSet - Class in oracle.spatial.hadoop.vector
Contains information of a data set which is the input of a job.
InputDataSet() - Constructor for class oracle.spatial.hadoop.vector.InputDataSet
 
InputDataSetCmdArgsParser - Interface in oracle.spatial.hadoop.vector.data.cmd
Defines a common interface for a command line argument parser for an instance of AbstractInputDataSet.
InputDataSetCmdArgsParserHandler - Class in oracle.spatial.hadoop.vector.data.cmd
Defines a handler of InputDataSetCmdArgsParser instances.
InputDataSetCmdArgsParserHandler() - Constructor for class oracle.spatial.hadoop.vector.data.cmd.InputDataSetCmdArgsParserHandler
 
InputDataSetConfigurator - Interface in oracle.spatial.hadoop.vector.data.conf
Defines the interface for a configurator of input data sets.
InputDataSetConfiguratorHandler - Class in oracle.spatial.hadoop.vector.data.conf
A handler of InputDataSetConfigurator instances.
InputDataSetConfiguratorHandler() - Constructor for class oracle.spatial.hadoop.vector.data.conf.InputDataSetConfiguratorHandler
 
InputDataSetUtils - Class in oracle.spatial.hadoop.vector.data
Contains utility static methods related to data sets.
InputDataSetUtils() - Constructor for class oracle.spatial.hadoop.vector.data.InputDataSetUtils
 
InputFormatPathsRelation(int, Object) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation
Deprecated.
 
InputSplitInputFormat - Class in oracle.spatial.hadoop.vector.mapred.input
 
InputSplitInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.InputSplitInputFormat
 
InputSplitInputFormat - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
InputSplitInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.InputSplitInputFormat
 
InputSplitInputFormat.InputSplitRecordReader<V extends InputSplit> - Class in oracle.spatial.hadoop.vector.mapred.input
 
InputSplitInputFormat.InputSplitRecordReader<V extends InputSplit> - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
InputSplitRecordInfoLoader<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input.recordinfo
 
InputSplitRecordInfoLoader() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
InputSplitRecordReader(InputSplit) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.InputSplitInputFormat.InputSplitRecordReader
 
InputSplitRecordReader() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.InputSplitInputFormat.InputSplitRecordReader
 
interacts(JGeometry) - Method in class oracle.spatial.spark.vector.index.SpatialPartition
Returns true if the partition interacts the given geometry
INTERNAL_INPUT_FORMAT - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Input format class used to read input data
IODataSet - Interface in oracle.spatial.hadoop.vector.data
Base interface to represent a data set.
IS_INPUT_INDEX - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
Whether a given input path is a spatial index or not.
isBinary(PrimitiveCategory) - Static method in class oracle.spatial.hadoop.vector.hive.Utils
Return true if the primitive type is a binary, false otherwise.
isBoolean(PrimitiveCategory) - Static method in class oracle.spatial.hadoop.vector.hive.Utils
Return true if the primitive type is a boolean, false otherwise.
isClusterConverging() - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.CriterionFunction
Tell whether the criterion function is converging for the current cluster
isClusterConverging() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.EuclideanDistanceCriterionFunction
 
isClusterConverging() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.SquaredErrorCriterionFunction
 
isConstant() - Method in class oracle.spatial.hadoop.vector.hive.function.GeometryParamHelper
 
isDeletePreviousClusterFiles() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Specifies whether the output generated by previous iterations should be removed or not
isEmpty() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSQueryRequester
 
isEmpty() - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSQueryRequester
Tells whether the query contains any records
isEmpty() - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSQueryRequester
 
isFileInputFormat(Class<?>) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
Utility method used to know if a given class is a subclass of FileInputFormat from wither, Hadoop old or new API
isGeodetic() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Returns true if the geoemetries in the collection are geodetic
isGeodetic() - Method in class oracle.spatial.hadoop.vector.RTreeWritable
Returns true if the data are geodetic, false otherwise
isGeodetic() - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Tells whether the spatial operation deals with geodetic geometries or not
isGeodetic() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Tells whether the indexed data is geodetic or not
isGeodeticSrid(Integer) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
Returns true if the current SRID is geodetic
isInputIndex() - Method in class oracle.spatial.hadoop.vector.data.SpatialIndexInputDataSet
Used for backward compatibility.
isInputIndex() - Method in class oracle.spatial.hadoop.vector.mapred.job.IndexedInputBaseJob
Tells whether the input path is the path to a spatial index.
isInside(JGeometry, JGeometry, Boolean, Double) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
Performs an isInside test between two geometry
isInt(PrimitiveCategory) - Static method in class oracle.spatial.hadoop.vector.hive.Utils
Return true if the primitive type is an int, false otherwise.
isIs_public() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
isJsonString(String) - Static method in class oracle.spatial.hadoop.vector.hive.Utils
Return true if the string is a JSON string, false otherwise.
isJsonString(String) - Static method in class oracle.spatial.spark.vector.sql.udf.util.SparkUDFUtils
Return true if the string is a JSON string, false otherwise.
isLocallyIndexed() - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Returns true if the current index's partitions contain a local spatial index
isLocallyIndexed() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
 
isLocallyIndexed() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
isLocallyIndexed() - Method in interface oracle.spatial.spark.vector.index.SpatialPartitioningConfiguration
 
isMapFile() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
 
isMapFileIndex() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
isMultiInputSupported(Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.InputDataSetConfiguratorHandler
 
isNumber(PrimitiveCategory) - Static method in class oracle.spatial.hadoop.vector.hive.Utils
Return true if the primitive type is a number, false otherwise.
isOverwriteMetadata() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
Gets whether the index metadata should be overwritten in case it already exists.
isOverwritePersistentServiceLocation() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
isPreSpatialFiltering() - Method in class oracle.spatial.spark.vector.rdd.SpatialTransformationContext
 
isPreSpatialFiltering(SpatialOperationConfig) - Static method in class oracle.spatial.spark.vector.rdd.SpatialTransformationContext
 
isProvideTemplates() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Tells whether the templates should be kept in memory so they can be retrieved by calling MVSService.getTemplate(String)
isRebuildIndex() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Tells whether the MVS index should be rebuilt when it does not exist.
isRecoverySupported() - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
isRecoverySupported(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
isRepositoryLocation() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Tells whether the current MVS location refers to a repository or not.
isSamplingRequired(Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelector
Deprecated.
 
isSingleInputSupported(Configuration) - Method in class oracle.spatial.hadoop.vector.data.conf.InputDataSetConfiguratorHandler
 
isSTFunction(String) - Static method in enum oracle.spatial.spark.vector.sql.udf.function.STFunction
 
isString(PrimitiveCategory) - Static method in class oracle.spatial.hadoop.vector.hive.Utils
Return true if the primitive type is a string, false otherwise.
isSTType(String) - Static method in enum oracle.spatial.spark.vector.sql.udf.types.STType
 
isSuccessfullIteration() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans.KMeansIterationResult
Tells whether the iteration finished successfully or not
isTagged(String, String) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsInputFormat
 
isUseLocalIndex() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Gets whether the generated distributed index will contain local indexes or not.
isValidCell(int[]) - Method in interface oracle.spatial.hadoop.vector.binning.BinningAlg
Indicates whether a given cell is valid within the current binning configuration or not
isValidCell(int[]) - Method in class oracle.spatial.hadoop.vector.binning.HexBinningAlg
 
isValidCell(int[]) - Method in class oracle.spatial.hadoop.vector.binning.RectBinningAlg
 
isValidIndexName(String) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
Tells whether the given string is a valid index name
isValidMBR(double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 

J

JDBCUtils - Class in oracle.spatial.spark.vector.util
Contains utility methods for creating Spatial RDDs using the Oracle RDBMS as a source
JDBCUtils() - Constructor for class oracle.spatial.spark.vector.util.JDBCUtils
 
JDBCUtils.ConnectionSupplier - Interface in oracle.spatial.spark.vector.util
Defines a template for creating a lambda function to supply a database connection
JGeometryKeyInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
 
JGeometryKeyInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.JGeometryKeyInputFormat
 
JGeometryKeyInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
JGeometryKeyInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.JGeometryKeyInputFormat
 
JGeometryWritable - Class in oracle.spatial.hadoop.vector
A writable wrapper for the JGeometry class.
JGeometryWritable() - Constructor for class oracle.spatial.hadoop.vector.JGeometryWritable
Creates an empty instance
JGeometryWritable(JGeometry) - Constructor for class oracle.spatial.hadoop.vector.JGeometryWritable
Creates a new instance containing the given JGeometry
jobCleanup(Configuration) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
Performs cleaning tasks once a job has finished.
JobUtils - Class in oracle.spatial.hadoop.vector.util
Contains convenience methods used among demo jobs
JobUtils() - Constructor for class oracle.spatial.hadoop.vector.util.JobUtils
 
join(SpatialJavaRDD<T2>, <any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
JoinCounters - Enum in oracle.spatial.hadoop.vector.join
Defines counters used by mapreduce spatial-join components.
joinFiles(Path, String, String, boolean, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
Joins files into a single file
joinFiles(Path, String, String, boolean, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
joinFiles(Path, String, Path, boolean, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
joinFiles(Path, String, Path, String, String, String, boolean, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
JoinFunction<T,T2,R> - Interface in oracle.spatial.spark.vector.index
 
JoinGroupGroupComparator - Class in oracle.spatial.hadoop.vector.join
A WritableComparator implementation that compare instances of JoinGroupKeyComparator only by their partition ids so records from different data sets but mapped to the same partition can be assigned to the same reduce group.
JoinGroupKeyComparator - Class in oracle.spatial.hadoop.vector.join
A WritableComparator implementation that compares instances of JoinGroupKeyComparator by both, partition id and data set length.
JoinGroupKeyComparator() - Constructor for class oracle.spatial.hadoop.vector.join.JoinGroupKeyComparator
 
JoinGroupWritable - Class in oracle.spatial.hadoop.vector.join
Contains the source data set and assigned partition information for a record .
JoinGroupWritable() - Constructor for class oracle.spatial.hadoop.vector.join.JoinGroupWritable
Creates a new empty instance
JoinGroupWritable(PartitionInfoWritable, int, long) - Constructor for class oracle.spatial.hadoop.vector.join.JoinGroupWritable
Creates a new instance
JoinMapper<K,V> - Class in oracle.spatial.hadoop.vector.join.mapred
Maps records from two different data sets to partitions so all the records laying in the same partition can be grouped.
MultipleInputsFileSplitInputFormat needs to be set as the job's input format in order to read two different data sets.
Partitions are read from a previously generated PartitoningResult file which is expected to be found in the distributed cache with the symbolic link ConfigParams.PARTITIONING_RESULT.
For information about generating a PartitioningResult file see Partitioning.
JoinMapper() - Constructor for class oracle.spatial.hadoop.vector.join.mapred.JoinMapper
 
JoinMapper<K,V> - Class in oracle.spatial.hadoop.vector.join.mapreduce
Maps records from two different data sets to partitions so all the records laying in the same partition can be grouped.
MultipleInputsFileSplitInputFormat needs to be set as the job's input format in order to read two different data sets.
Partitions are read from a previously generated PartitoningResult file which is expected to be found in the distributed cache with the symbolic link ConfigParams.PARTITIONING_RESULT.
For information about generating a PartitioningResult file see Partitioning.
JoinMapper() - Constructor for class oracle.spatial.hadoop.vector.join.mapreduce.JoinMapper
 
JoinOutputCommitter - Class in oracle.spatial.hadoop.vector.join.mapred
Cleans and commits the data output by the different JoinReducer instances.
JoinOutputCommitter() - Constructor for class oracle.spatial.hadoop.vector.join.mapred.JoinOutputCommitter
 
JoinOutputCommitter - Class in oracle.spatial.hadoop.vector.join.mapreduce
Cleans and commits the data output by the different JoinReducer instances.
JoinOutputCommitter(OutputCommitter, JobContext) - Constructor for class oracle.spatial.hadoop.vector.join.mapreduce.JoinOutputCommitter
 
JoinPartitioner - Class in oracle.spatial.hadoop.vector.join.mapred
Implementation of Partitioner.
JoinPartitioner() - Constructor for class oracle.spatial.hadoop.vector.join.mapred.JoinPartitioner
 
JoinPartitioner - Class in oracle.spatial.hadoop.vector.join.mapreduce
Implementation of Partitioner.
JoinPartitioner() - Constructor for class oracle.spatial.hadoop.vector.join.mapreduce.JoinPartitioner
 
JoinReducer - Class in oracle.spatial.hadoop.vector.join.mapred
Processes groups of records from two different data sets that belong to the same partition and determines which pair of records meet the spatial interaction defined in the job's SpatialOperationConfig.
Each reducer task is meant to process all the records for one partition which are expected to be grouped using JoinGroupGroupComparator and the values should be sorted using JoinGroupKeyComparator.
JoinReducer() - Constructor for class oracle.spatial.hadoop.vector.join.mapred.JoinReducer
 
JoinReducer - Class in oracle.spatial.hadoop.vector.join.mapreduce
Processes groups of records from two different data sets that belong to the same partition and determines which pair of records meet the spatial interaction defined in the job's SpatialOperationConfig.
Each reducer task is meant to process all the records for one partition which are expected to be grouped using JoinGroupGroupComparator and the values should be sorted using JoinGroupKeyComparator.
JoinReducer() - Constructor for class oracle.spatial.hadoop.vector.join.mapreduce.JoinReducer
 
JSON_CLUSTER_FILE - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
The name of the resulting JSON file
JsonUtils - Class in oracle.spatial.hadoop.vector.util
Provides some useful JSON-related functions.
JsonUtils() - Constructor for class oracle.spatial.hadoop.vector.util.JsonUtils
 

K

KeyPosFileSplitRecordInfoLoader<V> - Class in oracle.spatial.hadoop.vector.mapreduce.input.recordinfo
An implementation of RecordInfoLoader that works with InputFormats which provide the records offsets in the records keys such as TextInputFormat.
RecordInfo instances returned by this implementation will contain offset and and length information.
KeyPosFileSplitRecordInfoLoader() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.KeyPosFileSplitRecordInfoLoader
 
KeyPosRecordInfoLoader<V> - Class in oracle.spatial.hadoop.vector.mapred.input
RecordInfoLoader subclass for InputFormat implementations which Key is the offset start of a record.
KeyPosRecordInfoLoader(JobConf) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.KeyPosRecordInfoLoader
 
KeyPosSubSplitRecordReader<V> - Class in oracle.spatial.hadoop.vector.mapred.input
SubSplitRecordReader subclass used to read records for internal InputFormats which Key is the start offset of a record.
KeyPosSubSplitRecordReader(List<FileSplit>, <any>, JobConf, Reporter) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.KeyPosSubSplitRecordReader
 
KMeans - Class in oracle.spatial.hadoop.vector.cluster.kmeans
Contains constants, configuration parameter names and utility methods for KMean clusteting
KMeans() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
 
KMeans.KMeansCounters - Enum in oracle.spatial.hadoop.vector.cluster.kmeans
Counters incremented by the KMeans algorithm
KMeans.KMeansIterationResult - Class in oracle.spatial.hadoop.vector.cluster.kmeans
Holds the result of a cluster iteration.
KMeansClustering<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
Class used to perform spatial clustering over an input data set.The clustering is performed running one or more jobs iteratively.
KMeansClustering() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
KMeansClustering<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.job
Class used to perform spatial clustering over an input data set.The clustering is performed running one or more jobs iteratively.
KMeansClustering() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.KMeansClustering
 
KMeansCommonMapper<K_IN,V_IN> - Class in oracle.spatial.hadoop.vector.cluster.kmeans
Maps each input record to its closest cluster center.
KMeansCommonMapper() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansCommonMapper
 
KMeansCommonReducer - Class in oracle.spatial.hadoop.vector.cluster.kmeans
Processes reduce groups which are composed of records mapped to a cluster.
For each group, it updates a cluster center based on its members locations, determines if the cluster center converges and emits the updated cluster information.
KMeansCommonReducer() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansCommonReducer
 
KMeansIterationResult(ClusterInfo[], int, boolean) - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans.KMeansIterationResult
Creates a new instance
KMeansMapper<K,V> - Class in oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce
A subclass of Mapper that maps each input record to its closest cluster center.
Emitted key and value are a ClusterInfo instance containing the cluster information and a RecordInfo instance containing the information of the record mapped to the cluster.
KMeansMapper() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansMapper
 
KMeansReducer - Class in oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce
updates a cluster center based on its members locations, determines if the cluster center converges and emits the updated cluster information.
KMeansReducer() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansReducer
 
KMeansSampler<K,V> - Class in oracle.spatial.hadoop.vector.cluster.kmeans
Samples a dataset to find the initial k cluster centers
KMeansSampler(Class<? extends <any>>, Class<? extends RecordInfoProvider<K, V>>, int) - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansSampler
Creates a new instance
KMeansSampler<K,V> - Class in oracle.spatial.hadoop.vector.cluster.kmeans.mapred
Provides a sample containing points from an input data set.
KMeansSampler(double, int, int) - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.KMeansSampler
Creates a new instance
KMeansSampler(<any>) - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.KMeansSampler
Creates a new instance
KMeansSampler<K,V> - Class in oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce
Provides a sample containing points from an input data set.
KMeansSampler(double, int, int) - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansSampler
Creates a new instance
KMeansSampler(<any>) - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansSampler
Creates a new instance
KNNPairFlatMapFunction<T> - Class in oracle.spatial.spark.vector.rdd
 
KNNPairFlatMapFunction(int, JGeometry, double, SpatialTransformationContext<T>) - Constructor for class oracle.spatial.spark.vector.rdd.KNNPairFlatMapFunction
 
KNNPairFlatMapFunction(<any>, int, SpatialOperationConfig, SpatialTransformationContext<T>) - Constructor for class oracle.spatial.spark.vector.rdd.KNNPairFlatMapFunction
 

L

LazyIterator<T,R> - Class in oracle.spatial.spark.vector.util
 
LazyIterator(Iterator<T>, <any>) - Constructor for class oracle.spatial.spark.vector.util.LazyIterator
 
listMetadataFiles(Configuration) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
Lists the paths to all the spatial index metadata files contained in the currently set metadata folder
listMetadataFiles(Path, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
Lists the paths to all the spatial index metadata files contained in the given metadata filder
load(Configuration) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Loads a binning configuration from the job configuration
load(Configuration) - Method in interface oracle.spatial.hadoop.vector.ConfigurationStorable
Loads the current state from the given job configuration
load(Configuration) - Method in class oracle.spatial.hadoop.vector.data.FileInputDataSet
 
load(Configuration) - Method in class oracle.spatial.hadoop.vector.data.NoSQLInputDataSet
 
load(Configuration) - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
load(Configuration) - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Loads data set information from the configuration.
load(int, Configuration) - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Loads information of the data set with the given id from the configuration
load(Path[], int, JobConf) - Method in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
Loads the hierarchical catalog content from the given paths.
load(Path[], int, JobConf) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
 
load(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
 
load(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Loads the MVSuggest configuration from the job configuration
load(Configuration) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
load(Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Loads a spatial configuration from the job configuration
load(int, Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Loads a spatial configuration associated to a data set id from the job configuration
load(String, Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Loads a tagged spatial configuration from the job configuration
load(Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
load(int, Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
load(String, Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
load(JavaSparkContext, String) - Static method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Reads an existing persisted index from the given path
load(JavaSparkContext, String, Class<T>) - Static method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Reads an existing persisted index from the given path
loadFromIndex(HierarchyDataIndexReader[], int, Configuration) - Method in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
Loads the hierarchical catalog content from previously generated indices.
loadFromIndex(HierarchyDataIndexReader[], int, Configuration) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
 
loadHierarchyLevels(HierarchyInfo, Configuration) - Static method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
Loads the content for all the hierarchy levels defined in the current job configuration using an initialized HierarchyInfo instance.
loadHierarchyLevels(HierarchyInfo, int, int, Configuration) - Static method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
Loads the content for the hierarchy levels from fromLevel to toLevel using an initialized HierarchyInfo instance.
loadInputDataSet(Configuration) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
Loads an instance of AbstractInputDataSet stored in the configuration
loadInputDataSet(String, Configuration) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
Loads an instance of AbstractInputDataSet stored in the configuration using the the given tag
loadJsonAsObject(Path, Class<? extends V>, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
 
loadPartitioningResult(Path, Configuration) - Static method in class oracle.spatial.hadoop.vector.partition.PartitioningUtils
Returns an object representation of a partitioning result file
loadPartitioningResultFromDistCache(Configuration) - Static method in class oracle.spatial.hadoop.vector.partition.PartitioningUtils
Returns an object representation of a partitioning result file contained in the distributed cache.
loadTemplate(String, Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
Loads the template file of the given layer from the path specified
loadTemplate(String, String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
Parses the template JSON for the given layer
loadTemplates(String[], Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
Loads and parses the template files of the given layers from the path specified.
LocalIndex - Class in oracle.spatial.spark.vector.index.local
Provides methods to work with spatial local indexes
LocalIndex() - Constructor for class oracle.spatial.spark.vector.index.local.LocalIndex
 
LocalizableRecordInfoProvider<K,V> - Interface in oracle.spatial.hadoop.vector
A RecordInfoProvider whose records contain a text field which may contain a location information
LocalMVSConfig - Class in oracle.spatial.hadoop.vector.mvsuggest
Holds the configuration values for a Local MVSuggest instance additionally to the general configuration in MVSConfig
LocalMVSConfig() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
 
LocalMVSQueryRequester - Class in oracle.spatial.hadoop.vector.mvsuggest
MVSQueryRequester implementation used to request queries to a standalone MVSuggest service,
LocalMVSService - Class in oracle.spatial.hadoop.vector.mvsuggest
MVSService implementation used to communicate with a standalone instance of MVSuggest service.
LocalMVSService() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
LocationService - Interface in oracle.spatial.hadoop.vector.mvsuggest
This interface provides the search of geometric areas information by strings.

M

main(String[]) - Static method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapred.job.SpatialFilter
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapreduce.job.Binning
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapreduce.job.Categorization
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapreduce.job.KMeansClustering
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapreduce.job.MBR
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapreduce.job.Partitioning
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialFilter
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialIndexing
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialJoin
 
main(String[]) - Static method in class oracle.spatial.hadoop.vector.util.Tools
 
map(<any>) - Method in class oracle.spatial.hadoop.vector.binning.BinningCommonMapper
 
map(K, V, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.binning.mapred.BinMapper
 
map(<any>) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansCommonMapper
 
map(K, V, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.ClusterMembershipMapper
 
map(NullWritable, InputSplit, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.join.mapred.JoinMapper
 
map(Text, RTreeWritable, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
map(NullWritable, FileSplit, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.BufferMapper
 
map(Text, RTreeWritable, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.IndexedSpatialFilterMapper
 
map(NullWritable, InputSplit, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService.MVSMapper
 
map(NullWritable, FileSplit, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.MVSHierachicalCountMapper
 
map(NullWritable, InputSplit, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialFilterMapper
 
map(NullWritable, InputSplit, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialFilterOutputMapper
 
map(NullWritable, InputSplit, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialIndexingMapper
 
map(NullWritable, FileSplit, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
map(NullWritable, FileSplit, Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.MVSHierachicalCountMapper
 
map(NullWritable, InputSplit, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.partition.mapred.HilbertValueMapper
 
MAPRED_KEY_SEPARATOR - Static variable in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
Separator used in composite keys generated by HierarchyHelper.createMapRedOutputKey(String, String)
mapSpatialPartitions(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Calls the given lambda function for each spatial partition matching the spatial filter given by spatialOpConf parameter.
mapSpatialPartitions(<any>) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
mapSpatialPartitions(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
mapSpatialPartitionsWithPartKeys(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
MBR - Class in oracle.spatial.hadoop.vector.mapreduce.job
 
MBR() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.MBR
 
MBR.DoubleArrayWritable - Class in oracle.spatial.hadoop.vector.mapreduce.job
 
MBR.MBRCombiner - Class in oracle.spatial.hadoop.vector.mapreduce.job
 
MBR.MBRMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.job
 
MBR.MBRReducer - Class in oracle.spatial.hadoop.vector.mapreduce.job
 
MBRCombiner() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.MBR.MBRCombiner
 
MBRMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.MBR.MBRMapper
 
MBRReducer() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.MBR.MBRReducer
 
MergeFileOutputCommiter - Class in oracle.spatial.hadoop.vector.mapreduce.output
Merges multiple part files into one single file
MergeFileOutputCommiter(OutputCommitter, JobContext) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.output.MergeFileOutputCommiter
 
MergeFileOutputCommitter - Class in oracle.spatial.hadoop.vector.mapred.output
Merges multiple part files into one single file
MergeFileOutputCommitter() - Constructor for class oracle.spatial.hadoop.vector.mapred.output.MergeFileOutputCommitter
 
MergeJsonFileOutputCommiter - Class in oracle.spatial.hadoop.vector.mapreduce.output
Merges multiple part files into one single file
MergeJsonFileOutputCommiter(OutputCommitter, JobContext) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.output.MergeJsonFileOutputCommiter
 
MergeJsonFileOutputCommitter - Class in oracle.spatial.hadoop.vector.mapred.output
Merges multiple part files into one single file
MergeJsonFileOutputCommitter() - Constructor for class oracle.spatial.hadoop.vector.mapred.output.MergeJsonFileOutputCommitter
 
MIN_SUBSPLIT_DISTANCE - Static variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
The minimum distance (in bytes) between two sub splits to be read by different RecordReader instances.
MISSING_VALUE - Static variable in class oracle.spatial.hadoop.vector.mapred.BufferMapper
 
MR_OUT_DIR - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
The name of the directory where the intermediate results are stored
MultiInputDataSet - Class in oracle.spatial.hadoop.vector.data
Encapsulates a list of one or more input data sets
MultiInputDataSet() - Constructor for class oracle.spatial.hadoop.vector.data.MultiInputDataSet
 
MultiInputDataSetCmdArgsParser - Class in oracle.spatial.hadoop.vector.data.cmd
An implementation of InputDataSetCmdArgsParser to parse command line arguments for input data sets of type MultiInputDataSet
Internally, it uses an implementation of InputDataSetCmdArgsParserHandler to parse the parameters of the nested input data sets
MultiInputDataSetCmdArgsParser(InputDataSetCmdArgsParserHandler, Configuration) - Constructor for class oracle.spatial.hadoop.vector.data.cmd.MultiInputDataSetCmdArgsParser
Creates a new instance
MultiInputDataSetConfigurator - Class in oracle.spatial.hadoop.vector.data.conf
A configurator for data sets of type MultiInputDataSet.
MultiInputDataSetConfigurator(InputDataSetConfiguratorHandler) - Constructor for class oracle.spatial.hadoop.vector.data.conf.MultiInputDataSetConfigurator
Creates a new instance
MultiInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapred
An implementation of MultiInputDataSetConfigurator for the old Hadoop API
MultiInputDataSetConfiguratorImpl(InputDataSetConfiguratorHandler) - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapred.MultiInputDataSetConfiguratorImpl
Creates a new instance
MultiInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapreduce
An implementation of MultiInputDataSetConfigurator for the new Hadoop API
MultiInputDataSetConfiguratorImpl(InputDataSetConfiguratorHandler) - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapreduce.MultiInputDataSetConfiguratorImpl
Creates a new instance
MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation - Class in oracle.spatial.hadoop.vector.mapred.input
Deprecated.
 
MultipleInputsFileSplitInputFormat.SplitSelector - Class in oracle.spatial.hadoop.vector.mapred.input
Deprecated.
 
MultipleInputsInputFormat - Class in oracle.spatial.hadoop.vector.mapred.input
 
MultipleInputsInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsInputFormat
 
MultipleInputsInputFormat - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
MultipleInputsInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsInputFormat
 
MultipleInputsJob - Class in oracle.spatial.hadoop.vector.mapred.job
Base driver class for jobs that accept more than one input data sets which are processed by the same mapper.
MultipleInputsJob() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
Creates a new instance
MultipleJsonOutputMergeOutputCommitter - Class in oracle.spatial.hadoop.vector.mapred.output
Merges the part files of multiple named outputs into one file for each named output
MultipleJsonOutputMergeOutputCommitter() - Constructor for class oracle.spatial.hadoop.vector.mapred.output.MultipleJsonOutputMergeOutputCommitter
 
MultipleJsonOutputMergeOutputCommitter - Class in oracle.spatial.hadoop.vector.mapreduce.output
Merges the part files of multiple named outputs into one file for each named output
MultipleJsonOutputMergeOutputCommitter(OutputCommitter, JobContext) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.output.MultipleJsonOutputMergeOutputCommitter
 
MultipleOutputMergeOutputCommitter - Class in oracle.spatial.hadoop.vector.mapred.output
Merges the part files of multiple named outputs into one file for each named output
MultipleOutputMergeOutputCommitter() - Constructor for class oracle.spatial.hadoop.vector.mapred.output.MultipleOutputMergeOutputCommitter
 
MultipleOutputMergeOutputCommitter - Class in oracle.spatial.hadoop.vector.mapreduce.output
Merges the part files of multiple named outputs into one file for each named output
MultipleOutputMergeOutputCommitter(OutputCommitter, JobContext) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.output.MultipleOutputMergeOutputCommitter
 
MultiRecordReader<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
A record reader that contains one or more record readers.
MultiRecordReader(<any>[]) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.MultiRecordReader
Creates a new instance
MVS_CONFIG_FILE - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
MVS configuration file name
MVSConfig - Class in oracle.spatial.hadoop.vector.mvsuggest
Holds the MVSService configuration.
MVSConfig() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
 
MVSConfig.ResponseSpatialContent - Enum in oracle.spatial.hadoop.vector.mvsuggest
The type of spatial content returned by MVSuggest
MVSConfig.ServiceInterface - Enum in oracle.spatial.hadoop.vector.mvsuggest
The type of MVSuggest interface
MVSConfigFileBean - Class in oracle.spatial.hadoop.vector.mvsuggest
In-memory representation of the MVSuggest configuration file
MVSConfigFileBean() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
MVSConfigFileBean.Repository - Class in oracle.spatial.hadoop.vector.mvsuggest
 
MVSConfigFileBean.Tenants - Class in oracle.spatial.hadoop.vector.mvsuggest
 
MVSHelper - Class in oracle.spatial.hadoop.vector.mvsuggest
This class encapsulates an MVSuggest web client and helps performing configuration tasks and managing the requests.
MVSHelper(String, String[]) - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.MVSHelper
Creates a new instance with the given MVSuggest configuration.
MVSHierachicalCountMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapred
This mapper implementation catalogs records in different hierarchy levels using MVSuggest.
MVSHierachicalCountMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.MVSHierachicalCountMapper
 
MVSHierachicalCountMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce
This mapper implementation catalogs records in different hierarchy levels using MVSuggest.
MVSHierachicalCountMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.MVSHierachicalCountMapper
 
MVSMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.SuggestService.MVSMapper
 
MVSQueryRequester - Interface in oracle.spatial.hadoop.vector.mvsuggest
Component used to request queries to an implementation of MVSuggest.
MVSRepository - Class in oracle.spatial.hadoop.vector.mvsuggest
Reads an holds layers templates from the MVSuggest repository.
MVSRepository(boolean, boolean, boolean) - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
Creates a new instance
MVSService - Interface in oracle.spatial.hadoop.vector.mvsuggest
This interface provides a way to communicate with MVSuggest service independently of the actual service protocol and location.
MVSServiceFactory - Class in oracle.spatial.hadoop.vector.mvsuggest
Factory class used to create instances of MVSService.

N

nearestNeighbors(<any>, int, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Returns the k elements from the RDD which are closest to the query window defined in spatialOpConf
nearestNeighbors(<any>, int, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
nearestNeighbors(JGeometry, int, double) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
Returns the k elements which are closest to the given query window
nearestNeighbors(<any>, int, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaPairRDD
 
nearestNeighbors(JGeometry, int, double) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Returns the k elements which are closest to the given query window
nearestNeighbors(<any>, int, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.rdd.SpatialJavaRDD
Returns the k elements which are closest to a given query window defined in the give spatial operation configuration
nearestNeighbors(<any>, int, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Returns a DStream containing one single element with the k elements which are closest to the given query window
nearestNeighbors(<any>, int, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaPairDStream
Returns a DStream containing one single element with the k elements which are closest to the given query window
needsTaskCommit(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
needsTaskCommit(TaskAttemptContext, Path) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
NEW_INPUT_FORMAT - Static variable in class oracle.spatial.hadoop.vector.mapred.input.AdapterInputFormat
 
next(LongWritable, Text) - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonRecordReader
 
next() - Method in class oracle.spatial.hadoop.vector.mapred.input.FileSplitRecordInfoLoader
 
next(NullWritable, V) - Method in class oracle.spatial.hadoop.vector.mapred.input.InputSplitInputFormat.InputSplitRecordReader
 
next() - Method in class oracle.spatial.hadoop.vector.mapred.input.KeyPosRecordInfoLoader
 
next(LongWritable, V) - Method in class oracle.spatial.hadoop.vector.mapred.input.KeyPosSubSplitRecordReader
 
next(K, V) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultiRecordReader
 
next() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
next(K, V) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterRecordReader
 
next(Text, RecordInfo) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
 
next(K, V) - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
next() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
next() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.KeyPosFileSplitRecordInfoLoader
 
next(Text, RecordInfo) - Method in class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLRecordReader
 
next(LongWritable, MapWritable) - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileRecordReader
 
next() - Method in class oracle.spatial.spark.vector.util.FlatMapIterator
 
next() - Method in class oracle.spatial.spark.vector.util.LazyIterator
 
nextKeyValue() - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
 
nextKeyValue() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileRecordReaderAdapter
 
nextKeyValue() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
nextKeyValue() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.InputSplitInputFormat.InputSplitRecordReader
 
nextKeyValue() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLRecordReader
 
nextKeyValue() - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileRecordReader
 
nextParentRecords(Text, RecordInfoArrayWritable) - Method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyDataIndexReader
Gets the next key (parent id), value (parent's children records) pair
NoSQLBaseEntryProcessor<V> - Class in oracle.spatial.hadoop.vector.nosql
Defines common functionality that can aid on the implementation of a concrete NoSQLEntryProcessor
NoSQLBaseEntryProcessor() - Constructor for class oracle.spatial.hadoop.vector.nosql.NoSQLBaseEntryProcessor
 
NoSQLConfiguration - Class in oracle.spatial.hadoop.vector.nosql
Bean class that contains the properties to connect and query a NoSQL KV store
NoSQLConfiguration() - Constructor for class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
NoSQLContext - Interface in oracle.spatial.hadoop.vector.nosql
Provides the current state when NoSQL key-value pairs are being read by a RecordReader
NoSQLContextImpl - Class in oracle.spatial.hadoop.vector.nosql
A basic implementation of NoSQLContext
NoSQLContextImpl() - Constructor for class oracle.spatial.hadoop.vector.nosql.NoSQLContextImpl
Creates a new instance
NoSQLContextImpl(NoSQLConfiguration, Set<Integer>, String[]) - Constructor for class oracle.spatial.hadoop.vector.nosql.NoSQLContextImpl
Creates a new instance
NoSQLEntryGrouper - Interface in oracle.spatial.hadoop.vector.nosql
Defines behavior of a NoSQL entry grouper component.
NoSQLEntryProcessor - Interface in oracle.spatial.hadoop.vector.nosql
An entry processor can interpret and extract data from a NoSQL entry (key-value pair) and set this data to a Hadoop record defined by a Text key and a RecordInfo value.
NoSQLFileInputFormat - Class in oracle.spatial.hadoop.vector.nosql.mapreduce
 
NoSQLFileInputFormat() - Constructor for class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLFileInputFormat
 
NoSQLGeoJSONEntryProcessor - Class in oracle.spatial.hadoop.vector.nosql
 
NoSQLGeoJSONEntryProcessor() - Constructor for class oracle.spatial.hadoop.vector.nosql.NoSQLGeoJSONEntryProcessor
 
NoSQLHelper - Class in oracle.spatial.hadoop.vector.nosql
Contains utility NoSQL-related functions
NoSQLHelper() - Constructor for class oracle.spatial.hadoop.vector.nosql.NoSQLHelper
 
NoSQLInputCmdArgsParser - Class in oracle.spatial.hadoop.vector.data.cmd
An implementation of InputDataSetCmdArgsParser to parse command line arguments for input data sets of type NoSQLInputDataSet
NoSQLInputCmdArgsParser() - Constructor for class oracle.spatial.hadoop.vector.data.cmd.NoSQLInputCmdArgsParser
 
NoSQLInputDataSet - Class in oracle.spatial.hadoop.vector.data
Represents a NoSQL input data set
NoSQLInputDataSet() - Constructor for class oracle.spatial.hadoop.vector.data.NoSQLInputDataSet
 
NoSQLInputDataSetConfigurator - Class in oracle.spatial.hadoop.vector.data.conf
Configurator that accepts instances of input data sets of type NoSQLInputDataSet
NoSQLInputDataSetConfigurator() - Constructor for class oracle.spatial.hadoop.vector.data.conf.NoSQLInputDataSetConfigurator
 
NoSQLInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapred
An implementation of NoSQLInputDataSetConfigurator for the old Hadoop API
NoSQLInputDataSetConfiguratorImpl() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapred.NoSQLInputDataSetConfiguratorImpl
 
NoSQLInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapreduce
An implementation of NoSQLInputDataSetConfigurator for the new Hadoop API
NoSQLInputDataSetConfiguratorImpl() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapreduce.NoSQLInputDataSetConfiguratorImpl
 
NoSQLInputFormat - Class in oracle.spatial.hadoop.vector.nosql.mapred
A version of NoSQLInputFormat for the Hadoop old API
NoSQLInputFormat() - Constructor for class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLInputFormat
 
NoSQLInputFormat - Class in oracle.spatial.hadoop.vector.nosql.mapreduce
An InputFormat class that can read information from a NoSQL KV store.
NoSQLInputFormat() - Constructor for class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputFormat
 
NoSQLInputSplit - Class in oracle.spatial.hadoop.vector.nosql.mapred
A version of NoSQLInputSplit for the old Hadoop API
NoSQLInputSplit() - Constructor for class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLInputSplit
 
NoSQLInputSplit(List<Set<Integer>>, String[], String[]) - Constructor for class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLInputSplit
 
NoSQLInputSplit - Class in oracle.spatial.hadoop.vector.nosql.mapreduce
An InputSplit containing the NoSQL partitions to be read and how to accces to these partitions
NoSQLInputSplit() - Constructor for class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
Creates a new instance
NoSQLInputSplit(List<Set<Integer>>, String[], String[]) - Constructor for class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
Creates a new instance
NoSQLJGeometryEntryProcessor - Class in oracle.spatial.hadoop.vector.nosql
Gets a geometry from a NoSQL entry where the value is of type JGeometry and sets the value as the RecordInfo geometry
NoSQLJGeometryEntryProcessor() - Constructor for class oracle.spatial.hadoop.vector.nosql.NoSQLJGeometryEntryProcessor
 
NoSQLMajorKeyEntryGrouper - Class in oracle.spatial.hadoop.vector.nosql
Groups entries containing the same major key
NoSQLMajorKeyEntryGrouper() - Constructor for class oracle.spatial.hadoop.vector.nosql.NoSQLMajorKeyEntryGrouper
 
NoSQLRecordReader - Class in oracle.spatial.hadoop.vector.nosql.mapred
A version of NoSQLRecordReader for the Hadoop old API
NoSQLRecordReader(NoSQLInputSplit, Configuration) - Constructor for class oracle.spatial.hadoop.vector.nosql.mapred.NoSQLRecordReader
 
NoSQLRecordReader - Class in oracle.spatial.hadoop.vector.nosql.mapreduce
A NoSQL specific RecordReader implementation
NoSQLRecordReader() - Constructor for class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLRecordReader
 
NoSQLTextEntryProcessor - Class in oracle.spatial.hadoop.vector.nosql
Gets a string key and value from a NoSQL entry and sets them to a RecordInfo as a extra field name-value pair.
NoSQLTextEntryProcessor() - Constructor for class oracle.spatial.hadoop.vector.nosql.NoSQLTextEntryProcessor
 
numFields() - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Returns the number of fields in each record.
numPartitions() - Method in class oracle.spatial.spark.vector.index.PartitionKeyBasedPartitioner
 
numRecords() - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Returns the number of records in the DBF file.

O

openGroup() - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
openNameComplexValue(String) - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
openNestedBlock() - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
oracle.spatial.hadoop.vector - package oracle.spatial.hadoop.vector
Contains Writable classes, interfaces as well as other common types used by the vector analysis mapreduce components.
oracle.spatial.hadoop.vector.binning - package oracle.spatial.hadoop.vector.binning
Contains classes used for spatial binning.
oracle.spatial.hadoop.vector.binning.mapred - package oracle.spatial.hadoop.vector.binning.mapred
Mappers and reducers for binning generation.
oracle.spatial.hadoop.vector.binning.mapreduce - package oracle.spatial.hadoop.vector.binning.mapreduce
Mappers and reducers (Hadoop New API) for binning generation.
oracle.spatial.hadoop.vector.cluster.kmeans - package oracle.spatial.hadoop.vector.cluster.kmeans
Contains classes used for k-means clustering .
oracle.spatial.hadoop.vector.cluster.kmeans.mapred - package oracle.spatial.hadoop.vector.cluster.kmeans.mapred
Contains mapreduce-related components to perform the k-means clustering algorithm.
oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce - package oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce
Contains mapreduce-related components (Hadoop new API) to perform the k-means clustering algorithm.
oracle.spatial.hadoop.vector.data - package oracle.spatial.hadoop.vector.data
Classes for representing data sets.
oracle.spatial.hadoop.vector.data.cmd - package oracle.spatial.hadoop.vector.data.cmd
Parsers for parsing data set parameters from command line interface.
oracle.spatial.hadoop.vector.data.conf - package oracle.spatial.hadoop.vector.data.conf
Data sets Hadoop job configurators.
oracle.spatial.hadoop.vector.data.conf.mapred - package oracle.spatial.hadoop.vector.data.conf.mapred
Data sets configurators implementations for the old Hadoop API.
oracle.spatial.hadoop.vector.data.conf.mapreduce - package oracle.spatial.hadoop.vector.data.conf.mapreduce
Data sets configurators implementations for the new Hadoop API.
oracle.spatial.hadoop.vector.geojson - package oracle.spatial.hadoop.vector.geojson
Contains RecordInfoProvider and InputFormats for GeoJSON files.
oracle.spatial.hadoop.vector.geojson.mapred - package oracle.spatial.hadoop.vector.geojson.mapred
Contains RecordReader and InputFormats for GeoJSON files.
oracle.spatial.hadoop.vector.geojson.mapreduce - package oracle.spatial.hadoop.vector.geojson.mapreduce
Contains RecordReader and InputFormats for GeoJSON files (Hadoop new API).
oracle.spatial.hadoop.vector.hierarchy - package oracle.spatial.hadoop.vector.hierarchy
Classes used to manage hierarchical data catalogs.
oracle.spatial.hadoop.vector.hierarchy.impl - package oracle.spatial.hadoop.vector.hierarchy.impl
Contains HierarchyInfo implementations .
oracle.spatial.hadoop.vector.hive - package oracle.spatial.hadoop.vector.hive
Contains classes to create geometries.
oracle.spatial.hadoop.vector.hive.function - package oracle.spatial.hadoop.vector.hive.function
Contains classes to perform operations using one or two geometries.
oracle.spatial.hadoop.vector.hive.json - package oracle.spatial.hadoop.vector.hive.json
Contains GeoJSON related SerDes and a GeoJSON HiveRecordInfoProvider.
oracle.spatial.hadoop.vector.hive.shapefile - package oracle.spatial.hadoop.vector.hive.shapefile
Contains a Shapefile SerDe and a Shapefile HiveRecordInfoProvider.
oracle.spatial.hadoop.vector.join - package oracle.spatial.hadoop.vector.join
Spatial join - related classes
oracle.spatial.hadoop.vector.join.mapred - package oracle.spatial.hadoop.vector.join.mapred
Mapreduce-related classed for performing spatial join
oracle.spatial.hadoop.vector.join.mapreduce - package oracle.spatial.hadoop.vector.join.mapreduce
Mapreduce-related classed for performing spatial join (Hadoop new API)
oracle.spatial.hadoop.vector.mapred - package oracle.spatial.hadoop.vector.mapred
Mappers and reducers used for vector analysis jobs.
oracle.spatial.hadoop.vector.mapred.input - package oracle.spatial.hadoop.vector.mapred.input
Input format and record readers implementations.
oracle.spatial.hadoop.vector.mapred.job - package oracle.spatial.hadoop.vector.mapred.job
Contains job drivers.
oracle.spatial.hadoop.vector.mapred.output - package oracle.spatial.hadoop.vector.mapred.output
Contains OutputFormat and OutputCommitter implementations .
oracle.spatial.hadoop.vector.mapreduce - package oracle.spatial.hadoop.vector.mapreduce
Mappers and reducers used for vector analysis jobs (Hadoop new API).
oracle.spatial.hadoop.vector.mapreduce.input - package oracle.spatial.hadoop.vector.mapreduce.input
Input format and record readers implementations (Hadoop new API).
oracle.spatial.hadoop.vector.mapreduce.input.recordinfo - package oracle.spatial.hadoop.vector.mapreduce.input.recordinfo
Classes to help on reading and converting records to RecordInfoLoader.
oracle.spatial.hadoop.vector.mapreduce.job - package oracle.spatial.hadoop.vector.mapreduce.job
Contains job drivers (Hadoop new API).
oracle.spatial.hadoop.vector.mapreduce.output - package oracle.spatial.hadoop.vector.mapreduce.output
Contains OutputFormat and OutputCommitter implementations (Hadoop new API).
oracle.spatial.hadoop.vector.mvsuggest - package oracle.spatial.hadoop.vector.mvsuggest
Contains classes used to communicate with MVSuggest.
oracle.spatial.hadoop.vector.nosql - package oracle.spatial.hadoop.vector.nosql
Classes used for reading and processing data from NoSQL.
oracle.spatial.hadoop.vector.nosql.mapred - package oracle.spatial.hadoop.vector.nosql.mapred
Old Hadoop API InputFormat implementation used for reading data from NoSQL.
oracle.spatial.hadoop.vector.nosql.mapreduce - package oracle.spatial.hadoop.vector.nosql.mapreduce
New Hadoop API InputFormat implementation used for reading data from NoSQL.
oracle.spatial.hadoop.vector.partition - package oracle.spatial.hadoop.vector.partition
Classes used to perform spatial partitioning
oracle.spatial.hadoop.vector.partition.mapred - package oracle.spatial.hadoop.vector.partition.mapred
Mappers and reducers used for Hilbert Value sorted list generation which is used to perform spatial partitioning
oracle.spatial.hadoop.vector.partition.mapreduce - package oracle.spatial.hadoop.vector.partition.mapreduce
Mappers and reducers used for Hilbert Value sorted list generation which is used to perform spatial partitioning (Hadoop new API)
oracle.spatial.hadoop.vector.shapefile - package oracle.spatial.hadoop.vector.shapefile
Contains RecordInfoProvider and InputFormats for ESRI Shapefiles.
oracle.spatial.hadoop.vector.shapefile.mapred - package oracle.spatial.hadoop.vector.shapefile.mapred
Contains RecordReader and InputFormats for ESRI Shapefiles.
oracle.spatial.hadoop.vector.shapefile.mapreduce - package oracle.spatial.hadoop.vector.shapefile.mapreduce
Contains RecordReader and InputFormats for ESRI Shapefiles (Hadoop new API).
oracle.spatial.hadoop.vector.util - package oracle.spatial.hadoop.vector.util
Contains utility classes used by other components of this API.
oracle.spatial.spark.vector - package oracle.spatial.spark.vector
Core components used by the whole API
oracle.spatial.spark.vector.geoenrichment - package oracle.spatial.spark.vector.geoenrichment
Components used for geometry enrichment.
oracle.spatial.spark.vector.index - package 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.local - package oracle.spatial.spark.vector.index.local
Local spatial index related classes.
oracle.spatial.spark.vector.index.quadtree - package oracle.spatial.spark.vector.index.quadtree
QuadTree implementations of DistributedSpatialIndex and SpatialPartitioning
oracle.spatial.spark.vector.rdd - package oracle.spatial.spark.vector.rdd
Spatial RDD definitions
oracle.spatial.spark.vector.recordinfoprovider - package oracle.spatial.spark.vector.recordinfoprovider
Contains RecordInfoProviders for GeoJSON files and ESRI Shapefiles.
oracle.spatial.spark.vector.serialization - package oracle.spatial.spark.vector.serialization
Custom serializers and serialization-related classes.
oracle.spatial.spark.vector.sql - package oracle.spatial.spark.vector.sql
 
oracle.spatial.spark.vector.sql.udf.function - package oracle.spatial.spark.vector.sql.udf.function
 
oracle.spatial.spark.vector.sql.udf.types - package oracle.spatial.spark.vector.sql.udf.types
 
oracle.spatial.spark.vector.sql.udf.util - package oracle.spatial.spark.vector.sql.udf.util
 
oracle.spatial.spark.vector.streaming.dstream - package oracle.spatial.spark.vector.streaming.dstream
Spatial DStream Defintions
oracle.spatial.spark.vector.util - package oracle.spatial.spark.vector.util
Utility classes for the Spark Vector API
OUTPUT - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
The path where the job output will be stored
OVERWRITE_INDEX_METADATA - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
Whether the spatial index metadata can be overwritten in case it already exists

P

pairFlatMap(<any>) - Static method in class oracle.spatial.spark.vector.util.FunctionAdapters
 
PARAM_SPATIAL_EVAL_STAGE - Static variable in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
PARAM_WD_DISTANCE - Static variable in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
parse(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.InputDataSetCmdArgsParserHandler
Finds the appropriate instance of InputDataSetCmdArgsParser for the given command line arguments and then creates the input data set instance by calling the method InputDataSetCmdArgsParser.parseCmdArgs(CmdArgsParser, Configuration) on the parser.
parseCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.FileInputDataSetCmdArgsParser
 
parseCmdArgs(CmdArgsParser, Configuration) - Method in interface oracle.spatial.hadoop.vector.data.cmd.InputDataSetCmdArgsParser
Processes the command line arguments and creates an instance of AbstractInputDataSet
parseCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.MultiInputDataSetCmdArgsParser
 
parseCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.NoSQLInputCmdArgsParser
 
parseCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.SimpleInputDataSetCmdArgsParser
 
parseCmdArgs(CmdArgsParser, Configuration) - Method in class oracle.spatial.hadoop.vector.data.cmd.SpatialIndexInputDataSetCmdArgsParser
 
parseSpatialConfig(CmdArgsParser) - Static method in class oracle.spatial.hadoop.vector.data.cmd.CmdArgsParserUtils
Returns an instance of SpatialConfig from the given parameters
parseString(String) - Static method in enum oracle.spatial.hadoop.vector.geojson.GeoJsonParseType
Returns the GeoJsonParseType object related to the specified string.
partition(SpatialJavaRDD<V>, QuadTreePartition, JavaSparkContext) - Static method in class oracle.spatial.spark.vector.index.quadtree.QuadTreePartitioning
 
PARTITION_RESULT_FILE - Static variable in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
PartitionInfo - Class in oracle.spatial.hadoop.vector.partition
Represents a partition.
PartitionInfo(int, JGeometry, long) - Constructor for class oracle.spatial.hadoop.vector.partition.PartitionInfo
Creates a new instance
PartitionInfo(int) - Constructor for class oracle.spatial.hadoop.vector.partition.PartitionInfo
Creates a new instance
PartitionInfoWritable - Class in oracle.spatial.hadoop.vector.partition
Writable class that holds an instance of PartitionInfo
PartitionInfoWritable() - Constructor for class oracle.spatial.hadoop.vector.partition.PartitionInfoWritable
Creates a new instance
PartitionInfoWritable(PartitionInfo) - Constructor for class oracle.spatial.hadoop.vector.partition.PartitionInfoWritable
Creates a new instance
Partitioning - Class in oracle.spatial.hadoop.vector.mapred.job
This class can be used to run or configure a job for spatially partitioning one or more data sets.
Partitioning can be performed using only a fraction of the input data size by setting the Partitioning.setSamplingRatio(double) property (by default it is set to 0.1).
The job's output is a partitioning file, a GeoJSON file containing the generated partitions with information such as the partition geometry and number of elements in the partition.
Partitioning() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
Partitioning - Class in oracle.spatial.hadoop.vector.mapreduce.job
This class can be used to run or configure a job for spatially partitioning one or more data sets.
Partitioning can be performed using only a fraction of the input data size by setting the Partitioning.setSamplingRatio(double) property (by default it is set to 0.1).
The job's output is a partitioning file, a GeoJSON file containing the generated partitions with information such as the partition geometry and number of elements in the partition.
Partitioning() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.Partitioning
 
PARTITIONING_RESULT - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The path of a partitioning result file.
PartitioningResult - Class in oracle.spatial.hadoop.vector.partition
Object representation of a GeoJSON partitioning result file.
PartitioningResult() - Constructor for class oracle.spatial.hadoop.vector.partition.PartitioningResult
 
PartitioningUtils - Class in oracle.spatial.hadoop.vector.partition
Provides miscellaneous utility functions for working with partitions.
PartitioningUtils() - Constructor for class oracle.spatial.hadoop.vector.partition.PartitioningUtils
 
PartitioningUtils.PartitionCounters - Enum in oracle.spatial.hadoop.vector.partition
Counters used by mapreduce components when calculating hilbert values
PartitionKey - Class in oracle.spatial.spark.vector.index
A reference to an existing SpatialPartition.
PartitionKey() - Constructor for class oracle.spatial.spark.vector.index.PartitionKey
Creates an empty instance
PartitionKey(int) - Constructor for class oracle.spatial.spark.vector.index.PartitionKey
Creates an instance pointing to a partition with the given index
PartitionKey(int, Integer[]) - Constructor for class oracle.spatial.spark.vector.index.PartitionKey
Creates an instance pointing to a partition with the given index and the given previousIndexes
PartitionKeyBasedPartitioner - Class in oracle.spatial.spark.vector.index
A Partitioner that maps elements from pair RDDs which keys are of type PartitionKey, to partitions of type SpatialPartition which have been previously calculated by a SpatialPartitioning algorithm implementation.
PartitionKeyBasedPartitioner(List<SpatialPartition>) - Constructor for class oracle.spatial.spark.vector.index.PartitionKeyBasedPartitioner
Creates a new instance which will map RDD elements to the given spatial partitions
pathsToStringArray(Path[]) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
pathToString(List<String>) - Static method in class oracle.spatial.hadoop.vector.nosql.NoSQLHelper
Converts a given path represented as a list into a string
performFilter(JGeometry, SpatialOperationConfig) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
Performs the spatial operation described by the SpatialOperationConfig parameter.
persist(StorageLevel) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Sets the index' internal RDD's storage level to persist its values across operations after the first time it is computed.
persist(StorageLevel) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
PointKeyInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.cluster.kmeans.mapred
InputFormat implementation that returns each input record with spatial information as single point.
PointKeyInputFormat() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.PointKeyInputFormat
 
PointKeyInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce
InputFormat implementation that returns each input record with spatial information as single point.
PointKeyInputFormat() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.PointKeyInputFormat
 
PointWritable - Class in oracle.spatial.hadoop.vector.cluster.kmeans
A writable class that holds a point ordinates
PointWritable() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.PointWritable
Creates a new instance
PointWritable - Class in oracle.spatial.hadoop.vector
An ArrayWritable subclass that contains DoubleWritable values.
PointWritable() - Constructor for class oracle.spatial.hadoop.vector.PointWritable
 
prepend(InputDataSetConfigurator) - Method in class oracle.spatial.hadoop.vector.data.conf.DynamicInputDataSetConfiguratorHandler
Adds a configurator at the beginning of the configurators chain
prependParser(InputDataSetCmdArgsParser) - Method in class oracle.spatial.hadoop.vector.data.cmd.DynamicInputDataSetCmdArgsParserHandler
Inserts a parser at the beginning of the parsers chain
preprocess(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
Checks whether partitioning is required and if so, it runs the partitioning process.
preprocess(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialJoin
 
primaryFilter(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
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.
primaryFilter(<any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
print() - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
nicely print out the general information of this DBF file.
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Extracts and validates arguments from the command line
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
 
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialFilter
 
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
processArgs(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService
 
processEntry(KeyValueVersion, Text, RecordInfo, NoSQLContext) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLBaseEntryProcessor
 
processEntry(KeyValueVersion, Text, RecordInfo, NoSQLContext) - Method in interface oracle.spatial.hadoop.vector.nosql.NoSQLEntryProcessor
Sets information from the given NoSQL entry to the passed outKey and outValue
progress() - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
PROPERTY_ID - Static variable in class oracle.spatial.spark.vector.recordinfoprovider.GeoJSONTextRecordInfoProvider
Name of the id property
pushRequest(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSHelper
Adds a field to the current request.

Q

QuadTreeConfiguration - Class in oracle.spatial.spark.vector.index.quadtree
Configuration used by QuadTreeDistIndex and QuadTreePartitioning.
QuadTreeConfiguration() - Constructor for class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Creates an empty instance
QuadTreeConfiguration(boolean) - Constructor for class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Creates a new instance and sets the useLocalIndex property with the given value
QuadTreeDistIndex<T> - Class in oracle.spatial.spark.vector.index.quadtree
An implementation of DistributedSpatialIndex based on a QuadTree
QuadTreeDistIndex(Class<T>) - Constructor for class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
Crates a new instance ready for an RDD of the given generic type
QuadTreePartitioning<T> - Class in oracle.spatial.spark.vector.index.quadtree
An implementation of SpatialPartitioning that uses a QuadTree to partition an existing spatial RDD
QuadTreePartitioning(JavaSparkContext, SpatialJavaRDD<T>, QuadTreeConfiguration) - Constructor for class oracle.spatial.spark.vector.index.quadtree.QuadTreePartitioning
Creates a new instance and partitions the given RDD using the given configuration
QUERY_WINDOW - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
A query window used in a spatial operation.

R

read(JavaSparkContext, String) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Loads a persisted index from the given path.
read(JavaSparkContext, String, String) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
 
read(JavaSparkContext, String) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
read(JavaSparkContext, String, String) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
read(Kryo, Input, Class<FastJGeometry>) - Method in class oracle.spatial.spark.vector.serialization.FastJGeometryKryoSerializer
 
read(Kryo, Input, Class<<any>>) - Method in class oracle.spatial.spark.vector.serialization.RStarTreeKryoSerializer
 
readClusters(FileStatus[], int, Configuration) - Static method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Reads the information from a list of cluster files
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.PointWritable
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.JGeometryWritable
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileSplitAdapter
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfoWritable
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.RecordInfo
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.RTreeLoadable
 
readFields(DataInput) - Method in class oracle.spatial.hadoop.vector.RTreeWritable
 
readFields(DataInput) - Method in class oracle.spatial.spark.vector.index.PartitionKey
 
readFields(DataInput) - Method in class oracle.spatial.spark.vector.index.SpatialPartition
 
readGeomCollection(JsonNode, int, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a geometry collection from a geoJSON node
readGeometry(String, int, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a JGeometry from a geoJSON string in the form: {"type":<geometry-type>", "coordinates":[c1,c2,....cn]}
readGeometry(String) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a JGeometry from a geoJSON string in the form: {"type":<geometry-type>", "crs": { "type": "name", "properties": {"name": "EPSG:SRID"}}"coordinates":[c1,c2,....cn]}
readGeometry(String, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a JGeometry from a geoJSON string in the form: {"type":<geometry-type>", "coordinates":[c1,c2,....cn]}
readGeometry(JsonNode, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
 
readGeometry(JsonNode, int, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a JGeometry from a geoJSON node in the form: {"type":<geometry-type>", "coordinates":[c1,c2,....cn]}
readLine(JsonNode, int, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a line geometry collection from a geoJSON node
readMetadata(Path, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
 
readMetadata(InputStream) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
Reads a spatial index metadata from an input stream
readMultiLineString(JsonNode, int, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a MultiLineString from a geoJSON node
readMultiPoint(JsonNode, int, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a MultiPoint element from a geoJSON node
readMultiPolygon(JsonNode, int, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a multi-polygon geometry collection from a geoJSON node
readNextRecord() - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileStreamParser
Returns a map with the Shapefile attributes including ShapeFileInputFormat.GEOMETRY_ATTRIBUTE.
readPoint(JsonNode, int, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a point geometry collection from a geoJSON node
readPolygon(JsonNode, int, int) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Reads a polygon geometry collection from a geoJSON node
readType() - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonStreamParser
Reads the GeoJSON object.
RECORD_INFO_INCLUDE_PATH_FIELD - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Whether the RecordInfo path property should be set with the current split path when creating a record info
RECORD_INFO_PROVIDER - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
A RecordInfoProvider subclass to be used to interpret input records.
RECORD_INFO_PROVIDER - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Implementing class of RecordInfoProvider
RecordInfo - Class in oracle.spatial.hadoop.vector
Writable class that contains a subset of the data of a certain record called source record, typically, the record's id and spatial information as a JGeometry instance.
RecordInfo() - Constructor for class oracle.spatial.hadoop.vector.RecordInfo
Creates a new empty instance
RecordInfo(RecordInfo) - Constructor for class oracle.spatial.hadoop.vector.RecordInfo
Creates a new instance from another instance.
RecordInfoArrayWritable - Class in oracle.spatial.hadoop.vector
An ArrayWritable that contains instances of RecordInfo.
RecordInfoArrayWritable() - Constructor for class oracle.spatial.hadoop.vector.RecordInfoArrayWritable
Creates a new instance
RecordInfoLoader<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
A convenience class to read records as RecordInfo instances from an InputSplit using the internalInputFormat of a CompositeInputFormat implementation set as the current input format in the job configuration and the current RecordInfoProvider.
RecordInfoLoader(JobConf) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
Creates a new instance.
RecordInfoLoader<K,V> - Interface in oracle.spatial.hadoop.vector.mapreduce.input.recordinfo
Defines an interface to get the RecordInfo representation of records that are read from an input split, typically used in jobs where the whole block is passed to a mapper using FileSplitInputFormat.
Records are expected to be read using an input format and a RecordInfoProvider defined in the in the job configuration.
RecordInfoLoaderFactory - Class in oracle.spatial.hadoop.vector.mapred.input
Class used to create instances of RecordInfoLoader
RecordInfoLoaderFactory - Class in oracle.spatial.hadoop.vector.mapreduce.input.recordinfo
 
RecordInfoProvider<K,V> - Interface in oracle.spatial.hadoop.vector
An implementation of this interface is used to extract certain information needed by the API from any record represented as a Key,Value pair, typically, obtained from an InputFormat.
recordSize() - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Returns the record size in the DBF file.
recoverTask(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
RectBinningAlg - Class in oracle.spatial.hadoop.vector.binning
An implementation of BinningAlg for generating spatial binning with rectangular cells
RectBinningAlg(BinningConfig) - Constructor for class oracle.spatial.hadoop.vector.binning.RectBinningAlg
Creates a new instance of RectBinningAlg
reduce(<any>) - Method in class oracle.spatial.hadoop.vector.binning.BinningCommonReducer
 
reduce(LongWritable, Iterator<RecordInfo>, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.binning.mapred.BinReducer
 
reduce(<any>) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansCommonReducer
 
reduce(ClusterInfo, Iterator<RecordInfo>, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.ClusterCenterReducer
 
reduce(JoinGroupWritable, Iterator<RecordInfo>, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.join.mapred.JoinReducer
 
reduce(Text, Iterator<LongWritable>, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.HierarchicalCountReducer
 
reduce(Text, Iterator<RecordInfo>, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService.SuggestServiceReducer
 
reduce(Text, Iterator<RecordInfo>, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialFilterReducer
 
reduce(Text, Iterable<LongWritable>, Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.HierarchicalCountReducer
 
reduce(HilbertValueGroup, Iterator<RecordInfo>, <any>, Reporter) - Method in class oracle.spatial.hadoop.vector.partition.mapred.HilbertValueReducer
 
register(SparkConf) - Static method in class oracle.spatial.spark.vector.serialization.SpatialVectorKryoRegistrator
Sets this class as the current Kryo registrator by setting the property spark.kryo.registrator
registerClasses(Kryo) - Method in class oracle.spatial.spark.vector.serialization.SpatialVectorKryoRegistrator
 
registerUDFs(SparkSession) - Static method in class oracle.spatial.spark.vector.sql.udf.function.FunctionExecutor
Registers in Spark session all the known UDF to process geometries
registerUDFs(HiveContext) - Static method in class oracle.spatial.spark.vector.util.HiveUDFRegister
Registers in Hive Context all the known UDF to process geometries
remove() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
remove() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
removeAllTargetEntries() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Removes all the NoSQL minor keys that were added previously to be included in a job mapper value.
removeConfigurator(InputDataSetConfigurator) - Method in class oracle.spatial.hadoop.vector.data.conf.DynamicInputDataSetConfiguratorHandler
Removes a configurator from the configurators chain
removeField(String) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Removes the extra field with the given name
removeField(String) - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Removes a field from the record info
removeInputDataSet(AbstractInputDataSet) - Method in class oracle.spatial.hadoop.vector.data.MultiInputDataSet
Removes the given input data set
removeInputDataSet(InputDataSet) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
removeParser(InputDataSetCmdArgsParser) - Method in class oracle.spatial.hadoop.vector.data.cmd.DynamicInputDataSetCmdArgsParserHandler
Removes the given parser from the parsers chain
removeSpatialIndex(String, String, boolean) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
 
removeSpatialIndex(String, String, boolean, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
 
removeTag(String, String) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsInputFormat
 
Repository() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
REPOSITORY_CONFIG_DIR - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Repository configuration folder name
REPOSITORY_GEONAMES_DIR - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Geonames folder name
REPOSITORY_INDEX_DIR - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
MVS index folder name
request() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSHelper
Sends a request to MVSuggest using the location texts contained in the buffer.
requestQuery() - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSQueryRequester
 
requestQuery() - Method in interface oracle.spatial.hadoop.vector.mvsuggest.MVSQueryRequester
Sends the query request to MVSuggest.
requestQuery() - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSQueryRequester
 
reset(byte[]) - Method in class oracle.spatial.hadoop.vector.util.ReusableByteArrayInputStream
 
ReusableByteArrayInputStream - Class in oracle.spatial.hadoop.vector.util
 
ReusableByteArrayInputStream(byte[]) - Constructor for class oracle.spatial.hadoop.vector.util.ReusableByteArrayInputStream
 
RPartitionTuple2<V> - Class in oracle.spatial.spark.vector.index.local
A special subclass of RTuple2 for tuples of partitioned RDDs where the key is always of type PartitionKey
RPartitionTuple2(<any>, Mer) - Constructor for class oracle.spatial.spark.vector.index.local.RPartitionTuple2
 
RPartitionTuple2(<any>, JGeometry) - Constructor for class oracle.spatial.spark.vector.index.local.RPartitionTuple2
 
RRecord<T> - Class in oracle.spatial.spark.vector.index.local
An implementation of RNode which encapsulates a generic value in order to be stored in an RTreeInterface
RRecord(T, Mer) - Constructor for class oracle.spatial.spark.vector.index.local.RRecord
Creates a new instance with the given value and MER
RRecord(T, JGeometry) - Constructor for class oracle.spatial.spark.vector.index.local.RRecord
Creates a new instance with the given value and geometry
RStarTreeKryoSerializer - Class in oracle.spatial.spark.vector.serialization
Custom Kryo Serializer for the class oracle.spatial.util.RStarTree
RStarTreeKryoSerializer() - Constructor for class oracle.spatial.spark.vector.serialization.RStarTreeKryoSerializer
 
RTreeLoadable - Class in oracle.spatial.hadoop.vector
A writable version of RTree
RTreeLoadable(int, int, int, double) - Constructor for class oracle.spatial.hadoop.vector.RTreeLoadable
 
RTreeLoadable(int, int, int) - Constructor for class oracle.spatial.hadoop.vector.RTreeLoadable
 
RTreeLoadable() - Constructor for class oracle.spatial.hadoop.vector.RTreeLoadable
 
RTreeWritable - Class in oracle.spatial.hadoop.vector
Writable wrapper for a RTree.
RTreeWritable() - Constructor for class oracle.spatial.hadoop.vector.RTreeWritable
Creates an empty instance
RTreeWritable(RTree) - Constructor for class oracle.spatial.hadoop.vector.RTreeWritable
Creates an instance with the given tree
RTuple2<K,V> - Class in oracle.spatial.spark.vector.index.local
A specialized subclass of RRecord for tuples
RTuple2(<any>, Mer) - Constructor for class oracle.spatial.spark.vector.index.local.RTuple2
Creates a new instance containing the given tuple and MER
RTuple2(<any>, JGeometry) - Constructor for class oracle.spatial.spark.vector.index.local.RTuple2
Creates a new instance containing the given tuple and geometry
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialFilter
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.Binning
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.Categorization
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.KMeansClustering
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.MBR
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.Partitioning
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialFilter
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialIndexing
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.SpatialJoin
 
run(String[]) - Method in class oracle.spatial.hadoop.vector.util.Tools
 
runFullPartitioningProcess(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
Runs the full partitioning process.
runFullPartitioningProcess(Job) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.Partitioning
Runs the full partitioning process.
runIteration(int, JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Launches a mapreduce job to run a single iteration
runIteration(int, Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.KMeansClustering
Launches a mapreduce job to run a single iteration
runIterations(int, JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Runs the K Means clustering algorithm using the given configuration
runIterations(int, Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.KMeansClustering
Runs the K Means clustering algorithm using the given configuration

S

sameSRIDAndDim(JGeometry, JGeometry) - Static method in class oracle.spatial.hadoop.vector.hive.Utils
Return true if the geometries have the same SRID, false otherwise.
sameSRIDAndDim(JGeometry, JGeometry) - Static method in class oracle.spatial.spark.vector.sql.udf.util.SparkUDFUtils
Return true if the geometries have the same SRID, false otherwise.
sampleClusterCenters(int, JobConf) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansSampler
Samples the input data and return the k initial cluster center points
sampleClusterCenters(int, int, int, JobConf) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansSampler
Samples the input data and return the k initial cluster center points
SAMPLER_CLASS - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
 
SAMPLING_RATIO - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
Sampling ratio
SAMPLING_RATIO - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
When sampling, this parameter indicates the ratio of the sample size to the input size
save(JavaSparkContext, String) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Stores the current index as a file in the given path
SDOCounters - Enum in oracle.spatial.hadoop.vector.mapred
Common counters generated among mapreduce classes.
searchResult(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
searchResult(List<String>) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
searchResult(String) - Method in interface oracle.spatial.hadoop.vector.mvsuggest.LocationService
Return the geometric area information of the data string.
searchResult(List<String>) - Method in interface oracle.spatial.hadoop.vector.mvsuggest.LocationService
Return the geometric area informations of the data strings.
searchResult(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
Return the geometric area information of the data string.
searchResult(List<String>) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
Return the geometric area informations of the data strings.
serialize(Object, ObjectInspector) - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonSerDe
 
serialize(Object, ObjectInspector) - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonToWKTSerDe
 
serialize(Object, ObjectInspector) - Method in class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileSerDe
 
set(JGeometryWritable) - Method in class oracle.spatial.hadoop.vector.JGeometryWritable
Copies the content of another JGeometryWritable instance.
set(LongWritable, LongWritable) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
Sets the given group id and hilbert value to an existing instance
set(PartitionInfo) - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfoWritable
Sets a partition
set(RecordInfo) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Copies the content from another RecordInfo instance
set(RTreeWritable) - Method in class oracle.spatial.hadoop.vector.RTreeWritable
Copies the content from another instance.
set(String, String, String) - Method in class oracle.spatial.hadoop.vector.util.TaggedConfiguration
 
set(String, String, String) - Method in class oracle.spatial.hadoop.vector.util.TaggedJobConf
 
setAddExtraFields(Configuration, boolean) - Static method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
Sets the add extra fields flag.
setAddExtraFields(Configuration, boolean) - Static method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
Sets the add extra fields flag.
setAggrFields(String[]) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Sets the name of the fields to be aggregated
setAttrNames(String[]) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets the names of the attributes contained in the features
setAttrTypes(String[]) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets the types of the attributes contained in the features
setBatchSize(int) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Sets the current batch size
setBbox(double[]) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets the bounding box
setBinConf(BinningConfig) - Method in class oracle.spatial.hadoop.vector.mapred.job.Binning
Sets the binning configuration
setBoundaries(double[]) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Sets the minimum and maximum values for each dimension in the form dim1Min,dim2Min,dim1Max,dim2Max
setBounds(double[]) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets the dimensions minimum of maximum values
setCellHeight(double) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Sets the height of the cells
setCellWidth(double) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Sets the width of the cells
setCluster(ClusterInfo) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Copies the values from another ClusterInfo
setClusterCenter(double[]) - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.ClusterShapeGenerator
Sets the center point of the current cluster
setClusterCenter(double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ConvexHullClusterShapeGenerator
 
setClusterCenter(double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.DummyClusterShapeGenerator
 
setClustersPoints(double[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Sets the initial clusters points
setCollectionName(String) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets the feature collection name
setComment(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
setConf(Configuration) - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
 
setConf(Configuration) - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonInputFormat
 
setConf(Configuration) - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonInputFormat
 
setConf(Configuration) - Method in class oracle.spatial.hadoop.vector.join.mapreduce.JoinPartitioner
 
setConf(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
setConf(Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
setConf(Configuration) - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
 
setConf(Configuration) - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
 
setConf(Configuration) - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
 
setConfig(Configuration) - Static method in class oracle.spatial.hadoop.vector.util.FileNamePathFilter
Sets the job configuration
setConfiguration(Configuration) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Sets the current job configuration
setConfiguratorHandler(InputDataSetConfiguratorHandler) - Method in class oracle.spatial.hadoop.vector.data.conf.MultiInputDataSetConfigurator
Sets a configurator handler used to configure the data sets contained in a MultiInputDataSet
setConsistency(Consistency) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
setCopyright(String) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets the copyright value
setCPGFilesPath(JobConf, String) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
Sets the CPG files path.
setCPGFilesPath(Configuration, String) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
Sets the CPG files path.
setCriterionFunctionValue(double) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Sets the criterion function value generated the last time the cluster was updated
setCritetionFunctionClass(Class<? extends CriterionFunction>) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Sets the CriterionFunction subclass to be used
setCurrentRecord(LongWritable, Text) - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
 
setCurrentRecord(Object) - Method in interface oracle.spatial.hadoop.vector.hive.HiveRecordInfoProvider
Sets the record object.
setCurrentRecord(Object) - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonHiveRecordInfoProvider
 
setCurrentRecord(Object) - Method in class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileHiveRecordInfoProvider
 
setCurrentRecord(K, V) - Method in interface oracle.spatial.hadoop.vector.RecordInfoProvider
Sets the record's key and value.
setCurrentRecord(LongWritable, MapWritable) - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
 
setCurrentRecord(Text, RecordInfo) - Method in class oracle.spatial.hadoop.vector.SpatialIndexRecordInfoProvider
 
setDataSetId(int) - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
Sets the id of the data set associated to the current partition
setDataSetLength(long) - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
Sets the approximate length of the current data set
setDBFFilesPath(JobConf, String) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
Sets the DBF files path.
setDBFFilesPath(Configuration, String) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
Sets the DBF files path.
setDecimalFormat(Locale, String, int) - Static method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
setDefault_repository(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
setDefaultEntryProcessorClass(Class<? extends NoSQLEntryProcessor>) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Sets the default implementation of NoSQLEntryProcessor used for all the target entries for which an explicit entry processor was not specified
setDeletePreviousClusterFiles(boolean) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Specifies whether the output generated by previous iterations should be removed or not
setDepth(Depth) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
setDesc_default_repository(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
setDesc_repository_list(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
setDesc_uri(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
setDimensions(Configuration, int) - Static method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
Sets the geometries dimensions.
setDimensions(Integer) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Sets the number of dimensions of the geometries
setDimensions(int) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets the number of spatial dimensions of the indexed data
setElemCount(long) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
Sets the number of elements contained in the local spatial index
setElementCount(long) - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Sets the total number of the number of elements in all the partitions.
setEntryGrouperClass(Class<? extends NoSQLEntryGrouper>) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Sets the NoSQLEntryGrouper subclass which is in charge of grouping key-value pairs into a single record
setExtraFieldNames(Set<String>) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets a set of all the extra field names contained in the spatial index
setFeatures(List<Feature>) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets the collection's features
setField(String, String) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Adds an extra field.
setFields(Map<String, Object>) - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Sets the map entries as the current fields.
setFileName(String) - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
 
setFilterSpatialOperationConfig(SpatialOperationConfig, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
Sets an input-format specific SpatialOperationConfig.
setFilterSpatialOperationConfig(SpatialOperationConfig, Integer, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
Sets an input-format-dataset specific SpatialOperationConfig.
setFilterSpatialOperationConfig(SpatialOperationConfig, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialIndexInputFormat
Sets an input-format specific SpatialOperationConfig.
setFilterSpatialOperationConfig(SpatialOperationConfig, Integer, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialIndexInputFormat
Sets an input-format-dataset specific SpatialOperationConfig.
setFormatterClassName(String) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
setGeodetic(boolean) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets whether the geometries in the geodetic are geodetic
setGeodetic(boolean) - Method in class oracle.spatial.hadoop.vector.RTreeWritable
Sets true if the data are geodetic, false otherwise
setGeodetic(Boolean) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Sets whether the spatial operation deals with geodetic geometries or not
setGeodetic(boolean) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets whether the indexed data is geodetic or not
setGeoJsonTypesToParse(JobConf, GeoJsonParseType) - Static method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonInputFormat
Sets GeoJSON parsing type.
setGeoJsonTypesToParse(Configuration, GeoJsonParseType) - Static method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonInputFormat
Sets GeoJSON parsing type.
setGeom(JGeometry) - Method in class oracle.spatial.hadoop.vector.geojson.Feature
Sets the feature geometry
setGeometry(JGeometry) - Method in class oracle.spatial.hadoop.vector.JGeometryWritable
Sets the current JGeometry instance
setGeometry(JGeometry) - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfo
Sets the partition geometry
setGeometry(JGeometry) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Sets the geometry associated to the source record
setGeometry(JGeometry) - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Sets the current geometry
setGridColumns(int) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Sets the number of columns in the grid
setGridMbr(double[]) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Sets the minimum bounding box of the grid
setGridRows(int) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Sets the number of rows in the grid
setGroupId(LongWritable) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
Sets a group id
setHierarchyDataPaths(Path[]) - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Sets the paths to hierarchy data catalogs.
setHierarchyIndexPath(Path) - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Sets the HDFS path where the hierarchy data index is located or should be placed once it is generated
setHierarchyInfoClass(Class<? extends HierarchyInfo>) - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Sets the HierarchyInfo implementing class which describes the current hierarchy
setHilbertValue(LongWritable) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
Sets a hilbert value
setId(int) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Sets the cluster id
setId(int) - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Sets the data set id
setId(String) - Method in class oracle.spatial.hadoop.vector.geojson.Feature
Sets the feature id
setId(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Tenants
 
setId(int) - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfo
Sets the partition id
setId(String) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Sets the id used to identify the source record
setInClustersPath(Path) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Sets the path where the input cluster information is located
setIndex(String) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
Sets the path of the local spatial index
setIndex(int) - Method in class oracle.spatial.spark.vector.index.PartitionKey
Sets the index of the referenced partition
setIndex(int) - Method in class oracle.spatial.spark.vector.index.SpatialPartition
Sets the partition index
setIndexCount(long) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets the number of local indexes
setIndexFiles(List<SpatialIndexMetadata.SpatialIndexEntry>) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets a list of the metadata of each local index
setIndexFilesPath(JobConf, String) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
Sets the index files path.
setIndexFilesPath(Configuration, String) - Static method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
Sets the index files path.
setIndexMetadataDir(String) - Method in class oracle.spatial.hadoop.vector.data.SpatialIndexInputDataSet
Sets the directory where the spatial index metadata can be found for this data set
setIndexMetadataDir(String) - Method in class oracle.spatial.hadoop.vector.mapred.job.IndexedInputBaseJob
Sets the path to the directory where the index metadata is located
setIndexName(String) - Method in class oracle.spatial.hadoop.vector.data.SpatialIndexInputDataSet
Sets the data set spatial index name
setIndexName(String) - Method in class oracle.spatial.hadoop.vector.mapred.job.IndexedInputBaseJob
Sets the name of the spatial index to be used as input
setIndexName(String) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
The name of the index to be created.
setIndexName(String) - Method in class oracle.spatial.hadoop.vector.RTreeWritable
Sets the index name
setIndexName(String) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets the spatial index name
setIndexPath(Path) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets the path of the whole spatial index
setInput(String) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Sets the job input string
setInputDataSet(InputDataSet) - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Copies the information from the input data set
setInputDataSet(AbstractInputDataSet) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
setInputDataSets(List<InputDataSet>) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
setInputFormatClass(Class<?>) - Method in interface oracle.spatial.hadoop.vector.data.AbstractInputDataSet
Sets the InputFormat class used to read the input data set
setInputFormatClass(Class<?>) - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
setInputFormatClass(Class<?>) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Sets the input format used to read the input data
setInputFormatClass(Class<? extends <any>>, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter
 
setInputIndex(boolean) - Method in class oracle.spatial.hadoop.vector.data.SpatialIndexInputDataSet
Used for backward compatibility.
setInputIndex(boolean) - Method in class oracle.spatial.hadoop.vector.mapred.job.IndexedInputBaseJob
Sets whether the input path is the path to a spatial index.
setInputString(String) - Method in class oracle.spatial.hadoop.vector.data.FileInputDataSet
Sets the location of the data set's files as a string.
setInternalInputFormatClass(JobConf, Class<? extends <any>>) - Static method in class oracle.spatial.hadoop.vector.mapred.input.AdapterInputFormat
Sets the internal input format type which is used to actually read the data.
setInternalInputFormatClass(Configuration, Class<? extends <any>>) - Static method in class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
setInternalInputFormatClass(JobConf, Class<? extends <any>>) - Static method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
Sets the internal input format type which is used to actually read the data.
setInternalInputFormatClass(Configuration, Class<? extends <any>>) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
setInternalInputFormatClass(JobContext, Class<? extends <any>>) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Sets the internal input format type which is used to actually read the data.
setIs_public(boolean) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
setIteration(int) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Sets the current iteration number
setJarClass(Class<?>) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
setJdbc_datasource(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Tenants
 
setJsonQueryWindow(String) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
Sets the query window as a geometry in GeoJSON format
setK(int) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Sets the number of clusters
setKeys(Set<String>) - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Sets the keys that identify every path of the data set
setkHosts(String[]) - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
Sets the KV hosts locations
setKVConfiguration(NoSQLConfiguration) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLContextImpl
Sets the current NoSQLConfiguration
setKVHosts(String[]) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLContextImpl
Sets the current array of KV hosts locations
setKvStoreHosts(String[]) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Sets an array containing the KV store hosts locations
setKvStoreName(String) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Sets the current KV store name
setKvStoreSecurityFile(String) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
setLength(long) - Method in interface oracle.spatial.hadoop.vector.data.AbstractInputDataSet
Sets the length (in bytes) of the data set
setLength(long) - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
setLength(long) - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Sets the data set length in bytes
setLength(long) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Sets the length in bytes of the source record
setLocallyIndexed(boolean) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
 
setLocations(String[]) - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
 
setMapFile(boolean) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
 
setMapFileIndex(boolean) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
setMatchCountry(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Sets a country name used as context when performing a search
setMatchLayers(String[]) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Sets the layer names used to narrow MVS searches.
setMaxIterations(int) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Sets the maximum number of iterations allowed
setMaxPartitionCount(int) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Sets the maximum number of partitions to be generated
setMaxPartitionSize(long) - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Sets the size of the partition containing the maximum number of elements
setMaxQuadTreeDepth(int) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Sets the maximum number of levels contained by the generated QuadTree
setMaxQueryRecords(int) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Sets maximum number of records contained in a request to MVSuggest
setMaxRecordsPerPartition(long) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Sets the maximum number of RDD elements per partition
setMbr(double[]) - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfo
Sets the partition minimum bounding rectangle
setMbr(double[]) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets the MBR of the whole indexed data
setMbr(double[]) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
Sets the minimum bounding box of the indexed data
setMemberCount(long) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Sets the number of members contained by the cluster
setMetadataDir(String) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
Sets the directory where the index metadata will be stored
setMinPartitionSize(long) - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Sets the size of the partition containing the minimum number of elements
setMinRecordsPerPartition(long) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Sets the minimum number of RDD elements per partition
setMissingSpatialConfig(SpatialConfig, SpatialIndexMetadata) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
 
setMvsConf(MVSConfig) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService
Sets the MVSuggest configuration
setMvsConfig(MVSConfig) - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Sets the MVSuggest configuration
setMvsConfig(MVSConfig) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
Sets the MVSuggest configuration in case it is used.
setName(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
setName(String) - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
 
setNestedSplit(InputSplit) - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
setNestedSplit(InputSplit) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
setNoSQLConfig(NoSQLConfiguration) - Method in class oracle.spatial.hadoop.vector.data.NoSQLInputDataSet
Sets the NoSQL configuration.
setNumberOfFields(int) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Sets the number of extra fields that will be held by the instance.
setOffset(long) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Sets the position in file of the source record as an offset in bytes.
setOperation(SpatialOperation) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
Sets the operation to filter records.
setOperation(SpatialOperation) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
setOrdinates(double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
Sets the ordinates of the cluster center point
setOrds(double[]) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.PointWritable
Sets the point ordinates
setOutput(String) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Sets the job output
setOutput(String) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
setOutputFormatClass(Configuration, Class<? extends <any>>) - Static method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
Sets the OutputFormat class to be wrapped
setOverwriteMetadata(boolean) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
Sets whether the index metadata should be overwritten in case it already exists.
setOverwritePersistentServiceLocation(boolean) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
setParam(String) - Method in class oracle.spatial.spark.vector.sql.udf.function.GeometryParamHelper
Sets the geometry parameter received form query
setParentKey(Key) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
Sets the major key used to select NoSQL entries
setParentRefField(String) - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
 
setParentRefFieldMapping(String) - Method in class oracle.spatial.spark.vector.geoenrichment.GeoJSONSpatialLayerDescriptor
 
setPartition(PartitionInfoWritable) - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
Sets the partition object containing the partition information
setPartitionCount(long) - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Sets the number of partitions
setPartitionedPaths(String[]) - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Sets the paths of the sources that were partitioned.
setPartitioningResultPath(Path) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
Gets the location of a previously generated partitioning result file for the input data sets
setPartitionSet(Set<Integer>) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLContextImpl
Sets the current partition set ids
setPartitionSets(List<Set<Integer>>) - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
Sets the partitions in this split
setPath(String) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Sets the path (as a String) to the file containing the source record
setPaths(Path[]) - Method in class oracle.spatial.hadoop.vector.data.FileInputDataSet
Sets the paths where the data set files are located
setPersistentServiceLocation(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Sets the path where the MVS folder should be saved in HDFS.
setPreviousIndexes(Integer[]) - Method in class oracle.spatial.spark.vector.index.PartitionKey
Sets an array of partitions indexes which also contain the RDD element this key is associated with.
setProperties(Map<String, Object>) - Method in class oracle.spatial.hadoop.vector.geojson.Feature
Sets the feature properties
setProvideTemplates(boolean) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Sets whether the templates should be kept in memory so they can be retrieved by calling MVSService.getTemplate(String)
setQueryWindow(JGeometry) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
Sets the query window used in the spatial operation
setRddSize(long) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Sets the size of the RDD to be partitioned/indexed.
setRebuildIndex(boolean) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Sets whether the MVS index should be rebuilt when it does not exist.
setRecordInfo(SparkRecordInfo) - Method in class oracle.spatial.spark.vector.SparkRecordInfo
Copies the data (geometry and fields) from recordInfo
setRecordInfoProviderClass(Class<? extends RecordInfoProvider<?, ?>>) - Method in interface oracle.spatial.hadoop.vector.data.AbstractInputDataSet
Sets the RecordInfoProvider class used to extract required information from the key-value pairs provided by the InputFormat.
setRecordInfoProviderClass(Class<? extends RecordInfoProvider<?, ?>>) - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
setRecordInfoProviderClass(Configuration, Class<? extends RecordInfoProvider<?, ?>>) - Static method in class oracle.spatial.hadoop.vector.mapred.input.BaseCompositeInputFormat
 
setRecordInfoProviderClass(JobConf, Class<? extends RecordInfoProvider<K, V>>) - Static method in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
Sets the class of the RecordInfoProvider implementation
setRecordInfoProviderClass(Class<? extends RecordInfoProvider<K, V>>) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Sets the RecordInfoProvider class used to interpret input records.
setRecordInfoProviderClass(Configuration, Class<? extends RecordInfoProvider<?, ?>>) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.BaseWrapperInputFormat
 
setRecordInfoProviderClass(JobContext, Class<? extends RecordInfoProvider<K, V>>) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Sets the class of the RecordInfoProvider implementation
setRecordSize(long) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Sets the average record size
setRegex(String) - Static method in class oracle.spatial.hadoop.vector.util.FileNamePathFilter
Sets the regular expression used to determine if a path is accepted or not.
setRepository_list(List<MVSConfigFileBean.Repository>) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
setRepositoryLocation(boolean) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Sets whether the current MVS location refers to a repository or not.
setRepositoryName(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Sets the name of the repository folder name in an MVS location
setResponseSpatialContentType(MVSConfig.ResponseSpatialContent) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Sets the type of spatial content returned by MVSuggest when a match is found.
setSamplingFraction(Double) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Sets the sampling fraction used for sampling the RDD for calculating partitions.
setSamplingRatio(double) - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
Sets the ratio of the sample size to the input data size so only a fraction of the whole input data is used for partitioning.
setSamplingRatio(double) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
Sets the ratio of the sample size to the input data size used to sample when a partitioning result file is not set
setServiceInterfaceType(MVSConfig.ServiceInterface) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Sets the MVSuggest interface type
setServiceLocation(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Sets the MVS service location
setShape(BinningConfig.BinShape) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Sets the shape of the cells
setShape(JGeometry) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
 
setShapeGeneratorClass(Class<? extends ClusterShapeGenerator>) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Sets the ClusterShapeGenerator subclass to be used
setSize(long) - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfo
Sets the number of points in the partition
setSpatialConfig(SpatialConfig) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Sets the current spatial configuration
setSpatialConfig(SpatialConfig) - Method in interface oracle.spatial.hadoop.vector.data.AbstractInputDataSet
Sets the spatial configuration of the data set which defines the spatial features of the data set such as SRID, dimensions and boundaries.
setSpatialConfig(SpatialConfig) - Method in class oracle.spatial.hadoop.vector.data.MultiInputDataSet
 
setSpatialConfig(SpatialConfig) - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
setSpatialConfig(SpatialConfig) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Sets the spatial configuration that describes the geometries in the input data.
setSpatialConfig(SpatialConfig) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
setSpatialIndexName(JobConf, String) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
Sets the name of the spatial index.
setSpatialIndexPath(JobConf, Path, boolean) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
Sets the path of the spatial index
setSpatialOperationConfig(SpatialOperationConfig) - Method in class oracle.spatial.hadoop.vector.mapred.job.Categorization
Sets the configuration of the spatial operation to be performed.
setSpatialOperationConfig(SpatialOperationConfig) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialFilter
Sets the configuration of the spatial operation to be performed to filter the data.
setSpatialOperationConfig(SpatialOperationConfig) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
Sets the spatial operation configuration used to perform the spatial join
setSplit(InputSplit) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileSplitAdapter
 
setSrc(String) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
Sets the path of the source indexed data
setSrid(int) - Static method in class oracle.spatial.hadoop.vector.geojson.Feature
 
setSrid(Configuration, int) - Static method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
Sets the SRID.
setSrid(int) - Method in class oracle.spatial.hadoop.vector.RTreeWritable
Sets the SRID
setSrid(Configuration, int) - Static method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
Sets the SRID.
setSrid(Integer) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Sets the SRS id of the geometries involved in the spatial operation
setSrid(int) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets the SRID of the indexed data
setSrid(int) - Method in class oracle.spatial.spark.vector.BasicSparkRecordInfoProvider
 
setSrid(int) - Method in class oracle.spatial.spark.vector.recordinfoprovider.GeoJsonRecordInfoProvider
 
setSrid(int) - Method in class oracle.spatial.spark.vector.recordinfoprovider.ShapeFileRecordInfoProvider
 
setSrid(int) - Method in interface oracle.spatial.spark.vector.SparkRecordInfoProvider
Sets the SRID of the geometries returned by getRecordInfo
setSrs(int) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets the spatial reference system of the geometries in the collection
setStatus(String) - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
setSubRange(KeyRange) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
setTag(String) - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
setTag(String) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
setTenants_list(List<MVSConfigFileBean.Tenants>) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
setTenants_repository(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
setTimeOut(long) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
setTolerance(Double) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Sets the tolerance used in the spatial operation
setTolerance(double) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets the tolerance that should be used with the indexed data
setTolerance(double) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
 
setTolerance(double) - Method in interface oracle.spatial.spark.vector.index.SpatialPartitioningConfiguration
 
setTolerance(BigDecimal, JGeometry) - Static method in class oracle.spatial.spark.vector.sql.udf.util.SparkUDFUtils
Sets the tolerance to 0.05 for geodetic geometries by default
setTotalElemCount(long) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Sets the number of indexed records
setTree(RTree) - Method in class oracle.spatial.hadoop.vector.RTreeWritable
Sets a tree
setType(String) - Method in class oracle.spatial.hadoop.vector.geojson.Feature
Sets the feature type
setType(String) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets the feature collection type
setUndefinedValues() - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Sets fields with undefined (null) values to default values
setup(Configuration) - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.ClusterShapeGenerator
Perform initialization tasks.
setup(Configuration) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ConvexHullClusterShapeGenerator
 
setup(Configuration) - Method in interface oracle.spatial.hadoop.vector.cluster.kmeans.CriterionFunction
Perform initialization tasks.
setup(Configuration) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.DummyClusterShapeGenerator
 
setup(Configuration) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.EuclideanDistanceCriterionFunction
 
setup(Configuration) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.SquaredErrorCriterionFunction
 
setup(Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
setup(Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.HierarchicalCountReducer
 
setup(Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.IndexedSpatialFilterMapper
 
setup(Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.MVSHierachicalCountMapper
 
setup(Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialFilterMapper
 
setup(Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialFilterOutputMapper
 
setup(Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
setupHierarchyDataIndex(Path[], Path, HierarchyInfo, Configuration) - Static method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
If the given hierarchy index exists and is valid it is loaded to the distributed cache, otherwise the hierarchy index is created for the given hierarchy data paths
setupInputPath(String, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
A convenience method to infer a job's input provided by the user.
setupInputPath(String, Job) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
 
setupJob(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
setupOutputPath(String, Path, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
Convenience method for setting a job's output path.
setupOutputPath(String, Path, Job) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
 
setupTask(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
setUri(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
setUseLocalIndex(boolean) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
Sets whether the generated distributed index will contain local indexes or not.
setUserInputString(String) - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
 
setWrapperOutputCommitterClass(Configuration, Class<? extends WrapperOutputCommitter>) - Static method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
Sets the WrapperOutputCommitter that contains the final output committer
ShapefileHiveRecordInfoProvider - Class in oracle.spatial.hadoop.vector.hive.shapefile
Implementation of oracle.spatial.hadoop.vector.hive.HiveRecordInfoProvider for ESRI Shapefiles.
ShapefileHiveRecordInfoProvider() - Constructor for class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileHiveRecordInfoProvider
 
ShapeFileInputFormat - Class in oracle.spatial.hadoop.vector.shapefile.mapred
org.apache.hadoop.mapred.FileInputFormat for ESRI Shapefiles.
ShapeFileInputFormat() - Constructor for class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
 
ShapeFileInputFormat - Class in oracle.spatial.hadoop.vector.shapefile.mapreduce
FileInputFormat for ESRI Shapefiles.
ShapeFileInputFormat() - Constructor for class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
 
ShapeFileMapParser - Class in oracle.spatial.spark.vector.recordinfoprovider
 
ShapeFileMapParser() - Constructor for class oracle.spatial.spark.vector.recordinfoprovider.ShapeFileMapParser
 
ShapeFileRecordInfoProvider - Class in oracle.spatial.hadoop.vector.shapefile
RecordInfoProvider for ESRI Shapefiles.
ShapeFileRecordInfoProvider() - Constructor for class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
Creates a new instance
ShapeFileRecordInfoProvider - Class in oracle.spatial.spark.vector.recordinfoprovider
SparkRecordInfoProvider for ESRI Shapefiles.
ShapeFileRecordInfoProvider() - Constructor for class oracle.spatial.spark.vector.recordinfoprovider.ShapeFileRecordInfoProvider
 
ShapeFileRecordInfoProvider(List<String>, int) - Constructor for class oracle.spatial.spark.vector.recordinfoprovider.ShapeFileRecordInfoProvider
Create a ShapeFileRecordInfoProvider
ShapeFileRecordReader - Class in oracle.spatial.hadoop.vector.shapefile.mapred
org.apache.hadoop.mapred.RecordReader for ESRI Shapefiles.
ShapeFileRecordReader(JobConf, FileSplit, String, String, String) - Constructor for class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileRecordReader
Create an instance.
ShapeFileRecordReader - Class in oracle.spatial.hadoop.vector.shapefile.mapreduce
org.apache.hadoop.mapreduce.RecordReader for ESRI Shapefiles.
ShapeFileRecordReader(String, String, String) - Constructor for class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileRecordReader
Create an instance.
ShapefileSerDe - Class in oracle.spatial.hadoop.vector.hive.shapefile
This SerDe can be used to read data in ESRI Shapefile format and set the geometry column in GeoJSON format.
ShapefileSerDe() - Constructor for class oracle.spatial.hadoop.vector.hive.shapefile.ShapefileSerDe
 
ShapeFileStreamParser - Class in oracle.spatial.hadoop.vector.shapefile
A stream Shapefile parser used to read ESRI Shapefiles records.
ShapeFileStreamParser(InputStream, InputStream, DBFReader, long) - Constructor for class oracle.spatial.hadoop.vector.shapefile.ShapeFileStreamParser
Creates an instance.
ShapeFileStreamParser(InputStream, InputStream, long) - Constructor for class oracle.spatial.hadoop.vector.shapefile.ShapeFileStreamParser
Creates an instance.
SimpleGeoJsonParser - Class in oracle.spatial.hadoop.vector.mvsuggest
Provides some internal functions.
SimpleGeoJsonParser() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.SimpleGeoJsonParser
 
SimpleInputDataSet - Class in oracle.spatial.hadoop.vector.data
Contains the minimum information to represent an input data set.
SimpleInputDataSet() - Constructor for class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
SimpleInputDataSetCmdArgsParser - Class in oracle.spatial.hadoop.vector.data.cmd
An implementation of InputDataSetCmdArgsParser to parse command line arguments for input data sets of type SimpleInputDataSet
SimpleInputDataSetCmdArgsParser() - Constructor for class oracle.spatial.hadoop.vector.data.cmd.SimpleInputDataSetCmdArgsParser
 
SimpleInputDataSetConfigurator - Class in oracle.spatial.hadoop.vector.data.conf
A generic configurator that accepts any instance of AbstractInputDataSet.
SimpleInputDataSetConfigurator() - Constructor for class oracle.spatial.hadoop.vector.data.conf.SimpleInputDataSetConfigurator
 
SimpleInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapred
An implementation of SimpleInputDataSetConfigurator for the old Hadoop API
SimpleInputDataSetConfiguratorImpl() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapred.SimpleInputDataSetConfiguratorImpl
 
SimpleInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapreduce
An implementation of SimpleInputDataSetConfigurator for the new Hadoop API
SimpleInputDataSetConfiguratorImpl() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapreduce.SimpleInputDataSetConfiguratorImpl
 
SparkRecordInfo - Class in oracle.spatial.spark.vector
Holds a subset of a single record's data, typically, the spatial information which is represented as an instance of oracle.spatial.geometry.JGeometry.
SparkRecordInfo() - Constructor for class oracle.spatial.spark.vector.SparkRecordInfo
Creates an empty instance
SparkRecordInfo(SparkRecordInfo) - Constructor for class oracle.spatial.spark.vector.SparkRecordInfo
Creates a new instance with the same data than recordIndfo
SparkRecordInfo(JGeometry, Map<String, Object>) - Constructor for class oracle.spatial.spark.vector.SparkRecordInfo
Creates a new instance containing the specified geometry and fields
SparkRecordInfoProvider<V> - Interface in oracle.spatial.spark.vector
Defines a component used to extract spatial information from RDD's records independently of the data format.
SparkUDFUtils - Class in oracle.spatial.spark.vector.sql.udf.util
Utilitary methods to execute sdo UDFs
SparkUDFUtils() - Constructor for class oracle.spatial.spark.vector.sql.udf.util.SparkUDFUtils
 
SPATIAL_BOUNDARIES - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The boundaries which the the job's geometries should be into
SPATIAL_COLUMN_NAME - Static variable in class oracle.spatial.spark.vector.sql.SpatialJavaRDDConversions
 
SPATIAL_DIMENSIONS - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The dimensions number of the job's geometries
SPATIAL_INDEX_EXTRA_FIELD_NAMES - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Extra field names contained in the index metadata
SPATIAL_INDEX_LOCATION - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The location (as a path) of a spatial index
SPATIAL_INDEX_MAP_FILE - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Boolean configuration parameter that when set to false during a spatial index generation, causes the index to be generated as a sequence file instead of a map file
SPATIAL_INDEX_METADATA_DIR - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The path to the folder where the metadata for the spatial indices are stored
SPATIAL_INDEX_METADATA_DIR - Static variable in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
Default metadata directory path
SPATIAL_INDEX_METADATA_DIR_PATH - Static variable in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
 
SPATIAL_INDEX_NAME - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
A spatial index name
SPATIAL_INDEX_OVERWRITE_METADATA - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Whether the metadata file should be overwriten when generating an index
SPATIAL_OPERATION - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
A spatial operation to be performed.
SPATIAL_OPERATION - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The current spatial operation as the ordinal of any value defined in SpatialOperation.
SPATIAL_QUERY_WINDOW - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The query window used along with the current ConfigParams.SPATIAL_OPERATION.
SPATIAL_TOLERANCE - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The tolerance used when performing spatial operations
SpatialConfig - Class in oracle.spatial.hadoop.vector.util
Contains descriptions of the geometries contained in a dataset
SpatialConfig() - Constructor for class oracle.spatial.hadoop.vector.util.SpatialConfig
Creates a new instance
SpatialConfig(SpatialConfig) - Constructor for class oracle.spatial.hadoop.vector.util.SpatialConfig
 
SpatialFeature - Interface in oracle.spatial.spark.vector.geoenrichment
Represents a feature from a spatial data layer.
SpatialFilter<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
Runs or configures a job for performing spatial filtering over an input data set.
SpatialFilter() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.SpatialFilter
 
SpatialFilter<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.job
Runs or configures a job for performing spatial filtering over an input data set.
SpatialFilter() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.SpatialFilter
 
SpatialFilterInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
Input format used to filter information read through an internal input format.
SpatialFilterInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
 
SpatialFilterInputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input
An implementation of WrapperInputFormat that is capable of spatially filter records returned by an internal input format.
In order to perform a spatial filter, a SpatialOperationConfig must be configured in the current job.
A previously generated spatial index can be used to filter the data by adding the spatial index map file to the distributed cache and setting the index name in the job configuration as ConfigParams.SPATIAL_INDEX_NAME or setting the spatial index location the job configuration as ConfigParams.SPATIAL_INDEX_LOCATION.
SpatialFilterInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.SpatialFilterInputFormat
 
SpatialFilterMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapred
Emits all the records that satisfy the spatial operation over the query window specified in the job configuration
SpatialFilterMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.SpatialFilterMapper
 
SpatialFilterMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce
Emits all the records that satisfy the spatial operation over the query window specified in the job configuration
SpatialFilterMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.SpatialFilterMapper
 
SpatialFilterOutputMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapred
Emits all the records that satisfy the spatial operation over the query window specified in the job configuration
SpatialFilterOutputMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.SpatialFilterOutputMapper
 
SpatialFilterOutputMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce
Emits all the records that satisfy the spatial operation over the query window specified in the job configuration
SpatialFilterOutputMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.SpatialFilterOutputMapper
 
SpatialFilterRecordReader<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
A record reader that can spatially filter the output of another record reader.
SpatialFilterRecordReader(JobConf, <any>, RecordInfoProvider<K, V>, SpatialOperationConfig) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterRecordReader
Creates a new instance and sets it to use the given internal reader.
SpatialFilterReducer - Class in oracle.spatial.hadoop.vector.mapred
Output a query window and all the records associated with it in JSON format
SpatialFilterReducer() - Constructor for class oracle.spatial.hadoop.vector.mapred.SpatialFilterReducer
 
SpatialFilterReducer - Class in oracle.spatial.hadoop.vector.mapreduce
Outputs a query window and all the records associated with it in JSON format
SpatialFilterReducer() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.SpatialFilterReducer
 
SpatialHierarchicalCountMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapred
This implementation of AbstractSpatialHierarchicalMapper outputs as value a single count for each hierarchical entry.
SpatialHierarchicalCountMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.SpatialHierarchicalCountMapper
 
SpatialHierarchicalCountMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce
This implementation of AbstractSpatialHierarchicalMapper outputs as value a single count for each hierarchical entry.
SpatialHierarchicalCountMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.SpatialHierarchicalCountMapper
 
SpatialHierarchicalJoinMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapred
This implementation of AbstractSpatialHierarchicalMapper outputs as value every matching RecordInfo.
SpatialHierarchicalJoinMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.SpatialHierarchicalJoinMapper
 
SpatialHierarchicalJoinMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce
This implementation of AbstractSpatialHierarchicalMapper outputs as value every matching RecordInfo.
SpatialHierarchicalJoinMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.SpatialHierarchicalJoinMapper
 
SpatialIndexEntry() - Constructor for class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
 
SpatialIndexing<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
This class can be used to run or configure a job for creating a spatial index over a dataset.
SpatialIndexing() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
SpatialIndexing<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.job
This class can be used to run or configure a job for creating a spatial index over a dataset.
SpatialIndexing() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.SpatialIndexing
 
SpatialIndexingMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapred
This mapper generates a spatial index for each FileSplit input value.
SpatialIndexingMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.SpatialIndexingMapper
 
SpatialIndexingMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce
 
SpatialIndexingMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.SpatialIndexingMapper
 
SpatialIndexInputDataSet - Class in oracle.spatial.hadoop.vector.data
Represents a spatially indexed data set.
SpatialIndexInputDataSet() - Constructor for class oracle.spatial.hadoop.vector.data.SpatialIndexInputDataSet
 
SpatialIndexInputDataSetCmdArgsParser - Class in oracle.spatial.hadoop.vector.data.cmd
An implementation of InputDataSetCmdArgsParser to parse command line arguments for input data sets of type SpatialIndexInputDataSet
SpatialIndexInputDataSetCmdArgsParser() - Constructor for class oracle.spatial.hadoop.vector.data.cmd.SpatialIndexInputDataSetCmdArgsParser
 
SpatialIndexInputDataSetConfigurator - Class in oracle.spatial.hadoop.vector.data.conf
A configurator of spatially indexed input data sets represented as SpatialIndexInputDataSet.
SpatialIndexInputDataSetConfigurator() - Constructor for class oracle.spatial.hadoop.vector.data.conf.SpatialIndexInputDataSetConfigurator
 
SpatialIndexInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapred
An implementation of SpatialIndexInputDataSetConfigurator for the old Hadoop API
SpatialIndexInputDataSetConfiguratorImpl() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapred.SpatialIndexInputDataSetConfiguratorImpl
 
SpatialIndexInputDataSetConfiguratorImpl - Class in oracle.spatial.hadoop.vector.data.conf.mapreduce
An implementation of SpatialIndexInputDataSetConfigurator for the new Hadoop API
SpatialIndexInputDataSetConfiguratorImpl() - Constructor for class oracle.spatial.hadoop.vector.data.conf.mapreduce.SpatialIndexInputDataSetConfiguratorImpl
 
SpatialIndexInputFormat - Class in oracle.spatial.hadoop.vector.mapred.input
InputFormat for reading a Spatial Index generated with the Vector API.
This class delivers the records stored into the index as Text/RecordInfo key/value pairs instead of returning the whole RTreeWritable value.
Additionally, a spatial filter can be performed over the input data set; to do that, it is needed to specify a SpatialOperationConfig.
If required, an InputFormat-specific SpatialOperationConfig can be configured to be used only by this InputFormat by calling SpatialIndexInputFormat.setFilterSpatialOperationConfig(SpatialOperationConfig, Configuration).
If no spatial configuration is defined, a SpatialOperation.AnyInteract will be performed taking as query window the boundaries defined in the SpatialConfig (if any).
SpatialIndexInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
 
SpatialIndexInputFormat - Class in oracle.spatial.hadoop.vector.mapreduce.input
InputFormat for reading a Spatial Index generated with the Vector API.
This class delivers the records stored into the index as Text/RecordInfo key/value pairs instead of returning the whole RTreeWritable value.
Additionally, a spatial filter can be performed over the input data set; to do that, it is needed to specify a SpatialOperationConfig.
If required, an InputFormat-specific SpatialOperationConfig can be configured to be used only by this InputFormat by calling SpatialIndexInputFormat.setFilterSpatialOperationConfig(SpatialOperationConfig, Configuration).
If no spatial operation configuration is defined, a SpatialOperation.AnyInteract will be performed taking as query window the boundaries defined in the SpatialConfig (if any).
SpatialIndexInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.SpatialIndexInputFormat
 
SpatialIndexInputFormat.SpatialIndexRecordReader - Class in oracle.spatial.hadoop.vector.mapred.input
Reads records from a spatial index split
SpatialIndexMetadata - Class in oracle.spatial.hadoop.vector.util
In-memory representation of a spatial index metadata
SpatialIndexMetadata() - Constructor for class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
Creates a new instance
SpatialIndexMetadata.SpatialIndexEntry - Class in oracle.spatial.hadoop.vector.util
In-memory representation of a local spatial index metadata
SpatialIndexOutputCommitter - Class in oracle.spatial.hadoop.vector.mapred.output
Generates metadata for a spatial index.
SpatialIndexOutputCommitter() - Constructor for class oracle.spatial.hadoop.vector.mapred.output.SpatialIndexOutputCommitter
 
SpatialIndexOutputCommitter - Class in oracle.spatial.hadoop.vector.mapreduce.output
Generates metadata for a spatial index.
SpatialIndexOutputCommitter(OutputCommitter, JobContext) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.output.SpatialIndexOutputCommitter
 
SpatialIndexRecordInfoProvider - Class in oracle.spatial.hadoop.vector
A RecordInfoProvider subclass required when either SpatialIndexInputFormat or SpatialIndexInputFormat need to be used in jobs that require both, an input format class and a RecordInfoProvider class.
SpatialIndexRecordInfoProvider() - Constructor for class oracle.spatial.hadoop.vector.SpatialIndexRecordInfoProvider
 
SpatialIndexRecordReader(<any>, Configuration) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
Crates a new instance
SpatialIndexTextInputFormat - Class in oracle.spatial.hadoop.vector.mapred.input
Input format used to filter using a given spatial index.
SpatialIndexTextInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexTextInputFormat
 
SpatialIndexUtils - Class in oracle.spatial.hadoop.vector.util
Contains convenient methods used internally by the vector API for generating and reading spatial index metadata
SpatialIndexUtils() - Constructor for class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
 
SpatialJavaDStream<T> - Class in oracle.spatial.spark.vector.streaming.dstream
This class represents a spatially enabled DStream.
SpatialJavaPairDStream<K,V> - Class in oracle.spatial.spark.vector.streaming.dstream
This class represents a spatially enabled DStream.
SpatialJavaPairRDD<K,V> - Class in oracle.spatial.spark.vector.rdd
A pair version of SpatialJavaRDD.
SpatialJavaRDD<T> - Class in oracle.spatial.spark.vector.rdd
This class represents a spatially enabled RDD.
SpatialJavaRDDConversions - Class in oracle.spatial.spark.vector.sql
Utilty functions to transform a Spatial RDD into a Dataset of Rows (DataFrame)
SpatialJavaRDDConversions() - Constructor for class oracle.spatial.spark.vector.sql.SpatialJavaRDDConversions
 
SpatialJoin - Class in oracle.spatial.hadoop.vector.mapred.job
This class can be used to run or configure a job for joining pairs of records from different data sets based on a spatial interaction between records.
A partitioning result file as generated by Partitioning is required to perform the spatial join.
SpatialJoin() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
SpatialJoin - Class in oracle.spatial.hadoop.vector.mapreduce.job
This class can be used to run or configure a job for joining pairs of records from different data sets based on a spatial interaction between records.
A partitioning result file as generated by Partitioning is required to perform the spatial join.
SpatialJoin() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.SpatialJoin
 
spatialJoin(SpatialJavaRDD<T2>, <any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Joins records from the current index with records of the passed spatial RDD.
spatialJoin(DistributedSpatialIndex<T2>, <any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Joins records from the current index with records of the passed spatial index.
spatialJoin(SpatialJavaRDD<T2>, <any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
spatialJoin(DistributedSpatialIndex<T2>, <any>, SpatialOperationConfig) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
SpatialMVSHierarchicalCountMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapred
Mapper class that categorizes input records into features defined in a hierarchical dataset.
SpatialMVSHierarchicalCountMapper() - Constructor for class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
SpatialMVSHierarchicalCountMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce
Mapper class that categorizes input records into features defined in a hierarchical dataset.
SpatialMVSHierarchicalCountMapper() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
SpatialOperation - Enum in oracle.spatial.hadoop.vector.util
Defines the supported spatial operations.
SpatialOperationConfig - Class in oracle.spatial.hadoop.vector.util
Defines how a spatial operation should be performed
SpatialOperationConfig() - Constructor for class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
Creates a new instance
SpatialOperationConfig(SpatialOperation, JGeometry, double, Map<String, Number>) - Constructor for class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
Creates a new instance with the given parameters
SpatialOperationConfig(SpatialOperation, JGeometry, double) - Constructor for class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
Creates a new instance with the given parameters
SpatialOperationConfig(SpatialOperationConfig) - Constructor for class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
Creates a new instance copied from another one
SpatialPartition - Class in oracle.spatial.spark.vector.index
An RDD partition with spatial information
SpatialPartition() - Constructor for class oracle.spatial.spark.vector.index.SpatialPartition
Creates a new instance
SpatialPartition(int, double[]) - Constructor for class oracle.spatial.spark.vector.index.SpatialPartition
Creates a new instance with the given data
SpatialPartitioner - Class in oracle.spatial.spark.vector.index
A partitioner which uses instances of SpatialPartition to partition an RDD
SpatialPartitioner() - Constructor for class oracle.spatial.spark.vector.index.SpatialPartitioner
 
SpatialPartitioning<T> - Interface in oracle.spatial.spark.vector.index
Represents an algorithm to spatially partitioning an RDD
SpatialPartitioningConfiguration - Interface in oracle.spatial.spark.vector.index
A container of parameters passed to a concrete implementation of DistributedSpatialIndex
SpatialSampler<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
 
SpatialSampler(double, int, int) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.SpatialSampler
 
SpatialSampler(<any>) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.SpatialSampler
 
SpatialSampler<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
SpatialSampler(double, int, int) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.SpatialSampler
Creates a new instance
SpatialSampler(<any>) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.SpatialSampler
Creates a new instance
SpatialTransformationContext<T> - Class in oracle.spatial.spark.vector.rdd
A class used internally by spatial RDDs to distribute the transformation information and the SparkInfoProvider across nodes.
SpatialTransformationContext(SparkRecordInfoProvider<T>) - Constructor for class oracle.spatial.spark.vector.rdd.SpatialTransformationContext
Creates a new instance which uses the given SparkRecordInfoProvider
SpatialTransformationContext(SparkRecordInfoProvider<T>, SpatialOperationConfig) - Constructor for class oracle.spatial.spark.vector.rdd.SpatialTransformationContext
Creates a new instance which uses the given SparkRecordInfoProvider and can filter using the specified SpatialOperationConfig
SpatialUtils - Class in oracle.spatial.hadoop.vector.util
Provides convenience spatial operations used internally by the API components.
SpatialUtils() - Constructor for class oracle.spatial.hadoop.vector.util.SpatialUtils
 
SpatialVectorKryoRegistrator - Class in oracle.spatial.spark.vector.serialization
Kryo Registrator for classes used by the Oracle Spatial Vector API
SpatialVectorKryoRegistrator() - Constructor for class oracle.spatial.spark.vector.serialization.SpatialVectorKryoRegistrator
 
SplitSelector() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelector
Deprecated.
 
SquaredErrorCriterionFunction - Class in oracle.spatial.hadoop.vector.cluster.kmeans
CriterionFunction implementation that uses a squared error criterion function.
SquaredErrorCriterionFunction() - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.SquaredErrorCriterionFunction
 
SRID - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
The SRID of the spatial data
SRID - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The current SRS ID
ssc() - Method in class oracle.spatial.spark.vector.streaming.dstream.SpatialJavaDStream
Returns the underlying StreamingContext
ST_AnyInteract - Class in oracle.spatial.hadoop.vector.hive.function
Determines if geometry1 has any spatial interaction with geometry2, returning true or false.
ST_AnyInteract() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_AnyInteract
 
ST_Area - Class in oracle.spatial.hadoop.vector.hive.function
Returns the area of a polygon or multipolygon geometry.
ST_Area() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_Area
 
ST_AsWKB - Class in oracle.spatial.hadoop.vector.hive.function
Returns the well-known binary (WKB) representation of the geometry.
ST_AsWKB() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_AsWKB
 
ST_AsWKT - Class in oracle.spatial.hadoop.vector.hive.function
Returns the well-known text (WKT) representation of the geometry.
ST_AsWKT() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_AsWKT
 
ST_Buffer - Class in oracle.spatial.hadoop.vector.hive.function
Generates a new ST_Geometry object that is the buffered version of the input geometry.
ST_Buffer() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_Buffer
 
ST_Contains - Class in oracle.spatial.hadoop.vector.hive.function
Determines if geometry1 contains geometry2, returning true or false.
ST_Contains() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_Contains
 
ST_ConvexHull - Class in oracle.spatial.hadoop.vector.hive.function
Returns the convex hull of the input geometry as a ST_Geometry object.
ST_ConvexHull() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_ConvexHull
 
ST_Distance - Class in oracle.spatial.hadoop.vector.hive.function
Determines the distance between two 2D geometries.
ST_Distance() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_Distance
 
ST_Envelope - Class in oracle.spatial.hadoop.vector.hive.function
Returns the envelope (bounding polygon) of the input geometry as a ST_Geometry object.
ST_Envelope() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_Envelope
 
ST_Geometry - Class in oracle.spatial.hadoop.vector.hive
Creates a GeoJSON string representation of the geometry, and returns a GeoJSON string representation of the geometry.
ST_Geometry() - Constructor for class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
ST_Inside - Class in oracle.spatial.hadoop.vector.hive.function
Determines if geometry1 is inside geometry2, returning true or false.
ST_Inside() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_Inside
 
ST_Length - Class in oracle.spatial.hadoop.vector.hive.function
Returns the length of a line or polygon geometry.
ST_Length() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_Length
 
ST_LineString - Class in oracle.spatial.hadoop.vector.hive
Creates a line string geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
ST_LineString() - Constructor for class oracle.spatial.hadoop.vector.hive.ST_LineString
 
ST_MultiLineString - Class in oracle.spatial.hadoop.vector.hive
Creates a multiline string geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
ST_MultiLineString() - Constructor for class oracle.spatial.hadoop.vector.hive.ST_MultiLineString
 
ST_MultiPoint - Class in oracle.spatial.hadoop.vector.hive
Creates a multipoint geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
ST_MultiPoint() - Constructor for class oracle.spatial.hadoop.vector.hive.ST_MultiPoint
 
ST_MultiPolygon - Class in oracle.spatial.hadoop.vector.hive
Creates a multipolygon geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
ST_MultiPolygon() - Constructor for class oracle.spatial.hadoop.vector.hive.ST_MultiPolygon
 
ST_Point - Class in oracle.spatial.hadoop.vector.hive
Creates a point geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
ST_Point() - Constructor for class oracle.spatial.hadoop.vector.hive.ST_Point
 
ST_Polygon - Class in oracle.spatial.hadoop.vector.hive
Creates a polygon geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
ST_Polygon() - Constructor for class oracle.spatial.hadoop.vector.hive.ST_Polygon
 
ST_Simplify - Class in oracle.spatial.hadoop.vector.hive.function
Generates a new ST_Geometry object by simplifying the input geometry using the Douglas-Peucker algorithm.
ST_Simplify() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_Simplify
 
ST_SimplifyVW - Class in oracle.spatial.hadoop.vector.hive.function
Generates a new ST_Geometry object by simplifying the input geometry using the Visvalingham-Whyatt algorithm.
ST_SimplifyVW() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_SimplifyVW
 
ST_Volume - Class in oracle.spatial.hadoop.vector.hive.function
Returns the area of a multipolygon 3D geometry.
ST_Volume() - Constructor for class oracle.spatial.hadoop.vector.hive.function.ST_Volume
 
STAnyInteract - Class in oracle.spatial.spark.vector.sql.udf.function
Determines if geometry1 has any spatial interaction with geometry2, returning true or false.
STAnyInteract() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STAnyInteract
 
STArea - Class in oracle.spatial.spark.vector.sql.udf.function
Returns the area of a polygon or multipolygon geometry.
STArea() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STArea
 
startLoading(InputSplit, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.FileSplitRecordInfoLoader
Prepares the loader to start reading records from the given split
startLoading(InputSplit, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.KeyPosRecordInfoLoader
 
startLoading(InputSplit, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
Prepares the loader to start reading records from the given split
startLoading(InputSplit) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
startLoading(InputSplit) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.InputSplitRecordInfoLoader
 
startLoading(InputSplit) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.KeyPosFileSplitRecordInfoLoader
 
startLoading(InputSplit) - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Sets the split to be read
STAsWKB - Class in oracle.spatial.spark.vector.sql.udf.function
Returns the well-known binary (WKB) representation of the geometry.
STAsWKB() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STAsWKB
 
STAsWKT - Class in oracle.spatial.spark.vector.sql.udf.function
Returns the well-known text (WKT) representation of the geometry.
STAsWKT() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STAsWKT
 
StatefulSpatialTransformationContext<T> - Class in oracle.spatial.spark.vector.rdd
A class used internally by spatial RDDs to distribute the transformation information and the SparkInfoProvider across nodes.
StatefulSpatialTransformationContext(SpatialTransformationContext<T>) - Constructor for class oracle.spatial.spark.vector.rdd.StatefulSpatialTransformationContext
 
StatefulSpatialTransformationContext(SparkRecordInfoProvider<T>) - Constructor for class oracle.spatial.spark.vector.rdd.StatefulSpatialTransformationContext
Creates a new instance which uses the given SparkRecordInfoProvider
StatefulSpatialTransformationContext(SparkRecordInfoProvider<T>, SpatialOperationConfig) - Constructor for class oracle.spatial.spark.vector.rdd.StatefulSpatialTransformationContext
Creates a new instance which uses the given SparkRecordInfoProvider and can filter using the specified SpatialOperationConfig
STBuffer - Class in oracle.spatial.spark.vector.sql.udf.function
Generates a new ST_Geometry object that is the buffered version of the input geometry.
STBuffer() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STBuffer
 
STContains - Class in oracle.spatial.spark.vector.sql.udf.function
Determines if geometry1 contains geometry2, returning true or false.
STContains() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STContains
 
STConvexHull - Class in oracle.spatial.spark.vector.sql.udf.function
Returns the convex hull of the input geometry as a ST_Geometry object.
STConvexHull() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STConvexHull
 
STDistance - Class in oracle.spatial.spark.vector.sql.udf.function
Determines the distance between two 2D geometries.
STDistance() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STDistance
 
STEnvelope - Class in oracle.spatial.spark.vector.sql.udf.function
Returns the envelope (bounding polygon) of the input geometry as a ST_Geometry object.
STEnvelope() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STEnvelope
 
STFunction - Enum in oracle.spatial.spark.vector.sql.udf.function
 
STGeometry<T> - Class in oracle.spatial.spark.vector.sql.udf.types
Creates a GeoJSON string representation of the geometry, and returns a GeoJSON string representation of the geometry.
STGeometry() - Constructor for class oracle.spatial.spark.vector.sql.udf.types.STGeometry
 
STInside - Class in oracle.spatial.spark.vector.sql.udf.function
Determines if geometry1 is inside geometry2, returning true or false.
STInside() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STInside
 
STLength - Class in oracle.spatial.spark.vector.sql.udf.function
Returns the length of a line or polygon geometry.
STLength() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STLength
 
STLineString<T> - Class in oracle.spatial.spark.vector.sql.udf.types
Creates a line string geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
STLineString() - Constructor for class oracle.spatial.spark.vector.sql.udf.types.STLineString
 
STMultiLineString<T> - Class in oracle.spatial.spark.vector.sql.udf.types
Creates a multiline string geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
STMultiLineString() - Constructor for class oracle.spatial.spark.vector.sql.udf.types.STMultiLineString
 
STMultiPoint<T> - Class in oracle.spatial.spark.vector.sql.udf.types
Creates a multipoint geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
STMultiPoint() - Constructor for class oracle.spatial.spark.vector.sql.udf.types.STMultiPoint
 
STMultiPolygon<T> - Class in oracle.spatial.spark.vector.sql.udf.types
Creates a multipolygon geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
STMultiPolygon() - Constructor for class oracle.spatial.spark.vector.sql.udf.types.STMultiPolygon
 
store(Configuration) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Stores the binning configuration into the job configuration
store(Configuration) - Method in interface oracle.spatial.hadoop.vector.ConfigurationStorable
Stores the current state into the given job configuration
store(Configuration) - Method in class oracle.spatial.hadoop.vector.data.FileInputDataSet
 
store(Configuration) - Method in class oracle.spatial.hadoop.vector.data.NoSQLInputDataSet
 
store(Configuration) - Method in class oracle.spatial.hadoop.vector.data.SimpleInputDataSet
 
store(Configuration) - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Stores the current data set information in the configuration
store(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
 
store(Configuration) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Saves the MVSuggest to the job configuration
store(Configuration) - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
store(Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Stores the current spatial configuration into the job configuration
store(int, Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Stores the current spatial configuration into the job configuration.
store(String, Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
Stores the current spatial configuration into the job configuration.
store(Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
store(int, Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
store(String, Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
STPoint<T> - Class in oracle.spatial.spark.vector.sql.udf.types
Creates a point geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
STPoint() - Constructor for class oracle.spatial.spark.vector.sql.udf.types.STPoint
 
STPolygon<T> - Class in oracle.spatial.spark.vector.sql.udf.types
Creates a polygon geometry in GeoJSON format, and returns a GeoJSON string representation of the geometry.
STPolygon() - Constructor for class oracle.spatial.spark.vector.sql.udf.types.STPolygon
 
stringArrayToPaths(String[]) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
 
STSimplify - Class in oracle.spatial.spark.vector.sql.udf.function
Generates a new ST_Geometry object by simplifying the input geometry using the Douglas-Peucker algorithm.
STSimplify() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STSimplify
 
STSimplifyVW - Class in oracle.spatial.spark.vector.sql.udf.function
Generates a new ST_Geometry object by simplifying the input geometry using the Visvalingham-Whyatt algorithm.
STSimplifyVW() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STSimplifyVW
 
STType - Enum in oracle.spatial.spark.vector.sql.udf.types
 
STVolume - Class in oracle.spatial.spark.vector.sql.udf.function
Returns the area of a multipolygon 3D geometry.
STVolume() - Constructor for class oracle.spatial.spark.vector.sql.udf.function.STVolume
 
SubSplitRecordReader<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
This class takes a list of sub splits (smaller parts of a split ) and reads the splits records using an internal input format
SubSplitRecordReader(List<FileSplit>, <any>, JobConf, Reporter) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
Creates a new instance with the given sub splits to be read and sets the internal input format used to read the split's records.
SuggestService<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
Runs a or configures a job for suggesting locations for texts in input records using MVSuggest.
SuggestService() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.SuggestService
 
SuggestService.MVSMapper<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
Maps location texts from input records to a suggested feature/layer returned by MVSuggest
SuggestService.SuggestServiceReducer<K,V> - Class in oracle.spatial.hadoop.vector.mapred.job
Collects all the different texts associated to each feature id/layer
SuggestServiceReducer() - Constructor for class oracle.spatial.hadoop.vector.mapred.job.SuggestService.SuggestServiceReducer
 

T

TAG_SPATIAL_INDEX_SPATIAL_OP_CONFIG - Static variable in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
Tag used to identify an InputFormat-specific SpatialOperationConfig in a job's configuration.
TaggedConfiguration - Class in oracle.spatial.hadoop.vector.util
 
TaggedConfiguration(Configuration, String, boolean) - Constructor for class oracle.spatial.hadoop.vector.util.TaggedConfiguration
 
TaggedJobConf - Class in oracle.spatial.hadoop.vector.util
 
TaggedJobConf(Configuration, String, boolean) - Constructor for class oracle.spatial.hadoop.vector.util.TaggedJobConf
 
TaggedSplit - Class in oracle.spatial.hadoop.vector.mapred.input
 
TaggedSplit() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
TaggedSplit(InputSplit, String, Configuration) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
TaggedSplit - Class in oracle.spatial.hadoop.vector.mapreduce.input
 
TaggedSplit() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
TaggedSplit(InputSplit, String, Configuration) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
Tenants() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Tenants
 
TMP_HDFS_PATHS - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
HDFS path that can be used as temporary folder
toDataFrame(SpatialJavaRDD<T>, List<String>, SparkSession) - Static method in class oracle.spatial.spark.vector.sql.SpatialJavaRDDConversions
Transforms a spatial RDD to a DataFrame (Dataset<Row>)
toFastJGeometry(JGeometry, double, SpatialOperation) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
toFastJGeometry(JGeometry, double, EnumSet<SpatialOperation>) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
toFastJGeometrySafety(JGeometry, double, SpatialOperation) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
toFastOp(SpatialOperation) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
TOLERANCE - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
The tolerance used with the spatial data
Tools - Class in oracle.spatial.hadoop.vector.util
 
Tools() - Constructor for class oracle.spatial.hadoop.vector.util.Tools
 
toString() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
 
toString() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.PointWritable
 
toString() - Method in class oracle.spatial.hadoop.vector.data.cmd.CmdOptionsBuilder
 
toString() - Method in enum oracle.spatial.hadoop.vector.geojson.GeoJsonParseType
 
toString() - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
toString() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
toString() - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
 
toString() - Method in class oracle.spatial.hadoop.vector.nosql.NoSQLConfiguration
 
toString() - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
 
toString() - Method in class oracle.spatial.hadoop.vector.RecordInfo
 
toString() - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
 
toString() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata.SpatialIndexEntry
 
toString() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
 
toString() - Method in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
toString() - Method in class oracle.spatial.spark.vector.index.PartitionKey
 
toString() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeConfiguration
 
toString() - Method in class oracle.spatial.spark.vector.index.SpatialPartition
 
toString() - Method in class oracle.spatial.spark.vector.SparkRecordInfo
 
toValidIndexName(String) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
Converts an index name to a valid one
toValidMONamedOutput(String) - Static method in class oracle.spatial.hadoop.vector.util.FileUtils
Converts a name to a valud MultipleOutput's output name
TriFunction<T,U,V,R> - Interface in oracle.spatial.spark.vector.sql.udf.util
Interface to support UDFs that receive 3 parameters
truncate(double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
truncate(double[], int) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
TwoGeoFunction - Class in oracle.spatial.hadoop.vector.hive.function
Abstract class that represents a two geometries function.
TwoGeoFunction() - Constructor for class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 

U

UNDEFINED_PARENT_ID - Static variable in interface oracle.spatial.hadoop.vector.hierarchy.HierarchyInfo
 
unpersist() - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Marks the index' internal RDD as non-persistent
unpersist() - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
Utils - Class in oracle.spatial.hadoop.vector.hive
Provides some utilities functions used by Hive API.
Utils() - Constructor for class oracle.spatial.hadoop.vector.hive.Utils
 

V

V_FEAT_TYPE_FEAT - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
V_FEATCOLL_TYPE - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
V_GEOM_TYPE_GEOMETRYCOLLECTION - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
V_GEOM_TYPE_LINE - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
V_GEOM_TYPE_MULTILINE - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
V_GEOM_TYPE_MULTIPOINT - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
V_GEOM_TYPE_MULTIPOLYGON - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
V_GEOM_TYPE_POINT - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
V_GEOM_TYPE_POLYGON - Static variable in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
VAL_SPATIAL_EVAL_STAGE_POST - Static variable in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
VAL_SPATIAL_EVAL_STAGE_PRE - Static variable in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
validateIndexName(String) - Static method in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
If the given index name is invalid, it will throw an IllegalArgumentException, otherwise it will do nothing
validateInputDataSet(InputDataSet, JobConf) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
 
validateInputDataSet(InputDataSet, Job) - Static method in class oracle.spatial.hadoop.vector.data.InputDataSetUtils
 
validateInputDataSet(InputDataSet, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
 
validateInputFormatClass(FileInputDataSet, Class<?>) - Static method in class oracle.spatial.hadoop.vector.data.conf.FileInputDataSetConfigurator
Checks that the InputFormat class set to the data set is valid and a subclass of the specified baseInputFormat parameter
validateInputFormatClass(AbstractInputDataSet) - Static method in class oracle.spatial.hadoop.vector.data.conf.SimpleInputDataSetConfigurator
 
validateInputPaths(FileInputDataSet) - Static method in class oracle.spatial.hadoop.vector.data.conf.FileInputDataSetConfigurator
Check that the given data set contains the location of the data set files, as paths or as input string.
validateMapRedInputDataSet(InputDataSet, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
 
validateRecordInfoProviderClass(AbstractInputDataSet) - Static method in class oracle.spatial.hadoop.vector.data.conf.SimpleInputDataSetConfigurator
Validates the RecordInfoProvider contained by the given data set
valueOf(String) - Static method in enum oracle.spatial.hadoop.vector.binning.BinningConfig.BinShape
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.hadoop.vector.cluster.kmeans.KMeans.KMeansCounters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.hadoop.vector.geojson.GeoJsonParseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.hadoop.vector.join.JoinCounters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.hadoop.vector.mapred.SDOCounters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.hadoop.vector.mvsuggest.MVSConfig.ResponseSpatialContent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.hadoop.vector.mvsuggest.MVSConfig.ServiceInterface
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.hadoop.vector.partition.PartitioningUtils.PartitionCounters
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.hadoop.vector.util.SpatialOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.spark.vector.sql.udf.function.STFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum oracle.spatial.spark.vector.sql.udf.types.STType
Returns the enum constant of this type with the specified name.
values() - Static method in enum oracle.spatial.hadoop.vector.binning.BinningConfig.BinShape
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.hadoop.vector.cluster.kmeans.KMeans.KMeansCounters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.hadoop.vector.geojson.GeoJsonParseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.hadoop.vector.join.JoinCounters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.hadoop.vector.mapred.SDOCounters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.hadoop.vector.mvsuggest.MVSConfig.ResponseSpatialContent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.hadoop.vector.mvsuggest.MVSConfig.ServiceInterface
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.hadoop.vector.partition.PartitioningUtils.PartitionCounters
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.hadoop.vector.util.SpatialOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.spark.vector.sql.udf.function.STFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum oracle.spatial.spark.vector.sql.udf.types.STType
Returns an array containing the constants of this enum type, in the order they are declared.
voidFunction(Consumer<T>) - Static method in class oracle.spatial.spark.vector.util.FunctionAdapters
 

W

WebMVSQueryRequester - Class in oracle.spatial.hadoop.vector.mvsuggest
MVSQueryRequester implementation used to query a WebMVSService implementation.
WebMVSService - Class in oracle.spatial.hadoop.vector.mvsuggest
MVSService implementation used to communicate with a web MVSuggest service instance.
WebMVSService() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
WITHIN_DISTANCE - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
Distance parameter used for the within distance spatial operation
withinDistance(JGeometry, JGeometry, double, Boolean, Double) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
WORLD_POLITICAL_BOUNDARIES_CONF - Static variable in class oracle.spatial.spark.vector.geoenrichment.GeoJSONGeoEnricher
 
WrapperInputFormat<I,J,K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input
Abstract InputFormat which uses another InputFormat (internalInputFormat) to read data and allows adding additional functionality such as spatial filtering.
WrapperInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
 
WrapperOutputCommitter - Class in oracle.spatial.hadoop.vector.mapreduce.output
Redirects all the method calls to a wrapped OutputCommitter.
WrapperOutputCommitter(OutputCommitter, JobContext) - Constructor for class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
Creates a new instance
WrapperOutputFormat<V,K> - Class in oracle.spatial.hadoop.vector.mapreduce.output
A wrapper for a FileOutputFormat.
WrapperOutputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputFormat
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.ClusterInfo
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.PointWritable
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.JGeometryWritable
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.mapred.input.TaggedSplit
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileInputFormatAdapter.FileSplitAdapter
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.TaggedSplit
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.nosql.mapreduce.NoSQLInputSplit
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.partition.PartitionInfoWritable
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.RecordInfo
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.RTreeLoadable
 
write(DataOutput) - Method in class oracle.spatial.hadoop.vector.RTreeWritable
 
write(JavaSparkContext, String) - Method in class oracle.spatial.spark.vector.index.DistributedSpatialIndex
Writes the current index to the given path
write(DataOutput) - Method in class oracle.spatial.spark.vector.index.PartitionKey
 
write(JavaSparkContext, String) - Method in class oracle.spatial.spark.vector.index.quadtree.QuadTreeDistIndex
 
write(DataOutput) - Method in class oracle.spatial.spark.vector.index.SpatialPartition
 
write(Kryo, Output, FastJGeometry) - Method in class oracle.spatial.spark.vector.serialization.FastJGeometryKryoSerializer
 
write(Kryo, Output, <any>) - Method in class oracle.spatial.spark.vector.serialization.RStarTreeKryoSerializer
 
writeArray(Object) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeArray(T[]) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeArrayField(String, Object) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeAttrNames(String[]) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeAttrTypes(String[]) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeBbox(double[]) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeClusterCenters(Path, int, int, int, JobConf) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansSampler
Samples the input data to find the initial cluster centers and write them to the given file
writeClusters(Path, ClusterInfo[], Configuration) - Static method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Writes the given ClusterInfo array to a sequence file
writeCollectionName(String) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeCopyright(String) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeEndGeoJson() - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeFeature(String, JGeometry, Map<String, Object>) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeFeaturesEnd() - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeFeaturesStart() - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeField(String, Object) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeGeodetic(Boolean) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeIndex(int, JobConf) - Method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyDataIndexWriter
Generates and writes an index for the specified hierarchy level.
writeIndices(JobConf) - Method in class oracle.spatial.hadoop.vector.hierarchy.HierarchyDataIndexWriter
Creates and writes an index for each level of the current hierarchy defined by the HierarchyInfo object set at creation time
writeJsonClusters(Path, ClusterInfo[], Configuration) - Static method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans
Writes the given ClusterInfo array to a JSON file
writePrimitiveArray(Object) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeSample(AbstractInputDataSet, InputDataSetConfiguratorHandler, Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialSampler
 
writeSample(AbstractInputDataSet, InputDataSetConfiguratorHandler, Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialSampler
 
writeSrs(int) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeType(String) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
writeValue(Object) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
A B C D E F G H I J K L M N O P Q R S T U V W 
Skip navigation links
Oracle Big Data Spatial and Graph
Vector Analysis Java API Reference
Release 3 (3.0) E74607-08

Copyright © 2017, 2019 Oracle and/or its affiliates. All Rights Reserved.