Uses of Package
org.apache.hadoop.mapred

Packages that use org.apache.hadoop.mapred
org.apache.hadoop.contrib.index.example   
org.apache.hadoop.contrib.index.mapred   
org.apache.hadoop.contrib.utils.join   
org.apache.hadoop.examples Hadoop example code. 
org.apache.hadoop.examples.dancing This package is a distributed implementation of Knuth's dancing links algorithm that can run under Hadoop. 
org.apache.hadoop.mapred A software framework for easily writing applications which process vast amounts of data (multi-terabyte data-sets) parallelly on large clusters (thousands of nodes) built of commodity hardware in a reliable, fault-tolerant manner. 
org.apache.hadoop.mapred.jobcontrol Utilities for managing dependent jobs. 
org.apache.hadoop.mapred.join Given a set of sorted datasets keyed with the same class and yielding equal partitions, it is possible to effect a join of those datasets prior to the map. 
org.apache.hadoop.mapred.lib Library of generally useful mappers, reducers, and partitioners. 
org.apache.hadoop.mapred.lib.aggregate Classes for performing various counting and aggregations. 
org.apache.hadoop.mapred.pipes Hadoop Pipes allows C++ code to use Hadoop DFS and map/reduce. 
org.apache.hadoop.streaming Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g. 
org.apache.hadoop.util Common utilities. 
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.contrib.index.example
FileInputFormat
          A base class for file-based InputFormat.
FileSplit
          A section of an input file.
InputFormat
          InputFormat describes the input-specification for a Map-Reduce job.
InputSplit
          InputSplit represents the data to be processed by an individual Mapper.
JobConf
          A map/reduce job configuration.
JobConfigurable
          That what may be configured.
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.contrib.index.mapred
FileOutputFormat
          A base class for OutputFormat.
InputFormat
          InputFormat describes the input-specification for a Map-Reduce job.
JobConf
          A map/reduce job configuration.
JobConfigurable
          That what may be configured.
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
MapReduceBase
          Base class for Mapper and Reducer implementations.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
OutputFormat
          OutputFormat describes the output-specification for a Map-Reduce job.
Partitioner
          Partitions the key space.
RecordWriter
          RecordWriter writes the output <key, value> pairs to an output file.
Reducer
          Reduces a set of intermediate values which share a key to a smaller set of values.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.contrib.utils.join
JobConf
          A map/reduce job configuration.
JobConfigurable
          That what may be configured.
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
Reducer
          Reduces a set of intermediate values which share a key to a smaller set of values.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.examples
FileInputFormat
          A base class for file-based InputFormat.
InputFormat
          InputFormat describes the input-specification for a Map-Reduce job.
InputSplit
          InputSplit represents the data to be processed by an individual Mapper.
JobConf
          A map/reduce job configuration.
JobConfigurable
          That what may be configured.
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
MapReduceBase
          Base class for Mapper and Reducer implementations.
MultiFileInputFormat
          An abstract InputFormat that returns MultiFileSplit's in MultiFileInputFormat.getSplits(JobConf, int) method.
MultiFileSplit
          A sub-collection of input files.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
Partitioner
          Partitions the key space.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
Reducer
          Reduces a set of intermediate values which share a key to a smaller set of values.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.examples.dancing
JobConf
          A map/reduce job configuration.
JobConfigurable
          That what may be configured.
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
MapReduceBase
          Base class for Mapper and Reducer implementations.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapred
ClusterStatus
          Status information on the current state of the Map-Reduce cluster.
Counters
          A set of named counters.
Counters.Counter
          A counter record, comprising its name and value.
Counters.Group
          Group of counters, comprising of counters from a particular counter Enum class.
FileAlreadyExistsException
          Used when target file already exists for any operation and is not configured to be overwritten.
FileInputFormat
          A base class for file-based InputFormat.
FileOutputFormat
          A base class for OutputFormat.
FileSplit
          A section of an input file.
ID
          A general identifier, which internally stores the id as an integer.
InputFormat
          InputFormat describes the input-specification for a Map-Reduce job.
InputSplit
          InputSplit represents the data to be processed by an individual Mapper.
InvalidJobConfException
          This exception is thrown when jobconf misses some mendatory attributes or value of some attributes is invalid.
JobClient.TaskStatusFilter
           
JobConf
          A map/reduce job configuration.
JobConfigurable
          That what may be configured.
JobHistory.JobInfo
          Helper class for logging or reading back events related to job start, finish or failure.
