• Spark源代码分析之六:Task调度(二)


            话说在《Spark源代码分析之五:Task调度(一)》一文中,我们对Task调度分析到了DriverEndpoint的makeOffers()方法。这种方法针对接收到的ReviveOffers事件进行处理。代码例如以下:

    // Make fake resource offers on all executors
        // 在全部的executors上提供假的资源(抽象的资源。也就是资源的对象信息,我是这么理解的)
        private def makeOffers() {
          // Filter out executors under killing
          // 过滤掉under killing的executors
          val activeExecutors = executorDataMap.filterKeys(executorIsAlive)
          
          // 利用activeExecutors中executorData的executorHost、freeCores,构造workOffers,即资源
          val workOffers = activeExecutors.map { case (id, executorData) =>
            // 创建WorkerOffer对象
            new WorkerOffer(id, executorData.executorHost, executorData.freeCores)
          }.toSeq
          
          // 调用scheduler的resourceOffers()方法,分配资源,并调用launchTasks()方法,启动tasks
          // 这个scheduler就是TaskSchedulerImpl
          launchTasks(scheduler.resourceOffers(workOffers))
        }
            代码逻辑非常easy,一共分为三步:

            第一。从executorDataMap中过滤掉under killing的executors,得到activeExecutors。

            第二。利用activeExecutors中executorData的executorHost、freeCores,获取workOffers。即资源。

            第三,调用scheduler的resourceOffers()方法,分配资源,并调用launchTasks()方法,启动tasks:这个scheduler就是TaskSchedulerImpl。

            我们逐个进行分析。首先看看这个executorDataMap,其定义例如以下:

    private val executorDataMap = new HashMap[String, ExecutorData]
            它是CoarseGrainedSchedulerBackend掌握的集群中executor的数据集合,key为String类型的executorId,value为ExecutorData类型的executor具体信息。

    ExecutorData包括的主要内容例如以下:

            1、executorEndpoint:RpcEndpointRef类型。RPC终端的引用,用于数据通信。

            2、executorAddress:RpcAddress类型。RPC地址。用于数据通信。

            3、executorHost:String类型,executor的主机;

            4、freeCores:Int类型,可用处理器cores。

            5、totalCores:Int类型。处理器cores总数;

            6、logUrlMap:Map[String, String]类型,日志url映射集合。

            这样,通过executorDataMap这个集合我们就能知道集群当前executor的负载情况。方便资源分析并调度任务。那么executorDataMap内的数据是何时及怎样更新的呢?go on,继续分析。
            对于第一步中,过滤掉under killing的executors,事实上现是对executorDataMap中的全部executor调用executorIsAlive()方法中。推断是否在executorsPendingToRemove和executorsPendingLossReason两个数据结构中。这两个数据结构中的executors。都是即将移除或者已丢失的executor。

            第二步。在过滤掉已失效或者立即要失效的executor后,利用activeExecutors中executorData的executorHost、freeCores,构造workOffers,即资源。这个workOffers更简单,是一个WorkerOffer对象,它代表了系统的可利用资源。

    WorkerOffer代码例如以下:

    /**
     * Represents free resources available on an executor.
     */
    private[spark]
    case class WorkerOffer(executorId: String, host: String, cores: Int)
            而最重要的第三步,先是调用scheduler.resourceOffers(workOffers),即TaskSchedulerImpl的resourceOffers()方法,然后再调用launchTasks()方法将tasks载入到executor上去运行。

            我们先看下TaskSchedulerImpl的resourceOffers()方法。代码例如以下:

    /**
       * Called by cluster manager to offer resources on slaves. We respond by asking our active task
       * sets for tasks in order of priority. We fill each node with tasks in a round-robin manner so
       * that tasks are balanced across the cluster.
       *
       * 被集群manager调用以提供slaves上的资源。

    我们通过依照优先顺序询问活动task集中的task来回应。

    * 我们通过循环的方式将task调度到每一个节点上以便tasks在集群中能够保持大致的均衡。 */ def resourceOffers(offers: Seq[WorkerOffer]): Seq[Seq[TaskDescription]] = synchronized { // Mark each slave as alive and remember its hostname // Also track if new executor is added // 标记每一个slave节点为alive活跃的,而且记住它的主机名 // 同一时候也追踪是否有executor被加入 var newExecAvail = false // 循环offers。WorkerOffer为包括executorId、host、cores的结构体。代表集群中的可用executor资源 for (o <- offers) { // 利用HashMap存储executorId->host映射的集合 executorIdToHost(o.executorId) = o.host // Number of tasks running on each executor // 每一个executor上执行的task的数目,这里假设之前没有的话,初始化为0 executorIdToTaskCount.getOrElseUpdate(o.executorId, 0) // 每一个host上executors的集合 // 这个executorsByHost被用来计算host活跃性。反过来我们用它来决定在给定的主机上何时实现数据本地性 if (!executorsByHost.contains(o.host)) {// 假设executorsByHost中不存在相应的host // executorsByHost中加入一条记录。key为host,value为new HashSet[String]() executorsByHost(o.host) = new HashSet[String]() // 发送一个ExecutorAdded事件。并由DAGScheduler的handleExecutorAdded()方法处理 // eventProcessLoop.post(ExecutorAdded(execId, host)) // 调用DAGScheduler的executorAdded()方法处理 executorAdded(o.executorId, o.host) // 新的slave加入时,标志位newExecAvail设置为true newExecAvail = true } // 更新hostsByRack for (rack <- getRackForHost(o.host)) { hostsByRack.getOrElseUpdate(rack, new HashSet[String]()) += o.host } } // Randomly shuffle offers to avoid always placing tasks on the same set of workers. // 随机shuffle offers以避免总是把任务放在同一组workers上执行 val shuffledOffers = Random.shuffle(offers) // Build a list of tasks to assign to each worker. // 构造一个task列表,以分配到每一个worker val tasks = shuffledOffers.map(o => new ArrayBuffer[TaskDescription](o.cores)) // 能够使用的cpu资源 val availableCpus = shuffledOffers.map(o => o.cores).toArray // 获得排序好的task集合 // 先调用Pool.getSortedTaskSetQueue()方法 // 还记得这个Pool吗,就是调度器中的调度池啊 val sortedTaskSets = rootPool.getSortedTaskSetQueue // 循环每一个taskSet for (taskSet <- sortedTaskSets) { // 记录日志 logDebug("parentName: %s, name: %s, runningTasks: %s".format( taskSet.parent.name, taskSet.name, taskSet.runningTasks)) // 假设存在新的活跃的executor(新的slave节点被加入时) if (newExecAvail) { // 调用executorAdded()方法 taskSet.executorAdded() } } // Take each TaskSet in our scheduling order, and then offer it each node in increasing order // of locality levels so that it gets a chance to launch local tasks on all of them. // NOTE: the preferredLocality order: PROCESS_LOCAL, NODE_LOCAL, NO_PREF, RACK_LOCAL, ANY var launchedTask = false // 依照位置本地性规则调度每一个TaskSet,最大化实现任务的本地性 // 位置本地性规则的顺序是:PROCESS_LOCAL(同进程)、NODE_LOCAL(同节点)、NO_PREF、RACK_LOCAL(同机架)、ANY(不论什么) for (taskSet <- sortedTaskSets; maxLocality <- taskSet.myLocalityLevels) { do { // 调用resourceOfferSingleTaskSet()方法进行任务集调度 launchedTask = resourceOfferSingleTaskSet( taskSet, maxLocality, shuffledOffers, availableCpus, tasks) } while (launchedTask) } // 设置标志位hasLaunchedTask if (tasks.size > 0) { hasLaunchedTask = true } return tasks }

             首先来看下它的主体流程。例如以下:

            1、设置标志位newExecAvail为false。这个标志位是在新的slave被加入时被设置的一个标志。以下在计算任务的本地性规则时会用到;

            2、循环offers,WorkerOffer为包括executorId、host、cores的结构体。代表集群中的可用executor资源:

                2.1、更新executorIdToHost,executorIdToHost为利用HashMap存储executorId->host映射的集合;

                2.2、更新executorIdToTaskCount,executorIdToTaskCount为每一个executor上执行的task的数目集合,这里假设之前没有的话,初始化为0;

                2.3、假设新的slave增加:

                    2.3.1、executorsByHost中加入一条记录,key为host。value为new HashSet[String]()。

                    2.3.2、发送一个ExecutorAdded事件。并由DAGScheduler的handleExecutorAdded()方法处理;

                    2.3.3、新的slave增加时,标志位newExecAvail设置为true;

                2.4、更新hostsByRack;

            3、随机shuffle offers(集群中可用executor资源)以避免总是把任务放在同一组workers上运行;

            4、构造一个task列表。以分配到每一个worker,针对每一个executor依照其上的cores数目构造一个cores数目大小的ArrayBuffer,实现最大程度并行化;

            5、获取能够使用的cpu资源availableCpus;

            6、调用Pool.getSortedTaskSetQueue()方法获得排序好的task集合,即sortedTaskSets;

            7、循环sortedTaskSets中每一个taskSet:

                   7.1、假设存在新增加的slave,则调用taskSet的executorAdded()方法,动态调整位置策略级别,这么做非常easy理解,新的slave节点增加了,那么随之而来的是数据有可能存在于它上面。那么这时我们就须要又一次调整任务本地性规则;

            8、循环sortedTaskSets,依照位置本地性规则调度每一个TaskSet,最大化实现任务的本地性:

                  8.1、对每一个taskSet。调用resourceOfferSingleTaskSet()方法进行任务集调度。

            9、设置标志位hasLaunchedTask。并返回tasks。

            接下来。我们详解下当中的每一个步骤。

            第1步不用讲,仅仅是设置标志位newExecAvail为false。而且记住这个标志位是在新的slave被加入时被设置的一个标志,以下在计算任务的本地性规则时会用到;

            第2步是集群中的可用executor资源offers的循环处理。更新一些数据结构,而且,在新的slave增加时。标志位newExecAvail设置为true,而且发送一个ExecutorAdded事件,交由DAGScheduler的handleExecutorAdded()方法处理。我们来看下DAGScheduler的这种方法:

    private[scheduler] def handleExecutorAdded(execId: String, host: String) {
        // remove from failedEpoch(execId) ?
        if (failedEpoch.contains(execId)) {
          logInfo("Host added was in lost list earlier: " + host)
          failedEpoch -= execId
        }
        submitWaitingStages()
      }
            非常easy,先将相应host从failedEpoch中移除,failedEpoch存储的是系统探測到的失效节点的集合,存储的是execId->host的相应关系。接下来便是调用submitWaitingStages()方法提交等待的stages。

    这种方法我们之前分析过。这里不再赘述。可是存在一个疑点,之前stage都已提交了,这里为什么还要提交一遍呢?留待以后再寻找答案吧。

            第3步随机shuffle offers以避免总是把任务放在同一组workers上运行,这也没什么特别好讲的,为了避免所谓的热点问题而採取的一种随机策略而已。

            第4步也是。构造一个task列表。以分配到每一个worker,针对每一个executor,创建一个ArrayBuffer。存储的类型为TaskDescription,大小为executor的cores。即最大程度并行化,充分利用executor的cores。

            第5步就是获取到上述executor集合中cores集合availableCpus,即能够使用的cpu资源。

            以下我们重点分析下第6步,它是调用Pool.getSortedTaskSetQueue()方法。获得排序好的task集合。还记得这个Pool吗?它就是上篇文章《Spark源代码分析之五:Task调度(一)》里讲到的调度器的中的调度池啊,我们看下它的getSortedTaskSetQueue()方法。代码例如以下:

    override def getSortedTaskSetQueue: ArrayBuffer[TaskSetManager] = {
        
        // 创建一个ArrayBuffer。存储TaskSetManager
        var sortedTaskSetQueue = new ArrayBuffer[TaskSetManager]
        
        // schedulableQueue为Pool中的一个调度队列。里面存储的是TaskSetManager
        // 在TaskScheduler的submitTasks()方法中,通过层层调用,终于通过Pool的addSchedulable()方法将之前生成的TaskSetManager增加到schedulableQueue中
        // 而TaskSetManager包括详细的tasks
        // taskSetSchedulingAlgorithm为调度算法,包括FIFO和FAIR两种
        // 这里针对调度队列,<span style="font-family: Arial, Helvetica, sans-serif;">依照调度算法对其排序,</span>生成一个序列sortedSchedulableQueue,
        val sortedSchedulableQueue =
          schedulableQueue.asScala.toSeq.sortWith(taskSetSchedulingAlgorithm.comparator)
        
        // 循环sortedSchedulableQueue中全部的TaskSetManager,通过其getSortedTaskSetQueue来填充sortedTaskSetQueue
        for (schedulable <- sortedSchedulableQueue) {
          sortedTaskSetQueue ++= schedulable.getSortedTaskSetQueue
        }
        
        // 返回sortedTaskSetQueue
        sortedTaskSetQueue
      }
            首先,创建一个ArrayBuffer,用来存储TaskSetManager,然后。对Pool中已经存储好的TaskSetManager,即schedulableQueue队列,依照taskSetSchedulingAlgorithm调度规则或算法来排序,得到sortedSchedulableQueue,并循环其内的TaskSetManager。通过其getSortedTaskSetQueue()方法来填充sortedTaskSetQueue,最后返回。

    TaskSetManager的getSortedTaskSetQueue()方法也非常easy,追加ArrayBuffer[TaskSetManager]就可以。例如以下:

    override def getSortedTaskSetQueue(): ArrayBuffer[TaskSetManager] = {
        var sortedTaskSetQueue = new ArrayBuffer[TaskSetManager]()
        sortedTaskSetQueue += this
        sortedTaskSetQueue
      }
            我们着重来解说下这个调度准则或算法taskSetSchedulingAlgorithm。其定义例如以下:

    // 调度准则。包含FAIR和FIFO两种
      var taskSetSchedulingAlgorithm: SchedulingAlgorithm = {
        schedulingMode match {
          case SchedulingMode.FAIR =>
            new FairSchedulingAlgorithm()
          case SchedulingMode.FIFO =>
            new FIFOSchedulingAlgorithm()
        }
      }
            它包含两种。FAIR和FIFO。以下我们以FIFO为例来解说。

    代码在SchedulingAlgorithm.scala中。例如以下:

    private[spark] class FIFOSchedulingAlgorithm extends SchedulingAlgorithm {
      // 比較函数
      override def comparator(s1: Schedulable, s2: Schedulable): Boolean = {
        val priority1 = s1.priority
        val priority2 = s2.priority
        
        // 先比較priority,即优先级
        // priority同样的话,再比較stageId
        // 前者小于后者的话,返回true,否则为false
        var res = math.signum(priority1 - priority2)
        if (res == 0) {
          val stageId1 = s1.stageId
          val stageId2 = s2.stageId
          res = math.signum(stageId1 - stageId2)
        }
        if (res < 0) {
          true
        } else {
          false
        }
      }
    }
            非常easy,就是先比較两个TaskSetManagerder的优先级priority。优先级同样再比較stageId。而这个priority在TaskSet生成时。就是jobId,也就是FIFO是先依照Job的顺序再依照Stage的顺序进行顺序调度。一个Job完了再调度还有一个Job,Job内是依照Stage的顺序进行调度。关于priority生成的代码例如以下所看到的:

    // 利用taskScheduler.submitTasks()提交task
          // jobId即为TaskSet的priority
          taskScheduler.submitTasks(new TaskSet(
            tasks.toArray, stage.id, stage.latestInfo.attemptId, jobId, properties))

            比較复杂的是FairSchedulingAlgorithm。代码例如以下:

    private[spark] class FairSchedulingAlgorithm extends SchedulingAlgorithm {
      override def comparator(s1: Schedulable, s2: Schedulable): Boolean = {
        
        val minShare1 = s1.minShare
        val minShare2 = s2.minShare
        val runningTasks1 = s1.runningTasks
        val runningTasks2 = s2.runningTasks
        val s1Needy = runningTasks1 < minShare1
        val s2Needy = runningTasks2 < minShare2
        val minShareRatio1 = runningTasks1.toDouble / math.max(minShare1, 1.0).toDouble
        val minShareRatio2 = runningTasks2.toDouble / math.max(minShare2, 1.0).toDouble
        val taskToWeightRatio1 = runningTasks1.toDouble / s1.weight.toDouble
        val taskToWeightRatio2 = runningTasks2.toDouble / s2.weight.toDouble
        var compare: Int = 0
    
        // 前者的runningTasks<minShare而后者相反的的话,返回true。
        // runningTasks为正在执行的tasks数目,minShare为最小共享cores数。
        // 前面两个if推断的意思是两个TaskSetManager中,假设当中一个正在执行的tasks数目小于最小共享cores数。则优先调度该TaskSetManager
        if (s1Needy && !s2Needy) {
          return true
        } else if (!s1Needy && s2Needy) {// 前者的runningTasks>=minShare而后者相反的的话。返回true
          return false
        } else if (s1Needy && s2Needy) {
          // 假设两者的正在执行的tasks数目都比最小共享cores数小的话,再比較minShareRatio
          // minShareRatio为正在执行的tasks数目与最小共享cores数的比率
          compare = minShareRatio1.compareTo(minShareRatio2)
        } else {
          // 最后比較taskToWeightRatio,即权重使用率,weight代表调度池对资源获取的权重,越大须要越多的资源
          compare = taskToWeightRatio1.compareTo(taskToWeightRatio2)
        }
    
        if (compare < 0) {
          true
        } else if (compare > 0) {
          false
        } else {
          s1.name < s2.name
        }
      }
    }
            它的调度逻辑主要例如以下:

            1、优先看正在执行的tasks数目是否小于最小共享cores数,假设两者仅仅有一个小于,则优先调度小于的那个。原因是既然正在执行的Tasks数目小于共享cores数,说明该节点资源比較充足,应该优先利用;

            2、假设不是仅仅有一个的正在执行的tasks数目是否小于最小共享cores数的话,则再推断正在执行的tasks数目与最小共享cores数的比率。

            3、最后再比較权重使用率,即正在执行的tasks数目与该TaskSetManager的权重weight的比,weight代表调度池对资源获取的权重,越大须要越多的资源。

            到此为止,获得了排序好的task集合,我们来到了第7步:假设存在新增加的slave。则调用taskSet的executorAdded()方法,即TaskSetManager的executorAdded()方法。代码例如以下:

    def executorAdded() {
        recomputeLocality()
      }

            没说的,继续追踪。看recomputeLocality()方法。代码例如以下:

    // 又一次计算位置
      def recomputeLocality() {
        // 首先获取之前的位置Level
        // currentLocalityIndex为有效位置策略级别中的索引,默觉得0
        val previousLocalityLevel = myLocalityLevels(currentLocalityIndex)
        
        // 计算有效的位置Level
        myLocalityLevels = computeValidLocalityLevels()
        
        // 获得位置策略级别的等待时间
        localityWaits = myLocalityLevels.map(getLocalityWait)
        
        // 设置当前使用的位置策略级别的索引
        currentLocalityIndex = getLocalityIndex(previousLocalityLevel)
      }
            首先说下这个currentLocalityIndex,它的定义为:
    var currentLocalityIndex = 0    // Index of our current locality level in validLocalityLevels
            它是有效位置策略级别中的索引,指示当前的位置信息。也就是我们上一个task被launched所使用的Locality Level。

            接下来看下myLocalityLevels,它是任务集TaskSet中应该使用哪种位置Level的数组,在TaskSetManager对象实例化时即被初始化。变量定义例如以下:

    // Figure out which locality levels we have in our TaskSet, so we can do delay scheduling
      // 确定在我们的任务集TaskSet中应该使用哪种位置Level,以便我们做延迟调度
      var myLocalityLevels = computeValidLocalityLevels()
            computeValidLocalityLevels()方法为计算该TaskSet使用的位置策略的方法,代码例如以下:

    /**
       * Compute the locality levels used in this TaskSet. Assumes that all tasks have already been
       * added to queues using addPendingTask.
       * 计算该TaskSet使用的位置策略。假设全部的任务已经通过addPendingTask()被加入入队列
       */
      private def computeValidLocalityLevels(): Array[TaskLocality.TaskLocality] = {
        // 引入任务位置策略
        import TaskLocality.{PROCESS_LOCAL, NODE_LOCAL, NO_PREF, RACK_LOCAL, ANY}
        
        // 创建ArrayBuffer类型的levels,存储TaskLocality
        val levels = new ArrayBuffer[TaskLocality.TaskLocality]
        
        // 假设pendingTasksForExecutor不为空,且PROCESS_LOCAL级别中TaskSetManager等待分配下一个任务的时间不为零,且
        // 假设pendingTasksForExecutor中每一个executorId在sched的executorIdToTaskCount中存在
        // executorIdToTaskCount为每一个executor上执行的task的数目集合
        if (!pendingTasksForExecutor.isEmpty && getLocalityWait(PROCESS_LOCAL) != 0 &&
            pendingTasksForExecutor.keySet.exists(sched.isExecutorAlive(_))) {
          levels += PROCESS_LOCAL
        }
        
        // 假设pendingTasksForHost不为空。且NODE_LOCAL级别中TaskSetManager等待分配下一个任务的时间不为零,且
        // 假设pendingTasksForHost中每一个host在sched的executorsByHost中存在
        // executorsByHost为每一个host上executors的集合
        if (!pendingTasksForHost.isEmpty && getLocalityWait(NODE_LOCAL) != 0 &&
            pendingTasksForHost.keySet.exists(sched.hasExecutorsAliveOnHost(_))) {
          levels += NODE_LOCAL
        }
        
        // 假设存在没有位置信息的task。则加入NO_PREF级别
        if (!pendingTasksWithNoPrefs.isEmpty) {
          levels += NO_PREF
        }
        
        // 相同处理RACK_LOCAL级别
        if (!pendingTasksForRack.isEmpty && getLocalityWait(RACK_LOCAL) != 0 &&
            pendingTasksForRack.keySet.exists(sched.hasHostAliveOnRack(_))) {
          levels += RACK_LOCAL
        }
        
        // 最后加上一个ANY级别
        levels += ANY
        logDebug("Valid locality levels for " + taskSet + ": " + levels.mkString(", "))
        
        // 返回
        levels.toArray
      }
            这里,我们先看下当中几个比較重要的数据结构。在TaskSetManager中,存在例如以下几个数据结构:

    // 每一个executor上即将被运行的tasks的映射集合
      private val pendingTasksForExecutor = new HashMap[String, ArrayBuffer[Int]]
    
    // 每一个host上即将被运行的tasks的映射集合
      private val pendingTasksForHost = new HashMap[String, ArrayBuffer[Int]]
    
    // 每一个rack上即将被运行的tasks的映射集合
      private val pendingTasksForRack = new HashMap[String, ArrayBuffer[Int]]
    
    // Set containing pending tasks with no locality preferences.
      // 存储全部没有位置信息的即将运行tasks的index索引的集合
      var pendingTasksWithNoPrefs = new ArrayBuffer[Int]
    
    // Set containing all pending tasks (also used as a stack, as above).
      // 存储全部即将运行tasks的index索引的集合
      val allPendingTasks = new ArrayBuffer[Int]
            这些数据结构。存储了task与不同位置的载体的相应关系。在TaskSetManager对象被构造时。有例如以下代码被运行:

    // Add all our tasks to the pending lists. We do this in reverse order
      // of task index so that tasks with low indices get launched first.
      // 将全部的tasks加入到pending列表。我们用倒序的任务索引一遍较低索引的任务能够被优先载入
      for (i <- (0 until numTasks).reverse) {
        addPendingTask(i)
      }
            它对TaskSetManager中的tasks的索引倒序处理。addPendingTask()方法例如以下:

    /** Add a task to all the pending-task lists that it should be on. */
      // 加入一个任务的索引到全部相关的pending-task索引列表
      private def addPendingTask(index: Int) {
        // Utility method that adds `index` to a list only if it's not already there
        // 定义了一个假设索引不存在加入索引至列表的工具方法
        def addTo(list: ArrayBuffer[Int]) {
          if (!list.contains(index)) {
            list += index
          }
        }
    
        // 遍历task的优先位置
        for (loc <- tasks(index).preferredLocations) {
          loc match {
            case e: ExecutorCacheTaskLocation => // 假设为ExecutorCacheTaskLocation
              // 加入任务索引index至pendingTasksForExecutor列表
              addTo(pendingTasksForExecutor.getOrElseUpdate(e.executorId, new ArrayBuffer))
            case e: HDFSCacheTaskLocation => {// 假设为HDFSCacheTaskLocation
              
              // 调用sched(即TaskSchedulerImpl)的getExecutorsAliveOnHost()方法。获得指定Host上的Alive Executors
              val exe = sched.getExecutorsAliveOnHost(loc.host)
              exe match {
                case Some(set) => {
                  // 循环host上的每一个Alive Executor。加入任务索引index至pendingTasksForExecutor列表
                  for (e <- set) {
                    addTo(pendingTasksForExecutor.getOrElseUpdate(e, new ArrayBuffer))
                  }
                  logInfo(s"Pending task $index has a cached location at ${e.host} " +
                    ", where there are executors " + set.mkString(","))
                }
                case None => logDebug(s"Pending task $index has a cached location at ${e.host} " +
                    ", but there are no executors alive there.")
              }
            }
            case _ => Unit
          }
          
          // 加入任务索引index至pendingTasksForHost列表
          addTo(pendingTasksForHost.getOrElseUpdate(loc.host, new ArrayBuffer))
          
          // 依据获得任务优先位置host获得机架rack,循环。加入任务索引index至pendingTasksForRack列表
          for (rack <- sched.getRackForHost(loc.host)) {
            addTo(pendingTasksForRack.getOrElseUpdate(rack, new ArrayBuffer))
          }
        }
    
        // 假设task没有位置属性,则将任务的索引index加入到pendingTasksWithNoPrefs,pendingTasksWithNoPrefs为存储全部没有位置信息的即将执行tasks的index索引的集合
        if (tasks(index).preferredLocations == Nil) {
          addTo(pendingTasksWithNoPrefs)
        }
    
        // 将任务的索引index加入到allPendingTasks,allPendingTasks为存储全部即将执行tasks的index索引的集合
        allPendingTasks += index  // No point scanning this whole list to find the old task there
      }
            鉴于上面凝视非常清晰,这里,我们仅仅说下重点,它是依据task的preferredLocations。来决定该往哪个数据结构存储的。终于,将task的位置信息,存储到不同的数据结构中。方便兴许任务调度的处理。

            同一时候。在TaskSetManager中TaskSchedulerImpl类型的变量中,还存在着例如以下几个数据结构:

    // Number of tasks running on each executor
      // 每一个executor上正在执行的tasks的数目
      private val executorIdToTaskCount = new HashMap[String, Int]
    
      // The set of executors we have on each host; this is used to compute hostsAlive, which
      // in turn is used to decide when we can attain data locality on a given host
      // 每一个host上executors的集合
      // 这个executorsByHost被用来计算host活跃性,反过来我们用它来决定在给定的主机上何时实现数据本地性
      protected val executorsByHost = new HashMap[String, HashSet[String]]
    
      // 每一个rack上hosts的映射关系
      protected val hostsByRack = new HashMap[String, HashSet[String]]
            它反映了当前集群中executor、host、rack的相应关系。

    而在computeValidLocalityLevels()方法中。依据task的位置属性和当前集群中executor、host、rack的相应关系。依靠上面这两组数据结构。就能非常方便的确定该TaskSet的TaskLocality Level,具体流程不再赘述,读者可自行阅读代码。

            这里,我们仅仅说下getLocalityWait()方法,它是获取Locality级别相应TaskSetManager等待分配下一个任务的时间,代码例如以下:

    // 获取Locality级别相应TaskSetManager等待分配下一个任务的时间
      private def getLocalityWait(level: TaskLocality.TaskLocality): Long = {
        // 默认等待时间。取自參数spark.locality.wait,默觉得3s
        val defaultWait = conf.get("spark.locality.wait", "3s")
        
        // 依据不同的TaskLocality,取不同的參数,设置TaskLocality等待时间
        // PROCESS_LOCAL取參数spark.locality.wait.process
        // NODE_LOCAL取參数spark.locality.wait.node
        // RACK_LOCAL取參数spark.locality.wait.rack
        val localityWaitKey = level match {
          case TaskLocality.PROCESS_LOCAL => "spark.locality.wait.process"
          case TaskLocality.NODE_LOCAL => "spark.locality.wait.node"
          case TaskLocality.RACK_LOCAL => "spark.locality.wait.rack"
          case _ => null
        }
    
        if (localityWaitKey != null) {
          conf.getTimeAsMs(localityWaitKey, defaultWait)
        } else {
          0L
        }
      }
            不同的Locality级别相应取不同的參数。

    为什么要有这个Locality级别相应TaskSetManager等待分配下一个任务的时间呢?我们先留个小小的疑问。

            回到recomputeLocality()方法,接下来便是调用computeValidLocalityLevels()这种方法,计算当前最新的有效的位置策略Level。为什么要再次计算呢?主要就是新的slave节点增加。我们须要又一次评估下集群中task位置偏好与当前集群executor、host、rack等总体资源的关系,起到了一个位置策略级别动态调整的一个效果。

            然后,便是获得位置策略级别的等待时间localityWaits、设置当前使用的位置策略级别的索引currentLocalityIndex,不再赘述。

            好了。第7步就分析完了,有些细节留到以后再归纳整理吧。

            接着分析第8步,循环sortedTaskSets,依照位置本地性规则调度每一个TaskSet。最大化实现任务的本地性。也就是对每一个taskSet。调用resourceOfferSingleTaskSet()方法进行任务集调度。显然。我们须要首先看下resourceOfferSingleTaskSet()这种方法。代码例如以下:

    private def resourceOfferSingleTaskSet(
          taskSet: TaskSetManager,
          maxLocality: TaskLocality,
          shuffledOffers: Seq[WorkerOffer],
          availableCpus: Array[Int],
          tasks: Seq[ArrayBuffer[TaskDescription]]) : Boolean = {
        
        // 标志位launchedTask初始化为false,用它来标记是否有task被成功分配或者launched
        var launchedTask = false
        
        // 循环shuffledOffers,即每一个可用executor
        for (i <- 0 until shuffledOffers.size) {
          
          // 获取其executorId和host
          val execId = shuffledOffers(i).executorId
          val host = shuffledOffers(i).host
          
          // 假设executor上可利用cpu数目大于每一个task须要的数目,则继续task分配
          // CPUS_PER_TASK为參数spark.task.cpus配置的值,未配置的话默觉得1
          if (availableCpus(i) >= CPUS_PER_TASK) {
            try {
            
              // 调用TaskSetManager的resourceOffer()方法。处理返回的每一个TaskDescription
              for (task <- taskSet.resourceOffer(execId, host, maxLocality)) {
                
                // 分配task成功
                // 将task增加到tasks相应位置
                // 注意,tasks为一个空的。依据shuffledOffers和其可用cores生成的有一定结构的列表
                tasks(i) += task
                
                // 更新taskIdToTaskSetManager、taskIdToExecutorId、executorIdToTaskCount、
                // executorsByHost、availableCpus等数据结构
                val tid = task.taskId
                taskIdToTaskSetManager(tid) = taskSet // taskId与TaskSetManager的映射关系
                taskIdToExecutorId(tid) = execId // taskId与ExecutorId的映射关系
                executorIdToTaskCount(execId) += 1// executor上正在执行的task数目加1
                executorsByHost(host) += execId// host上相应的executor的映射关系
                availableCpus(i) -= CPUS_PER_TASK// 能够Cpu cores降低相应数目
                
                // 确保availableCpus(i)不小于0
                assert(availableCpus(i) >= 0)
                
                // 标志位launchedTask设置为true
                launchedTask = true
              }
            } catch {
              case e: TaskNotSerializableException =>
                logError(s"Resource offer failed, task set ${taskSet.name} was not serializable")
                // Do not offer resources for this task, but don't throw an error to allow other
                // task sets to be submitted.
                return launchedTask
            }
          }
        }
        return launchedTask
      }
            该方法的主体流程例如以下:

            1、标志位launchedTask初始化为false。用它来标记是否有task被成功分配或者launched;

            2、循环shuffledOffers,即每一个可用executor:

                 2.1、获取其executorId和host;

                 2.2、假设executor上可利用cpu数目大于每一个task须要的数目。则继续task分配;

                 2.3、调用TaskSetManager的resourceOffer()方法,处理返回的每一个TaskDescription:

                    2.3.1、分配task成功。将task增加到tasks相应位置(注意,tasks为一个空的,依据shuffledOffers和其可用cores生成的有一定结构的列表);

                    2.3.2、更新taskIdToTaskSetManager、taskIdToExecutorId、executorIdToTaskCount、executorsByHost、availableCpus等数据结构;

                    2.3.3、确保availableCpus(i)不小于0;

                    2.3.4、标志位launchedTask设置为true;

           3、返回launchedTask。

            其它都好说,我们仅仅看下TaskSetManager的resourceOffer()方法。

    代码例如以下:

    /**
       * Respond to an offer of a single executor from the scheduler by finding a task
       *
       * NOTE: this function is either called with a maxLocality which
       * would be adjusted by delay scheduling algorithm or it will be with a special
       * NO_PREF locality which will be not modified
       *
       * @param execId the executor Id of the offered resource
       * @param host  the host Id of the offered resource
       * @param maxLocality the maximum locality we want to schedule the tasks at
       */
      @throws[TaskNotSerializableException]
      def resourceOffer(
          execId: String,
          host: String,
          maxLocality: TaskLocality.TaskLocality)
        : Option[TaskDescription] =
      {
        if (!isZombie) {
        
          // 当前时间
          val curTime = clock.getTimeMillis()
    
          // 确定能够被同意的位置策略:allowedLocality
          var allowedLocality = maxLocality
    
          // 假设maxLocality不为TaskLocality.NO_PREF
          if (maxLocality != TaskLocality.NO_PREF) {
            // 获取被同意的Locality。主要是看等待时间
            allowedLocality = getAllowedLocalityLevel(curTime)
            
            // 假设allowedLocality大于maxLocality。将maxLocality赋值给allowedLocality
            if (allowedLocality > maxLocality) {
              // We're not allowed to search for farther-away tasks
              allowedLocality = maxLocality
            }
          }
    
          // 出列task,即分配task
          dequeueTask(execId, host, allowedLocality) match {
            case Some((index, taskLocality, speculative)) => {
              
              // 找到相应的task
              // Found a task; do some bookkeeping and return a task description
              val task = tasks(index)
              val taskId = sched.newTaskId()
              // Do various bookkeeping
              // 更新copiesRunning
              copiesRunning(index) += 1
              val attemptNum = taskAttempts(index).size
              
              // 创建TaskInfo
              val info = new TaskInfo(taskId, index, attemptNum, curTime,
                execId, host, taskLocality, speculative)
              
              // 更新taskInfos
              taskInfos(taskId) = info
              
              // 更新taskAttempts
              taskAttempts(index) = info :: taskAttempts(index)
              // Update our locality level for delay scheduling
              // NO_PREF will not affect the variables related to delay scheduling
              
              // 设置currentLocalityIndex、lastLaunchTime
              if (maxLocality != TaskLocality.NO_PREF) {
                currentLocalityIndex = getLocalityIndex(taskLocality)
                lastLaunchTime = curTime
              }
              
              // Serialize and return the task
              // 開始时间
              val startTime = clock.getTimeMillis()
              
              // 序列化task,得到serializedTask
              val serializedTask: ByteBuffer = try {
                Task.serializeWithDependencies(task, sched.sc.addedFiles, sched.sc.addedJars, ser)
              } catch {
                // If the task cannot be serialized, then there's no point to re-attempt the task,
                // as it will always fail. So just abort the whole task-set.
                case NonFatal(e) =>
                  val msg = s"Failed to serialize task $taskId, not attempting to retry it."
                  logError(msg, e)
                  abort(s"$msg Exception during serialization: $e")
                  throw new TaskNotSerializableException(e)
              }
              if (serializedTask.limit > TaskSetManager.TASK_SIZE_TO_WARN_KB * 1024 &&
                  !emittedTaskSizeWarning) {
                emittedTaskSizeWarning = true
                logWarning(s"Stage ${task.stageId} contains a task of very large size " +
                  s"(${serializedTask.limit / 1024} KB). The maximum recommended task size is " +
                  s"${TaskSetManager.TASK_SIZE_TO_WARN_KB} KB.")
              }
              
              // 加入running task
              addRunningTask(taskId)
    
              // We used to log the time it takes to serialize the task, but task size is already
              // a good proxy to task serialization time.
              // val timeTaken = clock.getTime() - startTime
              val taskName = s"task ${info.id} in stage ${taskSet.id}"
              logInfo(s"Starting $taskName (TID $taskId, $host, partition ${task.partitionId}," +
                s"$taskLocality, ${serializedTask.limit} bytes)")
    
              // 调用DagScheduler的taskStarted()方法,标记Task已启动
              sched.dagScheduler.taskStarted(task, info)
              
              // 返回TaskDescription。当中包括taskId、attemptNumber、execId、index、serializedTask等重要信息
              // attemptNumber是猜測运行原理必须使用的,即拖后腿的任务能够运行多份,谁先完毕用谁的结果
              return Some(new TaskDescription(taskId = taskId, attemptNumber = attemptNum, execId,
                taskName, index, serializedTask))
            }
            case _ =>
          }
        }
        None
      }
            resourceOffer()方法的处理流程大体例如以下:

            1、记录当前时间;

            2、 确定能够被同意的位置策略:allowedLocality;

            3、出列task。即分配task;

                3.1、假设找到相应的task,即task能够被分配:

                  3.1.1、完毕获得taskId、更新copiesRunning、获得attemptNum、创建TaskInfo、更新taskInfos、更新taskAttempts、设置currentLocalityIndex、lastLaunchTime等基础数据结构的更新;

                  3.1.2、序列化task,得到serializedTask;

                  3.1.3、加入running task;

                  3.1.4、调用DagScheduler的taskStarted()方法,标记Task已启动。

                  3.1.5、返回TaskDescription,当中包括taskId、attemptNumber、execId、index、serializedTask等重要信息,attemptNumber是猜測运行原理必须使用的。即拖后腿的任务能够运行多份,谁先完毕用谁的结果。

            首先说下这个allowedLocality。假设maxLocality不为TaskLocality.NO_PREF。我们须要调用getAllowedLocalityLevel(),传入当前时间,得到allowedLocality,getAllowedLocalityLevel()方法逻辑比較简单,代码例如以下:

    /**
       * Get the level we can launch tasks according to delay scheduling, based on current wait time.
       * 基于当前的等待是时间,得到我们能够调度task的级别
       */
      private def getAllowedLocalityLevel(curTime: Long): TaskLocality.TaskLocality = {
        // Remove the scheduled or finished tasks lazily
        // 推断task能否够被调度
        def tasksNeedToBeScheduledFrom(pendingTaskIds: ArrayBuffer[Int]): Boolean = {
          var indexOffset = pendingTaskIds.size
          // 循环
          while (indexOffset > 0) {
            // 索引递减
            indexOffset -= 1
            
            // 获得task索引
            val index = pendingTaskIds(indexOffset)
            
            // 假设相应task不存在不论什么执行实例。且未执行成功,能够调度。返回true
            if (copiesRunning(index) == 0 && !successful(index)) {
              return true
            } else {
            
              // 从pendingTaskIds中移除
              pendingTaskIds.remove(indexOffset)
            }
          }
          false
        }
        // Walk through the list of tasks that can be scheduled at each location and returns true
        // if there are any tasks that still need to be scheduled. Lazily cleans up tasks that have
        // already been scheduled.
        def moreTasksToRunIn(pendingTasks: HashMap[String, ArrayBuffer[Int]]): Boolean = {
          val emptyKeys = new ArrayBuffer[String]
          
          // 循环pendingTasks
          val hasTasks = pendingTasks.exists {
            case (id: String, tasks: ArrayBuffer[Int]) =>
              
              // 推断task能否够被调度
              if (tasksNeedToBeScheduledFrom(tasks)) {
                true
              } else {
                emptyKeys += id
                false
              }
          }
          // The key could be executorId, host or rackId
          // 移除数据
          emptyKeys.foreach(id => pendingTasks.remove(id))
          hasTasks
        }
        
        // 从当前索引currentLocalityIndex開始,循环myLocalityLevels
        while (currentLocalityIndex < myLocalityLevels.length - 1) {
          
          // 是否存在待调度task,依据不同的Locality Level。调用moreTasksToRunIn()方法从不同的数据结构中获取。
          // NO_PREF直接看pendingTasksWithNoPrefs是否为空
          val moreTasks = myLocalityLevels(currentLocalityIndex) match {
            case TaskLocality.PROCESS_LOCAL => moreTasksToRunIn(pendingTasksForExecutor)
            case TaskLocality.NODE_LOCAL => moreTasksToRunIn(pendingTasksForHost)
            case TaskLocality.NO_PREF => pendingTasksWithNoPrefs.nonEmpty
            case TaskLocality.RACK_LOCAL => moreTasksToRunIn(pendingTasksForRack)
          }
          if (!moreTasks) {// 不存在能够被调度的task
            // This is a performance optimization: if there are no more tasks that can
            // be scheduled at a particular locality level, there is no point in waiting
            // for the locality wait timeout (SPARK-4939).
            // 记录lastLaunchTime
            lastLaunchTime = curTime
            logDebug(s"No tasks for locality level ${myLocalityLevels(currentLocalityIndex)}, " +
              s"so moving to locality level ${myLocalityLevels(currentLocalityIndex + 1)}")
            
            // 位置策略索引加1
            currentLocalityIndex += 1
          } else if (curTime - lastLaunchTime >= localityWaits(currentLocalityIndex)) {
            // Jump to the next locality level, and reset lastLaunchTime so that the next locality
            // wait timer doesn't immediately expire
            
            // 更新localityWaits
            lastLaunchTime += localityWaits(currentLocalityIndex)
            
            // 位置策略索引加1
            currentLocalityIndex += 1
            logDebug(s"Moving to ${myLocalityLevels(currentLocalityIndex)} after waiting for " +
              s"${localityWaits(currentLocalityIndex)}ms")
          } else {
          
            // 返回当前位置策略级别
            return myLocalityLevels(currentLocalityIndex)
          }
        }
        
        // 返回当前位置策略级别
        myLocalityLevels(currentLocalityIndex)
      }
            在确定allowedLocality后,我们就须要调用dequeueTask()方法。出列task。进行调度。代码例如以下:

    /**
       * 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()方法。对PROCESS_LOCAL级别的task进行调度
        for (index <- dequeueTaskFromList(execId, getPendingTasksForExecutor(execId))) {
          return Some((index, TaskLocality.PROCESS_LOCAL, false))
        }
    
        // PROCESS_LOCAL未调度到task的话,再调度NODE_LOCAL级别
        if (TaskLocality.isAllowed(maxLocality, TaskLocality.NODE_LOCAL)) {
          for (index <- dequeueTaskFromList(execId, getPendingTasksForHost(host))) {
            return Some((index, TaskLocality.NODE_LOCAL, false))
          }
        }
    
        // NODE_LOCAL未调度到task的话,再调度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, pendingTasksWithNoPrefs)) {
            return Some((index, TaskLocality.PROCESS_LOCAL, false))
          }
        }
    
        // NO_PREF未调度到task的话。再调度RACK_LOCAL级别
        if (TaskLocality.isAllowed(maxLocality, TaskLocality.RACK_LOCAL)) {
          for {
            rack <- sched.getRackForHost(host)
            index <- dequeueTaskFromList(execId, getPendingTasksForRack(rack))
          } {
            return Some((index, TaskLocality.RACK_LOCAL, false))
          }
        }
    
        // 最好是ANY级别的调度
        if (TaskLocality.isAllowed(maxLocality, TaskLocality.ANY)) {
          for (index <- dequeueTaskFromList(execId, allPendingTasks)) {
            return Some((index, TaskLocality.ANY, false))
          }
        }
    
        // find a speculative task if all others tasks have been scheduled
        // 假设全部的class都被调度的话,寻找一个speculative task。同MapReduce的猜測运行原理的思想
        dequeueSpeculativeTask(execId, host, maxLocality).map {
          case (taskIndex, allowedLocality) => (taskIndex, allowedLocality, true)}
      }
            非常easy,依照PROCESS_LOCAL、NODE_LOCAL、NO_PREF、RACK_LOCAL、ANY的顺序进行调度。

    最后,假设全部的class都被调度的话,寻找一个speculative task,同MapReduce的猜測运行原理的思想。

            至此。我们得到了TaskDescription,也就知道了哪个Task须要在哪个节点上运行,而Task调度也就全讲完了。

            题外话:

            要透彻的、清晰的解说一个复杂的流程。是非常费力的,短短几篇文章也是远远不够的。Task调度这两篇文章。重在叙述一个完整的流程。同一时候解说部分细节。

    在这两篇文章的叙述中,肯定会有非常多细节没讲清晰、讲透彻,甚至会有些理解错误的地方,希望高手指教,以免继续误导大家。

            针对部分细节,和对流程的深入理解,我以后还会陆续推出博文。进行具体解说,并归纳总结。谢谢大家!



            




  • 相关阅读:
    js获取窗口大小
    ARCGIS接口详细说明
    输入框特效
    GeoServer源码解析和扩展 (二)注册服务
    GeoServer源码解析和扩展 (一)基础篇
    window.open参数大全
    Flex控件
    GeoServer源码解析和扩展 (三)结构篇
    js常用的几个正则表达式
    表单的diabled属性与readonly属性
  • 原文地址:https://www.cnblogs.com/wzzkaifa/p/7229982.html
Copyright © 2020-2023  润新知