Skip navigation links
Oracle Big Data Spatial and Graph Vector Analysis Java API Reference
Release 1.2

E74607-01
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, JobStatus.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
 
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
 
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
addInputDataSet(InputDataSet) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
addInputDataSet(InputDataSet, JobConf) - Method in class oracle.spatial.hadoop.vector.MultipleInputsConfig
Adds a data set to the job
addInputDataSet(InputDataSet, Job) - Method in class oracle.spatial.hadoop.vector.MultipleInputsConfig
Adds a data set to the job
addInputDataSets(List<InputDataSet>, JobConf) - Method in class oracle.spatial.hadoop.vector.MultipleInputsConfig
Adds a list of input data sets to the job.
addInputDataSets(List<InputDataSet>, Job) - Method in class oracle.spatial.hadoop.vector.MultipleInputsConfig
Adds a list of input data sets to the job.
addLevel(int, String, String, String) - Method in class oracle.spatial.hadoop.vector.hierarchy.impl.DynaAdminHierarchyInfo
Adds a level to the hierarchy.
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
 
addPath(Path) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation
 
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
 
anyInteract(JGeometry, JGeometry, Boolean, Double) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
Performs an anyInteract test between two geometries
ARG_AGGR_FIELDS - Static variable in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
ARG_CELL_SHAPE - Static variable in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
ARG_CELL_SIZE - Static variable in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
ARG_CLUSTERS_POINTS - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_CRIT_FUN_CLASS - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_DELETE_CLUSTER_FILES - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
ARG_GRID_MBR - Static variable in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
ARG_K - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
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_SHAPE_GEN_CLASS - Static variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
argsp - Variable in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
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

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
 
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
 
binConf - Variable in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
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<C extends oracle.spatial.hadoop.vector.common.RecordManagedMapperContext<K,V,org.apache.hadoop.io.LongWritable,RecordInfo>,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

C

CACHED_MVS_DIR - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
The symbolic link used to access the cached MVS directory
calculateMinSplitDistance() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
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
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
 
cleanup(Reducer<JoinGroupWritable, RecordInfo, Text, Text>.Context) - Method in class oracle.spatial.hadoop.vector.join.mapreduce.JoinReducer
 