JobHistory.Keys
          Job history files contain key="value" pairs, where keys belong to this enum.
JobHistory.Listener
          Callback interface for reading back log events from JobHistory.
JobHistory.RecordTypes
          Record types are identifiers for each line of log in history files.
JobHistory.Task
          Helper class for logging or reading back events related to Task's start, finish or failure.
JobHistory.TaskAttempt
          Base class for Map and Reduce TaskAttempts.
JobHistory.Values
          This enum contains some of the values commonly used by history log events.
JobID
          JobID represents the immutable and unique identifier for the job.
JobPriority
          Used to describe the priority of the running job.
JobProfile
          A JobProfile is a MapReduce primitive.
JobStatus
          Describes the current status of a job.
JobTracker
          JobTracker is the central location for submitting and tracking MR jobs in a network environment.
JobTracker.State
           
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
MapRunnable
          Expert: Generic interface for Mappers.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
OutputFormat
          OutputFormat describes the output-specification for a Map-Reduce job.
Partitioner
          Partitions the key space.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
RecordWriter
          RecordWriter writes the output <key, value> pairs to an output file.
Reducer
          Reduces a set of intermediate values which share a key to a smaller set of values.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
RunningJob
          RunningJob is the user-interface to query for details on a running Map-Reduce job.
SequenceFileInputFilter.Filter
          filter interface
SequenceFileInputFilter.FilterBase
          base class for Filters
SequenceFileInputFormat
          An InputFormat for SequenceFiles.
SequenceFileOutputFormat
          An OutputFormat that writes SequenceFiles.
TaskAttemptID
          TaskAttemptID represents the immutable and unique identifier for a task attempt.
TaskCompletionEvent
          This is used to track task completion events on job tracker.
TaskCompletionEvent.Status
           
TaskID
          TaskID represents the immutable and unique identifier for a Map or Reduce Task.
TaskLog.LogName
          The filter for userlogs.
TaskReport
          A report on the state of a task.
TaskTracker.TaskTrackerMetrics
           
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapred.jobcontrol
JobConf
          A map/reduce job configuration.
JobID
          JobID represents the immutable and unique identifier for the job.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapred.join
InputFormat
          InputFormat describes the input-specification for a Map-Reduce job.
InputSplit
          InputSplit represents the data to be processed by an individual Mapper.
JobConf
          A map/reduce job configuration.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapred.lib
FileInputFormat
          A base class for file-based InputFormat.
FileOutputFormat
          A base class for OutputFormat.
InputFormat
          InputFormat describes the input-specification for a Map-Reduce job.
InputSplit
          InputSplit represents the data to be processed by an individual Mapper.
JobConf
          A map/reduce job configuration.
JobConfigurable
          That what may be configured.
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
MapReduceBase
          Base class for Mapper and Reducer implementations.
MapRunnable
          Expert: Generic interface for Mappers.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
OutputFormat
          OutputFormat describes the output-specification for a Map-Reduce job.
Partitioner
          Partitions the key space.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
RecordWriter
          RecordWriter writes the output <key, value> pairs to an output file.
Reducer
          Reduces a set of intermediate values which share a key to a smaller set of values.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapred.lib.aggregate
JobConf
          A map/reduce job configuration.
JobConfigurable
          That what may be configured.
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
Reducer
          Reduces a set of intermediate values which share a key to a smaller set of values.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapred.pipes
JobConf
          A map/reduce job configuration.
RunningJob
          RunningJob is the user-interface to query for details on a running Map-Reduce job.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.streaming
FileInputFormat
          A base class for file-based InputFormat.
FileSplit
          A section of an input file.
InputFormat
          InputFormat describes the input-specification for a Map-Reduce job.
InputSplit
          InputSplit represents the data to be processed by an individual Mapper.
JobClient
          JobClient is the primary interface for the user-job to interact with the JobTracker.
JobConf
          A map/reduce job configuration.
JobConfigurable
          That what may be configured.
JobID
          JobID represents the immutable and unique identifier for the job.
KeyValueTextInputFormat
          An InputFormat for plain text files.
LineRecordReader.LineReader
          A class that provides a line reader from an input stream.
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
Reducer
          Reduces a set of intermediate values which share a key to a smaller set of values.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
RunningJob
          RunningJob is the user-interface to query for details on a running Map-Reduce job.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.util
JobConf
          A map/reduce job configuration.
 



Copyright © 2008 The Apache Software Foundation