当前位置: 首页 > news >正文

防水网站怎么做wordpress工作室主题下载

防水网站怎么做,wordpress工作室主题下载,wordpress自定义文章类型面包屑,网页排版设计模板本文主要讲 1、什么是RDD 2、RDD是如何从数据中构建 一、什么是RDD#xff1f; RDD#xff1a;弹性分布式数据集#xff0c;Resillient Distributed Dataset的缩写。 个人理解#xff1a;RDD是一个容错的、并行的数据结构#xff0c;可以让用户显式的将数据存储到磁盘…本文主要讲 1、什么是RDD 2、RDD是如何从数据中构建 一、什么是RDD RDD弹性分布式数据集Resillient Distributed Dataset的缩写。 个人理解RDD是一个容错的、并行的数据结构可以让用户显式的将数据存储到磁盘和内存中并能控制数据的分区。同时RDD还提供一组丰富的API来操作它。本质上RDD是一个只读的分区集合一个RDD可以包含多个分区每个分区就是一个dataset片段。RDD可以互相依赖 二、RDD是如何从数据中构建 2.1、RDD源码 Internally, each RDD is characterized by five main properties A list of pattitions A function for computing each split A list of dependencies on each RDDs optionally a partitioner for key-value RDDse.g. to say that RDD is hash-partitioned optionally, a list of preferred locations to compute each split on e.g. block locations for an HDFS file RDD基本都有这5个特性 1、每个RDD 都会有 一个分片列表。 就是可以被切分和hadoop一样能够被切分的数据才能并行计算 2、有一个函数计算每一个分片。这里是指下面会提到的compute函数 3、对其他RDD的依赖列表。依赖区分宽依赖和窄依赖 4、可选key-value类型的RDD是根据hash来分区的类似于mapreduce当中的partitioner接口控制哪个key分到哪个reduce 5、可选每一个分片的有效计算位置preferred locations比如HDFS的block的所在位置应该是优先计算的位置 2.2、宽窄依赖 如果一个RDD的每个分区最多只能被一个Child RDD的一个分区所使用 则称之为窄依赖Narrow dependency 如果被多个Child RDD分区依赖 则称之为宽依赖wide dependency 例如 map、filter是窄依赖 而join、groupby是宽依赖 2.3、源码分析 RDD的5个特征会对应到源码中的 4个方法 和一个属性 RDD.scala是一个总的抽象不同的子类会对下面的方法进行定制化的实现。比如compute方法不同子类在实现的时候是不同的。 // 该方法只会被调用一次。由子类实现返回这个RDD下的所有Partition protected def getPartitions: Array[Partition] ​ // 该方法只会被调用一次。计算该RDD和父RDD的关系 protected def getDenpendencies: Seq[Dependency[_]] deps ​ //对分区进行计算返回一个可遍历的结果 def compute(split: Partition, context: TaskContext): Iterator[T] ​ //可选的指定优先位置输入参数是split分片输出结果是一组优先的节点位置 protected def getPreferredLocations(split: Partition): Seq(String) Nil ​ // 可选的分区的方法针对第4点控制分区的计算规则 transient val partitioner: Option[Partitioner] None ​ 拿官网上的workcount举例 val textFile sc.textFile(文件目录/test.txt) val counts textFile.flatMap(line line.split( )).filter(_.length 2).map(word (word, 1)).reduceByKey(_ _) counts.saveAsTextFile(hdfs://...) 这里涉及到几个RDD的转换 1、textfile是一个hadoopRDD经过map转换后的MapPartitionsRDD 2、经过flatMap后仍然是一个MapPartitionsRDD 3、经过filter方法之后生成了一个新的MapPartitionRDD 4、经过map函数之后继续是一个MapPartitionsRDD 5、经过最后一个reduceByKey编程了ShuffleRDD 文件分为一个part1part2part3经过spark读取之后就变成了HadoopRDD再按上面流程理解即可 2.3.1、代码分析SparkContext 类 本次只看textfile方法注释上说明 Read a text file from HDFS, a local file system (available on all nodes), or any Hadoop-supported file system URI, and return it as an RDD of Strings. ​ 读取text文本从hdfs上、本地文件系统或者hadoop支持的文件系统URI中 返回一个String类型的RDD 看代码 hadoopFile最后返回的是一个HadoopRDD对象然后经过map变换后转换成MapPartitionsRDD鱿鱼HadoopRDD没有重写map函数所以调用的是父类的RDD的map def textFile(path: String,minPartitions: Int defaultMinPartitions): RDD[String] withScope {assertNotStopped() // 忽略不看hadoopFile(path, classOf[TextInputFormat], classOf[LongWritable], classOf[Text], minPartitions).map(pair pair._2.toString).setName(path)} 看下hadoopFile方法 1、广播hadoop的配置文件 2、设置文件的输入格式之类的也决定的文件的读取方式 3、new HadoopRDD并返回 def hadoopFile[K, V](path: String,inputFormatClass: Class[_ : InputFormat[K, V]],keyClass: Class[K],valueClass: Class[V],minPartitions: Int defaultMinPartitions): RDD[(K, V)] withScope {assertNotStopped() ​// 做一些校验FileSystem.getLocal(hadoopConfiguration) ​// A Hadoop configuration can be about 10 KiB, which is pretty big, so broadcast it.val confBroadcast broadcast(new SerializableConfiguration(hadoopConfiguration))val setInputPathsFunc (jobConf: JobConf) FileInputFormat.setInputPaths(jobConf, path)new HadoopRDD(this,confBroadcast,Some(setInputPathsFunc),inputFormatClass,keyClass,valueClass,minPartitions).setName(path)} 2.3.2、源码分析HadoopRDD类 先看注释 An RDD that provides core functionality for reading data stored in Hadoop (e.g., files in HDFS, sources in HBase, or S3), using the older MapReduce API (org.apache.hadoop.mapred). 看注释可以知道HadoopRDD是一个专为HadoopHDFS、Hbase、S3设计的RDD。使用的是以前的MapReduce 的API来读取的。 HadoopRDD extends RDD[(K, V)] 重写了RDD中的三个方法 override def compute(theSplit: Partition, context: TaskContext): InterruptibleIterator[(K, V)] {} ​ override def getPartitions: Array[Partition] {} ​ override def getPreferredLocations(split: Partition): Seq[String] {} 分别来看一下 HadoopRDD#getPartitions 1、读取配置文件 2、通过inputFormat自带的getSplits方法来计算分片获取所有的Splits 3、创建HadoopPartition的List并返回 这里是不是可以理解Hadoop中的一个分片就对应到Spark中的一个Partition override def getPartitions: Array[Partition] {val jobConf getJobConf()// add the credentials here as this can be called before SparkContext initializedSparkHadoopUtil.get.addCredentials(jobConf)try {// 通过配置的文件读取方式获取所有的Splitsval allInputSplits getInputFormat(jobConf).getSplits(jobConf, minPartitions)val inputSplits if (ignoreEmptySplits) {allInputSplits.filter(_.getLength 0)} else {allInputSplits}// 创建Partition的Listval array new Array[Partition](inputSplits.size)for (i - 0 until inputSplits.size) {// 创建HadoopPartitionarray(i) new HadoopPartition(id, i, inputSplits(i))}array} catch {异常处理} } HadoopRDD#compute compute的作用主要是 根据输入的partition信息生成一个InterruptibleIterator。 iter中的逻辑主要是 1、把Partition转成HadoopPartition通过InputSplit创建一个RecordReader 2、重写Iterator的getNext方法通过创建的reader调用next方法读取下一个值 compute方法通过Partition来获取Iterator接口以遍历Partition的数据 override def compute(theSplit: Partition, context: TaskContext): InterruptibleIterator[(K, V)] {val iter new NextIterator[(K, V)] {...}new InterruptibleIterator[(K, V)](context, iter)}override def compute(theSplit: Partition, context: TaskContext): InterruptibleIterator[(K, V)] { ​val iter new NextIterator[(K, V)] { ​//将compute的输入theSplit转换为HadoopPartitionval split theSplit.asInstanceOf[HadoopPartition]......//c重写getNext方法override def getNext(): (K, V) {try {finished !reader.next(key, value)} catch {case _: EOFException if ignoreCorruptFiles finished true}if (!finished) {inputMetrics.incRecordsRead(1)}(key, value)}} } HadoopRDD#getPreferredLocations getPreferredLocations方法比较简单直接调用SplitInfoReflections下的inputSplitWithLocationInfo方法获得所在的位置。 override def getPreferredLocations(split: Partition): Seq[String] {val hsplit split.asInstanceOf[HadoopPartition].inputSplit.valueval locs: Option[Seq[String]] HadoopRDD.SPLIT_INFO_REFLECTIONS match {case Some(c) try {val lsplit c.inputSplitWithLocationInfo.cast(hsplit)val infos c.getLocationInfo.invoke(lsplit).asInstanceOf[Array[AnyRef]]Some(HadoopRDD.convertSplitLocationInfo(infos))} catch {case e: Exception logDebug(Failed to use InputSplitWithLocations., e)None}case None None}locs.getOrElse(hsplit.getLocations.filter(_ ! localhost)) } 2.3.3、源码分析MapHadoopRDD类 An RDD that applies the provided function to every partition of the parent RDD. 经过RDD提供的function处理后的 父RDD 将会变成MapHadoopRDD MapHadoopRDD重写了父类的partitioner、getPartitions和compute方法 private[spark] class MapPartitionsRDD[U: ClassTag, T: ClassTag](var prev: RDD[T],f: (TaskContext, Int, Iterator[T]) Iterator[U], // (TaskContext, partition index, iterator)preservesPartitioning: Boolean false)extends RDD[U](prev) {override val partitioner if (preservesPartitioning) firstParent[T].partitioner else Noneoverride def getPartitions: Array[Partition] firstParent[T].partitionsoverride def compute(split: Partition, context: TaskContext): Iterator[U] f(context, split.index, firstParent[T].iterator(split, context))override def clearDependencies() {super.clearDependencies()prev null} } 在partitioner、getPartitions、compute中都用到了一个firstParent函数可以看到在MapPartition中并没有重写partitioner和getPartitions方法只是从firstParent中取了出来 再看下firstParent是干什么的其实就是取的父依赖 /** Returns the first parent RDD */ protected[spark] def firstParent[U: ClassTag]: RDD[U] {dependencies.head.rdd.asInstanceOf[RDD[U]] } 再看一下MapPartitionsRDD继承的RDD它继承的是RDD[U] (prev)这里的prev指的是我们的HadoopRDD也就是说HadoopRDD变成了我们这个MapPartitionRDD的OneToOneDependency依赖OneToOneDependency是窄依赖 def this(transient oneParent: RDD[_]) this(oneParent.context , List(new OneToOneDependency(oneParent))) 再来看map方法 /*** Return a new RDD by applying a function to all elements of this RDD.* 通过将函数应用于新RDD的所有元素返回新的RDD。*/ def map[U: ClassTag](f: T U): RDD[U] withScope {val cleanF sc.clean(f)new MapPartitionsRDD[U, T](this, (context, pid, iter) iter.map(cleanF)) } flatMap方法 /*** Return a new RDD by first applying a function to all elements of this* RDD, and then flattening the results.*/ def flatMap[U: ClassTag](f: T TraversableOnce[U]): RDD[U] withScope {val cleanF sc.clean(f)new MapPartitionsRDD[U, T](this, (context, pid, iter) iter.flatMap(cleanF)) } filter方法 /*** Return a new RDD containing only the elements that satisfy a predicate.* 返回仅包含满足表达式 的元素的新RDD。*/def filter(f: T Boolean): RDD[T] withScope {val cleanF sc.clean(f)new MapPartitionsRDD[T, T](this,(context, pid, iter) iter.filter(cleanF),preservesPartitioning true)} 观察代码发现他们返回的都是MapPartitionsRDD对象不同的仅仅是传入的function不同而已经过前面的分析这些都是窄依赖 注意这里我们可以明白了MapPartitionsRDD的compute方法的作用了 1、在没有依赖的条件下根据分片的信息生成遍历数据的iterable接口 2、在有前置依赖的条件下在父RDD的iterable接口上给遍历每个元素的时候再套上一个方法 2.3.4、源码分析PairRDDFunctions 类 接下来该reduceByKey操作了。它在PairRDDFunctions里面 reduceByKey稍微复杂一点因为这里有一个同相同key的内容聚合的一个过程它调用的是combineByKey方法。 /*** Merge the values for each key using an associative reduce function. This will also perform* the merging locally on each mapper before sending results to a reducer, similarly to a* combiner in MapReduce.*/def reduceByKey(partitioner: Partitioner, func: (V, V) V): RDD[(K, V)] self.withScope {combineByKeyWithClassTag[V]((v: V) v, func, func, partitioner)} ​/*** Generic function to combine the elements for each key using a custom set of aggregation泛型函数将每个key的元素 通过自定义的聚合 来组合到一起* functions. Turns an RDD[(K, V)] into a result of type RDD[(K, C)], for a combined type C** Users provide three functions:** - createCombiner, which turns a V into a C (e.g., creates a one-element list)* - mergeValue, to merge a V into a C (e.g., adds it to the end of a list)* - mergeCombiners, to combine two Cs into a single one.** In addition, users can control the partitioning of the output RDD, and whether to perform* map-side aggregation (if a mapper can produce multiple items with the same key).** note V and C can be different -- for example, one might group an RDD of type* (Int, Int) into an RDD of type (Int, Seq[Int]).*/def combineByKeyWithClassTag[C](createCombiner: V C,mergeValue: (C, V) C,mergeCombiners: (C, C) C,partitioner: Partitioner,mapSideCombine: Boolean true,serializer: Serializer null)(implicit ct: ClassTag[C]): RDD[(K, C)] self.withScope {require(mergeCombiners ! null, mergeCombiners must be defined) // required as of Spark 0.9.0// 判断keyclass是不是array类型如果是array并且在两种情况下throw exception。if (keyClass.isArray) {if (mapSideCombine) {throw SparkCoreErrors.cannotUseMapSideCombiningWithArrayKeyError()}if (partitioner.isInstanceOf[HashPartitioner]) {throw SparkCoreErrors.hashPartitionerCannotPartitionArrayKeyError()}}val aggregator new Aggregator[K, V, C](self.context.clean(createCombiner),self.context.clean(mergeValue),self.context.clean(mergeCombiners))//虽然不太明白但是此处基本上一直是false感兴趣的看后面的参考文章if (self.partitioner Some(partitioner)) {self.mapPartitions(iter {val context TaskContext.get()new InterruptibleIterator(context, aggregator.combineValuesByKey(iter, context))}, preservesPartitioning true)} else {// 默认走这个方法new ShuffledRDD[K, V, C](self, partitioner).setSerializer(serializer).setAggregator(aggregator).setMapSideCombine(mapSideCombine)}} 2.3.5、源码分析ShuffledRDD类 看上面代码最后传入了self和partitioner 并set了三个值shuffled过程暂时不做解析。这里看下ShuffledRDD的依赖关系getDependencies方法它是一个宽依赖 override def getDependencies: Seq[Dependency[_]] {val serializer userSpecifiedSerializer.getOrElse {val serializerManager SparkEnv.get.serializerManagerif (mapSideCombine) {serializerManager.getSerializer(implicitly[ClassTag[K]], implicitly[ClassTag[C]])} else {serializerManager.getSerializer(implicitly[ClassTag[K]], implicitly[ClassTag[V]])}}List(new ShuffleDependency(prev, part, serializer, keyOrdering, aggregator, mapSideCombine))} 总结我们讲了RDD的基本组成结构也通过一个wordcount程序举例来说明代码是如果运行的希望大家可以从源码入手学习spark共勉
http://www.zqtcl.cn/news/464686/

