public interface Job
Modifier and Type | Method and Description |
---|---|
boolean |
checkAccess(org.apache.hadoop.security.UserGroupInformation callerUGI,
org.apache.hadoop.mapreduce.JobACL jobOperation) |
org.apache.hadoop.mapreduce.Counters |
getAllCounters()
Get all the counters of this job.
|
List<org.apache.hadoop.mapreduce.v2.api.records.AMInfo> |
getAMInfos() |
int |
getCompletedMaps() |
int |
getCompletedReduces() |
org.apache.hadoop.fs.Path |
getConfFile() |
List<String> |
getDiagnostics() |
int |
getFailedMaps() |
int |
getFailedReduces() |
org.apache.hadoop.mapreduce.v2.api.records.JobId |
getID() |
Map<org.apache.hadoop.mapreduce.JobACL,org.apache.hadoop.security.authorize.AccessControlList> |
getJobACLs() |
int |
getKilledMaps() |
int |
getKilledReduces() |
org.apache.hadoop.mapred.TaskCompletionEvent[] |
getMapAttemptCompletionEvents(int startIndex,
int maxEvents) |
String |
getName() |
float |
getProgress() |
String |
getQueueName() |
org.apache.hadoop.mapreduce.v2.api.records.JobReport |
getReport() |
org.apache.hadoop.mapreduce.v2.api.records.JobState |
getState() |
Task |
getTask(org.apache.hadoop.mapreduce.v2.api.records.TaskId taskID) |
org.apache.hadoop.mapreduce.v2.api.records.TaskAttemptCompletionEvent[] |
getTaskAttemptCompletionEvents(int fromEventId,
int maxEvents) |
Map<org.apache.hadoop.mapreduce.v2.api.records.TaskId,Task> |
getTasks() |
Map<org.apache.hadoop.mapreduce.v2.api.records.TaskId,Task> |
getTasks(org.apache.hadoop.mapreduce.v2.api.records.TaskType taskType) |
int |
getTotalMaps() |
int |
getTotalReduces() |
String |
getUserName() |
boolean |
isUber() |
org.apache.hadoop.conf.Configuration |
loadConfFile() |
void |
setJobPriority(org.apache.hadoop.yarn.api.records.Priority priority) |
void |
setQueueName(String queueName) |
org.apache.hadoop.mapreduce.v2.api.records.JobId getID()
String getName()
org.apache.hadoop.mapreduce.v2.api.records.JobState getState()
org.apache.hadoop.mapreduce.v2.api.records.JobReport getReport()
org.apache.hadoop.mapreduce.Counters getAllCounters()
Map<org.apache.hadoop.mapreduce.v2.api.records.TaskId,Task> getTasks(org.apache.hadoop.mapreduce.v2.api.records.TaskType taskType)
Task getTask(org.apache.hadoop.mapreduce.v2.api.records.TaskId taskID)
int getTotalMaps()
int getTotalReduces()
int getCompletedMaps()
int getCompletedReduces()
int getFailedMaps()
int getFailedReduces()
int getKilledMaps()
int getKilledReduces()
float getProgress()
boolean isUber()
String getUserName()
String getQueueName()
org.apache.hadoop.fs.Path getConfFile()
org.apache.hadoop.conf.Configuration loadConfFile() throws IOException
getConfFile()
.IOException
- on any error trying to load the conf file.Map<org.apache.hadoop.mapreduce.JobACL,org.apache.hadoop.security.authorize.AccessControlList> getJobACLs()
org.apache.hadoop.mapreduce.v2.api.records.TaskAttemptCompletionEvent[] getTaskAttemptCompletionEvents(int fromEventId, int maxEvents)
org.apache.hadoop.mapred.TaskCompletionEvent[] getMapAttemptCompletionEvents(int startIndex, int maxEvents)
List<org.apache.hadoop.mapreduce.v2.api.records.AMInfo> getAMInfos()
boolean checkAccess(org.apache.hadoop.security.UserGroupInformation callerUGI, org.apache.hadoop.mapreduce.JobACL jobOperation)
void setQueueName(String queueName)
void setJobPriority(org.apache.hadoop.yarn.api.records.Priority priority)
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.