1 .MapReduce的运行机制详解

1.1:MapTask 工作机制

整个Map阶段流程大体如上图所示。

简单概述:inputFile通过split被逻辑切分为多个split文件,通过Record按行读取内容给map(用户自己实现的)进行处理,数据被map处理结束之后交给OutputCollector收集器,对其结果key进行分区(默认使用hash分区),然后写入buffer,每个map task都有一个内存缓冲区,存储着map的输出结果,当缓冲区快满的时候需要将缓冲区的数据以一个临时文件的方式存放到磁盘,当整个map task结束后再对磁盘中这个map task产生的所有临时文件做合并,生成最终的正式输出文件,然后等待reduce task来拉数据

详细步骤
  1. 读取数据组件 InputFormat (默认 TextInputFormat) 会通过 getSplits 方法对输入目录中文件进行逻辑切片规划得到 splits, 有多少个 splits就对应启动多少个 MapTask.

  2. 将输入文件切分为 block 之后, 由 RecordReader 对象 (默认是LineRecordReader) 进行读取, 以 \n 作为分隔符, 读取一行数据, 返回 <key,value>. Key 表示每行首字符偏移值, Value 表示这一行文本内容

  3. 读取 split 返回 <key,value>, 进入用户自己继承的 Mapper 类中,执行用户重写的 map 函数, RecordReader 读取一行这里调用一次

  4. Mapper 逻辑结束之后, 将 Mapper 的每条结果通过 context.write 进行collect数据收集. 在 collect 中, 会先对其进行分区处理,默认使用 HashPartitioner

    • MapReduce 提供 Partitioner 接口, 它的作用就是根据 KeyValueReducer 的数量来决定当前的这对输出数据最终应该交由哪个 Reduce task 处理, 默认对 Key Hash 后再以 Reducer 数量取模. 默认的取模方式只是为了平均 Reducer 的处理能力, 如果用户自己对 Partitioner 有需求, 可以订制并设置到 Job 上

  5. 接下来, 会将数据写入内存, 内存中这片区域叫做环形缓冲区, 缓冲区的作用是批量收集 Mapper 结果, 减少磁盘 IO 的影响. 我们的 Key/Value 对以及 Partition 的结果都会被写入缓冲区. 当然, 写入之前,Key 与 Value 值都会被序列化成字节数组

    • 环形缓冲区其实是一个数组, 数组中存放着 Key, Value 的序列化数据和 Key, Value 的元数据信息, 包括 Partition, Key 的起始位置, Value 的起始位置以及 Value 的长度. 环形结构是一个抽象概念

    • 缓冲区是有大小限制, 默认是 100MB. 当 Mapper 的输出结果很多时, 就可能会撑爆内存, 所以需要在一定条件下将缓冲区中的数据临时写入磁盘, 然后重新利用这块缓冲区. 这个从内存往磁盘写数据的过程被称为 Spill, 中文可译为溢写. 这个溢写是由单独线程来完成, 不影响往缓冲区写 Mapper 结果的线程. 溢写线程启动时不应该阻止 Mapper 的结果输出, 所以整个缓冲区有个溢写的比例 spill.percent. 这个比例默认是 0.8, 也就是当缓冲区的数据已经达到阈值 buffer size * spill percent = 100MB * 0.8 = 80MB, 溢写线程启动, 锁定这 80MB 的内存, 执行溢写过程. Mapper 的输出结果还可以往剩下的 20MB 内存中写, 互不影响

  6. 当溢写线程启动后, 需要对这 80MB 空间内的 Key 做排序 (Sort)(使用的是快排). 排序是 MapReduce 模型默认的行为, 这里的排序也是对序列化的字节做的排序

    • 如果 Job 设置过 Combiner, 那么现在就是使用 Combiner 的时候了. 将有相同 Key 的 Key/Value 对的 Value 加起来, 减少溢写到磁盘的数据量. Combiner 会优化 MapReduce 的中间结果, 所以它在整个模型中会多次使用

    • 那哪些场景才能使用 Combiner 呢? 从这里分析, Combiner 的输出是 Reducer 的输入, Combiner 绝不能改变最终的计算结果. Combiner 只应该用于那种 Reduce 的输入 Key/Value 与输出 Key/Value 类型完全一致, 且不影响最终结果的场景. 比如累加, 最大值等. Combiner 的使用一定得慎重, 如果用好, 它对 Job 执行效率有帮助, 反之会影响 Reducer 的最终结果

  7. 合并溢写文件(合并之后,会再次排序,为归并排序), 每次溢写会在磁盘上生成一个临时文件 (写之前判断是否有 Combiner), 如果 Mapper 的输出结果真的很大, 有多次这样的溢写发生, 磁盘上相应的就会有多个临时文件存在. 当整个数据处理结束之后开始对磁盘中的临时文件进行 Merge 合并, 因为最终的文件只有一个, 写入磁盘, 并且为这个文件提供了一个索引文件, 以记录每个reduce对应数据的偏移量

配置
配置 默认值 解释
mapreduce.task.io.sort.mb 100 设置环型缓冲区的内存值大小
mapreduce.map.sort.spill.percent 0.8 设置溢写的比例
mapreduce.cluster.local.dir ${hadoop.tmp.dir}/mapred/local 溢写数据目录
mapreduce.task.io.sort.factor 10 设置一次合并多少个溢写文件

1.2 :ReduceTask 工作机制

Reduce 大致分为 copy、sort、reduce 三个阶段,重点在前两个阶段。copy 阶段包含一个 eventFetcher 来获取已完成的 map 列表,由 Fetcher 线程去 copy 数据,在此过程中会启动两个 merge 线程,分别为 inMemoryMerger 和 onDiskMerger,分别将内存中的数据 merge 到磁盘和将磁盘中的数据进行 merge。待数据 copy 完成之后,copy 阶段就完成了,开始进行 sort 阶段,sort 阶段主要是执行 finalMerge 操作,纯粹的 sort 阶段,完成之后就是 reduce 阶段,调用用户定义的 reduce 函数进行处理

详细步骤
  1. Copy阶段,简单地拉取数据。Reduce进程启动一些数据copy线程(Fetcher),通过HTTP方式请求maptask获取属于自己的文件。
  2. Merge阶段。这里的merge如map端的merge动作,只是数组中存放的是不同map端copy来的数值。Copy过来的数据会先放入内存缓冲区中,这里的缓冲区大小要比map端的更为灵活。merge有三种形式:内存到内存;内存到磁盘;磁盘到磁盘。默认情况下第一种形式不启用。当内存中的数据量到达一定阈值,就启动内存到磁盘的merge。与map 端类似,这也是溢写的过程,这个过程中如果你设置有Combiner,也是会启用的,然后在磁盘中生成了众多的溢写文件。第二种merge方式一直在运行,直到没有map端的数据时才结束,然后启动第三种磁盘到磁盘的merge方式生成最终的文件。
  3. 合并排序。把分散的数据合并成一个大的数据后,还会再对合并后的数据排序。
  4. 对排序后的键值对调用reduce方法,键相等的键值对调用一次reduce方法,每次调用会产生零个或者多个键值对,最后把这些输出的键值对写入到HDFS文件中。

1.3:Shuffle 过程

map 阶段处理的数据如何传递给 reduce 阶段,是 MapReduce 框架中最关键的一个流程,这个流程就叫 shuffle
shuffle: 洗牌、发牌 ——(核心机制:数据分区,排序,分组,规约,合并等过程)

shuffle 是 Mapreduce 的核心,它分布在 Mapreduce 的 map 阶段和 reduce 阶段。一般把从 Map 产生输出开始到 Reduce 取得数据作为输入之前的过程称作 shuffle。

  1. Collect阶段:将 MapTask 的结果输出到默认大小为 100M 的环形缓冲区,保存的是 key/value,Partition 分区信息等。
  2. Spill阶段:当内存中的数据量达到一定的阀值的时候,就会将数据写入本地磁盘,在将数据写入磁盘之前需要对数据进行一次排序的操作,如果配置了 combiner,还会将有相同分区号和 key 的数据进行排序。
  3. Merge阶段:把所有溢出的临时文件进行一次合并操作,以确保一个 MapTask 最终只产生一个中间数据文件。
  4. Copy阶段:ReduceTask 启动 Fetcher 线程到已经完成 MapTask 的节点上复制一份属于自己的数据,这些数据默认会保存在内存的缓冲区中,当内存的缓冲区达到一定的阀值的时候,就会将数据写到磁盘之上。
  5. Merge阶段:在 ReduceTask 远程复制数据的同时,会在后台开启两个线程对内存到本地的数据文件进行合并操作。
  6. Sort阶段:在对数据进行合并的同时,会进行排序操作,由于 MapTask 阶段已经对数据进行了局部的排序,ReduceTask 只需保证 Copy 的数据的最终整体有效性即可。
    Shuffle 中的缓冲区大小会影响到 mapreduce 程序的执行效率,原则上说,缓冲区越大,磁盘io的次数越少,执行速度就越快
    缓冲区的大小可以通过参数调整, 参数:mapreduce.task.io.sort.mb 默认100M

