Spark 原始碼系列(六)Shuffle 的過程解析

EddieJ發表於2019-04-25

Spark 大會上,所有的演講嘉賓都認為 shuffle 是最影響效能的地方,但是又無可奈何。之前去百度面試 hadoop 的時候,也被問到了這個問題,直接回答了不知道。

這篇文章主要是沿著下面幾個問題來開展:

1、shuffle 過程的劃分?

2、shuffle 的中間結果如何儲存?

3、shuffle 的資料如何拉取過來?

Shuffle 過程的劃分

Spark 的操作模型是基於 RDD 的,當呼叫 RDD 的 reduceByKey、groupByKey 等類似的操作的時候,就需要有 shuffle 了。再拿出 reduceByKey 這個來講。

  def reduceByKey(func: (V, V) => V, numPartitions: Int): RDD[(K, V)] = {
    reduceByKey(new HashPartitioner(numPartitions), func)
  }
複製程式碼

reduceByKey 的時候,我們可以手動設定 reduce 的個數,如果不指定的話,就可能不受控制了。

  def defaultPartitioner(rdd: RDD[_], others: RDD[_]*): Partitioner = {
    val bySize = (Seq(rdd) ++ others).sortBy(_.partitions.size).reverse
    for (r <- bySize if r.partitioner.isDefined) {
      return r.partitioner.get
    }
    if (rdd.context.conf.contains("spark.default.parallelism")) {
      new HashPartitioner(rdd.context.defaultParallelism)
    } else {
      new HashPartitioner(bySize.head.partitions.size)
    }
  }
複製程式碼

如果不指定 reduce 個數的話,就按預設的走:

1、如果自定義了分割槽函式 partitioner 的話,就按你的分割槽函式來走。

2、如果沒有定義,那麼如果設定了 spark.default.parallelism,就使用雜湊的分割槽方式,reduce 個數就是設定的這個值。

3、如果這個也沒設定,那就按照輸入資料的分片的數量來設定。如果是 hadoop 的輸入資料的話,這個就多了,大家可要小心啊。

設定完之後,它會做三件事情,也就是之前講的 3 次 RDD 轉換。

//map端先按照key合併一次
val combined = self.mapPartitionsWithContext((context, iter) => {
        aggregator.combineValuesByKey(iter, context)
 }, preservesPartitioning = true)
//reduce抓取資料
val partitioned = new ShuffledRDD[K, C, (K, C)](combined, partitioner).setSerializer(serializer)
//合併資料,執行reduce計算
partitioned.mapPartitionsWithContext((context, iter) => {
        new InterruptibleIterator(context, aggregator.combineCombinersByKey(iter, context))
 }, preservesPartitioning = true)
複製程式碼

View Code

img

1、在第一個 MapPartitionsRDD 這裡先做一次 map 端的聚合操作。

2、ShuffledRDD 主要是做從這個抓取資料的工作。

3、第二個 MapPartitionsRDD 把抓取過來的資料再次進行聚合操作。

4、步驟 1 和步驟 3 都會涉及到 spill 的過程。

怎麼做的聚合操作,回去看 RDD 那章。

Shuffle 的中間結果如何儲存

作業提交的時候,DAGScheduler 會把 Shuffle 的過程切分成 map 和 reduce 兩個 Stage(之前一直被我叫做 shuffle 前和 shuffle 後),具體的切分的位置在上圖的虛線處。

