You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by tgravescs <gi...@git.apache.org> on 2018/08/02 17:53:33 UTC

[GitHub] spark pull request #21451: [SPARK-24296][CORE] Replicate large blocks as a s...

Github user tgravescs commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21451#discussion_r207309822
  
    --- Diff: core/src/main/scala/org/apache/spark/network/netty/NettyBlockRpcServer.scala ---
    @@ -73,10 +73,32 @@ class NettyBlockRpcServer(
             }
             val data = new NioManagedBuffer(ByteBuffer.wrap(uploadBlock.blockData))
             val blockId = BlockId(uploadBlock.blockId)
    +        logInfo(s"Receiving replicated block $blockId with level ${level} " +
    +          s"from ${client.getSocketAddress}")
             blockManager.putBlockData(blockId, data, level, classTag)
             responseContext.onSuccess(ByteBuffer.allocate(0))
         }
       }
     
    +  override def receiveStream(
    +      client: TransportClient,
    +      messageHeader: ByteBuffer,
    +    responseContext: RpcResponseCallback): StreamCallbackWithID = {
    --- End diff --
    
    fix spacing


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org