| Constructor and Description | 
|---|
| LocalContainerLauncher(AppContext context,
                      org.apache.hadoop.mapred.TaskUmbilicalProtocol umbilical) | 
| LocalContainerLauncher(AppContext context,
                      org.apache.hadoop.mapred.TaskUmbilicalProtocol umbilical,
                      ClassLoader jobClassLoader) | 
| MapTaskAttemptImpl(org.apache.hadoop.mapreduce.v2.api.records.TaskId taskId,
                  int attempt,
                  org.apache.hadoop.yarn.event.EventHandler eventHandler,
                  org.apache.hadoop.fs.Path jobFile,
                  int partition,
                  org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo splitInfo,
                  org.apache.hadoop.mapred.JobConf conf,
                  TaskAttemptListener taskAttemptListener,
                  org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier> jobToken,
                  org.apache.hadoop.security.Credentials credentials,
                  org.apache.hadoop.yarn.util.Clock clock,
                  AppContext appContext) | 
| ReduceTaskAttemptImpl(org.apache.hadoop.mapreduce.v2.api.records.TaskId id,
                     int attempt,
                     org.apache.hadoop.yarn.event.EventHandler eventHandler,
                     org.apache.hadoop.fs.Path jobFile,
                     int partition,
                     int numMapTasks,
                     org.apache.hadoop.mapred.JobConf conf,
                     TaskAttemptListener taskAttemptListener,
                     org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier> jobToken,
                     org.apache.hadoop.security.Credentials credentials,
                     org.apache.hadoop.yarn.util.Clock clock,
                     AppContext appContext) | 
| TaskAttemptListenerImpl(AppContext context,
                       org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager jobTokenSecretManager,
                       RMHeartbeatHandler rmHeartbeatHandler,
                       AMPreemptionPolicy preemptionPolicy) | 
| TaskAttemptListenerImpl(AppContext context,
                       org.apache.hadoop.mapreduce.security.token.JobTokenSecretManager jobTokenSecretManager,
                       RMHeartbeatHandler rmHeartbeatHandler,
                       AMPreemptionPolicy preemptionPolicy,
                       byte[] secretShuffleKey) | 
| Constructor and Description | 
|---|
| JobHistoryEventHandler(AppContext context,
                      int startCount) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MRAppMaster.RunningAppContext | 
| Modifier and Type | Method and Description | 
|---|---|
| AppContext | MRAppMaster. getContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ClientService | MRAppMaster. createClientService(AppContext context) | 
| protected org.apache.hadoop.yarn.event.EventHandler<CommitterEvent> | MRAppMaster. createCommitterEventHandler(AppContext context,
                           org.apache.hadoop.mapreduce.OutputCommitter committer) | 
| protected ContainerAllocator | MRAppMaster. createContainerAllocator(ClientService clientService,
                        AppContext context) | 
| protected ContainerLauncher | MRAppMaster. createContainerLauncher(AppContext context) | 
| protected org.apache.hadoop.yarn.event.EventHandler<JobHistoryEvent> | MRAppMaster. createJobHistoryHandler(AppContext context) | 
| protected Speculator | MRAppMaster. createSpeculator(org.apache.hadoop.conf.Configuration conf,
                AppContext context) | 
| protected TaskAttemptListener | MRAppMaster. createTaskAttemptListener(AppContext context,
                         AMPreemptionPolicy preemptionPolicy) | 
| Constructor and Description | 
|---|
| MRClientService(AppContext appContext) | 
| Constructor and Description | 
|---|
| CommitterEventHandler(AppContext context,
                     org.apache.hadoop.mapreduce.OutputCommitter committer,
                     RMHeartbeatHandler rmHeartbeatHandler) | 
| CommitterEventHandler(AppContext context,
                     org.apache.hadoop.mapreduce.OutputCommitter committer,
                     RMHeartbeatHandler rmHeartbeatHandler,
                     ClassLoader jobClassLoader) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected AppContext | TaskImpl. appContext | 
| 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) | 
| MapTaskImpl(org.apache.hadoop.mapreduce.v2.api.records.JobId jobId,
           int partition,
           org.apache.hadoop.yarn.event.EventHandler eventHandler,
           org.apache.hadoop.fs.Path remoteJobConfFile,
           org.apache.hadoop.mapred.JobConf conf,
           org.apache.hadoop.mapreduce.split.JobSplit.TaskSplitMetaInfo taskSplitMetaInfo,
           TaskAttemptListener taskAttemptListener,
           org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier> jobToken,
           org.apache.hadoop.security.Credentials credentials,
           org.apache.hadoop.yarn.util.Clock clock,
           int appAttemptId,
           MRAppMetrics metrics,
           AppContext appContext) | 
