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.examples.terasort This package consists of 3 map/reduce applications for Hadoop to compete in the annual terabyte sort competition. 
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.lib.db org.apache.hadoop.mapred.lib.db Package 
org.apache.hadoop.mapred.pipes Hadoop Pipes allows C++ code to use Hadoop DFS and map/reduce. 
org.apache.hadoop.mapreduce   
org.apache.hadoop.streaming Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g. 
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.contrib.index.example
FileInputFormat
          Deprecated. Use FileInputFormat instead.
FileSplit
          Deprecated. Use FileSplit instead.
InputFormat
          Deprecated. Use InputFormat instead.
InputSplit
          Deprecated. Use InputSplit instead.
JobConf
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
Mapper
          Deprecated. Use Mapper instead.
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
          Deprecated. Use InputFormat instead.
JobConf
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
Mapper
          Deprecated. Use Mapper instead.
MapReduceBase
          Deprecated. 
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
OutputFormat
          Deprecated. Use OutputFormat instead.
Partitioner
          Deprecated. Use Partitioner instead.
RecordWriter
          RecordWriter writes the output <key, value> pairs to an output file.
Reducer
          Deprecated. Use Reducer instead.
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
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
Mapper
          Deprecated. Use Mapper instead.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
Reducer
          Deprecated. Use Reducer instead.
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
          Deprecated. Use FileInputFormat instead.
InputFormat
          Deprecated. Use InputFormat instead.
InputSplit
          Deprecated. Use InputSplit instead.
JobConf
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
Mapper
          Deprecated. Use Mapper instead.
MapReduceBase
          Deprecated. 
MultiFileInputFormat
          Deprecated. Use CombineFileInputFormat instead
MultiFileSplit
          Deprecated. Use CombineFileSplit instead
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
Partitioner
          Deprecated. Use Partitioner instead.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
Reducer
          Deprecated. Use Reducer instead.
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.examples.dancing
JobConf
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
Mapper
          Deprecated. Use Mapper instead.
MapReduceBase
          Deprecated. 
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.examples.terasort
FileInputFormat
          Deprecated. Use FileInputFormat instead.
FileOutputFormat
          A base class for OutputFormat.
InputFormat
          Deprecated. Use InputFormat instead.
InputSplit
          Deprecated. Use InputSplit instead.
JobConf
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
Mapper
          Deprecated. Use Mapper instead.
MapReduceBase
          Deprecated. 
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
OutputFormat
          Deprecated. Use OutputFormat instead.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
RecordWriter
          RecordWriter writes the output <key, value> pairs to an output file.
Reporter
          A facility for Map-Reduce applications to report progress and update counters, status information etc.
TextOutputFormat
          Deprecated. Use TextOutputFormat instead.
 

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
          Deprecated. Use Counters instead.
Counters.Counter
          Deprecated. A counter record, comprising its name and value.
Counters.Group
          Deprecated. 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
          Deprecated. Use FileInputFormat instead.
FileOutputFormat
          A base class for OutputFormat.
FileSplit
          Deprecated. Use FileSplit instead.
InputFormat
          Deprecated. Use InputFormat instead.
InputSplit
          Deprecated. Use InputSplit instead.
InvalidJobConfException
          This exception is thrown when jobconf misses some mendatory attributes or value of some attributes is invalid.
JobClient.TaskStatusFilter
           
JobConf
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
JobContext
          Deprecated. Use JobContext instead.
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
          Deprecated. 
JobPriority
          Used to describe the priority of the running job.
JobProfile
          A JobProfile is a MapReduce primitive.
JobQueueInfo
          Class that contains the information regarding the Job Queues which are maintained by the Hadoop Map/Reduce framework.
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
          Deprecated. Use Mapper instead.
MapRunnable
          Deprecated. Use Mapper instead.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
OutputCommitter
          Deprecated. Use OutputCommitter instead.
OutputFormat
          Deprecated. Use OutputFormat instead.
Partitioner
          Deprecated. Use Partitioner instead.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
RecordWriter
          RecordWriter writes the output <key, value> pairs to an output file.
Reducer
          Deprecated. Use Reducer instead.
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
          Deprecated. Use SequenceFileInputFormat instead.
SequenceFileOutputFormat
          Deprecated. Use SequenceFileOutputFormat instead.
TaskAttemptContext
          Deprecated. Use TaskAttemptContext instead.
TaskAttemptID
          Deprecated. 
TaskCompletionEvent
          This is used to track task completion events on job tracker.
TaskCompletionEvent.Status
           
TaskID
          Deprecated. 
TaskLog.LogName
          The filter for userlogs.
TaskReport
          A report on the state of a task.
TIPStatus
          The states of a TaskInProgress as seen by the JobTracker.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapred.jobcontrol
JobClient
          JobClient is the primary interface for the user-job to interact with the JobTracker.
JobConf
          Deprecated. Use Configuration instead
JobID
          Deprecated. 
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapred.join
InputFormat
          Deprecated. Use InputFormat instead.
InputSplit
          Deprecated. Use InputSplit instead.
JobConf
          Deprecated. Use Configuration instead
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
          Deprecated. Use FileInputFormat instead.
FileOutputFormat
          A base class for OutputFormat.
InputFormat
          Deprecated. Use InputFormat instead.
InputSplit
          Deprecated. Use InputSplit instead.
JobConf
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
Mapper
          Deprecated. Use Mapper instead.
MapReduceBase
          Deprecated. 
MapRunnable
          Deprecated. Use Mapper instead.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
OutputFormat
          Deprecated. Use OutputFormat instead.
Partitioner
          Deprecated. Use Partitioner instead.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
RecordWriter
          RecordWriter writes the output <key, value> pairs to an output file.
Reducer
          Deprecated. Use Reducer instead.
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
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
Mapper
          Deprecated. Use Mapper instead.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
Reducer
          Deprecated. Use Reducer instead.
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.db
InputFormat
          Deprecated. Use InputFormat instead.
InputSplit
          Deprecated. Use InputSplit instead.
JobConf
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
OutputFormat
          Deprecated. Use OutputFormat instead.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
RecordWriter
          RecordWriter writes the output <key, value> pairs to an output file.
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
          Deprecated. Use Configuration instead
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.mapreduce
ID
          Deprecated. 
RawKeyValueIterator
          RawKeyValueIterator is an iterator used to iterate over the raw keys and values during sort/merge of intermediate data.
TaskCompletionEvent
          This is used to track task completion events on job tracker.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.streaming
FileInputFormat
          Deprecated. Use FileInputFormat instead.
FileSplit
          Deprecated. Use FileSplit instead.
InputFormat
          Deprecated. Use InputFormat instead.
InputSplit
          Deprecated. Use InputSplit instead.
JobClient
          JobClient is the primary interface for the user-job to interact with the JobTracker.
JobConf
          Deprecated. Use Configuration instead
JobConfigurable
          Deprecated. 
JobID
          Deprecated. 
KeyValueTextInputFormat
          An InputFormat for plain text files.
Mapper
          Deprecated. Use Mapper instead.
MapRunnable
          Deprecated. Use Mapper instead.
MapRunner
          Default MapRunnable implementation.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
RecordReader
          RecordReader reads <key, value> pairs from an InputSplit.
Reducer
          Deprecated. Use Reducer instead.
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.
 



Copyright © 2009 The Apache Software Foundation