Skip to content

Commit

Permalink
Compilation fixes
Browse files Browse the repository at this point in the history
  • Loading branch information
Ilya Ganelin committed Jun 30, 2015
1 parent 4a04b2a commit b74ca30
Show file tree
Hide file tree
Showing 3 changed files with 5 additions and 5 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -20,6 +20,9 @@ package org.apache.spark.util.collection
import java.io._
import java.util.Comparator

import scala.collection.mutable
import scala.collection.mutable.ArrayBuffer

import com.google.common.annotations.VisibleForTesting
import com.google.common.io.ByteStreams
import org.apache.spark._
Expand All @@ -28,9 +31,6 @@ import org.apache.spark.serializer._
import org.apache.spark.shuffle.sort.SortShuffleFileWriter
import org.apache.spark.storage.{BlockId, BlockObjectWriter}

import scala.collection.mutable
import scala.collection.mutable.ArrayBuffer

/**
* Sorts and potentially merges a number of key-value pairs of type (K, V) to produce key-combiner
* pairs of type (K, C). Uses a Partitioner to first group the keys into partitions, and then
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -86,7 +86,7 @@ private[spark] class ExternalSorterAgg[K, V, C](
partitioner: Option[Partitioner] = None,
ordering: Option[Ordering[K]] = None,
serializer: Option[Serializer] = None)
extends ExternalSorterParent[K,V,C]
extends ExternalSorter[K,V,C]
with Spillable[WritablePartitionedPairCollection[K, C]]
with SortShuffleFileWriter[K, V] {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -84,7 +84,7 @@ private[spark] class ExternalSorterNoAgg[K, V, C](
partitioner: Option[Partitioner] = None,
ordering: Option[Ordering[K]] = None,
serializer: Option[Serializer] = None)
extends ExternalSorterParent[K, V, C](partitioner, ordering, serializer)
extends ExternalSorter[K, V, C](partitioner, ordering, serializer)
with Spillable[WritablePartitionedPairCollection[K, C]]
with SortShuffleFileWriter[K, V] {

Expand Down

0 comments on commit b74ca30

Please sign in to comment.