| ReduceTaskImpl(org.apache.hadoop.mapreduce.v2.api.records.JobId jobId,
              int partition,
              org.apache.hadoop.yarn.event.EventHandler eventHandler,
              org.apache.hadoop.fs.Path jobFile,
              org.apache.hadoop.mapred.JobConf conf,
              int numMapTasks,
              TaskAttemptListener taskAttemptListener,
              org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier> jobToken,
              org.apache.hadoop.security.Credentials credentials,
              org.apache.hadoop.yarn.util.Clock clock,
              int appAttemptId,
              MRAppMetrics metrics,
              AppContext appContext) | 
| TaskAttemptImpl(org.apache.hadoop.mapreduce.v2.api.records.TaskId taskId,
               int i,
               org.apache.hadoop.yarn.event.EventHandler eventHandler,
               TaskAttemptListener taskAttemptListener,
               org.apache.hadoop.fs.Path jobFile,
               int partition,
               org.apache.hadoop.mapred.JobConf conf,
               String[] dataLocalHosts,
               org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier> jobToken,
               org.apache.hadoop.security.Credentials credentials,
               org.apache.hadoop.yarn.util.Clock clock,
               AppContext appContext) | 
| TaskImpl(org.apache.hadoop.mapreduce.v2.api.records.JobId jobId,
        org.apache.hadoop.mapreduce.v2.api.records.TaskType taskType,
        int partition,
        org.apache.hadoop.yarn.event.EventHandler eventHandler,
        org.apache.hadoop.fs.Path remoteJobConfFile,
        org.apache.hadoop.mapred.JobConf conf,
        TaskAttemptListener taskAttemptListener,
        org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.JobTokenIdentifier> jobToken,
        org.apache.hadoop.security.Credentials credentials,
        org.apache.hadoop.yarn.util.Clock clock,
        int appAttemptId,
        MRAppMetrics metrics,
        AppContext appContext) | 
| Constructor and Description | 
|---|
| ContainerLauncherImpl(AppContext context) | 
| Constructor and Description | 
|---|
| LocalContainerAllocator(ClientService clientService,
                       AppContext context,
                       String nmHost,
                       int nmPort,
                       int nmHttpPort,
                       org.apache.hadoop.yarn.api.records.ContainerId cId) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected AppContext | RMCommunicator. getContext() | 
| Constructor and Description | 
|---|
| RMCommunicator(ClientService clientService,
              AppContext context) | 
| RMContainerAllocator(ClientService clientService,
                    AppContext context,
                    AMPreemptionPolicy preemptionPolicy) | 
| RMContainerRequestor(ClientService clientService,
                    AppContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AMPreemptionPolicy. init(AppContext context) | 
| void | KillAMPreemptionPolicy. init(AppContext context) | 
| void | CheckpointAMPreemptionPolicy. init(AppContext context) | 
| void | NoopAMPreemptionPolicy. init(AppContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | NullTaskRuntimesEngine. contextualize(org.apache.hadoop.conf.Configuration conf,
             AppContext context) | 
| void | ExponentiallySmoothedTaskRuntimeEstimator. contextualize(org.apache.hadoop.conf.Configuration conf,
             AppContext context) | 
| void | TaskRuntimeEstimator. contextualize(org.apache.hadoop.conf.Configuration conf,
             AppContext context) | 
| void | SimpleExponentialTaskRuntimeEstimator. contextualize(org.apache.hadoop.conf.Configuration conf,
             AppContext context) | 
| Constructor and Description | 
|---|
| DefaultSpeculator(org.apache.hadoop.conf.Configuration conf,
                 AppContext context) | 
| DefaultSpeculator(org.apache.hadoop.conf.Configuration conf,
                 AppContext context,
                 org.apache.hadoop.yarn.util.Clock clock) | 
| DefaultSpeculator(org.apache.hadoop.conf.Configuration conf,
                 AppContext context,
                 TaskRuntimeEstimator estimator,
                 org.apache.hadoop.yarn.util.Clock clock) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Job | AMWebServices. getJobFromJobIdString(String jid,
                     AppContext appCtx)convert a job id string to an actual job and handle all the error checking. | 
| Constructor and Description | 
|---|
| AMWebServices(App app,
             AppContext context) | 
| Constructor and Description | 
|---|
| AppInfo(App app,
       AppContext context) | 
| BlacklistedNodesInfo(AppContext appContext) | 
| JobCounterInfo(AppContext ctx,
              Job job) | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.