map 端的任務會作為一個 ShuffleMapTask 提交,最後在 TaskRunner 裡面呼叫了它的 runTask 方法。

  override def runTask(context: TaskContext): MapStatus = {
    val numOutputSplits = dep.partitioner.numPartitions
    metrics = Some(context.taskMetrics)

    val blockManager = SparkEnv.get.blockManager
    val shuffleBlockManager = blockManager.shuffleBlockManager
    var shuffle: ShuffleWriterGroup = null
    var success = false

    try {
      // serializer為空的情況呼叫預設的JavaSerializer,也可以通過spark.serializer來設定成別的
      val ser = Serializer.getSerializer(dep.serializer)
      // 例項化Writer,Writer的數量=numOutputSplits=前面我們說的那個reduce的數量
      shuffle = shuffleBlockManager.forMapTask(dep.shuffleId, partitionId, numOutputSplits, ser)

      // 遍歷rdd的元素,按照key計算出來它所在的bucketId,然後通過bucketId找到相應的Writer寫入
      for (elem <- rdd.iterator(split, context)) {
        val pair = elem.asInstanceOf[Product2[Any, Any]]
        val bucketId = dep.partitioner.getPartition(pair._1)
        shuffle.writers(bucketId).write(pair)
      }

      // 提交寫入操作. 計算每個bucket block的大小
      var totalBytes = 0L
      var totalTime = 0L
      val compressedSizes: Array[Byte] = shuffle.writers.map { writer: BlockObjectWriter =>
        writer.commit()
        writer.close()
        val size = writer.fileSegment().length
        totalBytes += size
        totalTime += writer.timeWriting()
        MapOutputTracker.compressSize(size)
      }

      // 更新 shuffle 監控引數.
      val shuffleMetrics = new ShuffleWriteMetrics
      shuffleMetrics.shuffleBytesWritten = totalBytes
      shuffleMetrics.shuffleWriteTime = totalTime
      metrics.get.shuffleWriteMetrics = Some(shuffleMetrics)

      success = true
      new MapStatus(blockManager.blockManagerId, compressedSizes)
    } catch { case e: Exception =>
      // 出錯了,取消之前的操作,關閉writer
      if (shuffle != null && shuffle.writers != null) {
        for (writer <- shuffle.writers) {
          writer.revertPartialWrites()
          writer.close()
        }
      }
      throw e
    } finally {
      // 關閉writer
      if (shuffle != null && shuffle.writers != null) {
        try {
          shuffle.releaseWriters(success)
        } catch {
          case e: Exception => logError("Failed to release shuffle writers", e)
        }
      }
      // 執行註冊的回撥函式,一般是做清理工作
      context.executeOnCompleteCallbacks()
    }
  }
複製程式碼

遍歷每一個記錄,通過它的 key 來確定它的 bucketId,再通過這個 bucket 的 writer 寫入資料。

下面我們看看 ShuffleBlockManager 的 forMapTask 方法吧。