2. 案例: Reduce 端实现 JOIN

2.1. 需求

假如数据量巨大,两表的数据是以文件的形式存储在 HDFS 中, 需要用 MapReduce 程序来实现以下 SQL 查询运算

select  a.id,a.date,b.name,b.category_id,b.price from t_order a left join t_product b on a.pid = b.id
商品表
id pname category_id price
P0001 小米5 1000 2000
P0002 锤子T1 1000 3000
订单数据表
id date pid amount
1001 20150710 P0001 2
1002 20150710 P0002 3
  • map阶段要考虑:两个文件的读写;
  • reduce阶段要考虑:多对多的情况;后面代码要改reduce

2.2 实现步骤

通过将关联的条件作为map输出的key,将两表满足join条件的数据并携带数据所来源的文件信息,发往同一个reduce task,在reduce中进行数据的串联

Step 1: 定义 Mapper

public class ReduceJoinMapper extends Mapper<LongWritable,Text,Text,Text> {@Overrideprotected void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {//1:判断数据来自哪个文件FileSplit fileSplit = (FileSplit) context.getInputSplit();String fileName = fileSplit.getPath().getName();if(fileName.equals("product.txt")){//数据来自商品表//2:将K1和V1转为K2和V2,写入上下文中String[] split = value.toString().split(",");String productId = split[0];context.write(new Text(productId), value);}else{//数据来自订单表//2:将K1和V1转为K2和V2,写入上下文中String[] split = value.toString().split(",");String productId = split[2];context.write(new Text(productId), value);}}
}

Step 2: 定义 Reducer

public class ReduceJoinReducer extends Reducer<Text,Text,Text,Text> {@Overrideprotected void reduce(Text key, Iterable<Text> values, Context context) throws IOException, InterruptedException {//1:遍历集合,获取V3 (first +second)String first = "";String second = "";for (Text value : values) {if(value.toString().startsWith("p")){first = value.toString();}else{second += value.toString();}}//2:将K3和V3写入上下文中context.write(key, new Text(first+"\t"+second));}
}

Step 3: 定义主类

public class JoinJobMain extends Configured implements Tool {@Overridepublic int run(String[] args) throws Exception {Job job = Job.getInstance(super.getConf(), "join_mapreduce");job.setJarByClass(JoinJobMain.class);job.setInputFormatClass(TextInputFormat.class);job.setOutputFormatClass(TextOutputFormat.class);TextInputFormat.addInputPath(job,new Path("file:///C:\\Users\\tuyouxian\\Desktop\\input\\join_input"));TextOutputFormat.setOutputPath(job,new Path("file:///C:\\Users\\tuyouxian\\Desktop\\out\\join_out"));job.setMapperClass(ReduceJoinMapper.class);job.setMapOutputKeyClass(Text.class);job.setMapOutputValueClass(Text.class);job.setReducerClass(ReducerJoinReducer.class);job.setOutputKeyClass(Text.class);job.setOutputValueClass(Text.class);boolean b = job.waitForCompletion(true);return b ? 0 : 1;}public static void main(String[] args) throws Exception {int run = ToolRunner.run(new Configuration(), new JoinJobMain(), args);System.exit(run);}
}

3. 案例: Map端实现 JOIN

3.1 概述

​ 适用于关联表中有小表的情形.

​ 使用分布式缓存,可以将小表分发到所有的map节点,这样,map节点就可以在本地对自己所读到的大表数据进行join并输出最终结果,可以大大提高join操作的并发度,加快处理速度

3.2 实现步骤

先在mapper类中预先定义好小表,进行join

引入实际场景中的解决方案:一次加载数据库或者用

Step 1:定义Mapper
public class MapJoinMapper extends Mapper<LongWritable,Text,Text,Text>{private HashMap<String, String> map = new HashMap<>();//第一件事情:将分布式缓存的小表数据读取到本地Map集合(只需要做一次)//setup方法只会执行一次 @Overrideprotected void setup(Context context) throws IOException, InterruptedException {//1:获取分布式缓存文件列表URI[] cacheFiles =  context.getCacheFiles();//2:获取指定的分布式缓存文件的文件系统(FileSystem)//get获取已经存在的文件系统,不会创建//newInstance:如果已经存在的文件系统,会创建//在集群用get时,因为jobMain中有(TextInputFormat.addInputFormat)创建了一个文件系统,如果现在关闭,就会出现问题,所以在集群中我们这里改成newInstance或者不关闭;FileSystem fileSystem = FileSystem.get(cacheFiles[0], context.getConfiguration());//3:获取文件的输入流FSDataInputStream inputStream = fileSystem.open(new Path(cacheFiles[0]));//4:读取文件内容, 并将数据存入Map集合//4.1 将字节输入流转为字符缓冲流FSDataInputStream --->BufferedReaderBufferedReader bufferedReader = new BufferedReader(new InputStreamReader(inputStream));//4.2 读取小表文件内容,以行位单位,并将读取的数据存入map集合String line = null;while((line = bufferedReader.readLine()) != null){String[] split = line.split(",");map.put(split[0], line);}//5:关闭流//关闭流的顺序不能搞错bufferedReader.close();fileSystem.close();}//第二件事情:对大表的处理业务逻辑,而且要实现大表和小表的join操作@Overrideprotected void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {//1:从行文本数据中获取商品的id: p0001 , p0002  得到了K2String[] split = value.toString().split(",");String productId = split[2];  //K2//2:在Map集合中,将商品的id作为键,获取值(商品的行文本数据) ,将value和值拼接,得到V2String productLine = map.get(productId);String valueLine = productLine+"\t"+value.toString(); //V2//3:将K2和V2写入上下文中context.write(new Text(productId), new Text(valueLine));}
}
Step 2:定义主类
public class JobMain  extends Configured implements Tool{@Overridepublic int run(String[] args) throws Exception {//1:获取job对象Job job = Job.getInstance(super.getConf(), "map_join_job");//2:设置job对象(将小表放在分布式缓存中)//将小表放在分布式缓存中// DistributedCache.addCacheFile(new URI("hdfs://node01:8020/cache_file/product.txt"), super.getConf());2.2之前的写法job.addCacheFile(new URI("hdfs://node01:8020/cache_file/product.txt"));//第一步:设置输入类和输入的路径job.setInputFormatClass(TextInputFormat.class);TextInputFormat.addInputPath(job, new Path("file:///D:\\input\\map_join_input"));//第二步:设置Mapper类和数据类型job.setMapperClass(MapJoinMapper.class);job.setMapOutputKeyClass(Text.class);job.setMapOutputValueClass(Text.class);//第八步:设置输出类和输出路径job.setOutputFormatClass(TextOutputFormat.class);TextOutputFormat.setOutputPath(job, new Path("file:///D:\\out\\map_join_out"));//3:等待任务结束boolean bl = job.waitForCompletion(true);return bl ? 0 :1;}public static void main(String[] args) throws Exception {Configuration configuration = new Configuration();//启动job任务int run = ToolRunner.run(configuration, new JobMain(), args);System.exit(run);}
}

4. 案例:求共同好友

4.1 需求分析

以下是qq的好友列表数据,冒号前是一个用户,冒号后是该用户的所有好友(数据中的好友关系是单向的)

A:B,C,D,F,E,O
B:A,C,E,K
C:A,B,D,E,I
D:A,E,F,L
E:B,C,D,M,L
F:A,B,C,D,E,O,M
G:A,C,D,E,F
H:A,C,D,E,O
I:A,O
J:B,O
K:A,C,D
L:D,E,F
M:E,F,G
O:A,H,I,J

1求出哪些人两两之间有共同好友,及他俩的共同好友都有谁?

​ 解1:从下图中,反向推导容易理解

4.2 实现步骤

第一步:代码实现

Mapper类

public class Step1Mapper extends Mapper<LongWritable,Text,Text,Text> {@Overrideprotected void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {//1:以冒号拆分行文本数据: 冒号左边就是V2String[] split = value.toString().split(":");String userStr = split[0];//2:将冒号右边的字符串以逗号拆分,每个成员就是K2String[] split1 = split[1].split(",");for (String s : split1) {//3:将K2和v2写入上下文中context.write(new Text(s), new Text(userStr));}}
}

Reducer类:

public class Step1Reducer extends Reducer<Text,Text,Text,Text> {@Overrideprotected void reduce(Text key, Iterable<Text> values, Context context) throws IOException, InterruptedException {//1:遍历集合,并将每一个元素拼接,得到K3StringBuffer buffer = new StringBuffer();for (Text value : values) {buffer.append(value.toString()).append("-");}//2:K2就是V3//3:将K3和V3写入上下文中context.write(new Text(buffer.toString()), key);}
}

JobMain:

public class JobMain extends Configured implements Tool {@Overridepublic int run(String[] args) throws Exception {//1:获取Job对象Job job = Job.getInstance(super.getConf(), "common_friends_step1_job");//2:设置job任务//第一步:设置输入类和输入路径job.setInputFormatClass(TextInputFormat.class);TextInputFormat.addInputPath(job, new Path("file:///D:\\input\\common_friends_step1_input"));//第二步:设置Mapper类和数据类型job.setMapperClass(Step1Mapper.class);job.setMapOutputKeyClass(Text.class);job.setMapOutputValueClass(Text.class);//第三,四,五,六//第七步:设置Reducer类和数据类型job.setReducerClass(Step1Reducer.class);job.setOutputKeyClass(Text.class);job.setOutputValueClass(Text.class);//第八步:设置输出类和输出的路径job.setOutputFormatClass(TextOutputFormat.class);TextOutputFormat.setOutputPath(job, new Path("file:///D:\\out\\common_friends_step1_out"));//3:等待job任务结束boolean bl = job.waitForCompletion(true);return bl ? 0: 1;}public static void main(String[] args) throws Exception {Configuration configuration = new Configuration();//启动job任务int run = ToolRunner.run(configuration, new JobMain(), args);System.exit(run);}
}
第二步:代码实现

Mapper类

public class Step2Mapper extends Mapper<LongWritable,Text,Text,Text> {/*K1           V10            A-F-C-J-E- B----------------------------------K2             V2A-C            BA-E            BA-F            BC-E            B*/@Overrideprotected void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {//1:拆分行文本数据,结果的第二部分可以得到V2String[] split = value.toString().split("\t");String   friendStr =split[1];//2:继续以'-'为分隔符拆分行文本数据第一部分,得到数组String[] userArray = split[0].split("-");//3:对数组做一个排序Arrays.sort(userArray);//4:对数组中的元素进行两两组合,得到K2/*A-E-C ----->  A  C  EA  C  EA  C  E*/for (int i = 0; i <userArray.length -1 ; i++) {for (int j = i+1; j  < userArray.length ; j++) {//5:将K2和V2写入上下文中context.write(new Text(userArray[i] +"-"+userArray[j]), new Text(friendStr));}}}
}

Reducer类:

public class Step2Reducer extends Reducer<Text,Text,Text,Text> {@Overrideprotected void reduce(Text key, Iterable<Text> values, Context context) throws IOException, InterruptedException {//1:原来的K2就是K3//2:将集合进行遍历,将集合中的元素拼接,得到V3StringBuffer buffer = new StringBuffer();for (Text value : values) {buffer.append(value.toString()).append("-");}//3:将K3和V3写入上下文中context.write(key, new Text(buffer.toString()));}
}

JobMain:

public class JobMain extends Configured implements Tool {@Overridepublic int run(String[] args) throws Exception {//1:获取Job对象Job job = Job.getInstance(super.getConf(), "common_friends_step2_job");//2:设置job任务//第一步:设置输入类和输入路径job.setInputFormatClass(TextInputFormat.class);TextInputFormat.addInputPath(job, new Path("file:///D:\\out\\common_friends_step1_out"));//第二步:设置Mapper类和数据类型job.setMapperClass(Step2Mapper.class);job.setMapOutputKeyClass(Text.class);job.setMapOutputValueClass(Text.class);//第三,四,五,六//第七步:设置Reducer类和数据类型job.setReducerClass(Step2Reducer.class);job.setOutputKeyClass(Text.class);job.setOutputValueClass(Text.class);//第八步:设置输出类和输出的路径job.setOutputFormatClass(TextOutputFormat.class);TextOutputFormat.setOutputPath(job, new Path("file:///D:\\out\\common_friends_step2_out"));//3:等待job任务结束boolean bl = job.waitForCompletion(true);return bl ? 0: 1;}public static void main(String[] args) throws Exception {Configuration configuration = new Configuration();//启动job任务int run = ToolRunner.run(configuration, new JobMain(), args);System.exit(run);}
}

补充

MapReduce 的Shuffle阶段的溢写阶段,分两类:

1、环形缓冲区的数据到达80%时,就会溢写到本地磁盘,当再次达到80%时,就会再次溢写到磁盘,直到最后一次,不管环形缓冲区还有多少数据,都会溢写到磁盘。然后会对这多次溢写到磁盘的多个小文件进行合并,减少Reduce阶段的网络传输。

2.就是没有达到80%map阶段就结束了,这时直接把环形缓冲区的数据写到磁盘上,供下一步合并使用。

Mapreduce不设置reduce,只执行map的输出结果

在写MR程序时候,有时我们不需要reduce,比如对原始数据做Format等,这样我们在MR程序中就不需要写reduce函数,同样在main函数配置中也不需要reduce相关的配置信息,在MR执行的过程中,会为MR生成一个系统自带的reduce,这个reduce是系统为了保持框架的完整性自动调用的reduce函数,但这个函数并不做shuffle和数据拖取,生成的结果文件就是map的输出文件,也就是说,有多少个map,那么输出的结果就有多少个文件。so,总结如下:

