Modifier and Type | Method and Description |
---|---|
static JobId |
TypeConverter.toYarn(org.apache.hadoop.mapreduce.JobID id) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.mapred.JobID |
TypeConverter.fromYarn(JobId id) |
Modifier and Type | Method and Description |
---|---|
JobId |
KillJobRequest.getJobId() |
JobId |
GetTaskAttemptCompletionEventsRequest.getJobId() |
JobId |
GetCountersRequest.getJobId() |
JobId |
GetJobReportRequest.getJobId() |
JobId |
GetTaskReportsRequest.getJobId() |
Modifier and Type | Method and Description |
---|---|
void |
KillJobRequest.setJobId(JobId jobId) |
void |
GetTaskAttemptCompletionEventsRequest.setJobId(JobId jobId) |
void |
GetCountersRequest.setJobId(JobId jobId) |
void |
GetJobReportRequest.setJobId(JobId jobId) |
void |
GetTaskReportsRequest.setJobId(JobId jobId) |
Modifier and Type | Method and Description |
---|---|
JobId |
GetJobReportRequestPBImpl.getJobId() |
JobId |
GetTaskReportsRequestPBImpl.getJobId() |
JobId |
GetCountersRequestPBImpl.getJobId() |
JobId |
KillJobRequestPBImpl.getJobId() |
JobId |
GetTaskAttemptCompletionEventsRequestPBImpl.getJobId() |
Modifier and Type | Method and Description |
---|---|
void |
GetJobReportRequestPBImpl.setJobId(JobId jobId) |
void |
GetTaskReportsRequestPBImpl.setJobId(JobId jobId) |
void |
GetCountersRequestPBImpl.setJobId(JobId jobId) |
void |
KillJobRequestPBImpl.setJobId(JobId jobId) |
void |
GetTaskAttemptCompletionEventsRequestPBImpl.setJobId(JobId jobId) |
Modifier and Type | Method and Description |
---|---|
JobId |
JobReport.getJobId() |
abstract JobId |
TaskId.getJobId() |
Modifier and Type | Method and Description |
---|---|
int |
JobId.compareTo(JobId other) |
void |
JobReport.setJobId(JobId jobId) |
abstract void |
TaskId.setJobId(JobId jobId) |
Modifier and Type | Class and Description |
---|---|
class |
JobIdPBImpl |
Modifier and Type | Method and Description |
---|---|
JobId |
TaskIdPBImpl.getJobId() |
JobId |
JobReportPBImpl.getJobId() |
Modifier and Type | Method and Description |
---|---|
void |
TaskIdPBImpl.setJobId(JobId jobId) |
void |
JobReportPBImpl.setJobId(JobId jobId) |
Modifier and Type | Method and Description |
---|---|
JobId |
JobIndexInfo.getJobId() |
Modifier and Type | Method and Description |
---|---|
static String |
JobHistoryUtils.getIntermediateConfFileName(JobId jobId)
Get the done configuration file name for a job.
|
static String |
JobHistoryUtils.getIntermediateSummaryFileName(JobId jobId)
Get the done summary file name for a job.
|
static org.apache.hadoop.fs.Path |
JobHistoryUtils.getStagingConfFile(org.apache.hadoop.fs.Path logDir,
JobId jobId,
int attempt)
Gets the conf file path for jobs in progress.
|
static org.apache.hadoop.fs.Path |
JobHistoryUtils.getStagingJobHistoryFile(org.apache.hadoop.fs.Path dir,
JobId jobId,
int attempt)
Get the job history file path for non Done history files.
|
static String |
JobHistoryUtils.historyLogSubdirectory(JobId id,
String timestampComponent,
String serialNumberFormat)
Gets the history subdirectory based on the jobId, timestamp and serial number format.
|
static int |
JobHistoryUtils.jobSerialNumber(JobId id)
Computes a serial number used as part of directory naming for the given jobId.
|
static String |
JobHistoryUtils.serialNumberDirectoryComponent(JobId id,
String serialNumberFormat)
Gets the serial number part of the path based on the jobId and serialNumber format.
|
void |
JobIndexInfo.setJobId(JobId jobId) |
Constructor and Description |
---|
JobIndexInfo(long submitTime,
long finishTime,
String user,
String jobName,
JobId jobId,
int numMaps,
int numReduces,
String jobStatus) |
JobIndexInfo(long submitTime,
long finishTime,
String user,
String jobName,
JobId jobId,
int numMaps,
int numReduces,
String jobStatus,
String queueName) |
Modifier and Type | Method and Description |
---|---|
static JobId |
MRBuilderUtils.newJobId(org.apache.hadoop.yarn.api.records.ApplicationId appId,
int id) |
static JobId |
MRBuilderUtils.newJobId(long clusterTs,
int appIdInt,
int id) |
static JobId |
MRApps.toJobID(String jid) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.fs.Path |
MRApps.getEndJobCommitFailureFile(org.apache.hadoop.conf.Configuration conf,
String user,
JobId jobId) |
static org.apache.hadoop.fs.Path |
MRApps.getEndJobCommitSuccessFile(org.apache.hadoop.conf.Configuration conf,
String user,
JobId jobId) |
static org.apache.hadoop.fs.Path |
MRApps.getStartJobCommitFile(org.apache.hadoop.conf.Configuration conf,
String user,
JobId jobId) |
static JobReport |
MRBuilderUtils.newJobReport(JobId jobId,
String jobName,
String userName,
JobState state,
long submitTime,
long startTime,
long finishTime,
float setupProgress,
float mapProgress,
float reduceProgress,
float cleanupProgress,
String jobFile,
List<AMInfo> amInfos,
boolean isUber,
String diagnostics) |
static JobReport |
MRBuilderUtils.newJobReport(JobId jobId,
String jobName,
String userName,
JobState state,
long submitTime,
long startTime,
long finishTime,
float setupProgress,
float mapProgress,
float reduceProgress,
float cleanupProgress,
String jobFile,
List<AMInfo> amInfos,
boolean isUber,
String diagnostics,
org.apache.hadoop.yarn.api.records.Priority priority) |
static TaskId |
MRBuilderUtils.newTaskId(JobId jobId,
int id,
TaskType taskType) |
static String |
MRApps.toString(JobId jid) |
Copyright © 2008–2022 Apache Software Foundation. All rights reserved.