如何在单个作业中使用Spark写入依赖于键的多个输出。
相关:Write to multiple outputs by key Scalding Hadoop, one MapReduce Job
E.g。
sc.makeRDD(Seq((1, "a"), (1, "b"), (2, "c")))
.writeAsMultiple(prefix, compressionCodecOption)
将确保cat prefix/1
a
b
和cat prefix/2
将是
c
编辑:我最近添加了一个新答案,其中包括完整导入,皮条客和压缩编解码器,请参阅https://stackoverflow.com/a/46118044/1586965,除了之前的答案之外,这可能会有所帮助。
答案 0 :(得分:103)
如果使用Spark 1.4+,由于DataFrame API,这变得更加容易。 (DataFrames是在Spark 1.3中引入的,但我们需要的partitionBy()
是introduced in 1.4。)
如果你开始使用RDD,首先需要将其转换为数据框:
val people_rdd = sc.parallelize(Seq((1, "alice"), (1, "bob"), (2, "charlie")))
val people_df = people_rdd.toDF("number", "name")
在Python中,相同的代码是:
people_rdd = sc.parallelize([(1, "alice"), (1, "bob"), (2, "charlie")])
people_df = people_rdd.toDF(["number", "name"])
拥有DataFrame后,根据特定键写入多个输出很简单。还有什么 - 这就是DataFrame API的美妙之处 - Python,Scala,Java和R的代码几乎相同:
people_df.write.partitionBy("number").text("people")
如果您愿意,可以轻松使用其他输出格式:
people_df.write.partitionBy("number").json("people-json")
people_df.write.partitionBy("number").parquet("people-parquet")
在每个示例中,Spark将为我们在DataFrame上分区的每个键创建一个子目录:
people/
_SUCCESS
number=1/
part-abcd
part-efgh
number=2/
part-abcd
part-efgh
答案 1 :(得分:79)
我会这样做,这是可扩展的
import org.apache.hadoop.io.NullWritable
import org.apache.spark._
import org.apache.spark.SparkContext._
import org.apache.hadoop.mapred.lib.MultipleTextOutputFormat
class RDDMultipleTextOutputFormat extends MultipleTextOutputFormat[Any, Any] {
override def generateActualKey(key: Any, value: Any): Any =
NullWritable.get()
override def generateFileNameForKeyValue(key: Any, value: Any, name: String): String =
key.asInstanceOf[String]
}
object Split {
def main(args: Array[String]) {
val conf = new SparkConf().setAppName("Split" + args(1))
val sc = new SparkContext(conf)
sc.textFile("input/path")
.map(a => (k, v)) // Your own implementation
.partitionBy(new HashPartitioner(num))
.saveAsHadoopFile("output/path", classOf[String], classOf[String],
classOf[RDDMultipleTextOutputFormat])
spark.stop()
}
}
刚刚看到上面的类似答案,但实际上我们并不需要自定义分区。 MultipleTextOutputFormat将为每个键创建文件。具有相同键的多个记录可以归入同一分区。
new HashPartitioner(num),其中num是您想要的分区号。如果您有大量不同的密钥,可以将数字设置为大。在这种情况下,每个分区都不会打开太多的hdfs文件处理程序。
答案 2 :(得分:15)
如果给定密钥可能有很多值,我认为可扩展的解决方案是为每个分区的每个密钥写出一个文件。不幸的是,Spark中没有内置的支持,但我们可以鞭打一些东西。
sc.makeRDD(Seq((1, "a"), (1, "b"), (2, "c")))
.mapPartitionsWithIndex { (p, it) =>
val outputs = new MultiWriter(p.toString)
for ((k, v) <- it) {
outputs.write(k.toString, v)
}
outputs.close
Nil.iterator
}
.foreach((x: Nothing) => ()) // To trigger the job.
// This one is Local, but you could write one for HDFS
class MultiWriter(suffix: String) {
private val writers = collection.mutable.Map[String, java.io.PrintWriter]()
def write(key: String, value: Any) = {
if (!writers.contains(key)) {
val f = new java.io.File("output/" + key + "/" + suffix)
f.getParentFile.mkdirs
writers(key) = new java.io.PrintWriter(f)
}
writers(key).println(value)
}
def close = writers.values.foreach(_.close)
}
(将PrintWriter
替换为您选择的分布式文件系统操作。)
这使得一次通过RDD并且不执行随机播放。它为每个键提供一个目录,每个目录中包含许多文件。
答案 3 :(得分:8)
这包括请求的编解码器,必要的导入和请求的pimp。
import org.apache.spark.rdd.RDD
import org.apache.spark.sql.SQLContext
// TODO Need a macro to generate for each Tuple length, or perhaps can use shapeless
implicit class PimpedRDD[T1, T2](rdd: RDD[(T1, T2)]) {
def writeAsMultiple(prefix: String, codec: String,
keyName: String = "key")
(implicit sqlContext: SQLContext): Unit = {
import sqlContext.implicits._
rdd.toDF(keyName, "_2").write.partitionBy(keyName)
.format("text").option("codec", codec).save(prefix)
}
}
val myRdd = sc.makeRDD(Seq((1, "a"), (1, "b"), (2, "c")))
myRdd.writeAsMultiple("prefix", "org.apache.hadoop.io.compress.GzipCodec")
OP的一个细微差别是它会在<keyName>=
前加上目录名称。 E.g。
myRdd.writeAsMultiple("prefix", "org.apache.hadoop.io.compress.GzipCodec")
会给:
prefix/key=1/part-00000
prefix/key=2/part-00000
其中prefix/my_number=1/part-00000
包含行a
和b
,prefix/my_number=2/part-00000
包含行c
。
和
myRdd.writeAsMultiple("prefix", "org.apache.hadoop.io.compress.GzipCodec", "foo")
会给:
prefix/foo=1/part-00000
prefix/foo=2/part-00000
应该清楚如何编辑parquet
。
最后下面是Dataset
的示例,使用元组可能更好。
implicit class PimpedDataset[T](dataset: Dataset[T]) {
def writeAsMultiple(prefix: String, codec: String, field: String): Unit = {
dataset.write.partitionBy(field)
.format("text").option("codec", codec).save(prefix)
}
}
答案 4 :(得分:4)
我有类似的需求,并找到了一种方法。但它有一个缺点(对我来说这不是问题):你需要为每个输出文件的一个分区重新分区数据。
要以这种方式进行分区,通常需要事先知道作业将输出多少文件,并找到将每个键映射到每个分区的函数。
首先让我们创建基于MultipleTextOutputFormat的类:
import org.apache.hadoop.mapred.lib.MultipleTextOutputFormat
class KeyBasedOutput[T >: Null, V <: AnyRef] extends MultipleTextOutputFormat[T , V] {
override def generateFileNameForKeyValue(key: T, value: V, leaf: String) = {
key.toString
}
override protected def generateActualKey(key: T, value: V) = {
null
}
}
使用这个类,Spark会从一个分区(第一个/最后一个,我猜)得到一个密钥,并用这个密钥命名文件,所以在同一个分区上混合多个密钥并不好。
对于您的示例,您将需要自定义分区程序。这将完成这项工作:
import org.apache.spark.Partitioner
class IdentityIntPartitioner(maxKey: Int) extends Partitioner {
def numPartitions = maxKey
def getPartition(key: Any): Int = key match {
case i: Int if i < maxKey => i
}
}
现在让我们把所有东西放在一起:
val rdd = sc.makeRDD(Seq((1, "a"), (1, "b"), (2, "c"), (7, "d"), (7, "e")))
// You need to know the max number of partitions (files) beforehand
// In this case we want one partition per key and we have 3 keys,
// with the biggest key being 7, so 10 will be large enough
val partitioner = new IdentityIntPartitioner(10)
val prefix = "hdfs://.../prefix"
val partitionedRDD = rdd.partitionBy(partitioner)
partitionedRDD.saveAsHadoopFile(prefix,
classOf[Integer], classOf[String], classOf[KeyBasedOutput[Integer, String]])
这将在前缀(名称1,2和7)下生成3个文件,一次处理所有内容。
如您所见,您需要一些关于密钥的知识才能使用此解决方案。
对我来说这更容易,因为我需要一个输出文件用于每个密钥哈希,文件数量在我的控制之下,所以我可以使用股票HashPartitioner来完成这个技巧。
答案 5 :(得分:4)
我在Java中需要同样的东西。将我Zhang Zhan's Scala answer的翻译发布给Spark Java API用户:
import org.apache.hadoop.mapred.lib.MultipleTextOutputFormat;
import org.apache.spark.SparkConf;
import org.apache.spark.api.java.JavaSparkContext;
import scala.Tuple2;
import java.util.Arrays;
class RDDMultipleTextOutputFormat<A, B> extends MultipleTextOutputFormat<A, B> {
@Override
protected String generateFileNameForKeyValue(A key, B value, String name) {
return key.toString();
}
}
public class Main {
public static void main(String[] args) {
SparkConf conf = new SparkConf()
.setAppName("Split Job")
.setMaster("local");
JavaSparkContext sc = new JavaSparkContext(conf);
String[] strings = {"Abcd", "Azlksd", "whhd", "wasc", "aDxa"};
sc.parallelize(Arrays.asList(strings))
// The first character of the string is the key
.mapToPair(s -> new Tuple2<>(s.substring(0,1).toLowerCase(), s))
.saveAsHadoopFile("output/", String.class, String.class,
RDDMultipleTextOutputFormat.class);
sc.stop();
}
}
答案 6 :(得分:3)
saveAsText()和saveAsHadoop(...)是基于RDD数据实现的,特别是方法:PairRDD.saveAsHadoopDataset,它从PairRdd中获取执行它的数据。 我看到两个可能的选项:如果您的数据大小相对较小,您可以通过对RDD进行分组来节省一些实现时间,从每个集合创建一个新的RDD并使用该RDD来编写数据。像这样:
val byKey = dataRDD.groupByKey().collect()
val rddByKey = byKey.map{case (k,v) => k->sc.makeRDD(v.toSeq)}
val rddByKey.foreach{ case (k,rdd) => rdd.saveAsText(prefix+k}
请注意,它不适用于大型数据集b / c v.toSeq
处的迭代器的实现可能不适合内存。
我看到的另一个选项,实际上我在这种情况下推荐的是:通过直接调用hadoop / hdfs api来滚动自己。
这是我在研究这个问题时开始的讨论: How to create RDDs from another RDD?
答案 7 :(得分:3)
我有一个类似的用例,我根据密钥(每个密钥1个文件)将Hadoop HDFS上的输入文件拆分为多个文件。这是我的火花的scala代码
import org.apache.hadoop.conf.Configuration;
import org.apache.hadoop.fs.FileSystem;
import org.apache.hadoop.fs.Path;
val hadoopconf = new Configuration();
val fs = FileSystem.get(hadoopconf);
@serializable object processGroup {
def apply(groupName:String, records:Iterable[String]): Unit = {
val outFileStream = fs.create(new Path("/output_dir/"+groupName))
for( line <- records ) {
outFileStream.writeUTF(line+"\n")
}
outFileStream.close()
}
}
val infile = sc.textFile("input_file")
val dateGrouped = infile.groupBy( _.split(",")(0))
dateGrouped.foreach( (x) => processGroup(x._1, x._2))
我根据密钥对记录进行了分组。每个键的值都写入单独的文件。
答案 8 :(得分:1)
people_df.write.partitionBy("number").text("people")
错误消息是“AnalysisException:u'Text数据源仅支持一列,并且您有2列。;”
在spark 2.0.0(我的测试环境是hdp的spark 2.0.0)软件包“com.databricks.spark.csv”现已集成,它允许我们保存仅由一列分区的文本文件,参见示例打击:
people_rdd = sc.parallelize([(1,"2016-12-26", "alice"),
(1,"2016-12-25", "alice"),
(1,"2016-12-25", "tom"),
(1, "2016-12-25","bob"),
(2,"2016-12-26" ,"charlie")])
df = people_rdd.toDF(["number", "date","name"])
df.coalesce(1).write.partitionBy("number").mode("overwrite").format('com.databricks.spark.csv').options(header='false').save("people")
[root@namenode people]# tree
.
├── number=1
│?? └── part-r-00000-6bd1b9a8-4092-474a-9ca7-1479a98126c2.csv
├── number=2
│?? └── part-r-00000-6bd1b9a8-4092-474a-9ca7-1479a98126c2.csv
└── _SUCCESS
[root@namenode people]# cat number\=1/part-r-00000-6bd1b9a8-4092-474a-9ca7-1479a98126c2.csv
2016-12-26,alice
2016-12-25,alice
2016-12-25,tom
2016-12-25,bob
[root@namenode people]# cat number\=2/part-r-00000-6bd1b9a8-4092-474a-9ca7-1479a98126c2.csv
2016-12-26,charlie
在我的spark 1.6.1环境中,代码没有抛出任何错误,但是只生成了一个文件。它没有被两个文件夹分区。
希望这可以提供帮助。
答案 9 :(得分:1)
我有一个类似的用例。我通过编写实现MultipleTextOutputFormat
和RecordWriter
的两个自定义类来解决它在Java中的问题。
我的输入是JavaPairRDD<String, List<String>>
,我希望将其存储在由其键命名的文件中,其值包含所有行。
以下是我MultipleTextOutputFormat
实施的代码
class RDDMultipleTextOutputFormat<K, V> extends MultipleTextOutputFormat<K, V> {
@Override
protected String generateFileNameForKeyValue(K key, V value, String name) {
return key.toString(); //The return will be used as file name
}
/** The following 4 functions are only for visibility purposes
(they are used in the class MyRecordWriter) **/
protected String generateLeafFileName(String name) {
return super.generateLeafFileName(name);
}
protected V generateActualValue(K key, V value) {
return super.generateActualValue(key, value);
}
protected String getInputFileBasedOutputFileName(JobConf job, String name) {
return super.getInputFileBasedOutputFileName(job, name);
}
protected RecordWriter<K, V> getBaseRecordWriter(FileSystem fs, JobConf job, String name, Progressable arg3) throws IOException {
return super.getBaseRecordWriter(fs, job, name, arg3);
}
/** Use my custom RecordWriter **/
@Override
RecordWriter<K, V> getRecordWriter(final FileSystem fs, final JobConf job, String name, final Progressable arg3) throws IOException {
final String myName = this.generateLeafFileName(name);
return new MyRecordWriter<K, V>(this, fs, job, arg3, myName);
}
}
以下是我RecordWriter
实施的代码。
class MyRecordWriter<K, V> implements RecordWriter<K, V> {
private RDDMultipleTextOutputFormat<K, V> rddMultipleTextOutputFormat;
private final FileSystem fs;
private final JobConf job;
private final Progressable arg3;
private String myName;
TreeMap<String, RecordWriter<K, V>> recordWriters = new TreeMap();
MyRecordWriter(RDDMultipleTextOutputFormat<K, V> rddMultipleTextOutputFormat, FileSystem fs, JobConf job, Progressable arg3, String myName) {
this.rddMultipleTextOutputFormat = rddMultipleTextOutputFormat;
this.fs = fs;
this.job = job;
this.arg3 = arg3;
this.myName = myName;
}
@Override
void write(K key, V value) throws IOException {
String keyBasedPath = rddMultipleTextOutputFormat.generateFileNameForKeyValue(key, value, myName);
String finalPath = rddMultipleTextOutputFormat.getInputFileBasedOutputFileName(job, keyBasedPath);
Object actualValue = rddMultipleTextOutputFormat.generateActualValue(key, value);
RecordWriter rw = this.recordWriters.get(finalPath);
if(rw == null) {
rw = rddMultipleTextOutputFormat.getBaseRecordWriter(fs, job, finalPath, arg3);
this.recordWriters.put(finalPath, rw);
}
List<String> lines = (List<String>) actualValue;
for (String line : lines) {
rw.write(null, line);
}
}
@Override
void close(Reporter reporter) throws IOException {
Iterator keys = this.recordWriters.keySet().iterator();
while(keys.hasNext()) {
RecordWriter rw = (RecordWriter)this.recordWriters.get(keys.next());
rw.close(reporter);
}
this.recordWriters.clear();
}
}
大部分代码与FileOutputFormat
完全相同。唯一的区别是那几行
List<String> lines = (List<String>) actualValue;
for (String line : lines) {
rw.write(null, line);
}
这些行允许我在文件上写下输入List<String>
的每一行。 write
函数的第一个参数设置为null
,以避免在每一行上写入密钥。
要完成,我只需要执行此调用来编写我的文件
javaPairRDD.saveAsHadoopFile(path, String.class, List.class, RDDMultipleTextOutputFormat.class);