Unit IV Programming Model
Unit IV Programming Model
Overview
Hadoop MapReduce is a software framework for easily writing applications which process vast
amounts of data (multi-terabyte data-sets) in-parallel on large clusters (thousands of nodes)
of commodity hardware in a reliable, fault-tolerant manner.
A MapReduce job usually splits the input data-set into independent chunks which are
processed by the map tasks in a completely parallel manner. The framework sorts the
outputs of the maps, which are then input to the reduce tasks. Typically both the input and
the output of the job are stored in a file-system. The framework takes care of scheduling
tasks, monitoring them and re-executes the failed tasks.
Typically the compute nodes and the storage nodes are the same, that is, the MapReduce
framework and the Hadoop Distributed File System (see HDFS Architecture Guide) are
running on the same set of nodes. This configuration allows the framework to effectively
schedule tasks on the nodes where data is already present, resulting in very high aggregate
bandwidth across the cluster.
Although the Hadoop framework is implemented in JavaTM, MapReduce applications need not
be written in Java.
Hadoop Streaming is a utility which allows users to create and run jobs with any executables
(e.g. shell utilities) as the mapper and/or the reducer.
Hadoop Pipes is a SWIG- compatible C++ API to implement MapReduce applications (non
JNITM based).
WordCount is a simple application that counts the number of occurences of each word in a
given input set.
Source Code
WordCount.java
1. package org.myorg;
2.
3. import java.io.IOException;
4. import java.util.*;
5.
6. import org.apache.hadoop.fs.Path;
7. import org.apache.hadoop.conf.*;
8. import org.apache.hadoop.io.*;
9. import org.apache.hadoop.mapred.*;
11.
13.
17.
22. word.set(tokenizer.nextToken());
24. }
25. }
26. }
27.
28. public static class Reduce extends MapReduceBase implements Reducer<Text, IntWri
33. }
35. }
36. }
37.
40. conf.setJobName("wordcount");
41.
42. conf.setOutputKeyClass(Text.class);
43. conf.setOutputValueClass(IntWritable.class);
44.
45. conf.setMapperClass(Map.class);
46. conf.setCombinerClass(Reduce.class);
47. conf.setReducerClass(Reduce.class);
48.
49. conf.setInputFormat(TextInputFormat.class);
50. conf.setOutputFormat(TextOutputFormat.class);
51.
54.
55. JobClient.runJob(conf);
57. }
58. }
59.
Usage
Assuming HADOOP_HOME is the root of the installation and HADOOP_VERSION is the Hadoop
version installed, compile WordCount.java and create a jar:
$ mkdir wordcount_classes
$ javac -classpath ${HADOOP_HOME}/hadoop-${HADOOP_VERSION}-core.jar -d
wordcount_classes WordCount.java
$ jar -cvf /usr/joe/wordcount.jar -C wordcount_classes/ .
Assuming that:
Output:
$ bin/hadoop dfs -cat /usr/joe/wordcount/output/part-00000
Bye 1
Goodbye 1
Hadoop 2
Hello 2
World 2
Applications can specify a comma separated list of paths which would be present in the
current working directory of the task using the option -files. The -libjars option allows
applications to add jars to the classpaths of the maps and reduces. The option -
archives allows them to pass comma separated list of archives as arguments. These
archives are unarchived and a link with name of the archive is created in the current working
directory of tasks. More details about the command line options are available at Commands
Guide.
Running wordcount example with -libjars, -files and -archives:
hadoop jar hadoop-examples.jar wordcount -files cachefile.txt -libjars
mylib.jar -archives myarchive.zip input output Here, myarchive.zip will be
placed and unzipped into a directory by the name "myarchive.zip".
Users can specify a different symbolic name for files and archives passed through -files and -
archives option, using #.
Walk-through
The WordCount application is quite straight-forward.
We'll learn more about the number of maps spawned for a given job, and how to control
them in a fine-grained manner, a bit later in the tutorial.
WordCount also specifies a combiner (line 46). Hence, the output of each map is passed
through the local combiner (which is same as the Reducer as per the job configuration) for
local aggregation, after being sorted on the keys.
The output of the first map:
< Bye, 1>
< Hello, 1>
< World, 2>
The run method specifies various facets of the job, such as the input/output paths (passed
via the command line), key/value types, input/output formats etc., in the JobConf. It then
calls the JobClient.runJob (line 55) to submit the and monitor its progress.
Finally, we will wrap up by discussing some useful features of the framework such as
the DistributedCache, IsolationRunner etc.
Payload
Applications typically implement the Mapper and Reducer interfaces to provide
the map and reduce methods. These form the core of the job.
Mapper
Mapper maps input key/value pairs to a set of intermediate key/value pairs.
Maps are the individual tasks that transform input records into intermediate records. The
transformed intermediate records do not need to be of the same type as the input records. A
given input pair may map to zero or many output pairs.
The Hadoop MapReduce framework spawns one map task for each InputSplit generated
by the InputFormat for the job.
Output pairs do not need to be of the same types as input pairs. A given input pair may map
to zero or many output pairs. Output pairs are collected with calls
to OutputCollector.collect(WritableComparable,Writable).
Applications can use the Reporter to report progress, set application-level status messages
and update Counters, or just indicate that they are alive.
All intermediate values associated with a given output key are subsequently grouped by the
framework, and passed to the Reducer(s) to determine the final output. Users can control
the grouping by specifying a Comparator via JobConf.setOutputKeyComparatorClass(Class).
The Mapper outputs are sorted and then partitioned per Reducer. The total number of
partitions is the same as the number of reduce tasks for the job. Users can control which
keys (and hence records) go to which Reducer by implementing a custom Partitioner.
The intermediate, sorted outputs are always stored in a simple (key-len, key, value-len,
value) format. Applications can control if, and how, the intermediate outputs are to be
compressed and the CompressionCodec to be used via the JobConf.
The right level of parallelism for maps seems to be around 10-100 maps per-node, although
it has been set up to 300 maps for very cpu-light map tasks. Task setup takes awhile, so it is
best if the maps take at least a minute to execute.
Thus, if you expect 10TB of input data and have a blocksize of 128MB, you'll end up with
82,000 maps, unless setNumMapTasks(int) (which only provides a hint to the framework) is
used to set it even higher.
Reducer
Reducer reduces a set of intermediate values which share a key to a smaller set of values.
The number of reduces for the job is set by the user via JobConf.setNumReduceTasks(int).
Sort
The framework groups Reducer inputs by keys (since different mappers may have output
the same key) in this stage.
The shuffle and sort phases occur simultaneously; while map-outputs are being fetched they
are merged.
Secondary Sort
If equivalence rules for grouping the intermediate keys are required to be different from
those for grouping keys before reduction, then one may specify
a Comparator via JobConf.setOutputValueGroupingComparator(Class).
Since JobConf.setOutputKeyComparatorClass(Class) can be used to control how intermediate
keys are grouped, these can be used in conjunction to simulate secondary sort on values.
Reduce
In this phase the reduce(WritableComparable, Iterator, OutputCollector, Reporter) method is
called for each <key, (list of values)> pair in the grouped inputs.
Applications can use the Reporter to report progress, set application-level status messages
and update Counters, or just indicate that they are alive.
With 0.95 all of the reduces can launch immediately and start transfering map outputs as the
maps finish. With 1.75 the faster nodes will finish their first round of reduces and launch a
second wave of reduces doing a much better job of load balancing.
Increasing the number of reduces increases the framework overhead, but increases load
balancing and lowers the cost of failures.
The scaling factors above are slightly less than whole numbers to reserve a few reduce slots
in the framework for speculative-tasks and failed tasks.
Reducer NONE
It is legal to set the number of reduce-tasks to zero if no reduction is desired.
In this case the outputs of the map-tasks go directly to the FileSystem, into the output
path set by setOutputPath(Path). The framework does not sort the map-outputs before
writing them out to the FileSystem.
Partitioner
Partitioner partitions the key space.
Partitioner controls the partitioning of the keys of the intermediate map-outputs. The key (or
a subset of the key) is used to derive the partition, typically by a hash function. The total
number of partitions is the same as the number of reduce tasks for the job. Hence this
controls which of the m reduce tasks the intermediate key (and hence the record) is sent to
for reduction.
Reporter
Reporter is a facility for MapReduce applications to report progress, set application-level
status messages and update Counters.
OutputCollector
OutputCollector is a generalization of the facility provided by the MapReduce framework to
collect data output by the Mapper or the Reducer (either the intermediate outputs or the
output of the job).
Hadoop MapReduce comes bundled with a library of generally useful mappers, reducers, and
partitioners.
Job Configuration
JobConf represents a MapReduce job configuration.
JobConf is the primary interface for a user to describe a MapReduce job to the Hadoop
framework for execution. The framework tries to faithfully execute the job as described
by JobConf, however:
f Some configuration parameters may have been marked as final by administrators and
hence cannot be altered.
While some job parameters are straight-forward to set (e.g. setNumReduceTasks(int)), other
parameters interact subtly with the rest of the framework and/or job configuration and are
more complex to set (e.g. setNumMapTasks(int)).
JobConf is typically used to specify the Mapper, combiner (if
any), Partitioner, Reducer, InputFormat, OutputFormat and OutputCommitter impl
ementations. JobConf also indicates the set of input files (setInputPaths(JobConf,
Path...) /addInputPath(JobConf, Path)) and (setInputPaths(JobConf,
String) /addInputPaths(JobConf, String)) and where the output files should be written
(setOutputPath(Path)).
The child-task inherits the environment of the parent TaskTracker. The user can specify
additional options to the child-jvm via the mapred.{map|
reduce}.child.java.opts configuration parameter in the JobConf such as non-standard
paths for the run-time linker to search shared libraries via -Djava.library.path=<> etc.
If the mapred.{map|reduce}.child.java.opts parameters contains the
symbol @taskid@ it is interpolated with value of taskid of the MapReduce task.
Here is an example with multiple arguments and substitutions, showing jvm GC logging, and
start of a passwordless JVM JMX agent so that it can connect with jconsole and the likes to
watch child memory, threads and get thread dumps. It also sets the maximum heap-size of
the map and reduce child jvm to 512MB & 1024MB respectively. It also adds an additional
path to the java.library.path of the child-jvm.
<property>
<name>mapred.map.child.java.opts</name>
<value>
-Xmx512M -Djava.library.path=/home/mycompany/lib -verbose:gc -
Xloggc:/tmp/@taskid@.gc
-Dcom.sun.management.jmxremote.authenticate=false -
Dcom.sun.management.jmxremote.ssl=false
</value>
</property>
<property>
<name>mapred.reduce.child.java.opts</name>
<value>
-Xmx1024M -Djava.library.path=/home/mycompany/lib -verbose:gc -
Xloggc:/tmp/@taskid@.gc
-Dcom.sun.management.jmxremote.authenticate=false -
Dcom.sun.management.jmxremote.ssl=false
</value>
</property>
Memory Management
Users/admins can also specify the maximum virtual memory of the launched child-task, and
any sub-process it launches recursively, using mapred.{map|reduce}.child.ulimit.
Note that the value set here is a per process limit. The value for mapred.{map|
reduce}.child.ulimit should be specified in kilo bytes (KB). And also the value must be
greater than or equal to the -Xmx passed to JavaVM, else the VM might not start.
Users can choose to override default limits of Virtual Memory and RAM enforced by the task
tracker, if memory management is enabled. Users can set the following parameter per job:
mapred.task.maxvmem int A number, in bytes, that represents the maximum Virtual Memory task-limit for each task of the job.
number.
mapred.task.maxpmem int A number, in bytes, that represents the maximum RAM task-limit for each task of the job. This numb
tasks on a node based on RAM needs.
Map Parameters
A record emitted from a map will be serialized into a buffer and metadata will be stored into
accounting buffers. As described in the following options, when either the serialization buffer
or the metadata exceed a threshold, the contents of the buffers will be sorted and written to
disk in the background while the map continues to output records. If either buffer fills
completely while the spill is in progress, the map thread will block. When the map is finished,
any remaining records are written to disk and all on-disk segments are merged into a single
file. Minimizing the number of spills to disk can decrease map time, but a larger buffer also
decreases the memory available to the mapper.
io.sort.mb int The cumulative size of the serialization and accounting buffers storing records emitted from the map, in megab
io.sort.record.percent float The ratio of serialization to accounting space can be adjusted. Each serialized record requires 16 bytes of accou
This percentage of space allocated from io.sort.mb affects the probability of a spill to disk being caused
Clearly, for a map outputting small records, a higher value than the default will likely decrease the number of s
io.sort.spill.percent float This is the threshold for the accounting and serialization buffers. When this percentage of either buffer has fille
Let io.sort.record.percent be r, io.sort.mb be x, and this value be q. The maximum numbe
* q * 2^16. Note that a higher value may decrease the number of- or even eliminate- merges, but will als
average map times are usually obtained by accurately estimating the size of the map output and preventing mul
Other notes
If either spill threshold is exceeded while a spill is in progress, collection will continue until
the spill is finished. For example, if io.sort.buffer.spill.percent is set to 0.33, and
the remainder of the buffer is filled while the spill runs, the next spill will include all the
collected records, or 0.66 of the buffer, and will not generate additional spills. In other words,
the thresholds are defining triggers, not blocking.
A record larger than the serialization buffer will first trigger a spill, then be spilled to a
separate file. It is undefined whether or not this record will first pass through the combiner.
Shuffle/Reduce Parameters
As described previously, each reduce fetches the output assigned to it by the Partitioner via
HTTP into memory and periodically merges these outputs to disk. If intermediate
compression of map outputs is turned on, each output is decompressed into memory. The
following options affect the frequency of these merges to disk prior to the reduce and the
memory allocated to map output during the reduce.
Name Type Description
io.sort.factor int Specifies the number of segments on disk to be merged at the same time. It limits the numbe
of files exceeds this limit, the merge will proceed in several passes. Though this limit also ap
limit is unlikely there.
mapred.inmem.merge.threshold int The number of sorted map outputs fetched into memory before being merged to disk. Like th
partition, but a trigger. In practice, this is usually set very high (1000) or disabled (0), since m
disk (see notes following this table). This threshold influences only the frequency of in-mem
mapred.job.shuffle.merge.percent float The memory threshold for fetched map outputs before an in-memory merge is started, expres
memory. Since map outputs that can't fit in memory can be stalled, setting this high may dec
high as 1.0 have been effective for reduces whose input can fit entirely in memory. This para
shuffle.
mapred.job.shuffle.input.buffer.percent float The percentage of memory- relative to the maximum heapsize as typically specified in mapr
storing map outputs during the shuffle. Though some memory should be set aside for the fram
large and numerous map outputs.
mapred.job.reduce.input.buffer.percent float The percentage of memory relative to the maximum heapsize in which map outputs may be r
be merged to disk until those that remain are under the resource limit this defines. By default
maximize the memory available to the reduce. For less memory-intensive reduces, this shoul
Other notes
If a map output is larger than 25 percent of the memory allocated to copying map outputs, it
will be written directly to disk without first staging through memory.
When running with a combiner, the reasoning about high merge thresholds and large buffers
may not hold. For merges started before all map outputs have been fetched, the combiner is
run while spilling to disk. In some cases, one can obtain better reduce times by spending
resources combining map outputs- making disk spills small and parallelizing spilling and
fetching- rather than aggressively increasing buffer sizes.
When merging in-memory map outputs to disk to begin the reduce, if an intermediate merge
is necessary because there are segments to spill and at least io.sort.factor segments
already on disk, the in-memory map outputs will be part of the intermediate merge.
Directory Structure
The task tracker has local directory, ${mapred.local.dir}/taskTracker/ to create
localized cache and localized job. It can define multiple local directories (spanning multiple
disks) and then each filename is assigned to a semi-random local directory. When the job
starts, task tracker creates a localized job directory relative to the local directory specified in
the configuration. Thus the task tracker directory structure looks as following:
Configured Parameters
The following properties are localized in the job configuration for each task's execution:
Name Type
map.input.start long The offset of the start of the map input split
Note: During the execution of a streaming job, the names of the "mapred" parameters are
transformed. The dots ( . ) become underscores ( _ ). For example, mapred.job.id becomes
mapred_job_id and mapred.jar becomes mapred_jar. To get the values in a streaming job's
mapper/reducer use the parameter names with the underscores.
Task Logs
The standard output (stdout) and error (stderr) streams of the task are read by the
TaskTracker and logged to ${HADOOP_LOG_DIR}/userlogs
Distributing Libraries
The DistributedCache can also be used to distribute both jars and native libraries for use in
the map and/or reduce tasks. The child-jvm always has its current working directory added to
the java.library.path and LD_LIBRARY_PATH. And hence the cached libraries can be
loaded via System.loadLibrary or System.load. More details on how to load shared libraries
through distributed cache are documented at native_libraries.html
User can view the history logs summary in specified directory using the following command
$ bin/hadoop job -history output-dir
This command will print job details, failed and killed tip details.
More details about the job such as successful tasks and task attempts made for each task can
be viewed using the following command
$ bin/hadoop job -history all output-dir
User can use OutputLogFilter to filter log files from the output directory listing.
Normally the user creates the application, describes various facets of the job via JobConf,
and then uses the JobClient to submit the job and monitor its progress.
Job Authorization
Job level authorization and queue level authorization are enabled on the cluster, if the
configuration mapred.acls.enabled is set to true. When enabled, access control checks
are done by (a) the JobTracker before allowing users to submit jobs to queues and
administering these jobs and (b) by the JobTracker and the TaskTracker before allowing
users to view job details or to modify a job using MapReduce APIs, CLI or web user
interfaces.
A job submitter can specify access control lists for viewing or modifying a job via the
configuration properties mapreduce.job.acl-view-job and mapreduce.job.acl-
modify-job respectively. By default, nobody is given access in these properties.
However, irrespective of the job ACLs configured, a job's owner, the superuser and cluster
administrators (mapreduce.cluster.administrators) and queue administrators of the
queue to which the job was submitted to (mapred.queue.queue-name.acl-administer-
jobs) always have access to view and modify a job.
killing a job
killing/failing a task of a job
setting the priority of a job
These operations are also permitted by the queue level ACL, "mapred.queue.queue-name.acl-
administer-jobs", configured via mapred-queue-acls.xml. The caller will be able to do the
operation if he/she is part of either queue admins ACL or job modification ACL.
The format of a job level ACL is the same as the format for a queue level ACL as defined in
the Cluster Setup documentation.
Job Control
Users may need to chain MapReduce jobs to accomplish complex tasks which cannot be done
via a single MapReduce job. This is fairly easy since the output of the job typically goes to
distributed file-system, and the output, in turn, can be used as the input for the next job.
However, this also means that the onus on ensuring jobs are complete (success/failure) lies
squarely on the clients. In such cases, the various job-control options are:
runJob(JobConf) : Submits the job and returns only after the job has completed.
submitJob(JobConf) : Only submits the job, then poll the returned handle to
the RunningJob to query status and make scheduling decisions.
JobConf.setJobEndNotificationURI(String) : Sets up a notification upon job-completion, thus
avoiding polling.
Job Credentials
In a secure cluster, the user is authenticated via Kerberos' kinit command. Because of
scalability concerns, we don't push the client's Kerberos' tickets in MapReduce jobs. Instead,
we acquire delegation tokens from each HDFS NameNode that the job will use and store
them in the job as part of job submission. The delegation tokens are automatically obtained
for the HDFS that holds the staging directories, where the job job files are written, and any
HDFS systems referenced by FileInputFormats, FileOutputFormats, DistCp, and the
distributed cache. Other applications require to set the configuration "mapreduce.job.hdfs-
servers" for all NameNodes that tasks might need to talk during the job execution. This is a
comma separated list of file system names, such as "hdfs://nn1/,hdfs://nn2/". These tokens
are passed to the JobTracker as part of the job submission as Credentials.
Similar to HDFS delegation tokens, we also have MapReduce delegation tokens. The
MapReduce tokens are provided so that tasks can spawn jobs if they wish to. The tasks
authenticate to the JobTracker via the MapReduce delegation tokens. The delegation token
can be obtained via the API in JobClient.getDelegationToken. The obtained token must then
be pushed onto the credentials that is there in the JobConf used for job submission. The
API Credentials.addToken can be used for this.
The credentials are sent to the JobTracker as part of the job submission process. The
JobTracker persists the tokens and secrets in its filesystem (typically HDFS) in a file within
mapred.system.dir/JOBID. The TaskTracker localizes the file as part job localization. Tasks
see an environment variable called HADOOP_TOKEN_FILE_LOCATION and the framework sets
this to point to the localized file. In order to launch jobs from tasks or for doing any HDFS
operation, tasks must set the configuration "mapreduce.job.credentials.binary" to point to
this token file.
The HDFS delegation tokens passed to the JobTracker during job submission are are
cancelled by the JobTracker when the job completes. This is the default behavior unless
mapreduce.job.complete.cancel.delegation.tokens is set to false in the JobConf. For jobs
whose tasks in turn spawns jobs, this should be set to false. Applications sharing JobConf
objects between multiple jobs on the JobClient side should look at setting
mapreduce.job.complete.cancel.delegation.tokens to false. This is because the Credentials
object within the JobConf will then be shared. All jobs will end up sharing the same tokens,
and hence the tokens should not be canceled when the jobs in the sequence finish.
Apart from the HDFS delegation tokens, arbitrary secrets can also be passed during the job
submission for tasks to access other third party services. The
APIs JobConf.getCredentials or JobContext.getCredentials() should be used to get the
credentials object and then Credentials.addSecretKey should be used to add secrets.
For applications written using the old MapReduce API, the Mapper/Reducer classes need to
implement JobConfigurable in order to get access to the credentials in the tasks. A reference
to the JobConf passed in the JobConfigurable.configure should be stored. In the new
MapReduce API, a similar thing can be done in the Mapper.setup method. The
api JobConf.getCredentials() or the api JobContext.getCredentials() should be used to get the
credentials reference (depending on whether the new MapReduce API or the old MapReduce
API is used). Tasks can access the secrets using the APIs in Credentials
Job Input
InputFormat describes the input-specification for a MapReduce job.
Clearly, logical splits based on input-size is insufficient for many applications since record
boundaries must be respected. In such cases, the application should implement
a RecordReader, who is responsible for respecting record-boundaries and presents a
record-oriented view of the logical InputSplit to the individual task.
InputSplit
InputSplit represents the data to be processed by an individual Mapper.
FileSplit is the default InputSplit. It sets map.input.file to the path of the input file for
the logical split.
RecordReader
RecordReader reads <key, value> pairs from an InputSplit.
Job Output
OutputFormat describes the output-specification for a MapReduce job.
OutputCommitter
OutputCommitter describes the commit of task output for a MapReduce job.
1. Setup the job during initialization. For example, create the temporary output directory
for the job during the initialization of the job. Job setup is done by a separate task
when the job is in PREP state and after initializing tasks. Once the setup task
completes, the job will be moved to RUNNING state.
2. Cleanup the job after the job completion. For example, remove the temporary output
directory after the job completion. Job cleanup is done by a separate task at the end
of the job. Job is declared SUCCEDED/FAILED/KILLED after the cleanup task
completes.
3. Setup the task temporary output. Task setup is done as part of the same task, during
task initialization.
4. Check whether a task needs a commit. This is to avoid the commit procedure if a task
does not need commit.
5. Commit of the task output. Once task is done, the task will commit it's output if
required.
6. Discard the task commit. If the task has been failed/killed, the output will be cleaned-
up. If task could not cleanup (in exception block), a separate task will be launched
with same attempt-id to do the cleanup.
FileOutputCommitter is the default OutputCommitter. Job setup/cleanup tasks occupy
map or reduce slots, whichever is free on the TaskTracker. And JobCleanup task,
TaskCleanup tasks and JobSetup task have the highest priority, and in that order.
The application-writer can take advantage of this feature by creating any side-files required
in ${mapred.work.output.dir} during execution of a task
via FileOutputFormat.getWorkOutputPath(), and the framework will promote them similarly
for succesful task-attempts, thus eliminating the need to pick unique paths per task-attempt.
The entire discussion holds true for maps of jobs with reducer=NONE (i.e. 0 reduces) since
output of the map, in that case, goes directly to HDFS.
RecordWriter
RecordWriter writes the output <key, value> pairs to an output file.
Hadoop comes configured with a single mandatory queue, called 'default'. Queue names are
defined in the mapred.queue.names property of the Hadoop site configuration. Some job
schedulers, such as the Capacity Scheduler, support multiple queues.
Counters
Counters represent global counters, defined either by the MapReduce framework or
applications. Each Counter can be of any Enum type. Counters of a particular Enum are
bunched into groups of type Counters.Group.
DistributedCache
DistributedCache distributes application-specific, large, read-only files efficiently.
"Private" DistributedCache files are cached in a local directory private to the user whose jobs
need these files. These files are shared by all tasks and jobs of the specific user only and
cannot be accessed by jobs of other users on the slaves. A DistributedCache file becomes
private by virtue of its permissions on the file system where the files are uploaded, typically
HDFS. If the file has no world readable access, or if the directory path leading to the file has
no world executable access for lookup, then the file becomes private.
"Public" DistributedCache files are cached in a global directory and the file access is setup
such that they are publicly visible to all users. These files can be shared by tasks and jobs of
all users on the slaves. A DistributedCache file becomes public by virtue of its permissions on
the file system where the files are uploaded, typically HDFS. If the file has world readable
access, AND if the directory path leading to the file has world executable access for lookup,
then the file becomes public. In other words, if the user intends to make a file publicly
available to all users, the file permissions must be set to be world readable, and the directory
permissions on the path leading to the file must be world executable.
Tool
The Tool interface supports the handling of generic Hadoop command-line options.
Tool is the standard for any MapReduce tool or application. The application should delegate
the handling of standard command-line options
to GenericOptionsParser via ToolRunner.run(Tool, String[]) and only handle its custom
arguments.
IsolationRunner
IsolationRunner is a utility to help debug MapReduce programs.
Next, go to the node on which the failed task ran and go to the TaskTracker's local
directory and run the IsolationRunner:
$ cd <local path>/taskTracker/${taskid}/work
$ bin/hadoop org.apache.hadoop.mapred.IsolationRunner ../job.xml
IsolationRunner will run the failed task in a single jvm, which can be in the debugger,
over precisely the same input.
Profiling
Profiling is a utility to get a representative (2 or 3) sample of built-in java profiler for a
sample of maps and reduces.
User can specify whether the system should collect profiler information for some of the tasks
in the job by setting the configuration property mapred.task.profile. The value can be
set using the api JobConf.setProfileEnabled(boolean). If the value is set true, the task
profiling is enabled. The profiler information is stored in the user log directory. By default,
profiling is not enabled for the job.
Once user configures that profiling is needed, she/he can use the configuration
property mapred.task.profile.{maps|reduces} to set the ranges of MapReduce tasks
to profile. The value can be set using the api JobConf.setProfileTaskRange(boolean,String).
By default, the specified range is 0-2.
User can also specify the profiler configuration arguments by setting the configuration
property mapred.task.profile.params. The value can be specified using the
api JobConf.setProfileParams(String). If the string contains a %s, it will be replaced with the
name of the profiling output file when the task runs. These parameters are passed to the task
child JVM on the command line. The default value for the profiling parameters is -
agentlib:hprof=cpu=samples,heap=sites,force=n,thread=y,verbose=n,file=
%s
Debugging
The MapReduce framework provides a facility to run user-provided scripts for debugging.
When a MapReduce task fails, a user can run a debug script, to process task logs for
example. The script is given access to the task's stdout and stderr outputs, syslog and
jobconf. The output from the debug script's stdout and stderr is displayed on the console
diagnostics and also as part of the job UI.
In the following sections we discuss how to submit a debug script with a job. The script file
needs to be distributed and submitted to the framework.
The arguments to the script are the task's stdout, stderr, syslog and jobconf files. The debug
command, run on the node where the MapReduce task failed, is:
$script $stdout $stderr $syslog $jobconf
Pipes programs have the c++ program name as a fifth argument for the command. Thus for
the pipes programs the command is
$script $stdout $stderr $syslog $jobconf $program
Default Behavior:
For pipes, a default script is run to process core dumps under gdb, prints stack trace and
gives info about running threads.
JobControl
JobControl is a utility which encapsulates a set of MapReduce jobs and their dependencies.
Data Compression
Hadoop MapReduce provides facilities for the application-writer to specify compression for
both intermediate map-outputs and the job-outputs i.e. output of the reduces. It also comes
bundled with CompressionCodec implementation for the zlib compression algorithm.
The gzip file format is also supported.
Hadoop also provides native implementations of the above compression codecs for reasons of
both performance (zlib) and non-availability of Java libraries. More details on their usage and
availability are available here.
Intermediate Outputs
Applications can control compression of intermediate map-outputs via
the JobConf.setCompressMapOutput(boolean) api and the CompressionCodec to be used
via the JobConf.setMapOutputCompressorClass(Class) api.
Job Outputs
Applications can control compression of job-outputs via
the FileOutputFormat.setCompressOutput(JobConf, boolean) api and
the CompressionCodec to be used can be specified via
the FileOutputFormat.setOutputCompressorClass(JobConf, Class) api.
If the job outputs are to be stored in the SequenceFileOutputFormat, the
required SequenceFile.CompressionType (i.e. RECORD / BLOCK - defaults to RECORD)
can be specified via the SequenceFileOutputFormat.setOutputCompressionType(JobConf,
SequenceFile.CompressionType) api.
This feature can be used when map tasks crash deterministically on certain input. This
usually happens due to bugs in the map function. Usually, the user would have to fix these
bugs. This is, however, not possible sometimes. The bug may be in third party libraries, for
example, for which the source code is not available. In such cases, the task never completes
successfully even after multiple attempts, and the job fails. With this feature, only a small
portion of data surrounding the bad records is lost, which may be acceptable for some
applications (those performing statistical analysis on very large data, for example).
With this feature enabled, the framework gets into 'skipping mode' after a certain number of
map failures. For more details,
see SkipBadRecords.setAttemptsToStartSkipping(Configuration, int). In 'skipping mode', map
tasks maintain the range of records being processed. To do this, the framework relies on the
processed record counter.
See SkipBadRecords.COUNTER_MAP_PROCESSED_RECORDS and SkipBadRecords.COUNTER_
REDUCE_PROCESSED_GROUPS. This counter enables the framework to know how many
records have been processed successfully, and hence, what record range caused a task to
crash. On further attempts, this range of records is skipped.
The number of records skipped depends on how frequently the processed record counter is
incremented by the application. It is recommended that this counter be incremented after
every record is processed. This may not be possible in some applications that typically batch
their processing. In such cases, the framework may skip additional records surrounding the
bad record. Users can control the number of skipped records
through SkipBadRecords.setMapperMaxSkipRecords(Configuration,
long) and SkipBadRecords.setReducerMaxSkipGroups(Configuration, long). The framework
tries to narrow the range of skipped records using a binary search-like approach. The skipped
range is divided into two halves and only one half gets executed. On subsequent failures, the
framework figures out which half contains bad records. A task will be re-executed till the
acceptable skipped value is met or all task attempts are exhausted. To increase the number
of task attempts,
use JobConf.setMaxMapAttempts(int) and JobConf.setMaxReduceAttempts(int).
Skipped records are written to HDFS in the sequence file format, for later analysis. The
location can be changed through SkipBadRecords.setSkipOutputPath(JobConf, Path).
1. package org.myorg;
2.
3. import java.io.*;
4. import java.util.*;
5.
6. import org.apache.hadoop.fs.Path;
7. import org.apache.hadoop.filecache.DistributedCache;
8. import org.apache.hadoop.conf.*;
9. import org.apache.hadoop.io.*;
12.
14.
16.
18.
21.
24.
27.
28. public void configure(JobConf job) {
31.
34. try {
38. }
40. parseSkipFile(patternsFile);
41. }
42. }
43. }
44.
46. try {
50. patternsToSkip.add(pattern);
51. }
53. System.err.println("Caught exception while parsing the cached file '" + patte
StringUtils.stringifyException(ioe));
54. }
55. }
56.
59.
62. }
63.
66. word.set(tokenizer.nextToken());
69. }
70.
73. }
74. }
75. }
76.
77. public static class Reduce extends MapReduceBase implements Reducer<Text, IntWri
82. }
85. }
86.
89. conf.setJobName("wordcount");
90.
91. conf.setOutputKeyClass(Text.class);
92. conf.setOutputValueClass(IntWritable.class);
93.
94. conf.setMapperClass(Map.class);
95. conf.setCombinerClass(Reduce.class);
96. conf.setReducerClass(Reduce.class);
97.
98. conf.setInputFormat(TextInputFormat.class);
99. conf.setOutputFormat(TextOutputFormat.class);
100.
107. other_args.add(args[i]);
108. }
109. }
110.
114. JobClient.runJob(conf);
115. return 0;
116. }
117.
120. System.exit(res);
121. }
122. }
123.
Sample Runs
Sample text-files as input:
Output:
Notice that the inputs differ from the first version we looked at, and how they affect the
outputs.
Now, lets plug-in a pattern-file which lists the word-patterns to be ignored, via
the DistributedCache.
Highlights
The second version of WordCount improves upon the previous one by using some features
offered by the MapReduce framework: