public class Job extends JobContext
| 限定符和类型 | 类和说明 |
|---|---|
static class |
Job.JobState |
CACHE_ARCHIVES_VISIBILITIES, CACHE_FILE_VISIBILITIES, COMBINE_CLASS_ATTR, conf, credentials, INPUT_FORMAT_CLASS_ATTR, JOB_ACL_MODIFY_JOB, JOB_ACL_VIEW_JOB, JOB_CANCEL_DELEGATION_TOKEN, JOB_NAMENODES, MAP_CLASS_ATTR, OUTPUT_FORMAT_CLASS_ATTR, PARTITIONER_CLASS_ATTR, REDUCE_CLASS_ATTR, ugi, USER_LOG_RETAIN_HOURS| 构造器和说明 |
|---|
Job() |
Job(Configuration conf) |
Job(Configuration conf,
String jobName) |
| 限定符和类型 | 方法和说明 |
|---|---|
void |
failTask(TaskAttemptID taskId)
Fail indicated task attempt.
|
Counters |
getCounters()
Gets the counters for this job.
|
static Job |
getInstance()
Creates a new
Job
A Job will be created with a generic Configuration. |
static Job |
getInstance(Configuration conf)
Creates a new
Job with a given Configuration. |
static Job |
getInstance(Configuration conf,
String jobName)
Creates a new
Job with a given Configuration
and a given jobName. |
String |
getJar()
Get the pathname of the job's jar.
|
TaskCompletionEvent[] |
getTaskCompletionEvents(int startFrom)
Get events indicating completion (success/failure) of component tasks.
|
String |
getTrackingURL()
Get the URL where some job progress information will be displayed.
|
boolean |
isComplete()
Check if the job is finished or not.
|
boolean |
isSuccessful()
Check if the job completed successfully.
|
void |
killJob()
Kill the running job.
|
void |
killTask(TaskAttemptID taskId)
Kill indicated task attempt.
|
float |
mapProgress()
Get the progress of the job's map-tasks, as a float between 0.0
and 1.0.
|
float |
reduceProgress()
Get the progress of the job's reduce-tasks, as a float between 0.0
and 1.0.
|
void |
setCancelDelegationTokenUponJobCompletion(boolean value)
Sets the flag that will allow the JobTracker to cancel the HDFS delegation
tokens upon job completion.
|
void |
setCombinerClass(Class<? extends Reducer> cls)
Set the combiner class for the job.
|
void |
setGroupingComparatorClass(Class<? extends RawComparator> cls)
Define the comparator that controls which keys are grouped together
for a single call to
Reducer.reduce(Object, Iterable,
org.apache.hadoop.mapreduce.Reducer.Context) |
void |
setInputFormatClass(Class<? extends InputFormat> cls)
Set the
InputFormat for the job. |
void |
setJarByClass(Class<?> cls)
Set the Jar by finding where a given class came from.
|
void |
setJobName(String name)
Set the user-specified job name.
|
void |
setMapOutputKeyClass(Class<?> theClass)
Set the key class for the map output data.
|
void |
setMapOutputValueClass(Class<?> theClass)
Set the value class for the map output data.
|
void |
setMapperClass(Class<? extends Mapper> cls)
Set the
Mapper for the job. |
void |
setMapSpeculativeExecution(boolean speculativeExecution)
Turn speculative execution on or off for this job for map tasks.
|
void |
setNumReduceTasks(int tasks)
Set the number of reduce tasks for the job.
|
void |
setOutputFormatClass(Class<? extends OutputFormat> cls)
Set the
OutputFormat for the job. |
void |
setOutputKeyClass(Class<?> theClass)
Set the key class for the job output data.
|
void |
setOutputValueClass(Class<?> theClass)
Set the value class for job outputs.
|
void |
setPartitionerClass(Class<? extends Partitioner> cls)
Set the
Partitioner for the job. |
void |
setReducerClass(Class<? extends Reducer> cls)
Set the
Reducer for the job. |
void |
setReduceSpeculativeExecution(boolean speculativeExecution)
Turn speculative execution on or off for this job for reduce tasks.
|
void |
setSortComparatorClass(Class<? extends RawComparator> cls)
Define the comparator that controls how the keys are sorted before they
are passed to the
Reducer. |
void |
setSpeculativeExecution(boolean speculativeExecution)
Turn speculative execution on or off for this job.
|
float |
setupProgress()
Get the progress of the job's setup, as a float between 0.0
and 1.0.
|
void |
setWorkingDirectory(Path dir)
Set the current working directory for the default file system.
|
void |
submit()
Submit the job to the cluster and return immediately.
|
boolean |
waitForCompletion(boolean verbose)
Submit the job to the cluster and wait for it to finish.
|
getCombinerClass, getConfiguration, getCredentials, getGroupingComparator, getInputFormatClass, getJobID, getJobName, getMapOutputKeyClass, getMapOutputValueClass, getMapperClass, getNumReduceTasks, getOutputFormatClass, getOutputKeyClass, getOutputValueClass, getPartitionerClass, getReducerClass, getSortComparator, getWorkingDirectorypublic Job()
throws IOException
IOExceptionpublic Job(Configuration conf) throws IOException
IOExceptionpublic Job(Configuration conf, String jobName) throws IOException
IOExceptionpublic static Job getInstance() throws IOException
Job
A Job will be created with a generic Configuration.JobIOExceptionpublic static Job getInstance(Configuration conf) throws IOException
Job with a given Configuration.
The Job makes a copy of the Configuration so
that any necessary internal modifications do not reflect on the incoming
parameter.conf - the ConfigurationJobIOExceptionpublic static Job getInstance(Configuration conf, String jobName) throws IOException
Job with a given Configuration
and a given jobName.
The Job makes a copy of the Configuration so
that any necessary internal modifications do not reflect on the incoming
parameter.conf - the ConfigurationjobName - the job instance's nameJobIOExceptionpublic void setNumReduceTasks(int tasks)
throws IllegalStateException
tasks - the number of reduce tasksIllegalStateException - if the job is submittedpublic void setWorkingDirectory(Path dir) throws IOException
dir - the new current working directory.IllegalStateException - if the job is submittedIOExceptionpublic void setInputFormatClass(Class<? extends InputFormat> cls) throws IllegalStateException
InputFormat for the job.cls - the InputFormat to useIllegalStateException - if the job is submittedpublic void setOutputFormatClass(Class<? extends OutputFormat> cls) throws IllegalStateException
OutputFormat for the job.cls - the OutputFormat to useIllegalStateException - if the job is submittedpublic void setMapperClass(Class<? extends Mapper> cls) throws IllegalStateException
Mapper for the job.cls - the Mapper to useIllegalStateException - if the job is submittedpublic void setJarByClass(Class<?> cls)
cls - the example classpublic String getJar()
getJar 在类中 JobContextpublic void setCombinerClass(Class<? extends Reducer> cls) throws IllegalStateException
cls - the combiner to useIllegalStateException - if the job is submittedpublic void setReducerClass(Class<? extends Reducer> cls) throws IllegalStateException
Reducer for the job.cls - the Reducer to useIllegalStateException - if the job is submittedpublic void setPartitionerClass(Class<? extends Partitioner> cls) throws IllegalStateException
Partitioner for the job.cls - the Partitioner to useIllegalStateException - if the job is submittedpublic void setMapOutputKeyClass(Class<?> theClass) throws IllegalStateException
theClass - the map output key class.IllegalStateException - if the job is submittedpublic void setMapOutputValueClass(Class<?> theClass) throws IllegalStateException
theClass - the map output value class.IllegalStateException - if the job is submittedpublic void setOutputKeyClass(Class<?> theClass) throws IllegalStateException
theClass - the key class for the job output data.IllegalStateException - if the job is submittedpublic void setOutputValueClass(Class<?> theClass) throws IllegalStateException
theClass - the value class for job outputs.IllegalStateException - if the job is submittedpublic void setSortComparatorClass(Class<? extends RawComparator> cls) throws IllegalStateException
Reducer.cls - the raw comparatorIllegalStateException - if the job is submittedpublic void setGroupingComparatorClass(Class<? extends RawComparator> cls) throws IllegalStateException
Reducer.reduce(Object, Iterable,
org.apache.hadoop.mapreduce.Reducer.Context)cls - the raw comparator to useIllegalStateException - if the job is submittedpublic void setJobName(String name) throws IllegalStateException
name - the job's new name.IllegalStateException - if the job is submittedpublic void setSpeculativeExecution(boolean speculativeExecution)
speculativeExecution - true if speculative execution
should be turned on, else false.public void setMapSpeculativeExecution(boolean speculativeExecution)
speculativeExecution - true if speculative execution
should be turned on for map tasks,
else false.public void setReduceSpeculativeExecution(boolean speculativeExecution)
speculativeExecution - true if speculative execution
should be turned on for reduce tasks,
else false.public String getTrackingURL()
public float setupProgress()
throws IOException
IOExceptionpublic float mapProgress()
throws IOException
IOExceptionpublic float reduceProgress()
throws IOException
IOExceptionpublic boolean isComplete()
throws IOException
true if the job is complete, else false.IOExceptionpublic boolean isSuccessful()
throws IOException
true if the job succeeded, else false.IOExceptionpublic void killJob()
throws IOException
IOExceptionpublic TaskCompletionEvent[] getTaskCompletionEvents(int startFrom) throws IOException
startFrom - index to start fetching events fromTaskCompletionEventsIOExceptionpublic void killTask(TaskAttemptID taskId) throws IOException
taskId - the id of the task to be terminated.IOExceptionpublic void failTask(TaskAttemptID taskId) throws IOException
taskId - the id of the task to be terminated.IOExceptionpublic Counters getCounters() throws IOException
IOExceptionpublic void setCancelDelegationTokenUponJobCompletion(boolean value)
public void submit()
throws IOException,
InterruptedException,
ClassNotFoundException
public boolean waitForCompletion(boolean verbose)
throws IOException,
InterruptedException,
ClassNotFoundException
verbose - print the progress to the userIOException - thrown if the communication with the
JobTracker is lostInterruptedExceptionClassNotFoundExceptionCopyright © 2009 The Apache Software Foundation