def forMapTask(shuffleId: Int, mapId: Int, numBuckets: Int, serializer: Serializer) = {
    new ShuffleWriterGroup {
      shuffleStates.putIfAbsent(shuffleId, new ShuffleState(numBuckets))
      private val shuffleState = shuffleStates(shuffleId)
      private var fileGroup: ShuffleFileGroup = null

      val writers: Array[BlockObjectWriter] = if (consolidateShuffleFiles) {
        fileGroup = getUnusedFileGroup()
        Array.tabulate[BlockObjectWriter](numBuckets) { bucketId =>
          val blockId = ShuffleBlockId(shuffleId, mapId, bucketId)
&emsp;&emsp;&emsp;&emsp;&emsp;&emsp;// 從已有的檔案組裡選檔案,一個bucket一個檔案,即要傳送到同一個reduce的資料寫入到同一個檔案
          blockManager.getDiskWriter(blockId, fileGroup(bucketId), serializer, bufferSize)
        }
      } else {
        Array.tabulate[BlockObjectWriter](numBuckets) { bucketId =>
          // 按照blockId來生成檔案,檔案數為map數*reduce數
          val blockId = ShuffleBlockId(shuffleId, mapId, bucketId)
          val blockFile = blockManager.diskBlockManager.getFile(blockId)
          if (blockFile.exists) {
            if (blockFile.delete()) {
              logInfo(s"Removed existing shuffle file $blockFile")
            } else {
              logWarning(s"Failed to remove existing shuffle file $blockFile")
            }
          }
          blockManager.getDiskWriter(blockId, blockFile, serializer, bufferSize)
        }
      }
複製程式碼

1、map 的中間結果是寫入到本地硬碟的,而不是記憶體。

2、預設是一個 Executor 的中間結果檔案是 M*R(M=map 數量,R=reduce 的數量),設定了 spark.shuffle.consolidateFiles 為 true 之後是 R 個檔案,根據 bucketId 把要分到同一個 reduce 的結果寫入到一個檔案中。

3、consolidateFiles 採用的是一個 reduce 一個檔案,它還記錄了每個 map 的寫入起始位置,所以查詢的時候先通過 reduceId 查詢到哪個檔案,再通過 mapId 查詢索引當中的起始位置 offset,長度 length=(mapId + 1).offset -(mapId).offset,這樣就可以確定一個 FileSegment(file, offset, length)。

4、Finally,儲存結束之後, 返回了一個 new MapStatus(blockManager.blockManagerId, compressedSizes),把 blockManagerId 和 block 的大小都一起返回。

個人想法,shuffle 這塊和 hadoop 的機制差別不大,tez 這樣的引擎會趕上 spark 的速度呢?還是讓我們拭目以待吧!

Shuffle 的資料如何拉取過來

ShuffleMapTask 結束之後,最後走到 DAGScheduler 的 handleTaskCompletion 方法當中(關於中間的過程,請看《圖解作業生命週期》)。

case smt: ShuffleMapTask =>
val status = event.result.asInstanceOf[MapStatus]
val execId = status.location.executorId
if (failedEpoch.contains(execId) && smt.epoch <= failedEpoch(execId)) {
    logInfo("Ignoring possibly bogus ShuffleMapTask completion from " + execId)
} else {
    stage.addOutputLoc(smt.partitionId, status)
}
if (runningStages.contains(stage) && pendingTasks(stage).isEmpty) {
    markStageAsFinished(stage)
    if (stage.shuffleDep.isDefined) {
         // 真的map過程才會有這個依賴,reduce過程None
         mapOutputTracker.registerMapOutputs(
   &emsp;&emsp;stage.shuffleDep.get.shuffleId,
         stage.outputLocs.map(list => if (list.isEmpty) null else list.head).toArray,
         changeEpoch = true)
     }
      clearCacheLocs()
      if (stage.outputLocs.exists(_ == Nil)) {
          // 一些任務失敗了,需要重新提交stage
          submitStage(stage)
       } else {
          // 提交下一批任務              
&emsp;&emsp;&emsp;}
}
複製程式碼

1、把結果新增到 Stage 的 outputLocs 陣列裡,它是按照資料的分割槽 Id 來儲存對映關係的 partitionId->MapStaus。

2、stage 結束之後,通過 mapOutputTracker 的 registerMapOutputs 方法,把此次 shuffle 的結果 outputLocs 記錄到 mapOutputTracker 裡面。

這個 stage 結束之後,就到 ShuffleRDD 執行了,我們看一下它的 compute 函式。

SparkEnv.get.shuffleFetcher.fetch[P](shuffledId, split.index, context, ser)
複製程式碼

它是通過 ShuffleFetch 的 fetch 方法來抓取的,具體實現在 BlockStoreShuffleFetcher 裡面。

  override def fetch[T](
      shuffleId: Int,
      reduceId: Int,
      context: TaskContext,
      serializer: Serializer)
    : Iterator[T] =
{
    val blockManager = SparkEnv.get.blockManager
    val startTime = System.currentTimeMillis
&emsp;&emsp; // mapOutputTracker也分Master和Worker,Worker向Master請求獲取reduce相關的MapStatus,主要是(BlockManagerId和size)
    val statuses = SparkEnv.get.mapOutputTracker.getServerStatuses(shuffleId, reduceId)
    // 一個BlockManagerId對應多個檔案的大小
    val splitsByAddress = new HashMap[BlockManagerId, ArrayBuffer[(Int, Long)]]
    for (((address, size), index) <- statuses.zipWithIndex) {
      splitsByAddress.getOrElseUpdate(address, ArrayBuffer()) += ((index, size))
    }
    // 構造BlockManagerId 和 BlockId的對映關係,想不到ShffleBlockId的mapId,居然是1,2,3,4的序列...
    val blocksByAddress: Seq[(BlockManagerId, Seq[(BlockId, Long)])] = splitsByAddress.toSeq.map {
      case (address, splits) =>
        (address, splits.map(s => (ShuffleBlockId(shuffleId, s._1, reduceId), s._2)))
    }
    // 名為updateBlock,實際是檢驗函式,每個Block都對應著一個Iterator介面,如果該介面為空,則應該報錯
    def unpackBlock(blockPair: (BlockId, Option[Iterator[Any]])) : Iterator[T] = {
      val blockId = blockPair._1
      val blockOption = blockPair._2
      blockOption match {
        case Some(block) => {
          block.asInstanceOf[Iterator[T]]
        }
        case None => {
          blockId match {
            case ShuffleBlockId(shufId, mapId, _) =>
              val address = statuses(mapId.toInt)._1
              throw new FetchFailedException(address, shufId.toInt, mapId.toInt, reduceId, null)
            case _ =>
              throw new SparkException("Failed to get block " + blockId + ", which is not a shuffle block")
          }
        }
      }
    }
    // 從blockManager獲取reduce所需要的全部block,並新增校驗函式
    val blockFetcherItr = blockManager.getMultiple(blocksByAddress, serializer)
    val itr = blockFetcherItr.flatMap(unpackBlock)
    
&emsp;&emsp;val completionIter = CompletionIterator[T, Iterator[T]](itr, {
      // CompelteIterator迭代結束之後,會執行以下這部分程式碼,提交它記錄的各種引數
      val shuffleMetrics = new ShuffleReadMetrics
      shuffleMetrics.shuffleFinishTime = System.currentTimeMillis
      shuffleMetrics.fetchWaitTime = blockFetcherItr.fetchWaitTime
      shuffleMetrics.remoteBytesRead = blockFetcherItr.remoteBytesRead
      shuffleMetrics.totalBlocksFetched = blockFetcherItr.totalBlocks
      shuffleMetrics.localBlocksFetched = blockFetcherItr.numLocalBlocks
      shuffleMetrics.remoteBlocksFetched = blockFetcherItr.numRemoteBlocks
      context.taskMetrics.shuffleReadMetrics = Some(shuffleMetrics)
    })

    new InterruptibleIterator[T](context, completionIter)
  }
}
複製程式碼

1、MapOutputTrackerWorker 向 MapOutputTrackerMaster 獲取 shuffle 相關的 map 結果資訊。

2、把 map 結果資訊構造成 BlockManagerId --> Array(BlockId, size) 的對映關係。

3、通過 BlockManager 的 getMultiple 批量拉取 block。

4、返回一個可遍歷的 Iterator 介面,並更新相關的監控引數。

我們繼續看 getMultiple 方法。

  def getMultiple(
      blocksByAddress: Seq[(BlockManagerId, Seq[(BlockId, Long)])],
      serializer: Serializer): BlockFetcherIterator = {
    val iter =
      if (conf.getBoolean("spark.shuffle.use.netty", false)) {
        new BlockFetcherIterator.NettyBlockFetcherIterator(this, blocksByAddress, serializer)
      } else {
        new BlockFetcherIterator.BasicBlockFetcherIterator(this, blocksByAddress, serializer)
      }

    iter.initialize()
    iter
  }
複製程式碼

分兩種情況處理,分別是 netty 的和 Basic 的,Basic 的就不講了,就是通過 ConnectionManager 去指定的 BlockManager 那裡獲取資料,上一章剛好說了。

我們講一下 Netty 的吧,這個是需要設定的才能啟用的,不知道效能會不會好一些呢?

看 NettyBlockFetcherIterator 的 initialize 方法,再看 BasicBlockFetcherIterator 的 initialize 方法,發現 Basic 的不能同時抓取超過 48Mb 的資料。

    override def initialize() {
      // 分開本地請求和遠端請求,返回遠端的FetchRequest
      val remoteRequests = splitLocalRemoteBlocks()
      // 抓取順序隨機
      for (request <- Utils.randomize(remoteRequests)) {
        fetchRequestsSync.put(request)
      }
      // 預設是開6個執行緒去進行抓取
      copiers = startCopiers(conf.getInt("spark.shuffle.copier.threads", 6))// 讀取本地的block
      getLocalBlocks()
   }
複製程式碼

在 NettyBlockFetcherIterator 的 sendRequest 方法裡面,發現它是通過 ShuffleCopier 來試下的。

&emsp;&emsp;val cpier = new ShuffleCopier(blockManager.conf)
   cpier.getBlocks(cmId, req.blocks, putResult)
複製程式碼

這塊接下來就是 netty 的客戶端呼叫的方法了,我對這個不瞭解。在服務端的處理是在 DiskBlockManager 內部啟動了一個 ShuffleSender 的服務,最終的業務處理邏輯是在 FileServerHandler。

它是通過 getBlockLocation 返回一個 FileSegment,下面這段程式碼是 ShuffleBlockManager 的 getBlockLocation 方法。

  def getBlockLocation(id: ShuffleBlockId): FileSegment = {
    // Search all file groups associated with this shuffle.
    val shuffleState = shuffleStates(id.shuffleId)
    for (fileGroup <- shuffleState.allFileGroups) {
      val segment = fileGroup.getFileSegmentFor(id.mapId, id.reduceId)
      if (segment.isDefined) { return segment.get }
    }
    throw new IllegalStateException("Failed to find shuffle block: " + id)
  }
複製程式碼

先通過 shuffleId 找到 ShuffleState,再通過 reduceId 找到檔案,最後通過 mapId 確定它的檔案分片的位置。但是這裡有個疑問了,如果啟用了 consolidateFiles,一個 reduce 的所需資料都在一個檔案裡,是不是就可以把整個檔案一起返回呢,而不是通過 N 個 map 來多次讀取?還是害怕一次傳送一個大檔案容易失敗?這就不得而知了。

到這裡整個過程就講完了。可以看得出來 Shuffle 這塊還是做了一些優化的,但是這些引數並沒有啟用,有需要的朋友可以自己啟用一下試試效果。

參考文獻

Shuffle

相關文章