| Package | Description | 
|---|---|
| org.apache.hadoop.mapreduce.v2.app.job.event | |
| org.apache.hadoop.mapreduce.v2.app.job.impl | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | JobAbortCompletedEvent | 
| class  | JobCommitCompletedEvent | 
| class  | JobCommitFailedEvent | 
| class  | JobCounterUpdateEvent | 
| class  | JobDiagnosticsUpdateEvent | 
| class  | JobMapTaskRescheduledEvent | 
| class  | JobSetupCompletedEvent | 
| class  | JobSetupFailedEvent | 
| class  | JobStartEvent | 
| class  | JobTaskAttemptCompletedEvent | 
| class  | JobTaskAttemptFetchFailureEvent | 
| class  | JobTaskEvent | 
| class  | JobUpdatedNodesEvent | 
| 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 org.apache.hadoop.yarn.state.StateMachine<JobStateInternal,JobEventType,JobEvent> | JobImpl. getStateMachine() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | JobImpl. handle(JobEvent event) | 
| 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). | 
| void | JobImpl.StartTransition. transition(JobImpl job,
          JobEvent event)This transition executes in the event-dispatcher thread, though it's
 triggered in MRAppMaster's startJobs() method. | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.