You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by GitBox <gi...@apache.org> on 2020/03/18 17:08:13 UTC

[GitHub] [spark] sarthfrey opened a new pull request #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

sarthfrey opened a new pull request #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951
 
 
   This PR proposes that we change the return type of the `BarrierTaskContext.allGather` method to `Array[String]` instead of `ArrayBuffer[String]` since it is immutable. Based on discussion in #27640. cc @zhengruifeng @srowen 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] SparkQA removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
SparkQA removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600755979
 
 
   **[Test build #120000 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/120000/testReport)** for PR 27951 at commit [`baab965`](https://github.com/apache/spark/commit/baab9655153a1c20bfc8831c54dbf8b19e644e7d).

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600834577
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/120000/
   Test PASSed.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] srowen commented on a change in pull request #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
srowen commented on a change in pull request #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#discussion_r394541766
 
 

 ##########
 File path: core/src/main/scala/org/apache/spark/api/python/PythonRunner.scala
 ##########
 @@ -420,7 +420,7 @@ private[spark] abstract class BasePythonRunner[IN, OUT](
             context.asInstanceOf[BarrierTaskContext].barrier()
             result = BarrierTaskContextMessageProtocol.BARRIER_RESULT_SUCCESS
           case BarrierTaskContextMessageProtocol.ALL_GATHER_FUNCTION =>
-            val messages: ArrayBuffer[String] = context.asInstanceOf[BarrierTaskContext].allGather(
+            val messages: Array[String] = context.asInstanceOf[BarrierTaskContext].allGather(
 
 Review comment:
   You probably don't even need these types here and below, but it won't matter

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] mengxr removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
mengxr removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600796577
 
 
   jenkins, add to whitelist

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] HyukjinKwon closed pull request #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
HyukjinKwon closed pull request #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951
 
 
   

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] SparkQA commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600755979
 
 
   **[Test build #120000 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/120000/testReport)** for PR 27951 at commit [`baab965`](https://github.com/apache/spark/commit/baab9655153a1c20bfc8831c54dbf8b19e644e7d).

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] mengxr commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
mengxr commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600796577
 
 
   jenkins, add to whitelist

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] AmplabJenkins commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600834565
 
 
   Merged build finished. Test PASSed.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] AmplabJenkins commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600834577
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder/120000/
   Test PASSed.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] AmplabJenkins commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600756788
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/24720/
   Test PASSed.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600756788
 
 
   Test PASSed.
   Refer to this link for build results (access rights to CI server needed): 
   https://amplab.cs.berkeley.edu/jenkins//job/SparkPullRequestBuilder-K8s/24720/
   Test PASSed.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] SparkQA commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
SparkQA commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600833490
 
 
   **[Test build #120000 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/120000/testReport)** for PR 27951 at commit [`baab965`](https://github.com/apache/spark/commit/baab9655153a1c20bfc8831c54dbf8b19e644e7d).
    * This patch passes all tests.
    * This patch merges cleanly.
    * This patch adds no public classes.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600756777
 
 
   Merged build finished. Test PASSed.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] HyukjinKwon commented on issue #27951: [SPARK-30667][FOLLOW-UP][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
HyukjinKwon commented on issue #27951: [SPARK-30667][FOLLOW-UP][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600965094
 
 
   Merged to master and branch-3.0.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] AmplabJenkins commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
AmplabJenkins commented on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600756777
 
 
   Merged build finished. Test PASSed.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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


[GitHub] [spark] AmplabJenkins removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type

Posted by GitBox <gi...@apache.org>.
AmplabJenkins removed a comment on issue #27951: [SPARK-30667][CORE] Change BarrierTaskContext allGather method return type
URL: https://github.com/apache/spark/pull/27951#issuecomment-600834565
 
 
   Merged build finished. Test PASSed.

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

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