public class JobHistory extends org.apache.hadoop.service.AbstractService implements HistoryContext
| Modifier and Type | Field and Description | 
|---|---|
| static Pattern | CONF_FILENAME_REGEX | 
| static String | OLD_SUFFIX | 
| Constructor and Description | 
|---|
| JobHistory() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected org.apache.hadoop.conf.Configuration | createConf() | 
| protected HistoryFileManager | createHistoryFileManager() | 
| protected HistoryStorage | createHistoryStorage() | 
| Map<org.apache.hadoop.mapreduce.v2.api.records.JobId,org.apache.hadoop.mapreduce.v2.app.job.Job> | getAllJobs() | 
| Map<org.apache.hadoop.mapreduce.v2.api.records.JobId,org.apache.hadoop.mapreduce.v2.app.job.Job> | getAllJobs(org.apache.hadoop.yarn.api.records.ApplicationId appID) | 
| org.apache.hadoop.yarn.api.records.ApplicationAttemptId | getApplicationAttemptId() | 
| org.apache.hadoop.yarn.api.records.ApplicationId | getApplicationID() | 
| String | getApplicationName() | 
| Set<String> | getBlacklistedNodes() | 
| long | getCleanerInterval() | 
| org.apache.hadoop.yarn.security.client.ClientToAMTokenSecretManager | getClientToAMTokenSecretManager() | 
| org.apache.hadoop.yarn.util.Clock | getClock() | 
| org.apache.hadoop.mapreduce.v2.app.ClusterInfo | getClusterInfo() | 
| org.apache.hadoop.yarn.event.EventHandler<org.apache.hadoop.yarn.event.Event> | getEventHandler() | 
| String | getHistoryUrl() | 
| protected int | getInitDelaySecs() | 
| org.apache.hadoop.mapreduce.v2.app.job.Job | getJob(org.apache.hadoop.mapreduce.v2.api.records.JobId jobId) | 
| String | getNMHostname() | 
| JobsInfo | getPartialJobs(Long offset,
              Long count,
              String user,
              String queue,
              Long sBegin,
              Long sEnd,
              Long fBegin,
              Long fEnd,
              org.apache.hadoop.mapreduce.v2.api.records.JobState jobState)Look for a set of partial jobs. | 
| org.apache.hadoop.mapreduce.v2.app.TaskAttemptFinishingMonitor | getTaskAttemptFinishingMonitor() | 
| CharSequence | getUser() | 
| boolean | hasSuccessfullyUnregistered() | 
| boolean | isLastAMRetry() | 
| void | refreshJobRetentionSettings() | 
| void | refreshLoadedJobCache() | 
| protected void | serviceInit(org.apache.hadoop.conf.Configuration conf) | 
| protected void | serviceStart() | 
| protected void | serviceStop() | 
| void | setHistoryUrl(String historyUrl) | 
close, getBlockers, getConfig, getFailureCause, getFailureState, getLifecycleHistory, getName, getServiceState, getStartTime, init, isInState, noteFailure, putBlocker, registerGlobalListener, registerServiceListener, removeBlocker, setConfig, start, stop, toString, unregisterGlobalListener, unregisterServiceListener, waitForServiceToStoppublic static final Pattern CONF_FILENAME_REGEX
public static final String OLD_SUFFIX
protected void serviceInit(org.apache.hadoop.conf.Configuration conf)
                    throws Exception
serviceInit in class org.apache.hadoop.service.AbstractServiceExceptionprotected HistoryStorage createHistoryStorage()
protected HistoryFileManager createHistoryFileManager()
protected void serviceStart()
                     throws Exception
serviceStart in class org.apache.hadoop.service.AbstractServiceExceptionprotected int getInitDelaySecs()
protected void serviceStop()
                    throws Exception
serviceStop in class org.apache.hadoop.service.AbstractServiceExceptionpublic String getApplicationName()
getApplicationName in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic org.apache.hadoop.mapreduce.v2.app.job.Job getJob(org.apache.hadoop.mapreduce.v2.api.records.JobId jobId)
getJob in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic Map<org.apache.hadoop.mapreduce.v2.api.records.JobId,org.apache.hadoop.mapreduce.v2.app.job.Job> getAllJobs(org.apache.hadoop.yarn.api.records.ApplicationId appID)
getAllJobs in interface HistoryContextpublic Map<org.apache.hadoop.mapreduce.v2.api.records.JobId,org.apache.hadoop.mapreduce.v2.app.job.Job> getAllJobs()
getAllJobs in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic void refreshLoadedJobCache()
public JobsInfo getPartialJobs(Long offset, Long count, String user, String queue, Long sBegin, Long sEnd, Long fBegin, Long fEnd, org.apache.hadoop.mapreduce.v2.api.records.JobState jobState)
getPartialJobs in interface HistoryContextoffset - the offset into the list of jobs.count - the maximum number of jobs to return.user - only return jobs for the given user.queue - only return jobs for in the given queue.sBegin - only return Jobs that started on or after the given time.sEnd - only return Jobs that started on or before the given time.fBegin - only return Jobs that ended on or after the given time.fEnd - only return Jobs that ended on or before the given time.jobState - only return jobs that are in the give job state.public void refreshJobRetentionSettings()
protected org.apache.hadoop.conf.Configuration createConf()
public long getCleanerInterval()
public org.apache.hadoop.yarn.api.records.ApplicationAttemptId getApplicationAttemptId()
getApplicationAttemptId in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic org.apache.hadoop.yarn.api.records.ApplicationId getApplicationID()
getApplicationID in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic org.apache.hadoop.yarn.event.EventHandler<org.apache.hadoop.yarn.event.Event> getEventHandler()
getEventHandler in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic CharSequence getUser()
getUser in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic org.apache.hadoop.yarn.util.Clock getClock()
getClock in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic org.apache.hadoop.mapreduce.v2.app.ClusterInfo getClusterInfo()
getClusterInfo in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic Set<String> getBlacklistedNodes()
getBlacklistedNodes in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic org.apache.hadoop.yarn.security.client.ClientToAMTokenSecretManager getClientToAMTokenSecretManager()
getClientToAMTokenSecretManager in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic boolean isLastAMRetry()
isLastAMRetry in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic boolean hasSuccessfullyUnregistered()
hasSuccessfullyUnregistered in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic String getNMHostname()
getNMHostname in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic org.apache.hadoop.mapreduce.v2.app.TaskAttemptFinishingMonitor getTaskAttemptFinishingMonitor()
getTaskAttemptFinishingMonitor in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic String getHistoryUrl()
getHistoryUrl in interface org.apache.hadoop.mapreduce.v2.app.AppContextpublic void setHistoryUrl(String historyUrl)
setHistoryUrl in interface org.apache.hadoop.mapreduce.v2.app.AppContextCopyright © 2008–2023 Apache Software Foundation. All rights reserved.