public class NullTaskRuntimesEngine extends Object implements TaskRuntimeEstimator
Constructor and Description |
---|
NullTaskRuntimesEngine() |
Modifier and Type | Method and Description |
---|---|
long |
attemptEnrolledTime(org.apache.hadoop.mapreduce.v2.api.records.TaskAttemptId attemptID) |
void |
contextualize(org.apache.hadoop.conf.Configuration conf,
AppContext context) |
void |
enrollAttempt(TaskAttemptStatusUpdateEvent.TaskAttemptStatus status,
long timestamp) |
long |
estimatedNewAttemptRuntime(org.apache.hadoop.mapreduce.v2.api.records.TaskId id)
Estimates how long a new attempt on this task will take if we start
one now
|
long |
estimatedRuntime(org.apache.hadoop.mapreduce.v2.api.records.TaskAttemptId id)
Estimate a task attempt's total runtime.
|
long |
runtimeEstimateVariance(org.apache.hadoop.mapreduce.v2.api.records.TaskAttemptId id)
Computes the width of the error band of our estimate of the task
runtime as returned by
TaskRuntimeEstimator.estimatedRuntime(TaskAttemptId) |
long |
thresholdRuntime(org.apache.hadoop.mapreduce.v2.api.records.TaskId id)
Find a maximum reasonable execution wallclock time.
|
void |
updateAttempt(TaskAttemptStatusUpdateEvent.TaskAttemptStatus status,
long timestamp) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
hasStagnatedProgress
public void enrollAttempt(TaskAttemptStatusUpdateEvent.TaskAttemptStatus status, long timestamp)
enrollAttempt
in interface TaskRuntimeEstimator
public long attemptEnrolledTime(org.apache.hadoop.mapreduce.v2.api.records.TaskAttemptId attemptID)
attemptEnrolledTime
in interface TaskRuntimeEstimator
public void updateAttempt(TaskAttemptStatusUpdateEvent.TaskAttemptStatus status, long timestamp)
updateAttempt
in interface TaskRuntimeEstimator
public void contextualize(org.apache.hadoop.conf.Configuration conf, AppContext context)
contextualize
in interface TaskRuntimeEstimator
public long thresholdRuntime(org.apache.hadoop.mapreduce.v2.api.records.TaskId id)
TaskRuntimeEstimator
thresholdRuntime
in interface TaskRuntimeEstimator
id
- the TaskId
of the task we are asking aboutpublic long estimatedRuntime(org.apache.hadoop.mapreduce.v2.api.records.TaskAttemptId id)
TaskRuntimeEstimator
estimatedRuntime
in interface TaskRuntimeEstimator
id
- the TaskAttemptId
of the attempt we are asking about-1
if
we don't have enough information yet to produce an estimate.public long estimatedNewAttemptRuntime(org.apache.hadoop.mapreduce.v2.api.records.TaskId id)
TaskRuntimeEstimator
estimatedNewAttemptRuntime
in interface TaskRuntimeEstimator
id
- the TaskId
of the task we are asking about-1
if
we don't have enough information yet to produce an estimate.public long runtimeEstimateVariance(org.apache.hadoop.mapreduce.v2.api.records.TaskAttemptId id)
TaskRuntimeEstimator
TaskRuntimeEstimator.estimatedRuntime(TaskAttemptId)
runtimeEstimateVariance
in interface TaskRuntimeEstimator
id
- the TaskAttemptId
of the attempt we are asking about-1
if
we don't have enough information yet to produce an estimate.Copyright © 2008–2024 Apache Software Foundation. All rights reserved.