File tree Expand file tree Collapse file tree 2 files changed +4
-4
lines changed
core/src/main/scala/org/apache/spark/shuffle Expand file tree Collapse file tree 2 files changed +4
-4
lines changed Original file line number Diff line number Diff line change @@ -22,7 +22,7 @@ import java.nio.ByteBuffer
2222
2323import com .google .common .io .ByteStreams
2424
25- import org .apache .spark .SparkEnv
25+ import org .apache .spark .{ SparkConf , SparkEnv }
2626import org .apache .spark .network .buffer .{FileSegmentManagedBuffer , ManagedBuffer }
2727import org .apache .spark .network .netty .SparkTransportConf
2828import org .apache .spark .storage ._
@@ -39,11 +39,11 @@ import org.apache.spark.storage._
3939// Note: Changes to the format in this file should be kept in sync with
4040// org.apache.spark.network.shuffle.StandaloneShuffleBlockManager#getSortBasedShuffleBlockData().
4141private [spark]
42- class IndexShuffleBlockManager extends ShuffleBlockManager {
42+ class IndexShuffleBlockManager ( conf : SparkConf ) extends ShuffleBlockManager {
4343
4444 private lazy val blockManager = SparkEnv .get.blockManager
4545
46- private val transportConf = SparkTransportConf .fromSparkConf(SparkEnv .get. conf)
46+ private val transportConf = SparkTransportConf .fromSparkConf(conf)
4747
4848 /**
4949 * Mapping to a single shuffleBlockId with reduce ID 0.
Original file line number Diff line number Diff line change @@ -25,7 +25,7 @@ import org.apache.spark.shuffle.hash.HashShuffleReader
2525
2626private [spark] class SortShuffleManager (conf : SparkConf ) extends ShuffleManager {
2727
28- private val indexShuffleBlockManager = new IndexShuffleBlockManager ()
28+ private val indexShuffleBlockManager = new IndexShuffleBlockManager (conf )
2929 private val shuffleMapNumber = new ConcurrentHashMap [Int , Int ]()
3030
3131 /**
You can’t perform that action at this time.
0 commit comments