spark-streaming状态流之mapWithState

背景

刚接触spark-streaming,然后写了一个WordCount程序,对于不停流进来的数据,需要累加单词出现的次数,这时就需要把前一段时间的结果持久化,而不是数据计算过后就抛弃,在网上搜索到spark-streaming可以通过updateStateByKey mapWithState来实现这种有状态的流管理,后者虽然在spark1.6.x还是一个实验性的实现,不过由于它的实现思想以及性能都不错,所以简单通过阅读一下源码了解一下原理(其实太深入也不定看得懂~~).网上也有一些文章对比分析两种实现方式,不过始终觉得自己动手写写画画,按照自己的思路可能更有利于加深理解。

有状态的流,在WordCount这个例子中,状态(State)就是表示某个单词(Word)在这些流过的数据里面出现过的次数(Count),就像无状态的http一样通过Cookie或者Session来维持交互的状态,而流也一样,通过mapWithState实现了有状态的流。

工作流程

个人理解,mapWithState实现有状态管理主要是通过两点:a)历史状态需要在内存中维护,这里必需的了,updateStateBykey也是一样。b)自定义更新状态的mappingFunction,这些就是具体的业务功能实现逻辑了(什么时候需要更新状态)

[外链图片转存失败,源站可能有防盗链机制,建议将图片保存下来直接上传(img-43vbcLsp-1658739700091)(https://img-blog.csdn.net/20170124100554722?watermark/2/text/aHR0cDovL2Jsb2cuY3Nkbi5uZXQvY3ptYWNk/font/5a6L5L2T/fontsize/400/fill/I0JBQkFCMA==/dissolve/70/gravity/SouthEast)]

简单地画了一下mapWithState的工作过程,首先数据像水流一样从左侧的箭头流入,把mapWithState看成一个转换器的话,mappingFunc就是转换的规则,流入的新数据(key-value)结合历史状态(通过key从内存中获取的历史状态)进行一些自定义逻辑的更新等操作,最终从红色箭头中流出。

类及关系

主要涉及的类并不是很多,不过对scala不熟还是花了不少时间去看,一些具体的计算逻辑在:MapWithStateStreamImpl,InternalMapWithStateStream,MapWithStateRDD,MapWithStateRDDRecord.整个图可以从上至下看,从调用mapWithState到底层的存储,或者说从DStream->MapWithStateRDD(RDD[MapWithStateRDDRecord])->MapWithStateRDDRecord->Map这种有层次关系的结构,结合下面相应的源码片断会更容易理解。

[外链图片转存失败,源站可能有防盗链机制,建议将图片保存下来直接上传(img-1T64CqtN-1658739700092)(https://img-blog.csdn.net/20170124100610317?watermark/2/text/aHR0cDovL2Jsb2cuY3Nkbi5uZXQvY3ptYWNk/font/5a6L5L2T/fontsize/400/fill/I0JBQkFCMA==/dissolve/70/gravity/SouthEast)]

源码分析

以WordCount例子为切入点,这个例子是从kafka接收数据的,为了方便测试的话直接在sock获取数据即可:

val sparkConf = new SparkConf().setAppName("WordCount").setMaster("local")
    val ssc = new StreamingContext(sparkConf, Seconds(10))
    ssc.checkpoint("d:\\tmp")
    val params = Map("bootstrap.servers" -> "master:9092", "group.id" -> "scala-stream-group")
    val topic = Set("test")
    val initialRDD = ssc.sparkContext.parallelize(List[(String, Int)]())
    val messages = KafkaUtils.createDirectStream[String, String, StringDecoder, StringDecoder](ssc, params, topic)
    val word = messages.flatMap(_._2.split(" ")).map { x => (x, 1) }
    //自定义mappingFunction,累加单词出现的次数并更新状态
    val mappingFunc = (word: String, count: Option[Int], state: State[Int]) => {
      val sum = count.getOrElse(0) + state.getOption.getOrElse(0)
      val output = (word, sum)
      state.update(sum)
      output
    }
    //调用mapWithState进行管理流数据的状态
    val stateDstream = word.mapWithState(StateSpec.function(mappingFunc).initialState(initialRDD)).print()
    ssc.start()
    ssc.awaitTermination()

进入mapWithState,发现这是PairDStreamFunctions的方法,由于在DStream伴生对象中定义了隐式转换函数toPairDStreamFunctions,使得将DStream类型隐式转换成了PairDStreamFunctions类型,从而可以使用mapWithState方法:

 implicit def toPairDStreamFunctions[K, V](stream: DStream[(K, V)])
      (implicit kt: ClassTag[K], vt: ClassTag[V], ord: Ordering[K] = null):
    PairDStreamFunctions[K, V] = {
    new PairDStreamFunctions[K, V](stream)
  }

看一下PairDStreamFunctions.mapWithState()方法:

@Experimental
  def mapWithState[StateType: ClassTag, MappedType: ClassTag](
      spec: StateSpec[K, V, StateType, MappedType]
    ): MapWithStateDStream[K, V, StateType, MappedType] = {
    new MapWithStateDStreamImpl[K, V, StateType, MappedType](
      self,   #这是本批次DStream对象
      spec.asInstanceOf[StateSpecImpl[K, V, StateType, MappedType]]
    )
  }

mapWithState在spark1.6.x还处于试验阶段(@Experimental),通过StateSpec包装了mappingFunction函数(还可以设置状态的超时时间、初始化的状态数据等),然后将StateSpec作为参数传给mapWithState。mappingFunction函数将会被应用于本批次流数据的所有记录(key-value),并与对应key(唯一)的历史状态(通过key获取的State对象)进行相应的逻辑运算(就是mappingFunction的函数体)。

mapWithState中以本批次DStream对象和StateSpecImpl(它是StateSpec的子类)的实例对象作为参数构造出MapWithStateDStreamImpl(MapWithStateDStream的子类)。从名称就可以看出它是代表着一个有状态的流,看一下它的一个属性和一个方法:

private val internalStream =
    new InternalMapWithStateDStream[KeyType, ValueType, StateType, MappedType](dataStream, spec)
......

# 这个方法只是把需要返回的数据进行一下转换,主要的逻辑在internalStream的computer里面
override def compute(validTime: Time): Option[RDD[MappedType]] = {
    internalStream.getOrCompute(validTime).map { _.flatMap[MappedType] { _.mappedData } }
  }

MapWithStateDStreamImpl中没有什么逻辑处理,在computer中调用了internalStream.getOrCompute,这个其实是父类DStream的方法,然后在DStream.getOrCompute又回调了子类InternalMapWithStateDStream.compute,那么看下这个方法的内容:

InternalMapWithStateDStream: line 132

/** Method that generates a RDD for the given time */
  override def compute(validTime: Time): Option[RDD[MapWithStateRDDRecord[K, S, E]]] = {
    // 计算上一个状态的RDD
    val prevStateRDD = getOrCompute(validTime - slideDuration) match {
      case Some(rdd) =>  
      // 这个rdd是RDD[MapWithStateRDDRecord[K, S, E]]类型,其实就是一个MapWithStateRDD
        if (rdd.partitioner != Some(partitioner)) {
          // If the RDD is not partitioned the right way, let us repartition it using the
          // partition index as the key. This is to ensure that state RDD is always partitioned
          // before creating another state RDD using it
          // _.stateMap.getAll()就是获取了所有的状态数据(往会下看会明白),在此基础创建MapWithStateRDD
          MapWithStateRDD.createFromRDD[K, V, S, E](
            rdd.flatMap { _.stateMap.getAll() }, partitioner, validTime)
        } else {
          rdd
        }
      case None =>
        // 首批数据流入时会进入该分支
        MapWithStateRDD.createFromPairRDD[K, V, S, E](
          spec.getInitialStateRDD().getOrElse(new EmptyRDD[(K, S)](ssc.sparkContext)),
          partitioner,
          validTime
        )
    }
// 本批次流数据构成的RDD:dataRDD
  val dataRDD = parent.getOrCompute(validTime).getOrElse {
      context.sparkContext.emptyRDD[(K, V)]
    }
    val partitionedDataRDD = dataRDD.partitionBy(partitioner) // 重新分区
    val timeoutThresholdTime = spec.getTimeoutInterval().map { interval =>
      (validTime - interval).milliseconds
    }
    // 构造MapWithStateRDD
    Some(new MapWithStateRDD(
      prevStateRDD, partitionedDataRDD, mappingFunction, validTime, timeoutThresholdTime))
    }
}

compute方法是通过时间来生成MapWithStateRDD的,首先获取到前一个状态的prevStateRDD(validTime - 一次batch时间):

  • 如果可以得到结果MapWithStateRDD
    • 判断该RDD是否已经正确分区,后面的计算是分别每个分区对应的旧状态与新流入的数据进行计算的,如果两者的分区不一致,会导致计算出错(即会更新到错误的状态)。如果正确分区了,那么直接返回RDD,否则通过MapWithStateRDD.createFromRDD指定partitioner对数据进行重新分区
  • 如果计算不可以得到结果MapWithStateRDD
    • 通过MapWithStateRDD.createFromPairRDD创建一个,如果在WordCount代码中有对StateSpec进行设置initialStateRDD初始值,那么将在initialStateRDD基础上创建MapWithStateRDD,否则创建一个空的MapWithStateRDD,注意,这里使用的是同一个partitioner以保证具有相同的分区

然后再从DStream中获取本次batch数据的dataRDD(validTime),如果没有,则重建一个空的RDD,然后将该RDD重新分区,使得与上面的MapWithStateRDD具有相同的分区。

最后就是构造MapWithStateRDD对象:

new MapWithStateRDD(
      prevStateRDD, partitionedDataRDD, mappingFunction, validTime, timeoutThresholdTime)

上面WordCount例子中的mappingFunc函数就是这里的mappingFunction,而参数word与count来自partitionedDataRDD中的数据,参数state来自prevStateRDD中的数据,基本已经符合上文中第一张图了。

MapWithStateRDD包含了前一个状态数据(preStateRDD)以及本次需要进行更新的流数据(dataRDD),再看看它的compute过程:

override def compute(
      partition: Partition, context: TaskContext): Iterator[MapWithStateRDDRecord[K, S, E]] = {

    val stateRDDPartition = partition.asInstanceOf[MapWithStateRDDPartition]
    val prevStateRDDIterator = prevStateRDD.iterator(
      stateRDDPartition.previousSessionRDDPartition, context)
    val dataIterator = partitionedDataRDD.iterator(
      stateRDDPartition.partitionedDataRDDPartition, context)
# prevRecord代表prevStateRDD一个分区的数据
    val prevRecord = if (prevStateRDDIterator.hasNext) Some(prevStateRDDIterator.next()) else None
    val newRecord = MapWithStateRDDRecord.updateRecordWithData(
      prevRecord,
      dataIterator,
      mappingFunction,
      batchTime,
      timeoutThresholdTime,
      removeTimedoutData = doFullScan // remove timedout data only when full scan is enabled
    )
    Iterator(newRecord)
  }

这个方法把前一个状态的RDD以及本batch的RDD交给MapWithStateRDDRecord.updateRecordWithData进行计算,看下面的代码片段,这里有一个不明白的地方:为什么只获取了prevStateRDD的第一个分区数据(preRecord),有人明白的求解答。

 def updateRecordWithData[K: ClassTag, V: ClassTag, S: ClassTag, E: ClassTag](
    prevRecord: Option[MapWithStateRDDRecord[K, S, E]],
    dataIterator: Iterator[(K, V)],
    mappingFunction: (Time, K, Option[V], State[S]) => Option[E],
    batchTime: Time,
    timeoutThresholdTime: Option[Long],
    removeTimedoutData: Boolean
  ): MapWithStateRDDRecord[K, S, E] = {
    // 从prevRecord中拷贝历史的状态数据(保存在MapWithStateRDDRecord的stateMap属性中)
    val newStateMap = prevRecord.map { _.stateMap.copy() }. getOrElse { new EmptyStateMap[K, S]() }

    // 保存需要返回的数据
    val mappedData = new ArrayBuffer[E]
    val wrappedState = new StateImpl[S]()  // State子类,代表一个状态

    // 循环本batch的所有记录(key-value)
    dataIterator.foreach { case (key, value) =>
    // 根据key从历史状态数据中获取该key对应的历史状态
      wrappedState.wrap(newStateMap.get(key))  
    // 将mappingFunction应用到本次batch的每条记录 
      val returned = mappingFunction(batchTime, key, Some(value), wrappedState)
      if (wrappedState.isRemoved) {
        newStateMap.remove(key)
      } else if (wrappedState.isUpdated
          || (wrappedState.exists && timeoutThresholdTime.isDefined)) {
        newStateMap.put(key, wrappedState.get(), batchTime.milliseconds)
      }
      mappedData ++= returned
    } // 判断是否删除、更新等然后维护newStateMap里的状态,并记录返回数据mappedData

    // 如果有配置超时,也会进行一些更新操作
    if (removeTimedoutData && timeoutThresholdTime.isDefined) {
      newStateMap.getByTime(timeoutThresholdTime.get).foreach { case (key, state, _) =>
        wrappedState.wrapTimingOutState(state)
        val returned = mappingFunction(batchTime, key, None, wrappedState)
        mappedData ++= returned
        newStateMap.remove(key)
      }
    }
    // 依然是返回一个MapWithStateRDDRecord,只是里面的数据变了
    MapWithStateRDDRecord(newStateMap, mappedData)
  }

在这里面,循环本batch的数据,通过key获取到对应的状态并应用mappingFunction函数到每条记录,在WordCount例子中,假如某条记录key=“hello”,先获取它的状态(假如它的上一个状态是3,即出现过了3次):

# word="hello",value=1,state=("hello",3)
val mappingFunc = (word: String, value: Option[Int], state: State[Int]) => {
      val sum = value.getOrElse(0) + state.getOption.getOrElse(0) #sum=4
      val output = (word, sum) #("hello",4)
      state.update(sum)  #更新key="hello"的状态为4
      output  # 返回("hello",4)
    }

MapWithStateRDD代表着数据状态能够更新的RDD,但RDD本身是不可变的,MapWithStateRDD的元素是MapWithStateRDDRecord,而MapWithStateRDDRecord主要由stateMap:StateMap(保存着历史的状态)以及mappedData:Seq(保存返回,即流出的数据)这两个属性构成,当进行mapWithState转换时,根据上文的源码分析可知,其实就是对这两个数据结构进行操作,最终变化的只是这两个属性的数据,而MapWithStateRDD的元素依然是MapWithStateRDDRecord。

StateMap的内部是了个OpenHashMapBasedStateMap,当调用create方法时会创建一个对象:

/** Companion object for [[StateMap]], with utility methods */
private[streaming] object StateMap {
  def empty[K, S]: StateMap[K, S] = new EmptyStateMap[K, S]

  def create[K: ClassTag, S: ClassTag](conf: SparkConf): StateMap[K, S] = {
    val deltaChainThreshold = conf.getInt("spark.streaming.sessionByKey.deltaChainThreshold",
      DELTA_CHAIN_LENGTH_THRESHOLD)
    new OpenHashMapBasedStateMap[K, S](deltaChainThreshold)
  }
}

而OpenHashMapBasedStateMap又是基于spark的一个数据结构org.apache.spark.util.collection.OpenHashMap,至于再底层的实现有兴趣再看,就不再往下分析了。本文主要是围绕主线展开,还有很多分支的细节是需要去了解清楚,这样更能加深理解。

参考

http://www.jianshu.com/p/1463bc1d81b5

http://www.cnblogs.com/DT-Spark/articles/5616560.html

https://my.oschina.net/corleone/blog/684215

https://spark.apache.org/docs/1.6.1/api/scala/index.html

  • 13
    点赞
  • 20
    收藏
    觉得还不错? 一键收藏
  • 12
    评论

“相关推荐”对你有帮助么?

  • 非常没帮助
  • 没帮助
  • 一般
  • 有帮助
  • 非常有帮助
提交
评论 12
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值