File tree Expand file tree Collapse file tree 2 files changed +12
-2
lines changed
common/network-shuffle/src/main/java/org/apache/spark/network/shuffle
core/src/test/scala/org/apache/spark/storage Expand file tree Collapse file tree 2 files changed +12
-2
lines changed Original file line number Diff line number Diff line change @@ -152,7 +152,7 @@ public void onBlockPrepareFailure(Throwable exception) {
152152 if (this == currentListener ) {
153153 initiateRetry ();
154154 } else {
155- logger .error (String .format ("BM@ PrepareBlock failed to send blocks' info, " +
155+ logger .error (String .format ("PrepareBlock failed to send blocks' info, " +
156156 "and will not retry (%s retries)" , retryCount ), exception );
157157 shouldForwardFailure = true ;
158158 }
Original file line number Diff line number Diff line change @@ -39,7 +39,7 @@ import org.apache.spark.memory.UnifiedMemoryManager
3939import org .apache .spark .network .{BlockDataManager , BlockTransferService }
4040import org .apache .spark .network .buffer .{ManagedBuffer , NioManagedBuffer }
4141import org .apache .spark .network .netty .NettyBlockTransferService
42- import org .apache .spark .network .shuffle .BlockFetchingListener
42+ import org .apache .spark .network .shuffle .{ BlockFetchingListener , BlockPreparingListener }
4343import org .apache .spark .rpc .RpcEnv
4444import org .apache .spark .scheduler .LiveListenerBus
4545import org .apache .spark .serializer .{JavaSerializer , KryoSerializer , SerializerManager }
@@ -1241,6 +1241,16 @@ class BlockManagerSuite extends SparkFunSuite with Matchers with BeforeAndAfterE
12411241 Future {}
12421242 }
12431243
1244+ override def prepareBlocks (
1245+ host : String ,
1246+ port : Int ,
1247+ execId : String ,
1248+ prepareBlockIds : Array [String ],
1249+ releaseBlocks : Array [String ],
1250+ listener : BlockPreparingListener ): Unit = {
1251+ listener.onBlockPrepareSuccess(" mockBlockId" , new NioManagedBuffer (ByteBuffer .allocate(1 )))
1252+ }
1253+
12441254 override def fetchBlockSync (
12451255 host : String ,
12461256 port : Int ,
You can’t perform that action at this time.
0 commit comments