public class JobClient extends Configured implements Tool
JobClient is the primary interface for the user-job to interact
with the JobTracker.
JobClient provides facilities to submit jobs, track their
progress, access component-tasks' reports/logs, get the Map-Reduce cluster
status information etc.
The job submission process involves:
InputSplits for the job.
DistributedCache
of the job, if necessary.
JobTracker and optionally monitoring
it's status.
JobConf and then uses the JobClient to submit
the job and monitor its progress.
Here is an example on how to use JobClient:
// Create a new JobConf
JobConf job = new JobConf(new Configuration(), MyJob.class);
// Specify various job-specific parameters
job.setJobName("myjob");
job.setInputPath(new Path("in"));
job.setOutputPath(new Path("out"));
job.setMapperClass(MyJob.MyMapper.class);
job.setReducerClass(MyJob.MyReducer.class);
// Submit the job, then poll for progress until the job is complete
JobClient.runJob(job);
At times clients would chain map-reduce jobs to accomplish complex tasks which cannot be done via a single map-reduce job. This is fairly easy since the output of the job, typically, goes to distributed file-system and that 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 situations 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) : setup a notification
on job-completion, thus avoiding polling.
JobConf,
ClusterStatus,
Tool,
DistributedCache| 限定符和类型 | 类和说明 |
|---|---|
static class |
JobClient.Renewer |
static class |
JobClient.TaskStatusFilter |
| 限定符和类型 | 字段和说明 |
|---|---|
static long |
COUNTER_UPDATE_INTERVAL |
static long |
DEFAULT_DISK_HEALTH_CHECK_INTERVAL
How often TaskTracker needs to check the health of its disks, if not
configured using mapred.disk.healthChecker.interval
|
static int |
FILE_NOT_FOUND |
static String |
FOR_REDUCE_TASK
The reduce task number for which this map output is being transferred
|
static String |
FROM_MAP_TASK
The map task from which the map output data is being transferred
|
static int |
HEARTBEAT_INTERVAL_MIN |
static String |
MAP_OUTPUT_LENGTH
The custom http header used for the map output length.
|
static boolean |
MAPREDUCE_CLIENT_RETRY_POLICY_ENABLED_DEFAULT |
static String |
MAPREDUCE_CLIENT_RETRY_POLICY_ENABLED_KEY |
static String |
MAPREDUCE_CLIENT_RETRY_POLICY_SPEC_DEFAULT |
static String |
MAPREDUCE_CLIENT_RETRY_POLICY_SPEC_KEY |
static String |
RAW_MAP_OUTPUT_LENGTH
The custom http header used for the "raw" map output length.
|
static int |
SUCCESS |
static String |
WORKDIR |
| 构造器和说明 |
|---|
JobClient()
Create a job client.
|
JobClient(InetSocketAddress jobTrackAddr,
Configuration conf)
Build a job client, connect to the indicated job tracker.
|
JobClient(JobConf conf)
Build a job client with the given
JobConf, and connect to the
default JobTracker. |
| 限定符和类型 | 方法和说明 |
|---|---|
void |
cancelDelegationToken(Token<DelegationTokenIdentifier> token)
Cancel a delegation token from the JobTracker
|
void |
close()
Close the
JobClient. |
void |
displayTasks(JobID jobId,
String type,
String state)
Display the information about a job's tasks, of a particular type and
in a particular state
|
JobStatus[] |
getAllJobs()
Get the jobs that are submitted.
|
TaskReport[] |
getCleanupTaskReports(JobID jobId)
Get the information of the current state of the cleanup tasks of a job.
|
ClusterStatus |
getClusterStatus()
Get status information about the Map-Reduce cluster.
|
ClusterStatus |
getClusterStatus(boolean detailed)
Get status information about the Map-Reduce cluster.
|
int |
getDefaultMaps()
Get status information about the max available Maps in the cluster.
|
int |
getDefaultReduces()
Get status information about the max available Reduces in the cluster.
|
Token<DelegationTokenIdentifier> |
getDelegationToken(Text renewer) |
FileSystem |
getFs()
Get a filesystem handle.
|
RunningJob |
getJob(JobID jobid)
Get an
RunningJob object to track an ongoing job. |
RunningJob |
getJob(String jobid)
已过时。
Applications should rather use
getJob(JobID). |
JobStatus[] |
getJobsFromQueue(String queueName)
Gets all the jobs which were added to particular Job Queue
|
TaskReport[] |
getMapTaskReports(JobID jobId)
Get the information of the current state of the map tasks of a job.
|
TaskReport[] |
getMapTaskReports(String jobId)
已过时。
Applications should rather use
getMapTaskReports(JobID) |
QueueAclsInfo[] |
getQueueAclsForCurrentUser()
Gets the Queue ACLs for current user
|
JobQueueInfo |
getQueueInfo(String queueName)
Gets the queue information associated to a particular Job Queue
|
JobQueueInfo[] |
getQueues()
Return an array of queue information objects about all the Job Queues
configured.
|
TaskReport[] |
getReduceTaskReports(JobID jobId)
Get the information of the current state of the reduce tasks of a job.
|
TaskReport[] |
getReduceTaskReports(String jobId)
已过时。
Applications should rather use
getReduceTaskReports(JobID) |
TaskReport[] |
getSetupTaskReports(JobID jobId)
Get the information of the current state of the setup tasks of a job.
|
Path |
getStagingAreaDir()
Grab the jobtracker's view of the staging directory path where
job-specific files will be placed.
|
Path |
getSystemDir()
Grab the jobtracker system directory path where job-specific files are to be placed.
|
JobClient.TaskStatusFilter |
getTaskOutputFilter()
已过时。
|
static JobClient.TaskStatusFilter |
getTaskOutputFilter(JobConf job)
Get the task output filter out of the JobConf.
|
void |
init(JobConf conf)
Connect to the default
JobTracker. |
static boolean |
isJobDirValid(Path jobDirPath,
FileSystem fs)
Checks if the job directory is clean and has all the required components
for (re) starting the job
|
JobStatus[] |
jobsToComplete()
Get the jobs that are not completed and not failed.
|
static void |
main(String[] argv) |
boolean |
monitorAndPrintJob(JobConf conf,
RunningJob job)
Monitor a job and print status in real-time as progress is made and tasks
fail.
|
long |
renewDelegationToken(Token<DelegationTokenIdentifier> token)
Renew a delegation token
|
int |
run(String[] argv)
Execute the command with the given arguments.
|
static RunningJob |
runJob(JobConf job)
Utility that submits a job, then polls for progress until the job is
complete.
|
void |
setTaskOutputFilter(JobClient.TaskStatusFilter newValue)
已过时。
|
static void |
setTaskOutputFilter(JobConf job,
JobClient.TaskStatusFilter newValue)
Modify the JobConf to set the task output filter.
|
RunningJob |
submitJob(JobConf job)
Submit a job to the MR system.
|
RunningJob |
submitJob(String jobFile)
Submit a job to the MR system.
|
RunningJob |
submitJobInternal(JobConf job)
Internal method for submitting jobs to the system.
|
getConf, setConfclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitgetConf, setConfpublic static final String MAPREDUCE_CLIENT_RETRY_POLICY_ENABLED_KEY
public static final boolean MAPREDUCE_CLIENT_RETRY_POLICY_ENABLED_DEFAULT
public static final String MAPREDUCE_CLIENT_RETRY_POLICY_SPEC_KEY
public static final String MAPREDUCE_CLIENT_RETRY_POLICY_SPEC_DEFAULT
public static final int HEARTBEAT_INTERVAL_MIN
public static final long COUNTER_UPDATE_INTERVAL
public static final long DEFAULT_DISK_HEALTH_CHECK_INTERVAL
public static final int SUCCESS
public static final int FILE_NOT_FOUND
public static final String MAP_OUTPUT_LENGTH
public static final String RAW_MAP_OUTPUT_LENGTH
public static final String FROM_MAP_TASK
public static final String FOR_REDUCE_TASK
public JobClient()
public JobClient(JobConf conf) throws IOException
JobConf, and connect to the
default JobTracker.conf - the job configuration.IOExceptionpublic JobClient(InetSocketAddress jobTrackAddr, Configuration conf) throws IOException
jobTrackAddr - the job tracker to connect to.conf - configuration.IOExceptionpublic void init(JobConf conf) throws IOException
JobTracker.conf - the job configuration.IOExceptionpublic void close()
throws IOException
JobClient.IOExceptionpublic FileSystem getFs() throws IOException
IOExceptionpublic RunningJob submitJob(String jobFile) throws FileNotFoundException, InvalidJobConfException, IOException
RunningJob which can be used to track
the running-job.jobFile - the job configuration.RunningJob which can be used to track the
running-job.FileNotFoundExceptionInvalidJobConfExceptionIOExceptionpublic RunningJob submitJob(JobConf job) throws FileNotFoundException, IOException
RunningJob which can be used to track
the running-job.job - the job configuration.RunningJob which can be used to track the
running-job.FileNotFoundExceptionIOExceptionpublic RunningJob submitJobInternal(JobConf job) throws FileNotFoundException, ClassNotFoundException, InterruptedException, IOException
job - the configuration to submitFileNotFoundExceptionClassNotFoundExceptionInterruptedExceptionIOExceptionpublic static boolean isJobDirValid(Path jobDirPath, FileSystem fs) throws IOException
IOExceptionpublic RunningJob getJob(JobID jobid) throws IOException
RunningJob object to track an ongoing job. Returns
null if the id does not correspond to any known job.jobid - the jobid of the job.RunningJob handle to track the job, null if the
jobid doesn't correspond to any known job.IOException@Deprecated public RunningJob getJob(String jobid) throws IOException
getJob(JobID).IOExceptionpublic TaskReport[] getMapTaskReports(JobID jobId) throws IOException
jobId - the job to query.IOException@Deprecated public TaskReport[] getMapTaskReports(String jobId) throws IOException
getMapTaskReports(JobID)IOExceptionpublic TaskReport[] getReduceTaskReports(JobID jobId) throws IOException
jobId - the job to query.IOExceptionpublic TaskReport[] getCleanupTaskReports(JobID jobId) throws IOException
jobId - the job to query.IOExceptionpublic TaskReport[] getSetupTaskReports(JobID jobId) throws IOException
jobId - the job to query.IOException@Deprecated public TaskReport[] getReduceTaskReports(String jobId) throws IOException
getReduceTaskReports(JobID)IOExceptionpublic void displayTasks(JobID jobId, String type, String state) throws IOException
jobId - the ID of the jobtype - the type of the task (map/reduce/setup/cleanup)state - the state of the task
(pending/running/completed/failed/killed)IOExceptionpublic ClusterStatus getClusterStatus() throws IOException
ClusterStatus.IOExceptionpublic ClusterStatus getClusterStatus(boolean detailed) throws IOException
detailed - if true then get a detailed status including the
tracker names and memory usage of the JobTrackerClusterStatus.IOExceptionpublic Path getStagingAreaDir() throws IOException
IOExceptionpublic JobStatus[] jobsToComplete() throws IOException
JobStatus for the running/to-be-run jobs.IOExceptionpublic JobStatus[] getAllJobs() throws IOException
JobStatus for the submitted jobs.IOExceptionpublic static RunningJob runJob(JobConf job) throws IOException
job - the job configuration.IOException - if the job failspublic boolean monitorAndPrintJob(JobConf conf, RunningJob job) throws IOException, InterruptedException
conf - the job's configurationjob - the job to trackIOException - if communication to the JobTracker failsInterruptedException@Deprecated public void setTaskOutputFilter(JobClient.TaskStatusFilter newValue)
newValue - task filter.public static JobClient.TaskStatusFilter getTaskOutputFilter(JobConf job)
job - the JobConf to examine.public static void setTaskOutputFilter(JobConf job, JobClient.TaskStatusFilter newValue)
job - the JobConf to modify.newValue - the value to set.@Deprecated public JobClient.TaskStatusFilter getTaskOutputFilter()
public int run(String[] argv) throws Exception
Toolpublic int getDefaultMaps()
throws IOException
IOExceptionpublic int getDefaultReduces()
throws IOException
IOExceptionpublic Path getSystemDir()
public JobQueueInfo[] getQueues() throws IOException
IOExceptionpublic JobStatus[] getJobsFromQueue(String queueName) throws IOException
queueName - name of the Job QueueIOExceptionpublic JobQueueInfo getQueueInfo(String queueName) throws IOException
queueName - name of the job queue.IOExceptionpublic QueueAclsInfo[] getQueueAclsForCurrentUser() throws IOException
IOExceptionpublic Token<DelegationTokenIdentifier> getDelegationToken(Text renewer) throws IOException, InterruptedException
public long renewDelegationToken(Token<DelegationTokenIdentifier> token) throws SecretManager.InvalidToken, IOException, InterruptedException
token - the token to renewSecretManager.InvalidTokenIOExceptionInterruptedExceptionpublic void cancelDelegationToken(Token<DelegationTokenIdentifier> token) throws IOException, InterruptedException
token - the token to cancelIOExceptionInterruptedExceptionCopyright © 2009 The Apache Software Foundation