cleanup(Reducer<Text, LongWritable, NullWritable, NullWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.HierarchicalCountReducer
 
cleanup(Mapper<NullWritable, FileSplit, Text, RTreeWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialIndexingMapper
 
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.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.
clearFields() - Method in class oracle.spatial.hadoop.vector.RecordInfo
Clears the extra fields (names and values)
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.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.SpatialIndexTextInputFormat.SpatialIndexTextRecordReader
 
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.FileSplitInputFormat.FileSplitRecordReader
 
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
 
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.
clustersPoints - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
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
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.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.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 - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
conf - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
conf - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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_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_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_CURRENT_DS_ID - Static variable in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat
 
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_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_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_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_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_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_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.mapreduce.output.MergeFileOutputCommiter
Job configuration: boolean value that specifies whether the part files are removed or not.
CONF_REPOSITORY_NAME - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Job configuration: the name of the MVSuggest repository.
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_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.mapreduce.output.MergeFileOutputCommiter
Job configuration: the name of the resulting merged file
CONF_SAMPLER - Static variable in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelectetor
 
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
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
 
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.binning.mapred.IndexBinMapper
Deprecated.
 
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(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.MultipleInputsFileSplitInputFormat
 
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
 
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.IndexedInputBaseJob
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapred.job.IndexedInputBaseJob
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
configure(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
configure(Job) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
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.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
 
configureInputs(Job) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
configureInputs(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
constructWithRecordInfoProvider - Variable in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
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.
containsAnyProperty(String[], Configuration) - Method in class oracle.spatial.hadoop.vector.util.SpatialConfig
 
containsTemplates() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSRepository
Tells whether the templates JSON contents are contained
context - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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
 
createBinning(Configuration) - Static method in class oracle.spatial.hadoop.vector.binning.BinningFactory
Creates a BinningAlg based on the job configuration
createBinning(BinningConfig) - Static method in class oracle.spatial.hadoop.vector.binning.BinningFactory
Creates a BinningAlg based on a binning configuration
createFileSplitRecordInfoLoader(CompositeInputFormat<K, V>, JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoaderFactory
 
createFileSplitRecordInfoLoader(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoaderFactory
 
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.
createInternalInputFormat(JobContext) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
 
createJob() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
createJob(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
createJob(Configuration, String) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
createJob(Configuration, String, String) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
createJobConf() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Creates a job configuration
createJobConf(JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
createJobConf(JobConf, String) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
createKey() - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonRecordReader
 
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.SpatialIndexTextInputFormat.SpatialIndexTextRecordReader
 
createKey() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
createKey() - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileRecordReader
 
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
createMultipleInputsFileSplitRecordInfoLoader(CompositeInputFormat<K, V>, JobConf) - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoaderFactory
 
createMultipleInputsFileSplitRecordInfoLoader(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoaderFactory
 
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.
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(JobConf) - Static method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoaderFactory
Deprecated.
use RecordInfoLoaderFactory.createRILoader(JobConf) Creates a new RecordInfoLoader instance based on the job's configuration
createRecordInfoLoader(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoaderFactory
 
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.FileSplitInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsFileSplitInputFormat
 
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.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
createSpatialOperationConfig(JobConf) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
Deprecated.
Use SpatialOperationConfig.load() instead. Creates a SpatialOperationConfig out of the job configuration
createValue() - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonRecordReader
 
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.SpatialIndexTextInputFormat.SpatialIndexTextRecordReader
 
createValue() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
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.
critetionFunctionClass - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
currExpSplitEndPos - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
currPos - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
currPos - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
currReader - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
currReader - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
currReader - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
currSplit - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
currSplit - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
currSplitIndex - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
currSplitIndex - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
currSplitPath - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
currSplitPath - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 

D

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_REPOSITORY_NAME - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
 
DEFAULT_SERVICE_NAME_PREFIX - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Prefix used for temporal mvs folders
defineGlobaBounds() - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
Defines the dimension boundaries for the partitioning space based on the SpatialOperationConfig and the SpatialConfig defined for each input data set.
defineGlobaBounds() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
deletePreviousClusterFiles - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
deletePreviousClustersFiles(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
deserialize(Writable) - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonSerDe
 
dimensions - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
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
DoubleArrayWritable() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.job.MBR.DoubleArrayWritable
 
DummyClusterShapeGenerator - Class in oracle.spatial.hadoop.vector.cluster.kmeans
A ClusterShapeGenerated 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

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
 
EMPTY_TEXT - Static variable in class oracle.spatial.hadoop.vector.RecordInfo
 
EmptyFileOutputFormat<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.output
 
EmptyFileOutputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.output.EmptyFileOutputFormat
 
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.partition.HilbertValueGroup
 
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(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Area
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKB
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKT
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Buffer
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_ConvexHull
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Envelope
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Length
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Simplify
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_SimplifyVW
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Volume
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
evaluate(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
evaluateGeoJSONOrWKT(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
evaluateWithHiveRecordInfoProvider(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
evaluateWKB(GenericUDF.DeferredObject[]) - Method in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
executeFunction(JGeometry, JGeometry, double) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AnyInteract
 
executeFunction(JGeometry, JGeometry, double) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Contains
 
executeFunction(JGeometry, JGeometry, double) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Distance
 
executeFunction(JGeometry, JGeometry, double) - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Inside
 
executeFunction(JGeometry, JGeometry, double) - Method in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
expandMbr(double[], double[]) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
 
EXTENSION_TEMPLATE_CONFIG - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Extension of a template configuration file
EXTENSION_TEMPLATE_FILE - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Extension of a template file
EXTRA_FIELD_DS_ID - Static variable in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
 
extraFields - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
extraFields - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 

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_FIELDS - Static variable in class oracle.spatial.hadoop.vector.RecordInfo
 
F_GEOM - Static variable in class oracle.spatial.hadoop.vector.RecordInfo
 
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
 
F_ID - Static variable in class oracle.spatial.hadoop.vector.RecordInfo
 
F_LENGTH - Static variable in class oracle.spatial.hadoop.vector.RecordInfo
 
F_OFFSET - Static variable in class oracle.spatial.hadoop.vector.RecordInfo
 
F_PATH - Static variable in class oracle.spatial.hadoop.vector.RecordInfo
 
FAILED_ITERATION - Static variable in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans.KMeansIterationResult
 
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
 
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
 
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.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(JGeometry, SpatialOperationConfig) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
 
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.FileSplitRecordInfoLoader
 
finishLoading() - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
When called, stops reading the current split
fromOrdinal(int) - Static method in enum oracle.spatial.hadoop.vector.util.SpatialOperation
Gets the enum value associated to the given ordinal

G

genCellOutValue(long, long, JGeometry, Map<String, Double>, Text) - Method in class oracle.spatial.hadoop.vector.binning.BinningCommonReducer
 
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.
generateFinalResultClustersFile(ClusterInfo[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
generateInitialKClustersPoints(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
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
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
 
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
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
GeoJsonRecordReader - Class in oracle.spatial.hadoop.vector.geojson.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
 
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
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 - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Area
 
geometryParamHelper - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKB
 
geometryParamHelper - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKT
 
geometryParamHelper - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Buffer
 
geometryParamHelper - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_ConvexHull
 
geometryParamHelper - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Envelope
 
geometryParamHelper - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Length
 
geometryParamHelper - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Simplify
 
geometryParamHelper - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_SimplifyVW
 
geometryParamHelper - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Volume
 
geometryParamHelper1 - Variable in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
geometryParamHelper2 - Variable in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
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
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
getBbox() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the bounding box
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
getCmdOptions(String) - Static method in class oracle.spatial.hadoop.vector.InputDataSet
 
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.IndexedInputBaseJob
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
getCmdOptions() - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
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
 
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
 
getComment() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean
 
getCommittedTaskPath(int, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
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.shapefile.mapred.ShapeFileInputFormat
 
getConf() - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
 
getConf() - Method in class oracle.spatial.hadoop.vector.shapefile.ShapeFileRecordInfoProvider
 
getConfiguredInstance(JobConf) - Static method in class oracle.spatial.hadoop.vector.mvsuggest.MVSHelper
Creates a MVSHelper instance using the current job configuration
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
getCurrentKey() - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
 
getCurrentKey() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
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.FileSplitInputFormat.FileSplitRecordReader
 
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.FileSplitRecordInfoLoader
 
getCurrReader() - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Gets the current reader
getDataSet(int) - Method in class oracle.spatial.hadoop.vector.MultipleInputsConfig
Gets data set identified by the given id
getDataSetId() - Method in class oracle.spatial.hadoop.vector.join.JoinGroupWritable
Gets the id of the data set associated to the current partition
getDataSetId(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat
Gets the id which identifies the path's data set
getDataSetId(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper
 
getDataSetId() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation
 
getDataSetId(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsFileSplitInputFormat
Gets the id which identifies the path's data set
getDataSetId(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.MultipleInputsConfig
Gets the id of the data set to which the given path belongs.
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.cluster.kmeans.mapred.PointKeyInputFormat
 
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
 
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
 
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(String) - Static method in class oracle.spatial.hadoop.vector.util.JsonUtils
Returns the dimensions of a geoJSON object in the form: {"type":<geometry-type", "coordinates":[c1,c2,....cn]}
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
 
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
 
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
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
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.
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, InputFormat<?, ?>, 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, FileInputFormat<?, ?>, InputSplit) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Returns an instance of an InputSplit subclass appropriate for the given InputFormat.
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AnyInteract
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Contains
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Distance
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Inside
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.ST_LineString
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.ST_MultiLineString
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.ST_MultiPoint
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.ST_MultiPolygon
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.ST_Point
 
getFunctionName() - Method in class oracle.spatial.hadoop.vector.hive.ST_Polygon
 
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
getGeometry() - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
 
getGeometry(GenericUDF.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.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
 
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
 
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
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.InputDataSet
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.InputDataSet
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
getInputFormat(int, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper
 
getInputFormat() - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation
 
getInputFormat() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialFilterInputFormat
 
getInputFormatClass() - Method in class oracle.spatial.hadoop.vector.InputDataSet
Gets the input format class used to read the data set.
getInputFormatClass() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets the input format used to read the input data
getInputFormatClass(int) - Method in class oracle.spatial.hadoop.vector.MultipleInputsConfig
Gets the input format class used to read the data set identified by the given id
getInputFormatForPath(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat
Gets an instance of the InputFormat class used to read the data set from the given path
getInputFormatForPath(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper
 
getInputFormatForPath(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsFileSplitInputFormat
Gets an instance of the InputFormat class used to read the data set from the given path
getInputFormatPathsRelations(Path[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper
 
getInputListCmdOptions(int, int) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
getInputs() - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
getInputSplit() - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
getInputString() - Method in class oracle.spatial.hadoop.vector.InputDataSet
Gets the data set's location 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 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.CompositeInputFormat
Gets an instance of the class set as the internal input format
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(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(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(int) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
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.FileSplitRecordInfoLoader
 
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
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 class oracle.spatial.hadoop.vector.DistributedDataSet
Gets the data set length in bytes
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(RecordInfoProvider, Configuration) - Static method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
getLocationField() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
getLocationField() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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 interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Gets the location field
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
getMaxPartitionSize() - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Gets the size of the partition containing the maximum number of elements
getMaxQueryRecords() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Gets the maximum number of records contained in a request to MVSuggest.
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
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
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
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
 
getNamedToMergedOutMap(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.output.MultipleOutputMergeOutputCommitter
 
getNamedToMergedOutMap(Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.MultipleOutputMergeOutputCommitter
 
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.
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
 
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
getOutValue(RecordInfo) - Method in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
Given a RecordInfo instance representing a record that previously matched a hierarchy entry, returns the output value
getOutValue(RecordInfo) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialHierarchicalCountMapper
 
getOutValue(RecordInfo) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialHierarchicalJoinMapper
 
getOutValue(RecordInfo) - Method in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
Given a RecordInfo instance representing a record that previously matched a hierarchy entry, returns the output value
getOutValue(RecordInfo) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialHierarchicalCountMapper
 
getOutValue(RecordInfo) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialHierarchicalJoinMapper
 
getParam(String) - 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
 
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
 
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.
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
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.InputDataSet
Gets the paths where the data set files are located
getPaths(String, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
 
getPathsLength(Path[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
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
 
getPointGeometry() - Method in class oracle.spatial.hadoop.vector.mvsuggest.GeoAreaInfo
Deprecated.
see GeoAreaInfo.getGeometry() Returns the geometry.
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.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.SpatialIndexTextInputFormat.SpatialIndexTextRecordReader
 
getPos() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
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.
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.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.SpatialIndexTextInputFormat.SpatialIndexTextRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
getProgress() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
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
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
getRecord(int) - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Retrieves the nth record in the file.
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(int, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper
 
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() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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
getRecordInfoProviderClass() - Method in class oracle.spatial.hadoop.vector.InputDataSet
Gets the RecordInfoProvider class used to extract spatial information from the data set's records
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(JobContext) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Gets the class of the RecordInfoProvider implementation
getRecordInfoProviderClass(int) - Method in class oracle.spatial.hadoop.vector.MultipleInputsConfig
Gets the RecordInfoProvider class used for the data set identified by the given id
getRecordInfoProviderForPath(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat
Gets an instance of the RecordInfoProvider class used to interpret records of the data set from the given path
getRecordInfoProviderForPath(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper
 
getRecordInfoProviderForPath(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsFileSplitInputFormat
Gets an instance of the RecordInfoProvider class used to interpret records of the data set from the given path
getRecordNode() - Method in class oracle.spatial.hadoop.vector.geojson.GeoJsonRecordInfoProvider
Returns the JsonNode of the record.
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.MultipleInputsFileSplitInputFormat
 
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.shapefile.mapred.ShapeFileInputFormat
 
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.
getReturnedObjectInspector() - Method in class oracle.spatial.hadoop.vector.hive.function.ST_AnyInteract
 
getReturnedObjectInspector() - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Contains
 
getReturnedObjectInspector() - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Distance
 
getReturnedObjectInspector() - Method in class oracle.spatial.hadoop.vector.hive.function.ST_Inside
 
getReturnedObjectInspector() - Method in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
getRootOutput() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
getSample(Class<? extends InputFormat<K, V>>, 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(Class<? extends FileInputFormat<K, V>>, 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.
getSampledPoints(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
getSampledPoints(Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.KMeansClustering
 
getSamplePath(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
getSampleSplits(InputSplit[]) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelectetor
 
getSampleSplits(Collection<InputSplit>) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelectetor
 
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
 
getSerializedClass() - Method in class oracle.spatial.hadoop.vector.hive.json.GeoJsonSerDe
 
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 class oracle.spatial.hadoop.vector.InputDataSet
Gets the data set's spatial configuration
getSpatialConfig() - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Gets the spatial configuration that describes the geometries in the input data.
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
 
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
 
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.CompositeInputFormat
 
getSplits(JobConf, int) - Method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat
 
getSplits(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsFileSplitInputFormat
 
getSplits(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
 
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.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
getSrs() - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Gets the spatial reference system of the geometries in the collection
getTaskAttemptContext() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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
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
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
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.
getUri() - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
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.FileSplitRecordInfoLoader
 
getValue() - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Gets the current record's value
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
globalEnd - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
globalStart - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 

H

hashCode() - Method in class oracle.spatial.hadoop.vector.partition.HilbertValueGroup
 
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.FileSplitRecordInfoLoader
 
hasNext() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.KeyPosFileSplitRecordInfoLoader
 
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.
hierInfo - Variable in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
hierInfo - Variable in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
hierInfo - Variable in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
hierInfo - Variable in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
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
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.
HilbertValueGroupGroupComparator() - Constructor for class oracle.spatial.hadoop.vector.partition.HilbertValueGroupGroupComparator
 
HilbertValueGroupKeyComparator - Class in oracle.spatial.hadoop.vector.partition
Compares HilbertValueGroup instances by group id and the by hilbert value.
HilbertValueGroupKeyComparator() - Constructor for class oracle.spatial.hadoop.vector.partition.HilbertValueGroupKeyComparator
 
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.
hiveRecordInfoProvider - Variable in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 

I

iInputFormat - Variable in class oracle.spatial.hadoop.vector.mapred.input.CompositeInputFormat
 
iInputFormat - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
 
includePath - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
includePath - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
inClustersPath - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
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_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
IndexBinMapper - Class in oracle.spatial.hadoop.vector.binning.mapred
Deprecated.
Use BinMapper with SpatialIndexInputFormat instead.
Spatially indexed version of BinMapper.
IndexBinMapper() - Constructor for class oracle.spatial.hadoop.vector.binning.mapred.IndexBinMapper
Deprecated.
 
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
 
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.SplitSelectetor
 
init(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
init(JobContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.MultipleInputsFileSplitRecordInfoLoader
 
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, LocalMVSConfig) - 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(MVSConfig) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
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(ObjectInspector[]) - Method in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
initialize(InputSplit, TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
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
initSpatialOpConfig(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
 
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_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
 
inputDataSets - Variable in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
inputFormat - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
InputFormatPathsRelation(int, Object) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Area
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKB
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKT
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Buffer
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_ConvexHull
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Envelope
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Length
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Simplify
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_SimplifyVW
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Volume
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
inputOIList - Variable in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
instance - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.MVSServiceFactory
 
INTERNAL_INPUT_FORMAT - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Input format class used to read input data
internalInputFormat - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialIndexInputFormat
 
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(PrimitiveObjectInspector.PrimitiveCategory) - Static method in class oracle.spatial.hadoop.vector.hive.Utils
Return true if the primitive type is a binary, false otherwise.
isBoolean(PrimitiveObjectInspector.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
 
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.InputDataSet
Tells whether the input data set corresponds to a spatial index
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(PrimitiveObjectInspector.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.
isMapFile() - Method in class oracle.spatial.hadoop.vector.util.SpatialIndexMetadata
 
isMapFileIndex() - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialIndexing
 
isMultipleInputsJob(JobConf) - Static method in class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat
Returns true if the current job uses more than one input data sets
isNextIteration(int, int, int, Class<? extends ClusterShapeGenerator>) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
isNumber(PrimitiveObjectInspector.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
isPartitioningRequired(Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
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.SplitSelectetor
 
isSplitable(FileSystem, Path) - Method in class oracle.spatial.hadoop.vector.geojson.mapred.GeoJsonInputFormat
 
isSplitable(JobContext, Path) - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonInputFormat
 
isSplitable(FileSystem, Path) - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileInputFormat
 
isSplitable(JobContext, Path) - Method in class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileInputFormat
 
isString(PrimitiveObjectInspector.PrimitiveCategory) - Static method in class oracle.spatial.hadoop.vector.hive.Utils
Return true if the primitive type is a string, false otherwise.
isSuccessfullIteration() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeans.KMeansIterationResult
Tells whether the iteration finished successfully 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
 
isWKB - Variable in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
iteration - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 

J

jarClass - Variable in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
 
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_FOLDER - Static variable in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
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
 
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.
JoinGroupGroupComparator() - Constructor for class oracle.spatial.hadoop.vector.join.JoinGroupGroupComparator
 
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

k - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
key - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
key - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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 interanl InputFormats which Key is the start offset of a records.
KeyPosSubSplitRecordReader(List<FileSplit>, InputFormat<LongWritable, V>, 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 InputFormat<K, V>>, 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(InputSampler.Sampler<PointWritable, NullWritable>) - 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(InputSampler.Sampler<PointWritable, NullWritable>) - Constructor for class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansSampler
Creates a new instance

L

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 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.MultipleInputsConfig
Loads the multiple input data sets configuration from the job configuration
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.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
 
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.
loadInputFormatFilterReaders(Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.SpatialFilterInputFormat
 
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.
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.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
 
map(C) - Method in class oracle.spatial.hadoop.vector.binning.BinningCommonMapper
 
map(K, V, OutputCollector<LongWritable, RecordInfo>, Reporter) - Method in class oracle.spatial.hadoop.vector.binning.mapred.BinMapper
 
map(Text, RTreeWritable, OutputCollector<LongWritable, RecordInfo>, Reporter) - Method in class oracle.spatial.hadoop.vector.binning.mapred.IndexBinMapper
Deprecated.
 
map(K, V, Mapper<K, V, LongWritable, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.binning.mapreduce.BinMapper
 
map(RecordManagedMapperContext<K_IN, V_IN, ClusterInfo, RecordInfo>) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansCommonMapper
 
map(K, V, OutputCollector<ClusterInfo, RecordInfo>, Reporter) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.ClusterMembershipMapper
 
map(K, V, Mapper<K, V, ClusterInfo, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansMapper
 
map(NullWritable, FileSplit, OutputCollector<JoinGroupWritable, RecordInfo>, Reporter) - Method in class oracle.spatial.hadoop.vector.join.mapred.JoinMapper
 
map(NullWritable, FileSplit, Mapper<NullWritable, FileSplit, JoinGroupWritable, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.join.mapreduce.JoinMapper
 
map(Text, RTreeWritable, OutputCollector<Text, W>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
map(NullWritable, FileSplit, OutputCollector<Text, RecordInfo>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.BufferMapper
 
map(Text, RTreeWritable, OutputCollector<Text, RecordInfo>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.IndexedSpatialFilterMapper
 
map(NullWritable, FileSplit, OutputCollector<Text, RecordInfo>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService.MVSMapper
 
map(NullWritable, FileSplit, OutputCollector<Text, LongWritable>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.MVSHierachicalCountMapper
 
map(NullWritable, FileSplit, OutputCollector<Text, RecordInfo>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialFilterMapper
 
map(NullWritable, FileSplit, OutputCollector<Text, RTreeWritable>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialIndexingMapper
 
map(NullWritable, FileSplit, OutputCollector<Text, LongWritable>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
map(Text, RTreeWritable, Mapper<Text, RTreeWritable, Text, W>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
map(Text, RTreeWritable, Mapper<Text, RTreeWritable, Text, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.IndexedSpatialFilterMapper
 
map(NullWritable, FileSplit, Mapper<NullWritable, FileSplit, IntWritable, MBR.DoubleArrayWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.MBR.MBRMapper
 
map(NullWritable, FileSplit, Mapper<NullWritable, FileSplit, Text, LongWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.MVSHierachicalCountMapper
 
map(NullWritable, FileSplit, Mapper<NullWritable, FileSplit, Text, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialFilterMapper
 
map(NullWritable, FileSplit, Mapper<NullWritable, FileSplit, Text, RTreeWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialIndexingMapper
 
map(NullWritable, FileSplit, Mapper<NullWritable, FileSplit, Text, LongWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
map(NullWritable, FileSplit, OutputCollector<HilbertValueGroup, RecordInfo>, Reporter) - Method in class oracle.spatial.hadoop.vector.partition.mapred.HilbertValueMapper
 
map(NullWritable, FileSplit, Mapper<NullWritable, FileSplit, HilbertValueGroup, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.partition.mapreduce.HilbertValueMapper
 
mapHierarchicalResults(String, int, W, OutputCollector<Text, W>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
mapHierarchicalResults(String, int, OutputCollector<Text, LongWritable>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
mapHierarchicalResults(String, int, W, Mapper<Text, RTreeWritable, Text, W>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
mapHierarchicalResults(String, int, Mapper<NullWritable, FileSplit, Text, LongWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
MAPRED_KEY_SEPARATOR - Static variable in class oracle.spatial.hadoop.vector.hierarchy.HierarchyHelper
Separator used in composite keys generated by HierarchyHelper.createMapRedOutputKey(String, String)
maxIterations - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
maxLevel - Variable in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
maxLevel - Variable in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
maxLevel - Variable in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
maxLevel - Variable in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
maxMemberDistance - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
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
 
miConf - Variable in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
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.
minLevel - Variable in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
minLevel - Variable in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
minLevel - Variable in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
minLevel - Variable in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
minSplitDistance - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
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
MultipleInputsConfig - Class in oracle.spatial.hadoop.vector
Creates and manages the configuration for multiple intput data sets.
MultipleInputsConfig() - Constructor for class oracle.spatial.hadoop.vector.MultipleInputsConfig
 
MultipleInputsFileSplitInputFormat - Class in oracle.spatial.hadoop.vector.mapred.input
FileSplitInputFormat subclass that can take more than one data set.
Input data sets are added through MultipleInputsConfig in the following way:
MultipleInputsFileSplitInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat
 
MultipleInputsFileSplitInputFormat - Class in oracle.spatial.hadoop.vector.mapreduce.input
FileSplitInputFormat subclass that can take more than one data set.
Input data sets are added through MultipleInputsConfig in the following way:
MultipleInputsFileSplitInputFormat() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.MultipleInputsFileSplitInputFormat
 
MultipleInputsFileSplitInputFormat.MultipleInputsHelper - Class in oracle.spatial.hadoop.vector.mapred.input
 
MultipleInputsFileSplitInputFormat.MultipleInputsHelper.InputFormatPathsRelation - Class in oracle.spatial.hadoop.vector.mapred.input
 
MultipleInputsFileSplitInputFormat.SplitSelectetor - Class in oracle.spatial.hadoop.vector.mapred.input
 
MultipleInputsFileSplitRecordInfoLoader<K,V> - Class in oracle.spatial.hadoop.vector.mapred.input
 
MultipleInputsFileSplitRecordInfoLoader(JobConf) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitRecordInfoLoader
 
MultipleInputsFileSplitRecordInfoLoader<K,V> - Class in oracle.spatial.hadoop.vector.mapreduce.input.recordinfo
An implementation of RecordInfoLoader that works with MultipleInputsFileSplitInputFormat and multiple input data sets.
MultipleInputsFileSplitRecordInfoLoader() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.MultipleInputsFileSplitRecordInfoLoader
 
MultipleInputsHelper(Configuration) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.MultipleInputsHelper
 
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
 
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(RecordReader<K, V>[]) - 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
MVS_MATCHING_LAYERS - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Deprecated.
use MVSConfig.CONF_MATCH_LAYERS Which layers should be used by MVSuggest to search. It is expected as string of comma separated layer names
MVS_URL - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
Deprecated.
use MVSConfig.CONF_SERVCE_LOCATION The URL of the MVSuggest
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 - Variable in class oracle.spatial.hadoop.vector.mapred.job.Categorization
 
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.
MVSServiceFactory() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.MVSServiceFactory
Creates a new instance
MVSuggestService - Class in oracle.spatial.hadoop.vector.mvsuggest
Deprecated.
Use WebMVSService

Implementation of the LocationService based on the MVSuggest service.

MVSuggestService() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.MVSuggestService
Deprecated.
 

N

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.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 - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
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(Text, Text) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexTextInputFormat.SpatialIndexTextRecordReader
 
next(K, V) - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
next - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
next() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
next() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.KeyPosFileSplitRecordInfoLoader
 
next(LongWritable, MapWritable) - Method in class oracle.spatial.hadoop.vector.shapefile.mapred.ShapeFileRecordReader
 
nextExpandedRangeSplit() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
nextKeyValue() - Method in class oracle.spatial.hadoop.vector.geojson.mapreduce.GeoJsonRecordReader
 
nextKeyValue() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.FileSplitInputFormat.FileSplitRecordReader
 
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
nextReader() - Method in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
numFields() - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Returns the number of fields in each record.
numRecords() - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
Returns the number of records in the DBF file.

O

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.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 a GeoJSON SerDe and a GeoJSON 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.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.
outKey - Variable in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
outKey - Variable in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
outKey - Variable in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
outKey - Variable in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
OUTPUT - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
The path where the job output will be stored
outValue - Variable in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
outValue - Variable in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
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

PARAM_WD_DISTANCE - Static variable in class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
 
parseString(String) - Static method in enum oracle.spatial.hadoop.vector.geojson.GeoJsonParseType
Returns the GeoJsonParseType object related to the specified string.
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, double[], 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_FOLDER - Static variable in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
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
 
partitioningResultPath - Variable in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
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
performFilter(JGeometry, SpatialOperationConfig) - Static method in class oracle.spatial.hadoop.vector.util.SpatialUtils
Performs the spatial operation described by the SpatialOperationConfig parameter.
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
 
pointsToClusterInfo(double[], int) - Static method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
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
 
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
 
prevPos - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
prevPos - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
print() - Method in class oracle.spatial.hadoop.vector.shapefile.DBFReader
nicely print out the general information of this DBF file.
processArgs(String[]) - Method in class oracle.spatial.hadoop.vector.InputDataSet
Takes the input data set information from arguments introduced through the command line
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.IndexedInputBaseJob
 
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
 
progress() - Method in class oracle.spatial.hadoop.vector.util.DummyReporter
 
pushRequest(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSHelper
Adds a field to the current request.

Q

query(MGRequest) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSService
 
query(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
QUERY_WINDOW - Static variable in class oracle.spatial.hadoop.vector.util.CmdArgs
A query window used in a spatial operation.

R

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.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.RTreeWritable
 
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 - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
recordInfo - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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(JobConf, boolean) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
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() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoaderFactory
 
RecordInfoLoaderFactory - Class in oracle.spatial.hadoop.vector.mapreduce.input.recordinfo
 
RecordInfoLoaderFactory() - Constructor for class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoaderFactory
 
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(CommonReducerContext<LongWritable, RecordInfo, NullWritable, Text>) - Method in class oracle.spatial.hadoop.vector.binning.BinningCommonReducer
 
reduce(LongWritable, Iterator<RecordInfo>, OutputCollector<NullWritable, Text>, Reporter) - Method in class oracle.spatial.hadoop.vector.binning.mapred.BinReducer
 
reduce(LongWritable, Iterable<RecordInfo>, Reducer<LongWritable, RecordInfo, NullWritable, Text>.Context) - Method in class oracle.spatial.hadoop.vector.binning.mapreduce.BinReducer
 
reduce(CommonReducerContext<ClusterInfo, RecordInfo, ClusterInfo, NullWritable>) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.KMeansCommonReducer
 
reduce(ClusterInfo, Iterator<RecordInfo>, OutputCollector<ClusterInfo, NullWritable>, Reporter) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapred.ClusterCenterReducer
 
reduce(ClusterInfo, Iterable<RecordInfo>, Reducer<ClusterInfo, RecordInfo, ClusterInfo, NullWritable>.Context) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansReducer
 
reduce(JoinGroupWritable, Iterator<RecordInfo>, OutputCollector<Text, Text>, Reporter) - Method in class oracle.spatial.hadoop.vector.join.mapred.JoinReducer
 
reduce(JoinGroupWritable, Iterable<RecordInfo>, Reducer<JoinGroupWritable, RecordInfo, Text, Text>.Context) - Method in class oracle.spatial.hadoop.vector.join.mapreduce.JoinReducer
 
reduce(Text, Iterator<LongWritable>, OutputCollector<NullWritable, NullWritable>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.HierarchicalCountReducer
 
reduce(Text, Iterator<RecordInfo>, OutputCollector<NullWritable, Text>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.job.SuggestService.SuggestServiceReducer
 
reduce(Text, Iterator<RecordInfo>, OutputCollector<NullWritable, Text>, Reporter) - Method in class oracle.spatial.hadoop.vector.mapred.SpatialFilterReducer
 
reduce(Text, Iterable<LongWritable>, Reducer<Text, LongWritable, NullWritable, NullWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.HierarchicalCountReducer
 
reduce(IntWritable, Iterable<MBR.DoubleArrayWritable>, Reducer<IntWritable, MBR.DoubleArrayWritable, IntWritable, MBR.DoubleArrayWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.MBR.MBRCombiner
 
reduce(IntWritable, Iterable<MBR.DoubleArrayWritable>, Reducer<IntWritable, MBR.DoubleArrayWritable, NullWritable, Text>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.MBR.MBRReducer
 
reduce(Text, Iterable<RecordInfo>, Reducer<Text, RecordInfo, NullWritable, Text>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialFilterReducer
 
reduce(HilbertValueGroup, Iterator<RecordInfo>, OutputCollector<LongWritable, PointWritable>, Reporter) - Method in class oracle.spatial.hadoop.vector.partition.mapred.HilbertValueReducer
 
reduce(HilbertValueGroup, Iterable<RecordInfo>, Reducer<HilbertValueGroup, RecordInfo, LongWritable, PointWritable>.Context) - Method in class oracle.spatial.hadoop.vector.partition.mapreduce.HilbertValueReducer
 
remove() - Method in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
remove() - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
removeField(String) - Method in class oracle.spatial.hadoop.vector.RecordInfo
Removes the extra field with the given name
removeInputDataSet(InputDataSet) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
removeSuccessFile(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.output.SpatialIndexOutputCommitter
 
removeSuccessFile(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.SpatialIndexOutputCommitter
 
replaceEmptyOutClusters(ClusterInfo[], ClusterInfo[]) - Static method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
reporter - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
reporter - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
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
 
RESULT_FILE_NAME - Static variable in class oracle.spatial.hadoop.vector.mapred.job.Binning
 
riProvider - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
riProvider - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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
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
 
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.
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
samplingRatio - Variable in class oracle.spatial.hadoop.vector.mapred.job.Partitioning
 
samplingRatio - Variable in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
SCHEMA_DISTRIBUTED - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
HDFS schema
SCHEMA_LOCAL - Static variable in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Local file system schema
SDOCounters - Enum in oracle.spatial.hadoop.vector.mapred
Common counters generated among mapreduce classes.
search(RTree) - Method in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat.SpatialIndexRecordReader
 
searchMultiLevels - Variable in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
searchMultiLevels - Variable in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
searchMultiLevels - Variable in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
searchMultiLevels - Variable in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
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
 
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.
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
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.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
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(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
 
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
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.
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.
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.
setGeodetic(boolean) - Method in class oracle.spatial.hadoop.vector.geojson.FeatureCollection
Sets whether the geometries in the geodetic are geodetic
setGeodetic(JobConf, boolean) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
Deprecated.
Use SpatialOperationConfig.store() Sets whether the geometries to compare are geodetic or not.
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
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
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.InputDataSet
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.InputDataSet
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
setInputDataSet(InputDataSet) - Method in class oracle.spatial.hadoop.vector.DistributedDataSet
Copies the information from the input data set
setInputDataSets(List<InputDataSet>) - Method in class oracle.spatial.hadoop.vector.mapred.job.MultipleInputsJob
 
setInputFormatClass(Class<?>) - Method in class oracle.spatial.hadoop.vector.InputDataSet
Sets the input format class used to read the data set.
setInputFormatClass(Class<?>) - Method in class oracle.spatial.hadoop.vector.mapred.job.BaseJob
Sets the input format used to read the input data
setInputIndex(boolean) - Method in class oracle.spatial.hadoop.vector.InputDataSet
Sets whether the input data set corresponds to a spatial index
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.InputDataSet
Sets the data set's location as a string.
setInternalInputFormatClass(JobConf, Class<? extends FileInputFormat<K, V>>) - 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(JobConf, Class<? extends InputFormat<K, V>>) - 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(JobContext, Class<? extends FileInputFormat<K, V>>) - 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
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
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.
setMatchLayers(String[]) - Method in class oracle.spatial.hadoop.vector.mvsuggest.WebMVSService
 
setMaxIterations(int) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
Sets the maximum number of iterations allowed
setMaxPartitionSize(long) - Method in class oracle.spatial.hadoop.vector.partition.PartitioningResult
Sets the size of the partition containing the maximum number of elements
setMaxQueryRecords(int) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfig
Sets maximum number of records contained in a request to MVSuggest
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
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
 
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 OutputFormat<K, V>>) - 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
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
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.InputDataSet
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.
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
setRebuildIndex(boolean) - Method in class oracle.spatial.hadoop.vector.mvsuggest.LocalMVSConfig
Sets whether the MVS index should be rebuilt when it does not exist.
setRecordInfoProviderClass(Class<? extends RecordInfoProvider<?, ?>>) - Method in class oracle.spatial.hadoop.vector.InputDataSet
Sets the RecordInfoProvider class used to extract spatial information from the data set's records
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(JobContext, Class<? extends RecordInfoProvider<K, V>>) - Static method in class oracle.spatial.hadoop.vector.mapreduce.input.WrapperInputFormat
Sets the class of the RecordInfoProvider implementation
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.
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 class oracle.spatial.hadoop.vector.InputDataSet
Sets the spatial configuration for the data set
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
setSpatialOperation(JobConf, SpatialOperation) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
Deprecated.
Use SpatialOperationConfig.store() Sets the spatial operation used to do the spatial filtering.
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
setSpatialQueryWindow(JobConf, String) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
Deprecated.
Use SpatialOperationConfig.setJsonQueryWindow() Sets the geometry used to perform the filtering. It should be specified with the GeoJson format.
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(JobConf, int) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
Deprecated.
Use SpatialOperationConfig.store() Sets the SRID of the geometry used as query window.
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
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
 
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
 
setTolerance(JobConf, float) - Static method in class oracle.spatial.hadoop.vector.mapred.input.SpatialFilterInputFormat
Deprecated.
Use SpatialOperationConfig.store() Optional. Sets the tolerance used when performing the spatial operation.
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
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(Mapper<K, V, LongWritable, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.binning.mapreduce.BinMapper
 
setup(Reducer<LongWritable, RecordInfo, NullWritable, Text>.Context) - Method in class oracle.spatial.hadoop.vector.binning.mapreduce.BinReducer
 
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(Mapper<K, V, ClusterInfo, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansMapper
 
setup(Reducer<ClusterInfo, RecordInfo, ClusterInfo, NullWritable>.Context) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.mapreduce.KMeansReducer
 
setup(Configuration) - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.SquaredErrorCriterionFunction
 
setup(Mapper<NullWritable, FileSplit, JoinGroupWritable, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.join.mapreduce.JoinMapper
 
setup(Reducer<JoinGroupWritable, RecordInfo, Text, Text>.Context) - Method in class oracle.spatial.hadoop.vector.join.mapreduce.JoinReducer
 
setup(Mapper<Text, RTreeWritable, Text, W>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
setup(Reducer<Text, LongWritable, NullWritable, NullWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.HierarchicalCountReducer
 
setup(Mapper<Text, RTreeWritable, Text, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.IndexedSpatialFilterMapper
 
setup(Reducer<IntWritable, MBR.DoubleArrayWritable, IntWritable, MBR.DoubleArrayWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.MBR.MBRCombiner
 
setup(Mapper<NullWritable, FileSplit, IntWritable, MBR.DoubleArrayWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.MBR.MBRMapper
 
setup(Reducer<IntWritable, MBR.DoubleArrayWritable, NullWritable, Text>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.job.MBR.MBRReducer
 
setup(Mapper<NullWritable, FileSplit, Text, LongWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.MVSHierachicalCountMapper
 
setup(Mapper<NullWritable, FileSplit, Text, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialFilterMapper
 
setup(Mapper<NullWritable, FileSplit, Text, RTreeWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialIndexingMapper
 
setup(Mapper<NullWritable, FileSplit, Text, LongWritable>.Context) - Method in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
setup(Mapper<NullWritable, FileSplit, HilbertValueGroup, RecordInfo>.Context) - Method in class oracle.spatial.hadoop.vector.partition.mapreduce.HilbertValueMapper
 
setup(Reducer<HilbertValueGroup, RecordInfo, LongWritable, PointWritable>.Context) - Method in class oracle.spatial.hadoop.vector.partition.mapreduce.HilbertValueReducer
 
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
 
setupNextIteractionClusters(KMeans.KMeansIterationResult, ClusterInfo[], Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
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
 
setupPartitioningResult(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
setupTask(TaskAttemptContext) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.WrapperOutputCommitter
 
setUri(String) - Method in class oracle.spatial.hadoop.vector.mvsuggest.MVSConfigFileBean.Repository
 
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
ShapeFileInputFormat - Class in oracle.spatial.hadoop.vector.shapefile.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
 
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
ShapeFileRecordReader - Class in oracle.spatial.hadoop.vector.shapefile.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
RecordReader for ESRI Shapefiles.
ShapeFileRecordReader(String, String, String) - Constructor for class oracle.spatial.hadoop.vector.shapefile.mapreduce.ShapeFileRecordReader
Create an instance.
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.
shapeGeneratorClass - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
SimpleGeoJsonParser - Class in oracle.spatial.hadoop.vector.mvsuggest
Provides some internal functions.
SimpleGeoJsonParser() - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.SimpleGeoJsonParser
 
SPATIAL_BOUNDARIES - Static variable in class oracle.spatial.hadoop.vector.util.ConfigParams
The boundaries which the the job's geometries should be into
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_PATH - Static variable in class oracle.spatial.hadoop.vector.util.SpatialIndexUtils
Default metadata directory path
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_OP_LU_CHAIN - Static variable in class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexInputFormat
 
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
 
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
 
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, RecordReader<K, V>, 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
 
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(RecordReader<Text, RTreeWritable>, 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
 
SpatialIndexTextInputFormat.SpatialIndexTextRecordReader - Class in oracle.spatial.hadoop.vector.mapred.input
 
SpatialIndexTextRecordReader(SpatialIndexInputFormat.SpatialIndexRecordReader, Configuration) - Constructor for class oracle.spatial.hadoop.vector.mapred.input.SpatialIndexTextInputFormat.SpatialIndexTextRecordReader
 
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
 
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
 
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
 
spatialOpConf - Variable in class oracle.spatial.hadoop.vector.mapred.AbstractSpatialHierarchicalMapper
 
spatialOpConf - Variable in class oracle.spatial.hadoop.vector.mapred.SpatialMVSHierarchicalCountMapper
 
spatialOpConf - Variable in class oracle.spatial.hadoop.vector.mapreduce.AbstractSpatialHierarchicalMapper
 
spatialOpConf - Variable in class oracle.spatial.hadoop.vector.mapreduce.SpatialMVSHierarchicalCountMapper
 
SpatialOperation - Enum in oracle.spatial.hadoop.vector.util
Defines the supported spatial operations.
spatialOperationConfig - Variable in class oracle.spatial.hadoop.vector.mapred.job.SpatialJoin
 
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(SpatialOperationConfig) - Constructor for class oracle.spatial.hadoop.vector.util.SpatialOperationConfig
Creates a new instance copied from another one
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
 
splitIndex - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
splits - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
splits - Variable in class oracle.spatial.hadoop.vector.mapred.input.SubSplitRecordReader
 
splits - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
SplitSelectetor() - Constructor for class oracle.spatial.hadoop.vector.mapred.input.MultipleInputsFileSplitInputFormat.SplitSelectetor
 
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
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
 
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.MultipleInputsFileSplitRecordInfoLoader
 
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.KeyPosFileSplitRecordInfoLoader
 
startLoading(InputSplit) - Method in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.MultipleInputsFileSplitRecordInfoLoader
 
startLoading(InputSplit) - Method in interface oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.RecordInfoLoader
Sets the split to be read
store(Configuration) - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
Stores the binning configuration into the job configuration
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.MultipleInputsConfig
Stores the multiple input data sets configuration to the job 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.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
 
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>, InputFormat<K, V>, 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

taCtx - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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.
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
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
toleranceIndex - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Area
 
toleranceIndex - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Buffer
 
toleranceIndex - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Length
 
toleranceIndex - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_Volume
 
toleranceIndex - Variable in class oracle.spatial.hadoop.vector.hive.function.TwoGeoFunction
 
toString() - Method in class oracle.spatial.hadoop.vector.binning.BinningConfig
 
toString() - Method in class oracle.spatial.hadoop.vector.cluster.kmeans.PointWritable
 
toString() - Method in enum oracle.spatial.hadoop.vector.geojson.GeoJsonParseType
 
toString() - Method in class oracle.spatial.hadoop.vector.InputDataSet
 
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
 
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
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
 
usrInputFormat - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
usrInputFormat - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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_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
 
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, Configuration) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
 
validateMapRedInputDataSet(InputDataSet, JobConf) - Static method in class oracle.spatial.hadoop.vector.util.JobUtils
 
value - Variable in class oracle.spatial.hadoop.vector.mapred.input.RecordInfoLoader
 
value - Variable in class oracle.spatial.hadoop.vector.mapreduce.input.recordinfo.FileSplitRecordInfoLoader
 
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.
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.

W

WebMVSQueryRequester - Class in oracle.spatial.hadoop.vector.mvsuggest
MVSQueryRequester implementation used to query a WebMVSService implementation.
WebMVSQueryRequester(WebMVSService) - Constructor for class oracle.spatial.hadoop.vector.mvsuggest.WebMVSQueryRequester
 
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
 
wkb - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKB
 
wkb - Variable in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
wkt - Variable in class oracle.spatial.hadoop.vector.hive.function.ST_AsWKT
 
wkt - Variable in class oracle.spatial.hadoop.vector.hive.ST_Geometry
 
workDirPath - Variable in class oracle.spatial.hadoop.vector.mapred.job.KMeansClustering
 
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.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.RTreeWritable
 
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
 
writeFeature(String, double[], 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
writeMetadata(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapred.output.SpatialIndexOutputCommitter
 
writeMetadata(Path, Configuration) - Method in class oracle.spatial.hadoop.vector.mapreduce.output.SpatialIndexOutputCommitter
 
writePrimitiveArray(Object) - Method in class oracle.spatial.hadoop.vector.util.GeoJsonGen
 
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 1.2

E74607-01

Copyright © 2016, Oracle and/or its affiliates. All rights reserved.