相关文章:

  • 武宁网站ui专业设计wordpress评论通知代码6
  • thymeleaf做网站 seo重庆平台网站建设找哪家
  • WordPress子站站群建筑工程网上申请质量安全监督
  • 怎么给网站添加图标山西手机版建站系统哪家好
  • frontpage网页制作视频教程昆明网站建设优化企业
  • 工信部 诚信网站备案公司网络营销方案
  • 网站开发采集工具如何做网站内链优化
  • 在线做英语题的网站揭阳建站服务
  • 网站非法篡改wordpress的知名网站
  • 保定网建站模板uv推广平台
  • 股权分配系统建设网站wordpress mip 模板
  • 网站及其建设的心得体会昆明云南微网站
  • 详情页在线设计网站推荐广州建设网站企业
  • 设计师网站建设哪家网络公司做网站
  • 宣城网站开发专业制注册资金写100万后悔
  • 专业的高密做网站的建公司网站要多久
  • 蚌埠做网站哪家好WordPress强制ssl
  • 1m宽带做网站平台建站
  • 学习做ppt 的网站班会活动设计方案模板
  • 廊坊住房和城乡建设厅网站门户网站开发招标
  • 免费下载网站设计方案wordpress zenmeyong
  • 网站建设与维护相关知识网站建设遵循的规范
  • 网站建设费科目东莞市塘厦镇
  • 网站建设策划书1万字深圳公司网站设计企业
  • 建设企业网站小微asp iis设置网站路径
  • 分类信息网站营销小程序appid是什么
  • 营销软文是什么意思网络seo培训
  • 效果好的手机网站建设成都网站制作报价
  • 江门网站建设推广平台注册公司费用要多少
  • 淄博哪家公司做网站最好新手做地方门户网站