程序包 | 说明 |
---|---|
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.streaming |
Hadoop Streaming is a utility which allows users to create and run
Map-Reduce jobs with any executables (e.g.
|
限定符和类型 | 方法和说明 |
---|---|
static JobID |
JobID.downgrade(JobID old)
Downgrade a new JobID to an old one
|
static JobID |
JobID.forName(String str)
Construct a JobId object from given string
|
JobID |
RunningJob.getID()
Get the job identifier.
|
JobID |
TaskID.getJobID() |
JobID |
TaskAttemptID.getJobID() |
JobID |
Task.getJobID()
Get the job name for this task.
|
JobID |
JobStatus.getJobID() |
JobID |
JobProfile.getJobID()
Get the job id.
|
JobID |
JobInProgress.getJobID() |
JobID |
LocalJobRunner.getNewJobId() |
JobID |
JobTracker.getNewJobId()
Allocates a new JobId string.
|
static JobID |
JobID.read(DataInput in)
已过时。
|
限定符和类型 | 方法和说明 |
---|---|
void |
JobClient.displayTasks(JobID jobId,
String type,
String state)
Display the information about a job's tasks, of a particular type and
in a particular state
|
TaskReport[] |
LocalJobRunner.getCleanupTaskReports(JobID id) |
TaskReport[] |
JobTracker.getCleanupTaskReports(JobID jobid) |
TaskReport[] |
JobClient.getCleanupTaskReports(JobID jobId)
Get the information of the current state of the cleanup tasks of a job.
|
static String |
JobHistory.getHistoryFilePath(JobID jobId)
Given the job id, return the history file path from the cache
|
JobInProgress |
JobTracker.getJob(JobID jobid) |
RunningJob |
JobClient.getJob(JobID jobid)
Get an
RunningJob object to track an ongoing job. |
Counters |
LocalJobRunner.getJobCounters(JobID id) |
Counters |
JobTracker.getJobCounters(JobID jobid) |
static String |
JobHistory.JobInfo.getJobHistoryFileName(JobConf jobConf,
JobID id)
Recover the job history filename from the history folder.
|
JobProfile |
LocalJobRunner.getJobProfile(JobID id) |
JobProfile |
JobTracker.getJobProfile(JobID jobid) |
JobStatus |
LocalJobRunner.getJobStatus(JobID id) |
JobStatus |
JobTracker.getJobStatus(JobID jobid) |
static String |
JobTracker.getLocalJobFilePath(JobID jobId)
Get the localized job file path on the job trackers local file system
|
static String |
JobHistory.JobInfo.getLocalJobFilePath(JobID jobId)
Get the path of the locally stored job file
|
MapTaskCompletionEventsUpdate |
TaskUmbilicalProtocol.getMapCompletionEvents(JobID jobId,
int fromIndex,
int maxLocs,
TaskAttemptID id,
org.apache.hadoop.mapred.JvmContext jvmContext)
Called by a reduce task to get the map output locations for finished maps.
|
MapTaskCompletionEventsUpdate |
TaskTracker.getMapCompletionEvents(JobID jobId,
int fromEventId,
int maxLocs,
TaskAttemptID id,
org.apache.hadoop.mapred.JvmContext jvmContext) |
TaskReport[] |
LocalJobRunner.getMapTaskReports(JobID id) |
TaskReport[] |
JobTracker.getMapTaskReports(JobID jobid) |
TaskReport[] |
JobClient.getMapTaskReports(JobID jobId)
Get the information of the current state of the map tasks of a job.
|
TaskReport[] |
LocalJobRunner.getReduceTaskReports(JobID id) |
TaskReport[] |
JobTracker.getReduceTaskReports(JobID jobid) |
TaskReport[] |
JobClient.getReduceTaskReports(JobID jobId)
Get the information of the current state of the reduce tasks of a job.
|
TaskReport[] |
LocalJobRunner.getSetupTaskReports(JobID id) |
TaskReport[] |
JobTracker.getSetupTaskReports(JobID jobid) |
TaskReport[] |
JobClient.getSetupTaskReports(JobID jobId)
Get the information of the current state of the setup tasks of a job.
|
TaskCompletionEvent[] |
LocalJobRunner.getTaskCompletionEvents(JobID jobid,
int fromEventId,
int maxEvents) |
TaskCompletionEvent[] |
JobTracker.getTaskCompletionEvents(JobID jobid,
int fromEventId,
int maxEvents) |
void |
Task.initialize(JobConf job,
JobID id,
Reporter reporter,
boolean useNewApi) |
void |
LocalJobRunner.killJob(JobID id) |
void |
JobTracker.killJob(JobID jobid) |
static void |
JobHistory.JobInfo.logFailed(JobID jobid,
long timestamp,
int finishedMaps,
int finishedReduces,
String failReason)
Logs job failed event.
|
static void |
JobHistory.JobInfo.logFinished(JobID jobId,
long finishTime,
int finishedMaps,
int finishedReduces,
int failedMaps,
int failedReduces,
Counters mapCounters,
Counters reduceCounters,
Counters counters)
Log job finished. closes the job file in history.
|
static void |
JobHistory.JobInfo.logInited(JobID jobId,
long startTime,
int totalMaps,
int totalReduces)
Logs launch time of job.
|
static void |
JobHistory.JobInfo.logJobInfo(JobID jobid,
long submitTime,
long launchTime) |
static void |
JobHistory.JobInfo.logJobInfo(JobID jobid,
long submitTime,
long launchTime,
int restartCount)
已过时。
Use
JobHistory.JobInfo.logJobInfo(JobID, long, long) instead. |
static void |
JobHistory.JobInfo.logJobPriority(JobID jobid,
JobPriority priority)
Log job's priority.
|
static void |
JobHistory.JobInfo.logKilled(JobID jobid,
long timestamp,
int finishedMaps,
int finishedReduces)
Logs job killed event.
|
static void |
JobHistory.JobInfo.logStarted(JobID jobId)
Logs job as running
|
static void |
JobHistory.JobInfo.logStarted(JobID jobId,
long startTime,
int totalMaps,
int totalReduces)
|
static void |
JobHistory.JobInfo.logSubmitted(JobID jobId,
JobConf jobConf,
String jobConfPath,
long submitTime)
已过时。
|
static void |
JobHistory.JobInfo.logSubmitted(JobID jobId,
JobConf jobConf,
String jobConfPath,
long submitTime,
boolean restarted) |
void |
LocalJobRunner.setJobPriority(JobID id,
String jp) |
void |
JobTracker.setJobPriority(JobID jobid,
String priority) |
JobStatus |
LocalJobRunner.submitJob(JobID jobid,
String jobSubmitDir,
Credentials credentials) |
JobStatus |
JobTracker.submitJob(JobID jobId,
String jobSubmitDir,
Credentials ts)
JobTracker.submitJob() kicks off a new job.
|
构造器和说明 |
---|
JobInProgress(JobID jobid,
JobConf conf,
JobTracker tracker)
Create an almost empty JobInProgress, which can be used only for tests
|
JobStatus(JobID jobid,
float setupProgress,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int runState,
JobPriority jp)
Create a job status object for a given jobid.
|
JobStatus(JobID jobid,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int runState)
Create a job status object for a given jobid.
|
JobStatus(JobID jobid,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int runState,
JobPriority jp)
Create a job status object for a given jobid.
|
JobStatus(JobID jobid,
float mapProgress,
float reduceProgress,
int runState)
Create a job status object for a given jobid.
|
限定符和类型 | 方法和说明 |
---|---|
JobID |
Job.getAssignedJobID() |
限定符和类型 | 方法和说明 |
---|---|
void |
Job.setAssignedJobID(JobID mapredJobID)
Set the mapred ID for this job as assigned by the
mapred framework.
|
限定符和类型 | 字段和说明 |
---|---|
protected JobID |
StreamJob.jobId_ |
Copyright © 2009 The Apache Software Foundation