Skip to content

Commit a3da81c

Browse files
committed
Revert some unwanted changes
1 parent 34865d2 commit a3da81c

File tree

3 files changed

+3
-3
lines changed

3 files changed

+3
-3
lines changed

core/src/main/scala/org/apache/spark/shuffle/ShuffleMemoryManager.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -92,7 +92,7 @@ private[spark] class ShuffleMemoryManager(maxMemory: Long) extends Logging {
9292
}
9393

9494
/** Release numBytes bytes for the current thread. */
95-
def release(numBytes: Long): Unit = synchronized {
95+
def release(numBytes: Long): Unit = synchronized {
9696
val threadId = Thread.currentThread().getId
9797
val curMem = threadMemory.getOrElse(threadId, 0L)
9898
if (curMem < numBytes) {

core/src/main/scala/org/apache/spark/shuffle/hash/BlockStoreShuffleFetcher.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -27,7 +27,7 @@ import org.apache.spark.shuffle.FetchFailedException
2727
import org.apache.spark.storage.{BlockId, BlockManagerId, ShuffleBlockFetcherIterator, ShuffleBlockId}
2828
import org.apache.spark.util.CompletionIterator
2929

30-
private[shuffle] object BlockStoreShuffleFetcher extends Logging {
30+
private[hash] object BlockStoreShuffleFetcher extends Logging {
3131
def fetch[T](
3232
shuffleId: Int,
3333
reduceId: Int,

core/src/main/scala/org/apache/spark/storage/ShuffleBlockFetcherIterator.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -125,7 +125,7 @@ final class ShuffleRawBlockFetcherIterator(
125125
* Current [[FetchResult]] being processed. We track this so we can release the current buffer
126126
* in case of a runtime exception when processing the current buffer.
127127
*/
128-
private[spark] var currentResult: FetchResult = null
128+
@volatile private[spark] var currentResult: FetchResult = null
129129

130130
/**
131131
* Queue of fetch requests to issue; we'll pull requests off this gradually to make sure that

0 commit comments

Comments
 (0)