  1. MR可以没有reduce

  2. 如果没有reduce,那么系统也会自动生成一个reduce,但是这个reduce不做任何操作,也不做shuffle拖取数据

  3. 最终文件的数量就是map的数量,根据数据的输入量和块大小和切片最大最小值有关

  4. 最简便的方法就是直接将reduce的数量设置成0

改成不是好友的两个人的共同好友,又该怎么做?做推荐好友

先考虑好友关系是双向的,求二度好友(参考链接:http://developer.51cto.com/art/201301/375661.htm)

根据第一轮MapReduce的Map,第一轮MapReduce的Reduce 的输入是例如key =I,value={“H,I”、“C,I”、“G,I”} 。其实Reduce 的输入是所有与Key代表的结点相互关注的人。如果H、C、G是与I相互关注的好友,那么H、C、G就可能是二度好友的关系,如果他们之间不是相互关注的。,H与C是二度好友,G与C是二度好友,但G与H不是二度好友,因为他们是相互关注的。第一轮MapReduce的Reduce的处理就是把相互关注的好友对标记为一度好友(“deg1friend”)并输出,把有可能是二度好友的好友对标记为二度好友(“deg2friend”)并输出。

第二轮MapReduce则需要根据第一轮MapReduce的输出,即每个好友对之间是否是一度好友(“deg1friend”),是否有可能是二度好友(“deg2friend”)的关系,确认他们之间是不是真正的二度好友关系。如果他们有deg1friend的标签,那么不可能是二度好友的关系;如果有deg2friend的标签、没有deg1friend的标签,那么他们就是二度好友的关系。另外,特别可以利用的是,某好友对deg2friend标签的个数就是他们成为二度好友的支持数,即他们之间可以通过多少个都相互关注的好友认识。

import java.io.IOException;
import java.util.Random;
import java.util.Vector;import org.apache.hadoop.conf.Configuration;
import org.apache.hadoop.fs.FileSystem;
import org.apache.hadoop.fs.Path;
import org.apache.hadoop.io.Text;
import org.apache.hadoop.mapreduce.Job;
import org.apache.hadoop.mapreduce.Mapper;
import org.apache.hadoop.mapreduce.Reducer;
import org.apache.hadoop.mapreduce.lib.input.FileInputFormat;
import org.apache.hadoop.mapreduce.lib.output.FileOutputFormat;
import org.apache.hadoop.util.GenericOptionsParser;public class deg2friend {public static class job1Mapper extends Mapper<Object, Text, Text, Text>{private Text job1map_key = new Text();private Text job1map_value = new Text();public void map(Object key, Text value, Context context) throws IOException, InterruptedException {String eachterm[] = value.toString().split(",");if(eachterm[0].compareTo(eachterm[1])<0){job1map_value.set(eachterm[0]+"\t"+eachterm[1]);}else if(eachterm[0].compareTo(eachterm[1])>0){job1map_value.set(eachterm[1]+"\t"+eachterm[0]);}job1map_key.set(eachterm[0]);context.write(job1map_key, job1map_value);job1map_key.set(eachterm[1]);context.write(job1map_key, job1map_value);}} public static class job1Reducer extends Reducer<Text,Text,Text,Text> {private Text job1reduce_key = new Text();private Text job1reduce_value = new Text();public void reduce(Text key, Iterable<Text> values, Context context) throws IOException, InterruptedException {String someperson = key.toString();Vector<String> hisfriends = new Vector<String>();for (Text val : values) {String eachterm[] = val.toString().split("\t");if(eachterm[0].equals(someperson)){hisfriends.add(eachterm[1]);job1reduce_value.set("deg1friend");context.write(val, job1reduce_value);}else if(eachterm[1].equals(someperson)){hisfriends.add(eachterm[0]);job1reduce_value.set("deg1friend");context.write(val, job1reduce_value);}}for(int i = 0; i<hisfriends.size(); i++){for(int j = 0; j<hisfriends.size(); j++){if (hisfriends.elementAt(i).compareTo(hisfriends.elementAt(j))<0){job1reduce_key.set(hisfriends.elementAt(i)+"\t"+hisfriends.elementAt(j));job1reduce_value.set("deg2friend");context.write(job1reduce_key, job1reduce_value);}
//                  else if(hisfriends.elementAt(i).compareTo(hisfriends.elementAt(j))>0){//                      job1reduce_key.set(hisfriends.elementAt(j)+"\t"+hisfriends.elementAt(i));
//                  }   }}} }public static class job2Mapper extends Mapper<Object, Text, Text, Text>{private Text job2map_key = new Text();private Text job2map_value = new Text();public void map(Object key, Text value, Context context) throws IOException, InterruptedException {String lineterms[] = value.toString().split("\t");if(lineterms.length == 3){job2map_key.set(lineterms[0]+"\t"+lineterms[1]);job2map_value.set(lineterms[2]);context.write(job2map_key,job2map_value);}}} public static class job2Reducer extends Reducer<Text,Text,Text,Text> {private Text job2reducer_key = new Text();private Text job2reducer_value = new Text();public void reduce(Text key, Iterable<Text> values, Context context) throws IOException, InterruptedException {Vector<String> relationtags = new Vector<String>();String deg2friendpair = key.toString();for (Text val : values) {relationtags.add(val.toString());}boolean isadeg1friendpair = false;boolean isadeg2friendpair = false;int surport = 0;for(int i = 0; i<relationtags.size(); i++){if(relationtags.elementAt(i).equals("deg1friend")){isadeg1friendpair = true;}else if(relationtags.elementAt(i).equals("deg2friend")){isadeg2friendpair = true;surport += 1;}    }if ((!isadeg1friendpair) && isadeg2friendpair){job2reducer_key.set(String.valueOf(surport));job2reducer_value.set(deg2friendpair);context.write(job2reducer_key,job2reducer_value);}}  }public static void main(String[] args) throws Exception {Configuration conf = new Configuration();String[] otherArgs = new GenericOptionsParser(conf, args).getRemainingArgs();if (otherArgs.length != 2) {System.err.println("Usage: deg2friend <in> <out>");System.exit(2);}Job job1 = new Job(conf, "deg2friend");job1.setJarByClass(deg2friend.class);job1.setMapperClass(job1Mapper.class);job1.setReducerClass(job1Reducer.class);job1.setOutputKeyClass(Text.class);job1.setOutputValueClass(Text.class);//定义一个临时目录,先将任务的输出结果写到临时目录中, 下一个排序任务以临时目录为输入目录。FileInputFormat.addInputPath(job1, new Path(otherArgs[0]));Path tempDir = new Path("deg2friend-temp-" + Integer.toString(new Random().nextInt(Integer.MAX_VALUE))); FileOutputFormat.setOutputPath(job1, tempDir);if(job1.waitForCompletion(true)){Job job2 = new Job(conf, "deg2friend");job2.setJarByClass(deg2friend.class);FileInputFormat.addInputPath(job2, tempDir);job2.setMapperClass(job2Mapper.class);job2.setReducerClass(job2Reducer.class);FileOutputFormat.setOutputPath(job2, new Path(otherArgs[1]));job2.setOutputKeyClass(Text.class);job2.setOutputValueClass(Text.class);FileSystem.get(conf).deleteOnExit(tempDir);System.exit(job2.waitForCompletion(true) ? 0 : 1);}System.exit(job1.waitForCompletion(true) ? 0 : 1);}}

MapReduce的运行机制及共同好友相关推荐

  1. 【大数据day14】——MapReduce的运行机制详解(案列:Reduce 端实现 JOIN, Map端实现 JOIN,求共同好友)

    文章目录 1 .MapReduce的运行机制详解 1.1:MapTask 工作机制 详细步骤 配置 1.2 :ReduceTask 工作机制 详细步骤 1.3:Shuffle 过程 2. 案例: Re ...

  2. 经典MapReduce作业和Yarn上MapReduce作业运行机制

    一.经典MapReduce的作业运行机制 如下图是经典MapReduce作业的工作原理: 1.1 经典MapReduce作业的实体 经典MapReduce作业运行过程包含的实体: 客户端,提交MapR ...

  3. 什么是MapReduce?MapReduce的运行机制是什么?MapReduce的实现过程

    1. MAPREDUCE原理篇(1) Mapreduce是一个分布式运算程序的编程框架,是用户开发"基于hadoop的数据分析应用"的核心框架: Mapreduce核心功能是将用户 ...

  4. MapReduce 运行机制

    Hadoop 中的MapReduce是一个使用简单的软件框架,基于它写出来的应用程序能够运行在由上千个商用机器组成的大型集群上,并以一种可靠容错式并行处理TB级别的数据集. 一个MapReduce作业 ...

  5. MapTask并行度决定机制、FileInputFormat切片机制、map并行度的经验之谈、ReduceTask并行度的决定、MAPREDUCE程序运行演示(来自学笔记)

    1.3 MapTask并行度决定机制 maptask的并行度决定map阶段的任务处理并发度,进而影响到整个job的处理速度 那么,mapTask并行实例是否越多越好呢?其并行度又是如何决定呢? 1.3 ...

  6. MapReduce运行机制-Map阶段

    MapTask 运行机制 整个Map阶段流程大体如上图所示. 简单概述:inputFile通过split被逻辑切分为多个split文件,通过Record按行读取内容给map(用户自己实现的)进行处理, ...

  7. MapReduce运行机制

    相关链接  MapReduce中Shuffle机制详解--Map端Shuffle链接  MapReduce中Shuffle机制详解--Reduce端Shuffle链接 MapReduce将作业job的 ...

  8. 大数据之MapReduce详解(MR的运行机制及配合WordCount实例来说明运行机制)

    目录 前言: 1.MapReduce原理 2.mapreduce实践(WordCount实例) 目录 今天先总体说下MapReduce的相关知识,后续将会详细说明对应的shuffle.mr与yarn的 ...

  9. MapTask运行机制详解以及Map任务的并行度,ReduceTask 工作机制以及reduceTask的并行度,MapReduce总体工作机制

    MapTask运行机制详解 整个Map阶段流程大体如图所示 简单概述 inputFile通过split被逻辑切分为多个split文件, 通过Record按行读取内容给map(用户自己实现的)进行处理, ...

最新文章

  1. Android友盟增量更新
  2. 数据结构基础温故-6.查找(下):哈希表
  3. Android开发之fragment传递参数的两种方法
  4. 小白学jquery Mobile《构建跨平台APP:jQuery Mobile移动应用实战》连载四(场景切换)...
  5. Python~win32com~Excel
  6. idea卸载不干净怎么办_fxfactory卸载不干净?Fxfactory及插件卸载教程
  7. matplotlib 数据可视化
  8. Kotlin学习笔记 第四章注解
  9. 用最简单直白的人类语言解释下jsonP到底是什么鬼
  10. Centos7开放及查看端口
  11. 苹果公司发布TestFlight Groups,放宽二进制版本提交限制
  12. 一次linux root密码错修改历程
  13. 如何检查SFP光模块的光信号强度?
  14. [QT_015]Qt学习之基于条目控件的自定义特性(拖拽+右键菜单+样式)
  15. mysql 取top 10_我的mysql如何分组取top10?
  16. android平板电脑怎么才能连接电脑,平板电脑怎么连接电脑 最有效方法【图解】...
  17. 从晶体管开始聊聊计算机为什么采用二进制
  18. JVM的GC算法详解(二)
  19. 【渝粤题库】陕西师范大学200791 软件工程
  20. 2000-2019年世界人口数据集内附下载地址和链接

热门文章

  1. 一位架构师用服务打动客户的故事之二
  2. 【技术专题】如何做数据库选型?
  3. spring cloud整合feign和nacos报错:No Feign Client for loadBalancing defined. Did you forget to include
  4. 怎么开发联机小游戏_Q飞机游戏:空战吃鸡大乱斗游戏!好玩的联机Q飞机对战小游戏...
  5. B站黑马Java基础+就业班+各种项目idea版本(正在更新)2 IO流
  6. [golang]-golang将中文转化为拼音
  7. 布隆(Bloom Filter)过滤器——全面讲解,建议收藏
  8. Git本地仓库与GitHub远程仓库的同步方法
  9. 走马观花之bug预防
  10. 注册表:HKCR, HKCU, HKLM, HKU, HKCC,注册表中常用的5种数据类型