You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by xuanyuanking <gi...@git.apache.org> on 2018/11/23 21:23:04 UTC

[GitHub] spark pull request #23128: [SPARK-26139][SQL] Support passing shuffle metric...

GitHub user xuanyuanking opened a pull request:

    https://github.com/apache/spark/pull/23128

    [SPARK-26139][SQL] Support passing shuffle metrics to exchange operator

    ## What changes were proposed in this pull request?
    
    Implement `SQLShuffleMetricsReporter` on the sql side as the customized ShuffleMetricsReporter, which extended the `TempShuffleReadMetrics` and update SQLMetrics, in this way shuffle metrics can be reported in the SQL UI.
    
    ## How was this patch tested?
    
    Add UT in SQLMetricsSuite.
    Manual test locally, before:
    ![image](https://user-images.githubusercontent.com/4833765/48960517-30f97880-efa8-11e8-982c-92d05938fd1d.png)
    after:
    ![image](https://user-images.githubusercontent.com/4833765/48960587-b54bfb80-efa8-11e8-8e95-7a3c8c74cc5c.png)


You can merge this pull request into a Git repository by running:

    $ git pull https://github.com/xuanyuanking/spark SPARK-26142

Alternatively you can review and apply these changes as the patch at:

    https://github.com/apache/spark/pull/23128.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

    This closes #23128
    
----
commit fba590f040c8fd7ce75df3f733f246db18e79ee6
Author: Reynold Xin <rx...@...>
Date:   2018-11-21T14:56:23Z

    [SPARK-26140] Pull TempShuffleReadMetrics creation out of shuffle reader

commit 35b48b21028110742aed7f7f5b5d62109c2f0adf
Author: Reynold Xin <rx...@...>
Date:   2018-11-21T15:02:04Z

    less movement of code

commit 1b556ecf869685af8f34d448ac3f08102a758124
Author: liyuanjian <li...@...>
Date:   2018-11-23T21:02:25Z

    [SPARK-26142] Implement shuffle read metric in SQL

----


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99308 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99308/testReport)** for PR 23128 at commit [`8689acb`](https://github.com/apache/spark/commit/8689acbc6c1f106d7b2d906bcd627147f649e6ff).
     * This patch **fails due to an unknown error code, -9**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5424/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Implement shuffle read metrics...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236926403
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/ShuffledRowRDD.scala ---
    @@ -154,7 +156,10 @@ class ShuffledRowRDD(
     
       override def compute(split: Partition, context: TaskContext): Iterator[InternalRow] = {
         val shuffledRowPartition = split.asInstanceOf[ShuffledRowRDDPartition]
    -    val metrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    val tempMetrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    // metrics here could be empty cause user can use ShuffledRowRDD directly,
    +    // so we just use the tempMetrics created in TaskContext in this case.
    --- End diff --
    
    Removing this.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5440/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99225 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99225/testReport)** for PR 23128 at commit [`cb46bfe`](https://github.com/apache/spark/commit/cb46bfeb930b71d560340393e95097ee66303862).


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99236/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99363 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99363/testReport)** for PR 23128 at commit [`8e84c5b`](https://github.com/apache/spark/commit/8e84c5bbfc4b9151310bce84c1506c6aad449011).


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    thanks , merging to master!


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5316/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99311 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99311/testReport)** for PR 23128 at commit [`8689acb`](https://github.com/apache/spark/commit/8689acbc6c1f106d7b2d906bcd627147f649e6ff).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99225 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99225/testReport)** for PR 23128 at commit [`cb46bfe`](https://github.com/apache/spark/commit/cb46bfeb930b71d560340393e95097ee66303862).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99334 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99334/testReport)** for PR 23128 at commit [`0348ae5`](https://github.com/apache/spark/commit/0348ae54aca3e268f45cfa8778a2867df849fe93).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Support passing shuffle metric...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236637264
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/ShuffledRowRDD.scala ---
    @@ -154,7 +156,14 @@ class ShuffledRowRDD(
     
       override def compute(split: Partition, context: TaskContext): Iterator[InternalRow] = {
         val shuffledRowPartition = split.asInstanceOf[ShuffledRowRDDPartition]
    -    val metrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    val tempMetrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    // metrics here could be empty cause user can use ShuffledRowRDD directly,
    --- End diff --
    
    do you mean we may leave the `metrics` empty when creating `ShuffledRowRDD` in tests?


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Support passing shuffle metric...

Posted by rxin <gi...@git.apache.org>.
Github user rxin commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236025817
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLShuffleMetricsReporter.scala ---
    @@ -0,0 +1,60 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.sql.execution.metric
    +
    +import org.apache.spark.executor.TempShuffleReadMetrics
    +
    +/**
    + * A shuffle metrics reporter for SQL exchange operators.
    + * @param tempMetrics [[TempShuffleReadMetrics]] created in TaskContext.
    + * @param metrics All metrics in current SparkPlan.
    + */
    +class SQLShuffleMetricsReporter(
    +  tempMetrics: TempShuffleReadMetrics,
    +  metrics: Map[String, SQLMetric]) extends TempShuffleReadMetrics {
    +
    +  override def incRemoteBlocksFetched(v: Long): Unit = {
    +    metrics(SQLMetrics.REMOTE_BLOCKS_FETCHED).add(v)
    --- End diff --
    
    Doing a hashmap lookup here could introduce serious performance regressions.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Implement shuffle read metrics...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236982643
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/ShuffledRowRDD.scala ---
    @@ -154,7 +156,10 @@ class ShuffledRowRDD(
     
       override def compute(split: Partition, context: TaskContext): Iterator[InternalRow] = {
         val shuffledRowPartition = split.asInstanceOf[ShuffledRowRDDPartition]
    -    val metrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    val tempMetrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    // Wrap the tempMetrics with SQLShuffleMetricsReporter here to support
    +    // shuffle read metrics in SQL.
    --- End diff --
    
    Thanks Wenchen, done in 8e84c5b.


---

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


[GitHub] spark issue #23128: [SPARK-26139][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99355 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99355/testReport)** for PR 23128 at commit [`d12ea31`](https://github.com/apache/spark/commit/d12ea311e58e7925f21d343e5de13bfec6737549).


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99347 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99347/testReport)** for PR 23128 at commit [`d12ea31`](https://github.com/apache/spark/commit/d12ea311e58e7925f21d343e5de13bfec6737549).
     * This patch **fails PySpark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99334 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99334/testReport)** for PR 23128 at commit [`0348ae5`](https://github.com/apache/spark/commit/0348ae54aca3e268f45cfa8778a2867df849fe93).


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Implement shuffle read metrics...

Posted by asfgit <gi...@git.apache.org>.
Github user asfgit closed the pull request at:

    https://github.com/apache/spark/pull/23128


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99236 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99236/testReport)** for PR 23128 at commit [`8689acb`](https://github.com/apache/spark/commit/8689acbc6c1f106d7b2d906bcd627147f649e6ff).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99236 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99236/testReport)** for PR 23128 at commit [`8689acb`](https://github.com/apache/spark/commit/8689acbc6c1f106d7b2d906bcd627147f649e6ff).


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Implement shuffle read metrics...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r237346431
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLMetrics.scala ---
    @@ -194,4 +202,16 @@ object SQLMetrics {
             SparkListenerDriverAccumUpdates(executionId.toLong, metrics.map(m => m.id -> m.value)))
         }
       }
    +
    +  /**
    +   * Create all shuffle read relative metrics and return the Map.
    +   */
    +  def getShuffleReadMetrics(sc: SparkContext): Map[String, SQLMetric] = Map(
    --- End diff --
    
    Thanks, rename it to createShuffleReadMetrics and move to SQLShuffleMetricsReporter.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by rxin <gi...@git.apache.org>.
Github user rxin commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    @xuanyuanking @cloud-fan when you think about where to put each code block, make sure you also think about future evolution of the codebase. In general put relevant things closer to each other (e.g. in one class, one file, or one method).



---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Implement shuffle read metrics...

Posted by rxin <gi...@git.apache.org>.
Github user rxin commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r237129249
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLMetrics.scala ---
    @@ -82,6 +82,14 @@ object SQLMetrics {
     
       private val baseForAvgMetric: Int = 10
     
    +  val REMOTE_BLOCKS_FETCHED = "remoteBlocksFetched"
    --- End diff --
    
    rather than putting this list and the getShuffleReadMetrics function here, we should move it into SQLShuffleMetricsReporter. Otherwise in the future when one adds another metric, he/she is likely to forget to update SQLShuffleMetricsReporter.



---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99311/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99355 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99355/testReport)** for PR 23128 at commit [`d12ea31`](https://github.com/apache/spark/commit/d12ea311e58e7925f21d343e5de13bfec6737549).
     * This patch **fails due to an unknown error code, -9**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    @rxin Thanks for guidance, I'll address these comments in a follow up PR soon.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99363 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99363/testReport)** for PR 23128 at commit [`8e84c5b`](https://github.com/apache/spark/commit/8e84c5bbfc4b9151310bce84c1506c6aad449011).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99223 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99223/testReport)** for PR 23128 at commit [`cb46bfe`](https://github.com/apache/spark/commit/cb46bfeb930b71d560340393e95097ee66303862).


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99220/
    Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99220 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99220/testReport)** for PR 23128 at commit [`1b556ec`](https://github.com/apache/spark/commit/1b556ecf869685af8f34d448ac3f08102a758124).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds the following public classes _(experimental)_:
      * `class SQLShuffleMetricsReporter(`


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99308/
    Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #4440 has started](https://amplab.cs.berkeley.edu/jenkins/job/NewSparkPullRequestBuilder/4440/testReport)** for PR 23128 at commit [`cb46bfe`](https://github.com/apache/spark/commit/cb46bfeb930b71d560340393e95097ee66303862).


---

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


[GitHub] spark issue #23128: [SPARK-26139][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5312/
    Test PASSed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Support passing shuffle metric...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236108610
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLMetrics.scala ---
    @@ -82,6 +82,14 @@ object SQLMetrics {
     
       private val baseForAvgMetric: Int = 10
     
    +  val REMOTE_BLOCKS_FETCHED = "remoteBlocksFetched"
    +  val LOCAL_BLOCKS_FETCHED = "localBlocksFetched"
    +  val REMOTE_BYTES_READ = "remoteBytesRead"
    +  val REMOTE_BYTES_READ_TO_DISK = "remoteBytesReadToDisk"
    +  val LOCAL_BYTES_READ = "localBytesRead"
    +  val FETCH_WAIT_TIME = "fetchWaitTime"
    +  val RECORDS_READ = "recordsRead"
    --- End diff --
    
    Is there an easy way to sync this list with `ShuffleReadMetrics` instead of doing it manually?


---

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


[GitHub] spark issue #23128: [SPARK-26139][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99220 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99220/testReport)** for PR 23128 at commit [`1b556ec`](https://github.com/apache/spark/commit/1b556ecf869685af8f34d448ac3f08102a758124).


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Support passing shuffle metric...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236251210
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLMetrics.scala ---
    @@ -82,6 +82,14 @@ object SQLMetrics {
     
       private val baseForAvgMetric: Int = 10
     
    +  val REMOTE_BLOCKS_FETCHED = "remoteBlocksFetched"
    +  val LOCAL_BLOCKS_FETCHED = "localBlocksFetched"
    +  val REMOTE_BYTES_READ = "remoteBytesRead"
    +  val REMOTE_BYTES_READ_TO_DISK = "remoteBytesReadToDisk"
    +  val LOCAL_BYTES_READ = "localBytesRead"
    +  val FETCH_WAIT_TIME = "fetchWaitTime"
    +  val RECORDS_READ = "recordsRead"
    --- End diff --
    
    Thanks for your advise Wenchen, I tried `sync this list with ShuffleReadMetrics` locally and left these comments below:
    1. It's easy to sync SQLMetrics with `ShuffleReadMetrics` while the task has only one shuffle reader, just call `ShuffleMetricsReporter.incXXX` to achieve this.
    2. But for multi shuffle reader in single task, we need add `setXXX` functions in `ShuffleMetricsReporter` trait, cause we need reset the SQLMetrics after `setMergeValues` called by every shuffle reader.
    3. I also tried to achieve this but not change the `ShuffleMetricsReporter`, like call the `ShuffleMetricsReporter.incXXX` at driver side when taskEnd, but maybe this is not a good way.
    
    If you think it's make sense to change the `ShuffleMetricsReporter` trait, I'll give a commit soon.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Implement shuffle read metrics...

Posted by rxin <gi...@git.apache.org>.
Github user rxin commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r237128247
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLShuffleMetricsReporter.scala ---
    @@ -0,0 +1,67 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.sql.execution.metric
    +
    +import org.apache.spark.executor.TempShuffleReadMetrics
    +
    +/**
    + * A shuffle metrics reporter for SQL exchange operators.
    + * @param tempMetrics [[TempShuffleReadMetrics]] created in TaskContext.
    + * @param metrics All metrics in current SparkPlan. This param should not empty and
    + *   contains all shuffle metrics defined in [[SQLMetrics.getShuffleReadMetrics]].
    + */
    +private[spark] class SQLShuffleMetricsReporter(
    +  tempMetrics: TempShuffleReadMetrics,
    --- End diff --
    
    4 space indent


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Thanks @cloud-fan @gatorsmile @rxin !


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99359 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99359/testReport)** for PR 23128 at commit [`d12ea31`](https://github.com/apache/spark/commit/d12ea311e58e7925f21d343e5de13bfec6737549).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99225/
    Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99308 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99308/testReport)** for PR 23128 at commit [`8689acb`](https://github.com/apache/spark/commit/8689acbc6c1f106d7b2d906bcd627147f649e6ff).


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99223/
    Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by gatorsmile <gi...@git.apache.org>.
Github user gatorsmile commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    @xuanyuanking Could you address the conflicts? Thanks for you fast work!


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99363/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5391/
    Test PASSed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Support passing shuffle metric...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236646423
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/ShuffledRowRDD.scala ---
    @@ -154,7 +156,14 @@ class ShuffledRowRDD(
     
       override def compute(split: Partition, context: TaskContext): Iterator[InternalRow] = {
         val shuffledRowPartition = split.asInstanceOf[ShuffledRowRDDPartition]
    -    val metrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    val tempMetrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    // metrics here could be empty cause user can use ShuffledRowRDD directly,
    --- End diff --
    
    ```
    do you mean we may leave the metrics empty when creating ShuffledRowRDD in tests?
    ```
    Yes, like we did in `UnsafeRowSerializerSuite`.
    ```
    I don't think we need to consider this case since ShuffledRowRDD is a private API
    ```
    Got it, after search `new ShuffledRowRDD` in all source code, `UnsafeRowSerializerSuite` is the only place, I'll change the test and delete the default value of `metrics` in this commit.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    retest this please


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Support passing shuffle metric...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236032855
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLShuffleMetricsReporter.scala ---
    @@ -0,0 +1,60 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.sql.execution.metric
    +
    +import org.apache.spark.executor.TempShuffleReadMetrics
    +
    +/**
    + * A shuffle metrics reporter for SQL exchange operators.
    + * @param tempMetrics [[TempShuffleReadMetrics]] created in TaskContext.
    + * @param metrics All metrics in current SparkPlan.
    + */
    +class SQLShuffleMetricsReporter(
    +  tempMetrics: TempShuffleReadMetrics,
    +  metrics: Map[String, SQLMetric]) extends TempShuffleReadMetrics {
    +
    +  override def incRemoteBlocksFetched(v: Long): Unit = {
    +    metrics(SQLMetrics.REMOTE_BLOCKS_FETCHED).add(v)
    --- End diff --
    
    Sorry for the less consideration on per-row operation here, I should be more careful. Fix done in cb46bfe.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Support passing shuffle metric...

Posted by rxin <gi...@git.apache.org>.
Github user rxin commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236025838
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLShuffleMetricsReporter.scala ---
    @@ -0,0 +1,60 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.sql.execution.metric
    +
    +import org.apache.spark.executor.TempShuffleReadMetrics
    +
    +/**
    + * A shuffle metrics reporter for SQL exchange operators.
    + * @param tempMetrics [[TempShuffleReadMetrics]] created in TaskContext.
    + * @param metrics All metrics in current SparkPlan.
    + */
    +class SQLShuffleMetricsReporter(
    +  tempMetrics: TempShuffleReadMetrics,
    +  metrics: Map[String, SQLMetric]) extends TempShuffleReadMetrics {
    +
    +  override def incRemoteBlocksFetched(v: Long): Unit = {
    +    metrics(SQLMetrics.REMOTE_BLOCKS_FETCHED).add(v)
    --- End diff --
    
    (I’m not referring to just this function, but in general, especially for per-row).


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Support passing shuffle metric...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236720141
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/ShuffledRowRDD.scala ---
    @@ -154,7 +156,14 @@ class ShuffledRowRDD(
     
       override def compute(split: Partition, context: TaskContext): Iterator[InternalRow] = {
         val shuffledRowPartition = split.asInstanceOf[ShuffledRowRDDPartition]
    -    val metrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    val tempMetrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    // metrics here could be empty cause user can use ShuffledRowRDD directly,
    --- End diff --
    
    Done in 0348ae5.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99359 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99359/testReport)** for PR 23128 at commit [`d12ea31`](https://github.com/apache/spark/commit/d12ea311e58e7925f21d343e5de13bfec6737549).


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Implement shuffle read metrics...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r237346452
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLShuffleMetricsReporter.scala ---
    @@ -0,0 +1,67 @@
    +/*
    + * Licensed to the Apache Software Foundation (ASF) under one or more
    + * contributor license agreements.  See the NOTICE file distributed with
    + * this work for additional information regarding copyright ownership.
    + * The ASF licenses this file to You under the Apache License, Version 2.0
    + * (the "License"); you may not use this file except in compliance with
    + * the License.  You may obtain a copy of the License at
    + *
    + *    http://www.apache.org/licenses/LICENSE-2.0
    + *
    + * Unless required by applicable law or agreed to in writing, software
    + * distributed under the License is distributed on an "AS IS" BASIS,
    + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    + * See the License for the specific language governing permissions and
    + * limitations under the License.
    + */
    +
    +package org.apache.spark.sql.execution.metric
    +
    +import org.apache.spark.executor.TempShuffleReadMetrics
    +
    +/**
    + * A shuffle metrics reporter for SQL exchange operators.
    + * @param tempMetrics [[TempShuffleReadMetrics]] created in TaskContext.
    + * @param metrics All metrics in current SparkPlan. This param should not empty and
    + *   contains all shuffle metrics defined in [[SQLMetrics.getShuffleReadMetrics]].
    + */
    +private[spark] class SQLShuffleMetricsReporter(
    +  tempMetrics: TempShuffleReadMetrics,
    --- End diff --
    
    Thanks ,done in https://github.com/apache/spark/pull/23175.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99347 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99347/testReport)** for PR 23128 at commit [`d12ea31`](https://github.com/apache/spark/commit/d12ea311e58e7925f21d343e5de13bfec6737549).


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99347/
    Test FAILed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Implement shuffle read metrics...

Posted by rxin <gi...@git.apache.org>.
Github user rxin commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r237128189
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/metric/SQLMetrics.scala ---
    @@ -194,4 +202,16 @@ object SQLMetrics {
             SparkListenerDriverAccumUpdates(executionId.toLong, metrics.map(m => m.id -> m.value)))
         }
       }
    +
    +  /**
    +   * Create all shuffle read relative metrics and return the Map.
    +   */
    +  def getShuffleReadMetrics(sc: SparkContext): Map[String, SQLMetric] = Map(
    --- End diff --
    
    I'd prefer to name this create, rather than get, to imply we are creating a new set rather than just returning some existing sets.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5436/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99359/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5394/
    Test PASSed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Implement shuffle read metrics...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236976020
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/ShuffledRowRDD.scala ---
    @@ -154,7 +156,10 @@ class ShuffledRowRDD(
     
       override def compute(split: Partition, context: TaskContext): Iterator[InternalRow] = {
         val shuffledRowPartition = split.asInstanceOf[ShuffledRowRDDPartition]
    -    val metrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    val tempMetrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    // Wrap the tempMetrics with SQLShuffleMetricsReporter here to support
    +    // shuffle read metrics in SQL.
    --- End diff --
    
    ```
    // `SQLShuffleMetricsReporter` will update its own metrics for SQL exchange operator,
    // as well as the `tempMetrics` for basic shuffle metrics.
    ```


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    retest this please


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5412/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5433/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99223 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99223/testReport)** for PR 23128 at commit [`cb46bfe`](https://github.com/apache/spark/commit/cb46bfeb930b71d560340393e95097ee66303862).
     * This patch **fails due to an unknown error code, -9**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    python UT failed cause jvm crush.
    retest this pleas.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99334/
    Test PASSed.


---

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


[GitHub] spark pull request #23128: [SPARK-26142][SQL] Support passing shuffle metric...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on a diff in the pull request:

    https://github.com/apache/spark/pull/23128#discussion_r236636819
  
    --- Diff: sql/core/src/main/scala/org/apache/spark/sql/execution/ShuffledRowRDD.scala ---
    @@ -154,7 +156,14 @@ class ShuffledRowRDD(
     
       override def compute(split: Partition, context: TaskContext): Iterator[InternalRow] = {
         val shuffledRowPartition = split.asInstanceOf[ShuffledRowRDDPartition]
    -    val metrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    val tempMetrics = context.taskMetrics().createTempShuffleReadMetrics()
    +    // metrics here could be empty cause user can use ShuffledRowRDD directly,
    --- End diff --
    
    I don't think we need to consider this case since `ShuffledRowRDD` is a private API. If we do need to consider it, we also need to take care if users pass in a `metrics` that is invalid.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    retest this please


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    retest this please.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    @gatorsmile Thanks Xiao! Conflicts resolve done, as Reynold comments in https://github.com/apache/spark/pull/23105#discussion_r235950427, when the ShuffleMetricsReporter move to ShuffleReadMetricsReporter in write pr, it will conflict again here, I'll keep tracking the relevant pr.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by cloud-fan <gi...@git.apache.org>.
Github user cloud-fan commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    LGTM except one comment


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/99355/
    Test FAILed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Implement shuffle read metrics in SQL

Posted by xuanyuanking <gi...@git.apache.org>.
Github user xuanyuanking commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    retest this please


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #99311 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/99311/testReport)** for PR 23128 at commit [`8689acb`](https://github.com/apache/spark/commit/8689acbc6c1f106d7b2d906bcd627147f649e6ff).


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5314/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Merged build finished. Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by AmplabJenkins <gi...@git.apache.org>.
Github user AmplabJenkins commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins//job/testing-k8s-prb-make-spark-distribution-unified/5325/
    Test PASSed.


---

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


[GitHub] spark issue #23128: [SPARK-26142][SQL] Support passing shuffle metrics to ex...

Posted by SparkQA <gi...@git.apache.org>.
Github user SparkQA commented on the issue:

    https://github.com/apache/spark/pull/23128
  
    **[Test build #4440 has finished](https://amplab.cs.berkeley.edu/jenkins/job/NewSparkPullRequestBuilder/4440/testReport)** for PR 23128 at commit [`cb46bfe`](https://github.com/apache/spark/commit/cb46bfeb930b71d560340393e95097ee66303862).
     * This patch passes all tests.
     * This patch **does not merge cleanly**.
     * This patch adds no public classes.


---

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