Skip to content
Snippets Groups Projects
Commit a685e65a authored by Josh Rosen's avatar Josh Rosen
Browse files

Revert "[SPARK-14719] WriteAheadLogBasedBlockHandler should ignore BlockManager put errors"

This reverts commit ed2de029.
parent ecd877e8
No related branches found
No related tags found
No related merge requests found
...@@ -20,7 +20,6 @@ package org.apache.spark.streaming.receiver ...@@ -20,7 +20,6 @@ package org.apache.spark.streaming.receiver
import scala.concurrent.{ExecutionContext, Future} import scala.concurrent.{ExecutionContext, Future}
import scala.concurrent.duration._ import scala.concurrent.duration._
import scala.language.{existentials, postfixOps} import scala.language.{existentials, postfixOps}
import scala.util.control.NonFatal
import org.apache.hadoop.conf.Configuration import org.apache.hadoop.conf.Configuration
import org.apache.hadoop.fs.Path import org.apache.hadoop.fs.Path
...@@ -190,19 +189,14 @@ private[streaming] class WriteAheadLogBasedBlockHandler( ...@@ -190,19 +189,14 @@ private[streaming] class WriteAheadLogBasedBlockHandler(
// Store the block in block manager // Store the block in block manager
val storeInBlockManagerFuture = Future { val storeInBlockManagerFuture = Future {
try { val putSucceeded = blockManager.putBytes(
val putSucceeded = blockManager.putBytes( blockId,
blockId, serializedBlock,
serializedBlock, effectiveStorageLevel,
effectiveStorageLevel, tellMaster = true)
tellMaster = true) if (!putSucceeded) {
if (!putSucceeded) { throw new SparkException(
logWarning( s"Could not store $blockId to block manager with storage level $storageLevel")
s"Could not store $blockId to block manager with storage level $storageLevel")
}
} catch {
case NonFatal(t) =>
logError(s"Could not store $blockId to block manager with storage level $storageLevel", t)
} }
} }
......
...@@ -127,17 +127,7 @@ class ReceivedBlockHandlerSuite ...@@ -127,17 +127,7 @@ class ReceivedBlockHandlerSuite
test("BlockManagerBasedBlockHandler - handle errors in storing block") { test("BlockManagerBasedBlockHandler - handle errors in storing block") {
withBlockManagerBasedBlockHandler { handler => withBlockManagerBasedBlockHandler { handler =>
// Handle error in iterator (e.g. divide-by-zero error) testErrorHandling(handler)
intercept[Exception] {
val iterator = (10 to (-10, -1)).toIterator.map { _ / 0 }
handler.storeBlock(StreamBlockId(1, 1), IteratorBlock(iterator))
}
// Handler error in block manager storing (e.g. too big block)
intercept[SparkException] {
val byteBuffer = ByteBuffer.wrap(new Array[Byte](blockManagerSize + 1))
handler.storeBlock(StreamBlockId(1, 1), ByteBufferBlock(byteBuffer))
}
} }
} }
...@@ -177,15 +167,7 @@ class ReceivedBlockHandlerSuite ...@@ -177,15 +167,7 @@ class ReceivedBlockHandlerSuite
test("WriteAheadLogBasedBlockHandler - handle errors in storing block") { test("WriteAheadLogBasedBlockHandler - handle errors in storing block") {
withWriteAheadLogBasedBlockHandler { handler => withWriteAheadLogBasedBlockHandler { handler =>
// Handle error in iterator (e.g. divide-by-zero error) testErrorHandling(handler)
intercept[Exception] {
val iterator = (10 to (-10, -1)).toIterator.map { _ / 0 }
handler.storeBlock(StreamBlockId(1, 1), IteratorBlock(iterator))
}
// Throws no errors when storing blocks that are too large to be cached
val byteBuffer = ByteBuffer.wrap(new Array[Byte](blockManagerSize + 1))
handler.storeBlock(StreamBlockId(1, 1), ByteBufferBlock(byteBuffer))
} }
} }
...@@ -222,26 +204,26 @@ class ReceivedBlockHandlerSuite ...@@ -222,26 +204,26 @@ class ReceivedBlockHandlerSuite
sparkConf.set("spark.storage.unrollFraction", "0.4") sparkConf.set("spark.storage.unrollFraction", "0.4")
// Block Manager with 12000 * 0.4 = 4800 bytes of free space for unroll // Block Manager with 12000 * 0.4 = 4800 bytes of free space for unroll
blockManager = createBlockManager(12000, sparkConf) blockManager = createBlockManager(12000, sparkConf)
// This block is way too large to possibly be cached in memory:
def hugeBlock: IteratorBlock = IteratorBlock(List.fill(100)(new Array[Byte](1000)).iterator)
// there is not enough space to store this block in MEMORY, // there is not enough space to store this block in MEMORY,
// But BlockManager will be able to serialize this block to WAL // But BlockManager will be able to serialize this block to WAL
// and hence count returns correct value. // and hence count returns correct value.
testRecordcount(false, StorageLevel.MEMORY_ONLY, hugeBlock, blockManager, Some(100)) testRecordcount(false, StorageLevel.MEMORY_ONLY,
IteratorBlock((List.fill(70)(new Array[Byte](100))).iterator), blockManager, Some(70))
// there is not enough space to store this block in MEMORY, // there is not enough space to store this block in MEMORY,
// But BlockManager will be able to serialize this block to DISK // But BlockManager will be able to serialize this block to DISK
// and hence count returns correct value. // and hence count returns correct value.
testRecordcount(true, StorageLevel.MEMORY_AND_DISK, hugeBlock, blockManager, Some(100)) testRecordcount(true, StorageLevel.MEMORY_AND_DISK,
IteratorBlock((List.fill(70)(new Array[Byte](100))).iterator), blockManager, Some(70))
// there is not enough space to store this block With MEMORY_ONLY StorageLevel. // there is not enough space to store this block With MEMORY_ONLY StorageLevel.
// BlockManager will not be able to unroll this block // BlockManager will not be able to unroll this block
// and hence it will not tryToPut this block, resulting the SparkException // and hence it will not tryToPut this block, resulting the SparkException
storageLevel = StorageLevel.MEMORY_ONLY storageLevel = StorageLevel.MEMORY_ONLY
withBlockManagerBasedBlockHandler { handler => withBlockManagerBasedBlockHandler { handler =>
intercept[SparkException] { val thrown = intercept[SparkException] {
storeSingleBlock(handler, hugeBlock) storeSingleBlock(handler, IteratorBlock((List.fill(70)(new Array[Byte](100))).iterator))
} }
} }
} }
...@@ -364,6 +346,21 @@ class ReceivedBlockHandlerSuite ...@@ -364,6 +346,21 @@ class ReceivedBlockHandlerSuite
storeAndVerify(blocks.map { b => ByteBufferBlock(dataToByteBuffer(b).toByteBuffer) }) storeAndVerify(blocks.map { b => ByteBufferBlock(dataToByteBuffer(b).toByteBuffer) })
} }
/** Test error handling when blocks that cannot be stored */
private def testErrorHandling(receivedBlockHandler: ReceivedBlockHandler) {
// Handle error in iterator (e.g. divide-by-zero error)
intercept[Exception] {
val iterator = (10 to (-10, -1)).toIterator.map { _ / 0 }
receivedBlockHandler.storeBlock(StreamBlockId(1, 1), IteratorBlock(iterator))
}
// Handler error in block manager storing (e.g. too big block)
intercept[SparkException] {
val byteBuffer = ByteBuffer.wrap(new Array[Byte](blockManagerSize + 1))
receivedBlockHandler.storeBlock(StreamBlockId(1, 1), ByteBufferBlock(byteBuffer))
}
}
/** Instantiate a BlockManagerBasedBlockHandler and run a code with it */ /** Instantiate a BlockManagerBasedBlockHandler and run a code with it */
private def withBlockManagerBasedBlockHandler(body: BlockManagerBasedBlockHandler => Unit) { private def withBlockManagerBasedBlockHandler(body: BlockManagerBasedBlockHandler => Unit) {
body(new BlockManagerBasedBlockHandler(blockManager, storageLevel)) body(new BlockManagerBasedBlockHandler(blockManager, storageLevel))
......
0% Loading or .
You are about to add 0 people to the discussion. Proceed with caution.
Finish editing this message first!
Please register or to comment