Skip to content

Commit

Permalink
Double check and clean few nits
Browse files Browse the repository at this point in the history
  • Loading branch information
HyukjinKwon committed Feb 26, 2017
1 parent 647457c commit 2294a19
Show file tree
Hide file tree
Showing 2 changed files with 2 additions and 3 deletions.
2 changes: 1 addition & 1 deletion core/src/test/java/test/org/apache/spark/JavaAPISuite.java
Original file line number Diff line number Diff line change
Expand Up @@ -1071,7 +1071,7 @@ public void writeWithNewAPIHadoopFile() {

rdd.mapToPair(pair -> new Tuple2<>(new IntWritable(pair._1()), new Text(pair._2())))
.saveAsNewAPIHadoopFile(outputDir, IntWritable.class, Text.class,
org.apache.hadoop.mapreduce.lib.output.SequenceFileOutputFormat.class);
org.apache.hadoop.mapreduce.lib.output.SequenceFileOutputFormat.class);

JavaPairRDD<IntWritable, Text> output =
sc.sequenceFile(outputDir, IntWritable.class, Text.class);
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -146,8 +146,7 @@ public void testReduceByWindow() {

JavaDStream<Integer> stream = JavaTestUtils.attachTestInputStream(ssc, inputData, 1);
JavaDStream<Integer> reducedWindowed = stream.reduceByWindow(
(x, y) -> x + y,
(x, y) -> x - y, new Duration(2000), new Duration(1000));
(x, y) -> x + y, (x, y) -> x - y, new Duration(2000), new Duration(1000));
JavaTestUtils.attachTestOutputStream(reducedWindowed);
List<List<Integer>> result = JavaTestUtils.runStreams(ssc, 4, 4);

Expand Down

0 comments on commit 2294a19

Please sign in to comment.