Uses of Package
org.apache.hadoop.mapred

Packages that use org.apache.hadoop.mapred
org.apache.hadoop.mapred   
org.apache.hadoop.mapred.jobcontrol   
org.apache.hadoop.mapred.join   
org.apache.hadoop.mapred.lib   
org.apache.hadoop.mapred.lib.aggregate   
org.apache.hadoop.mapred.lib.db   
org.apache.hadoop.mapred.pipes   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.jobhistory   
org.apache.hadoop.mapreduce.security   
org.apache.hadoop.mapreduce.split   
org.apache.hadoop.mapreduce.task   
org.apache.hadoop.mapreduce.task.reduce   
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapred
ClusterStatus
          Status information on the current state of the Map-Reduce cluster.
ClusterStatus.BlackListInfo
          Class which encapsulates information about a blacklisted tasktracker.
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.
IFile.Reader
          IFile.Reader to read intermediate map-outputs.
IFile.Writer
          IFile.Writer to write out intermediate map-outputs.
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.
JobContext
           
JobID
          JobID represents the immutable and unique identifier for the job.
JobInProgress.Counter
          Deprecated. Provided for compatibility. Use JobCounter instead.
JobPriority
          Used to describe the priority of the running job.
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.
JvmTask
          Task abstraction that can be serialized, implements the writable interface.
MapOutputFile
          Manipulate the working area for the transient store for maps and reduces.
Mapper
          Maps input key/value pairs to a set of intermediate key/value pairs.
MapRunnable
          Expert: Generic interface for Mappers.
MapTaskCompletionEventsUpdate
          A class that represents the communication between the tasktracker and child tasks w.r.t the map task completion events.
Master.State
           
Merger.Segment
           
Operation
          Generic operation that maps to the dependent set of ACLs that drive the authorization of the operation.
OutputCollector
          Collects the <key, value> pairs output by Mappers and Reducers.
OutputCommitter
          OutputCommitter describes the commit of task output for a Map-Reduce job.
OutputFormat
          OutputFormat describes the output-specification for a Map-Reduce job.
Partitioner
          Partitions the key space.
QueueACL
          Enum representing an AccessControlList that drives set of operations that can be performed on a queue.
RawKeyValueIterator
          RawKeyValueIterator is an iterator used to iterate over the raw keys and values during sort/merge of intermediate data.
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.FilterBase
          base class for Filters
SequenceFileInputFormat
          An InputFormat for SequenceFiles.
SequenceFileOutputFormat
          An OutputFormat that writes SequenceFiles.
Task
          Base class for tasks.
Task.CombinerRunner
           
Task.Counter
          Deprecated. Provided for compatibility. Use TaskCounter instead.
Task.TaskReporter
           
TaskAttemptContext
           
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.
TaskStatus
          Describes the current status of a task.
TaskStatus.Phase
           
TaskStatus.State
           
TaskUmbilicalProtocol
          Protocol that task child process uses to contact its parent process.
TIPStatus
          The states of a Tasks.
Utils.OutputFileUtils.OutputLogFilter
          This class filters log files from directory given It doesnt accept paths having _logs.
 

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 cluster.
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.lib.db
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.
OutputFormat
          OutputFormat describes the output-specification for a Map-Reduce job.
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
          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.mapreduce
ID
          A general identifier, which internally stores the id as an integer.
TIPStatus
          The states of a Tasks.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapreduce.jobhistory
JobPriority
          Used to describe the priority of the running job.
 

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

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapreduce.split
InputSplit
          InputSplit represents the data to be processed by an individual Mapper.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapreduce.task
RawKeyValueIterator
          RawKeyValueIterator is an iterator used to iterate over the raw keys and values during sort/merge of intermediate data.
 

Classes in org.apache.hadoop.mapred used by org.apache.hadoop.mapreduce.task.reduce
Counters.Counter
          A counter record, comprising its name and value.
IFile.Reader
          IFile.Reader to read intermediate map-outputs.
IFile.Writer
          IFile.Writer to write out intermediate map-outputs.
JobConf
          A map/reduce job configuration.
MapOutputFile
          Manipulate the working area for the transient store for maps and reduces.
RawKeyValueIterator
          RawKeyValueIterator is an iterator used to iterate over the raw keys and values during sort/merge of intermediate data.
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.
Task
          Base class for tasks.
Task.CombineOutputCollector
          OutputCollector for the combiner.
TaskStatus
          Describes the current status of a task.
TaskUmbilicalProtocol
          Protocol that task child process uses to contact its parent process.
 



Copyright © 2012 Apache Software Foundation. All Rights Reserved.