1. 背景
hadoop的推测执行
推测执行(Speculative Execution)
是指在分布式集群环境下,因为程序BUG,负载不均衡或者资源分布不均等原因,造成同一个job的多个task运行速度不一致
,有的task运行速度明显慢于其他task(比如:一个job的某个task进度只有10%,而其他所有task已经运行完毕),则这些task拖慢了作业的整体执行进度,为了避免这种情况发生,Hadoop会为该task启动备份任务
,让该speculative task与原始task同时处理一份数据,哪个先运行完,则将谁的结果作为最终结果
。
推测执行优化机制
采用了典型的以空间换时间
的优化策略,它同时启动多个相同task(备份任务)处理相同的数据块
,哪个完成的早,则采用哪个task的结果
,这样可防止拖后腿Task任务出现
,进而提高作业计算速度,但是,这样却会占用更多的资源
,在集群资源紧缺的情况下,设计合理的推测执行机制可在多用少量资源情况下,减少大作业的计算时间。
这里可以类比spark的推测执行
推测任务是指对于一个Stage里面拖后腿的Task,会在其他节点的Executor上再次启动这个task,如果其中一个Task实例运行成功则将这个最先完成的Task的计算结果作为最终结果,同时会干掉其他Executor上运行的实例。spark推测式执行默认是关闭的,可通过spark.speculation属性来开启。
2. 注意事项
- 谨慎使用,严重的会造成所有资源被全部占用,不能及时释放
3. 源代码
-
/**
-
* TaskScheduleImpl的初始化和启动是在SparkConext中,进行的,初始化的时候会
-
* 传入SparkDeploySchedulerBackend对象。启动则直接调用start方法。在Start
-
* 方法中,会判断是否启动任务的推测执行,由spark.speculation属性指定,默认不执行
-
*/
-
if (!isLocal && conf.getBoolean("spark.speculation", false)) {
-
logInfo("Starting speculative execution thread")
-
speculationScheduler.scheduleWithFixedDelay(new Runnable {
-
override def run(): Unit = Utils.tryOrStopSparkContext(sc) {
-
// 检查我们所有活跃的job中是否有可推测的任务。
-
checkSpeculatableTasks()
-
}
-
}, SPECULATION_INTERVAL_MS, SPECULATION_INTERVAL_MS, TimeUnit.MILLISECONDS)
-
}
若开启则会启动一个线程每隔SPECULATION_INTERVAL_MS
(默认100ms,可通过spark.speculation.interval
属性设置)通过checkSpeculatableTasks
方法检测是否有需要推测式执行的tasks:
-
// How often to check for speculative tasks 多久检查一次推测任务
-
val SPECULATION_INTERVAL_MS = conf.getTimeAsMs("spark.speculation.interval", "100ms")
-
// Duplicate copies of a task will only be launched if the original copy has been running for
-
// at least this amount of time. This is to avoid the overhead of launching speculative copies
-
// of tasks that are very short.
-
// 只有在原始副本至少运行了这么多时间的情况下,才会启动任务的副本。这是为了避免产生非常短的任务的推测性副本的开销。
-
val MIN_TIME_TO_SPECULATION = 100
-
// Check for speculatable tasks in all our active jobs.
-
// 检查我们所有活跃的job中是否有可推测的任务。
-
def checkSpeculatableTasks() {
-
var shouldRevive = false
-
synchronized {
-
shouldRevive = rootPool.checkSpeculatableTasks(MIN_TIME_TO_SPECULATION)
-
}
-
if (shouldRevive) {
-
backend.reviveOffers()
-
}
-
}
然后又通过rootPool
的方法判断是否有需要推测式执行的tasks,若有则会调用SchedulerBackend的reviveOffers去尝试拿资源运行推测任务
。继续看看检测逻辑是什么样的:
-
override def checkSpeculatableTasks(): Boolean = {
-
var shouldRevive = false
-
for (schedulable <- schedulableQueue.asScala) {
-
shouldRevive |= schedulable.checkSpeculatableTasks()
-
}
-
shouldRevive
-
}
直接点开schedulable.checkSpeculatableTasks()
调用的是
private[spark] trait Schedulable 特质中的接口
def checkSpeculatableTasks(minTimeToSpeculation: Int): Boolean
然后看schedulable <- schedulableQueue.asScala
,继续看schedulableQueue
的定义,
-
// 存储(pools或者TaskSetManagers)的链表
-
val schedulableQueue = new ConcurrentLinkedQueue[Schedulable]
在rootPool里又调用了schedulable的方法,schedulable是ConcurrentLinkedQueue[Schedulable]类型,队列里面放的都是TaskSetMagager,
最后再看TaskSetMagager的checkSpeculatableTasks方法,终于找到检测根源了:
-
/**
-
* Check for tasks to be speculated and return true if there are any. This is called periodically
-
* by the TaskScheduler.
-
*
-
*/
-
override def checkSpeculatableTasks(minTimeToSpeculation: Int): Boolean = {
-
// Can't speculate if we only have one task, and no need to speculate if the task set is a
-
// zombie.
-
// 如果task只有一个或者所有task都不需要再执行了就没有必要再检测
-
if (isZombie || numTasks == 1) {
-
return false
-
}
-
var foundTasks = false
-
// 所有task数 * SPECULATION_QUANTILE(默认0.75,可通过spark.speculation.quantile设置)
-
val minFinishedForSpeculation = (SPECULATION_QUANTILE * numTasks).floor.toInt
-
logDebug("Checking for speculative tasks: minFinished = " + minFinishedForSpeculation)
-
// 成功的task数是否超过总数的75%,并且成功的task是否大于0
-
if (tasksSuccessful >= minFinishedForSpeculation && tasksSuccessful > 0) {
-
val time = clock.getTimeMillis()
-
// 取这多个task任务执行成功时间的中位数
-
var medianDuration = successfulTaskDurations.median
-
// 中位数 * SPECULATION_MULTIPLIER (默认1.5,可通过spark.speculation.multiplier设置)
-
val threshold = max(SPECULATION_MULTIPLIER * medianDuration, minTimeToSpeculation)
-
// TODO: Threshold should also look at standard deviation of task durations and have a lower
-
// bound based on that.
-
logDebug("Task length threshold for speculation: " + threshold)
-
// 遍历该TaskSet中的task,取未成功执行、正在执行、执行时间已经大于threshold 、
-
// 推测式执行task列表中未包括的task放进需要推测式执行的列表中speculatableTasks
-
for (tid <- runningTasksSet) {
-
val info = taskInfos(tid)
-
val index = info.index
-
if (!successful(index) && copiesRunning(index) == 1 && info.timeRunning(time) > threshold &&
-
!speculatableTasks.contains(index)) {
-
logInfo(
-
"Marking task %d in stage %s (on %s) as speculatable because it ran more than %.0f ms"
-
.format(index, taskSet.id, info.host, threshold))
-
speculatableTasks += index
-
foundTasks = true
-
}
-
}
-
}
-
foundTasks
-
}
- 查逻辑代码中注释很明白,当
成功的Task数超过总Task数的75%
(可通过参数spark.speculation.quantile设置)时,再统计所有成功的Tasks的运行时间,得到一个中位数,用这个中位数乘以1.5(可通过参数spark.speculation.multiplier控制)得到运行时间门限
,如果在运行的Tasks的运行时间超过这个门限,则对它启用推测
。简单来说就是对那些拖慢整体进度的Tasks启用推测,以加速整个Stage的运行。
算法大致流程如图:
3.1 推测式任务什么时候被调度
在TaskSetMagager在延迟调度策略下为一个executor分配一个task时会调用dequeueTask方法:
-
/**
-
* Dequeue a pending task for a given node and return its index and locality level.
-
* Only search for tasks matching the given locality constraint.
-
*
-
* 将给定节点的挂起任务删除,并返回其索引和位置级别。只搜索与给定区域约束匹配的任务。
-
*
-
* @return An option containing (task index within the task set, locality, is speculative?)
-
* 包含(任务集中的任务索引,地点,是推测的?)
-
*/
-
private def dequeueTask(execId: String, host: String, maxLocality: TaskLocality.Value)
-
: Option[(Int, TaskLocality.Value, Boolean)] =
-
{
-
// dequeueTaskFromList()方法:从给定的列表中取消一个挂起的任务并返回它的索引。如果列表为空,则返回None。
-
// PROCESS_LOCAL: 数据在同一个 JVM 中,即同一个 executor 上。这是最佳数据 locality。
-
for (index <- dequeueTaskFromList(execId, host, getPendingTasksForExecutor(execId))) {
-
return Some((index, TaskLocality.PROCESS_LOCAL, false))
-
}
-
// NODE_LOCAL: 数据在同一个节点上。比如数据在同一个节点的另一个 executor上;或在 HDFS 上,
-
// 恰好有 block 在同一个节点上。速度比 PROCESS_LOCAL 稍慢,因为数据需要在不同进程之间传递或从文件中读取
-
if (TaskLocality.isAllowed(maxLocality, TaskLocality.NODE_LOCAL)) {
-
for (index <- dequeueTaskFromList(execId, host, getPendingTasksForHost(host))) {
-
return Some((index, TaskLocality.NODE_LOCAL, false))
-
}
-
}
-
// NO_PREF: 数据从哪里访问都一样快,不需要位置优先
-
if (TaskLocality.isAllowed(maxLocality, TaskLocality.NO_PREF)) {
-
// Look for noPref tasks after NODE_LOCAL for minimize cross-rack traffic
-
for (index <- dequeueTaskFromList(execId, host, pendingTasksWithNoPrefs)) {
-
return Some((index, TaskLocality.PROCESS_LOCAL, false))
-
}
-
}
-
// RACK_LOCAL: 数据在同一机架的不同节点上。需要通过网络传输数据及文件 IO,比 NODE_LOCAL 慢
-
if (TaskLocality.isAllowed(maxLocality, TaskLocality.RACK_LOCAL)) {
-
for {
-
rack <- sched.getRackForHost(host)
-
index <- dequeueTaskFromList(execId, host, getPendingTasksForRack(rack))
-
} {
-
return Some((index, TaskLocality.RACK_LOCAL, false))
-
}
-
}
-
// ANY: 数据在非同一机架的网络上,速度最慢
-
if (TaskLocality.isAllowed(maxLocality, TaskLocality.ANY)) {
-
for (index <- dequeueTaskFromList(execId, host, allPendingTasks)) {
-
return Some((index, TaskLocality.ANY, false))
-
}
-
}
-
// find a speculative task if all others tasks have been scheduled
-
// 如果所有其他任务都安排好了,就去找一个推测的任务。
-
dequeueSpeculativeTask(execId, host, maxLocality).map {
-
case (taskIndex, allowedLocality) => (taskIndex, allowedLocality, true)}
-
}
该方法的最后一段就是在其他任务都被调度后为推测式任务进行调度,看看起实现:
-
/**
-
* Return a speculative task for a given executor if any are available. The task should not have
-
* an attempt running on this host, in case the host is slow. In addition, the task should meet
-
* the given locality constraint.
-
*
-
* 如果有任何可用的执行器,返回一个推测任务。任务不应该在主机上运行,以防主机运行缓慢。此外,
-
* 该任务还应满足给定的局部约束条件。
-
*/
-
// Labeled as protected to allow tests to override providing speculative tasks if necessary
-
protected def dequeueSpeculativeTask(execId: String, host: String, locality: TaskLocality.Value)
-
: Option[(Int, TaskLocality.Value)] =
-
{
-
// 从推测式执行任务列表中移除已经成功完成的task,因为从检测到调度之间还有一段时间,
-
// 某些task已经成功执行
-
// 从set集合中删除完成的任务
-
speculatableTasks.retain(index => !successful(index)) // Remove finished tasks from set
-
// 判断task是否可以在该executor对应的Host上执行,判断条件是:
-
// task没有在该host上运行;
-
// 该executor没有在task的黑名单里面(task在这个executor上失败过,并还在'黑暗'时间内)
-
def canRunOnHost(index: Int): Boolean = {
-
!hasAttemptOnHost(index, host) &&
-
!isTaskBlacklistedOnExecOrNode(index, execId, host)
-
}
-
// // 推测执行任务集合是否为空
-
if (!speculatableTasks.isEmpty) {
-
// Check for process-local tasks; note that tasks can be process-local
-
// on multiple nodes when we replicate cached blocks, as in Spark Streaming
-
// 获取能在该executor上启动的taskIndex
-
for (index <- speculatableTasks if canRunOnHost(index)) {
-
// 获取task的优先位置
-
val prefs = tasks(index).preferredLocations
-
val executors = prefs.flatMap(_ match {
-
case e: ExecutorCacheTaskLocation => Some(e.executorId)
-
case _ => None
-
});
-
// 优先位置若为ExecutorCacheTaskLocation并且数据所在executor包含当前executor,
-
// 则返回其task在taskSet的index和Locality Levels
-
if (executors.contains(execId)) {
-
speculatableTasks -= index
-
return Some((index, TaskLocality.PROCESS_LOCAL))
-
}
-
}
-
// Check for node-local tasks
-
// 这里的判断是延迟调度的作用,即使是推测式任务也尽量以最好的本地性级别来启动
-
if (TaskLocality.isAllowed(locality, TaskLocality.NODE_LOCAL)) {
-
for (index <- speculatableTasks if canRunOnHost(index)) {
-
val locations = tasks(index).preferredLocations.map(_.host)
-
if (locations.contains(host)) {
-
speculatableTasks -= index
-
return Some((index, TaskLocality.NODE_LOCAL))
-
}
-
}
-
}
-
// Check for no-preference tasks
-
if (TaskLocality.isAllowed(locality, TaskLocality.NO_PREF)) {
-
for (index <- speculatableTasks if canRunOnHost(index)) {
-
val locations = tasks(index).preferredLocations
-
if (locations.size == 0) {
-
speculatableTasks -= index
-
return Some((index, TaskLocality.PROCESS_LOCAL))
-
}
-
}
-
}
-
// Check for rack-local tasks
-
if (TaskLocality.isAllowed(locality, TaskLocality.RACK_LOCAL)) {
-
for (rack <- sched.getRackForHost(host)) {
-
for (index <- speculatableTasks if canRunOnHost(index)) {
-
val racks = tasks(index).preferredLocations.map(_.host).flatMap(sched.getRackForHost)
-
if (racks.contains(rack)) {
-
speculatableTasks -= index
-
return Some((index, TaskLocality.RACK_LOCAL))
-
}
-
}
-
}
-
}
-
// Check for non-local tasks
-
if (TaskLocality.isAllowed(locality, TaskLocality.ANY)) {
-
for (index <- speculatableTasks if canRunOnHost(index)) {
-
speculatableTasks -= index
-
return Some((index, TaskLocality.ANY))
-
}
-
}
-
}
-
None
-
}
今天的文章Spark推测执行spark.speculation分享到此就结束了,感谢您的阅读。
版权声明:本文内容由互联网用户自发贡献,该文观点仅代表作者本人。本站仅提供信息存储空间服务,不拥有所有权,不承担相关法律责任。如发现本站有涉嫌侵权/违法违规的内容, 请发送邮件至 举报,一经查实,本站将立刻删除。
如需转载请保留出处:https://bianchenghao.cn/62655.html