| Package | Description | 
|---|---|
| org.apache.hadoop.mapreduce.v2.app | |
| org.apache.hadoop.mapreduce.v2.app.job | |
| org.apache.hadoop.mapreduce.v2.app.job.impl | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Job | MRAppMaster. createJob(org.apache.hadoop.conf.Configuration conf,
         JobStateInternal forcedState,
         String diagnostic)Create and initialize (but don't start) a single job. | 
| Modifier and Type | Method and Description | 
|---|---|
| static JobStateInternal | JobStateInternal. valueOf(String name)Returns the enum constant of this type with the specified name. | 
| static JobStateInternal[] | JobStateInternal. values()Returns an array containing the constants of this enum type, in
the order they are declared. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected static org.apache.hadoop.yarn.state.StateMachineFactory<JobImpl,JobStateInternal,JobEventType,JobEvent> | JobImpl. stateMachineFactory | 
| Modifier and Type | Method and Description | 
|---|---|
| protected JobStateInternal | JobImpl. checkReadyForCommit() | 
| JobStateInternal | JobImpl. getInternalState() | 
| JobStateInternal | JobImpl.InitTransition. transition(JobImpl job,
          JobEvent event)Note that this transition method is called directly (and synchronously)
 by MRAppMaster's init() method (i.e., no RPC, no thread-switching;
 just plain sequential call within AM context), so we can trigger
 modifications in AM state from here (at least, if AM is written that
 way; MR version is). | 
| Modifier and Type | Method and Description | 
|---|---|
| protected org.apache.hadoop.yarn.state.StateMachine<JobStateInternal,JobEventType,JobEvent> | JobImpl. getStateMachine() | 
| Constructor and Description | 
|---|
| JobImpl(org.apache.hadoop.mapreduce.v2.api.records.JobId jobId,
       org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
       org.apache.hadoop.conf.Configuration conf,
       org.apache.hadoop.yarn.event.EventHandler eventHandler,
       TaskAttemptListener taskAttemptListener,
       org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager jobTokenSecretManager,
       org.apache.hadoop.security.Credentials jobCredentials,
       org.apache.hadoop.yarn.util.Clock clock,
       Map<org.apache.hadoop.mapreduce.v2.api.records.TaskId,org.apache.hadoop.mapreduce.jobhistory.JobHistoryParser.TaskInfo> completedTasksFromPreviousRun,
       MRAppMetrics metrics,
       org.apache.hadoop.mapreduce.OutputCommitter committer,
       boolean newApiCommitter,
       String userName,
       long appSubmitTime,
       List<org.apache.hadoop.mapreduce.v2.api.records.AMInfo> amInfos,
       AppContext appContext,
       JobStateInternal forcedState,
       String forcedDiagnostic) | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.