You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by zsxwing <gi...@git.apache.org> on 2015/10/20 16:00:38 UTC

[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

GitHub user zsxwing opened a pull request:

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

    [SPARK-11212][Core][Streaming]Make preferred locations support ExecutorCacheTaskLocation and update…

    … ReceiverTracker and ReceiverSchedulingPolicy to use it
    
    This PR includes the following changes:
    
    1. Add a new preferred location format, `executor_<host>_<executorID>` (e.g., "executor_localhost_2"), to support specifying the executor locations for RDD.
    2. Use the new preferred location format in `ReceiverTracker` to optimize the starting time of Receivers when there are multiple executors in a host. 

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

    $ git pull https://github.com/zsxwing/spark executor-location

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

    https://github.com/apache/spark/pull/9181.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 #9181
    
----
commit f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2
Author: zsxwing <zs...@gmail.com>
Date:   2015-10-20T11:42:04Z

    Make preferred locations support ExecutorCacheTaskLocation and update ReceiverTracker and ReceiverSchedulingPolicy to use it

----


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r43063147
  
    --- Diff: streaming/src/main/scala/org/apache/spark/streaming/scheduler/ReceiverSchedulingPolicy.scala ---
    @@ -30,22 +30,22 @@ import org.apache.spark.util.Utils
      * - The first phase is global scheduling when ReceiverTracker is starting and we need to schedule
      *   all receivers at the same time. ReceiverTracker will call `scheduleReceivers` at this phase.
      *   It will try to schedule receivers with evenly distributed. ReceiverTracker should update its
    --- End diff --
    
    nit: grammar. It will try to scheduler receiver such that they are evenly distributed


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by zsxwing <gi...@git.apache.org>.
Github user zsxwing commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-149581655
  
    I tested this patch using 5 workers, 24 executors, 24 receivers and there were no receiver restarting logs in the test.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

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


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r43063234
  
    --- Diff: streaming/src/main/scala/org/apache/spark/streaming/scheduler/ReceiverSchedulingPolicy.scala ---
    @@ -30,22 +30,22 @@ import org.apache.spark.util.Utils
      * - The first phase is global scheduling when ReceiverTracker is starting and we need to schedule
      *   all receivers at the same time. ReceiverTracker will call `scheduleReceivers` at this phase.
      *   It will try to schedule receivers with evenly distributed. ReceiverTracker should update its
    - *   receiverTrackingInfoMap according to the results of `scheduleReceivers`.
    - *   `ReceiverTrackingInfo.scheduledExecutors` for each receiver will set to an executor list that
    + *   `receiverTrackingInfoMap` according to the results of `scheduleReceivers`.
    + *   `ReceiverTrackingInfo.scheduledLocations` for each receiver will set to an location list that
    --- End diff --
    
    nit: will set --> should be set


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by zsxwing <gi...@git.apache.org>.
Github user zsxwing commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-151341978
  
    @tdas addressed your comments.
    
    > Its probably a good idea to also add executor information, not just the host.
    
    For this one, I prefer to add the executor info in a separate PR and also add it to UI.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149810748
  
    Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by srowen <gi...@git.apache.org>.
Github user srowen commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-149790070
  
    @zsxwing I think this duplicated the existing issue / PR https://github.com/apache/spark/pull/9096 . Does this cover the same logic, and, can you include all of the changes here?


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r43063455
  
    --- Diff: streaming/src/main/scala/org/apache/spark/streaming/scheduler/ReceiverSchedulingPolicy.scala ---
    @@ -163,40 +169,46 @@ private[streaming] class ReceiverSchedulingPolicy {
           receiverId: Int,
           preferredLocation: Option[String],
           receiverTrackingInfoMap: Map[Int, ReceiverTrackingInfo],
    -      executors: Seq[String]): Seq[String] = {
    +      executors: Seq[ExecutorCacheTaskLocation]): Seq[TaskLocation] = {
         if (executors.isEmpty) {
           return Seq.empty
         }
     
         // Always try to schedule to the preferred locations
    -    val scheduledExecutors = mutable.Set[String]()
    -    scheduledExecutors ++= preferredLocation
    -
    -    val executorWeights = receiverTrackingInfoMap.values.flatMap { receiverTrackingInfo =>
    -      receiverTrackingInfo.state match {
    -        case ReceiverState.INACTIVE => Nil
    -        case ReceiverState.SCHEDULED =>
    -          val scheduledExecutors = receiverTrackingInfo.scheduledExecutors.get
    -          // The probability that a scheduled receiver will run in an executor is
    -          // 1.0 / scheduledLocations.size
    -          scheduledExecutors.map(location => location -> (1.0 / scheduledExecutors.size))
    -        case ReceiverState.ACTIVE => Seq(receiverTrackingInfo.runningExecutor.get -> 1.0)
    -      }
    -    }.groupBy(_._1).mapValues(_.map(_._2).sum) // Sum weights for each executor
    +    val scheduledLocations = mutable.Set[TaskLocation]()
    +    // Note: preferredLocation could be `HDFSCacheTaskLocation`, so use `TaskLocation.apply` to
    +    // handle this case
    +    scheduledLocations ++= preferredLocation.map(TaskLocation(_))
    +
    +    val executorWeights: Map[ExecutorCacheTaskLocation, Double] =
    --- End diff --
    
    nit: would be good to put a `{...}` around this whole thing.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

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


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by zsxwing <gi...@git.apache.org>.
Github user zsxwing commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-149754736
  
    retest this please


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-150274327
  
    Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151370433
  
    **[Test build #44390 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44390/consoleFull)** for PR 9181 at commit [`63c66eb`](https://github.com/apache/spark/commit/63c66eb231b034820ace712299946ebaef7c922e).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r42543028
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskLocation.scala ---
    @@ -65,7 +70,15 @@ private[spark] object TaskLocation {
       def apply(str: String): TaskLocation = {
         val hstr = str.stripPrefix(inMemoryLocationTag)
         if (hstr.equals(str)) {
    -      new HostTaskLocation(str)
    +      if (str.startsWith(executorLocationTag)) {
    +        val splits = str.split("_")
    +        if (splits.length != 3) {
    +          throw new IllegalArgumentException("Illegal executor location format: " + str)
    +        }
    +        new ExecutorCacheTaskLocation(splits(1), splits(2))
    +      } else {
    +        new HostTaskLocation(str)
    +      }
         } else {
    --- End diff --
    
    @andrewor14 @kayousterhout 
    Can you take a look at this change?


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r43063559
  
    --- Diff: streaming/src/main/scala/org/apache/spark/streaming/scheduler/ReceiverSchedulingPolicy.scala ---
    @@ -163,40 +169,46 @@ private[streaming] class ReceiverSchedulingPolicy {
           receiverId: Int,
           preferredLocation: Option[String],
           receiverTrackingInfoMap: Map[Int, ReceiverTrackingInfo],
    -      executors: Seq[String]): Seq[String] = {
    +      executors: Seq[ExecutorCacheTaskLocation]): Seq[TaskLocation] = {
         if (executors.isEmpty) {
           return Seq.empty
         }
     
         // Always try to schedule to the preferred locations
    -    val scheduledExecutors = mutable.Set[String]()
    -    scheduledExecutors ++= preferredLocation
    -
    -    val executorWeights = receiverTrackingInfoMap.values.flatMap { receiverTrackingInfo =>
    -      receiverTrackingInfo.state match {
    -        case ReceiverState.INACTIVE => Nil
    -        case ReceiverState.SCHEDULED =>
    -          val scheduledExecutors = receiverTrackingInfo.scheduledExecutors.get
    -          // The probability that a scheduled receiver will run in an executor is
    -          // 1.0 / scheduledLocations.size
    -          scheduledExecutors.map(location => location -> (1.0 / scheduledExecutors.size))
    -        case ReceiverState.ACTIVE => Seq(receiverTrackingInfo.runningExecutor.get -> 1.0)
    -      }
    -    }.groupBy(_._1).mapValues(_.map(_._2).sum) // Sum weights for each executor
    +    val scheduledLocations = mutable.Set[TaskLocation]()
    +    // Note: preferredLocation could be `HDFSCacheTaskLocation`, so use `TaskLocation.apply` to
    +    // handle this case
    +    scheduledLocations ++= preferredLocation.map(TaskLocation(_))
    +
    +    val executorWeights: Map[ExecutorCacheTaskLocation, Double] =
    +      receiverTrackingInfoMap.values.flatMap { receiverTrackingInfo =>
    +        receiverTrackingInfo.state match {
    --- End diff --
    
    can you make this a separation method, this is getting pretty big and hard to read.
    and add comments.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r42567524
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskLocation.scala ---
    @@ -65,7 +70,15 @@ private[spark] object TaskLocation {
       def apply(str: String): TaskLocation = {
         val hstr = str.stripPrefix(inMemoryLocationTag)
         if (hstr.equals(str)) {
    -      new HostTaskLocation(str)
    +      if (str.startsWith(executorLocationTag)) {
    +        val splits = str.split("_")
    +        if (splits.length != 3) {
    +          throw new IllegalArgumentException("Illegal executor location format: " + str)
    +        }
    +        new ExecutorCacheTaskLocation(splits(1), splits(2))
    +      } else {
    +        new HostTaskLocation(str)
    +      }
         } else {
    --- End diff --
    
    @zsxwing Please do so. :)


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149577147
  
    Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r42559207
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskLocation.scala ---
    @@ -65,7 +70,15 @@ private[spark] object TaskLocation {
       def apply(str: String): TaskLocation = {
         val hstr = str.stripPrefix(inMemoryLocationTag)
         if (hstr.equals(str)) {
    -      new HostTaskLocation(str)
    +      if (str.startsWith(executorLocationTag)) {
    +        val splits = str.split("_")
    +        if (splits.length != 3) {
    +          throw new IllegalArgumentException("Illegal executor location format: " + str)
    +        }
    +        new ExecutorCacheTaskLocation(splits(1), splits(2))
    +      } else {
    +        new HostTaskLocation(str)
    +      }
         } else {
    --- End diff --
    
    The goal of this PR is to enable the streaming scheduler to place receivers (which run as tasks) in specific executors. Basically, I want to have more control on the placement of the receivers such that they are evenly distributed among the executors. We tried to do this without changing the core scheduling logic, but its not possible to precisely put a task in a specific executor with this change. I dont think this change affects the performance of anything else. 
    
    Also this is not exposed to the user. Only the streaming scheduler uses this.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-150236704
  
    **[Test build #44148 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44148/consoleFull)** for PR 9181 at commit [`35f7936`](https://github.com/apache/spark/commit/35f7936ac38551d13c0dc253c05d63a95a4ff30d).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-150233593
  
     Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151370544
  
    Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

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


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149577116
  
     Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151441563
  
    Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151343451
  
    **[Test build #44390 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44390/consoleFull)** for PR 9181 at commit [`63c66eb`](https://github.com/apache/spark/commit/63c66eb231b034820ace712299946ebaef7c922e).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

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


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149770944
  
    **[Test build #44028 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44028/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

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


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by zsxwing <gi...@git.apache.org>.
Github user zsxwing commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-149791460
  
    > @zsxwing I think this duplicated the existing issue / PR #9096 . Does this cover the same logic, and, can you include all of the changes here?
    
    This is a different issue that only about `ExecutorCacheTaskLocation`.  #9096 is a minor patch. I can update this one after #9096 gets merged.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-150274113
  
    **[Test build #44148 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44148/consoleFull)** for PR 9181 at commit [`35f7936`](https://github.com/apache/spark/commit/35f7936ac38551d13c0dc253c05d63a95a4ff30d).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151341966
  
    Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149770988
  
    Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149771668
  
    Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by zsxwing <gi...@git.apache.org>.
Github user zsxwing commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-149791252
  
    retest this please


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149754838
  
     Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r43066104
  
    --- Diff: streaming/src/test/scala/org/apache/spark/streaming/scheduler/ReceiverSchedulingPolicySuite.scala ---
    @@ -20,73 +20,102 @@ package org.apache.spark.streaming.scheduler
     import scala.collection.mutable
     
     import org.apache.spark.SparkFunSuite
    +import org.apache.spark.scheduler.{ExecutorCacheTaskLocation, HostTaskLocation, TaskLocation}
     
     class ReceiverSchedulingPolicySuite extends SparkFunSuite {
     
       val receiverSchedulingPolicy = new ReceiverSchedulingPolicy
     
       test("rescheduleReceiver: empty executors") {
    -    val scheduledExecutors =
    +    val scheduledLocations =
           receiverSchedulingPolicy.rescheduleReceiver(0, None, Map.empty, executors = Seq.empty)
    -    assert(scheduledExecutors === Seq.empty)
    +    assert(scheduledLocations === Seq.empty)
       }
     
       test("rescheduleReceiver: receiver preferredLocation") {
    +    val executors = Seq(ExecutorCacheTaskLocation("host2", "2"))
         val receiverTrackingInfoMap = Map(
           0 -> ReceiverTrackingInfo(0, ReceiverState.INACTIVE, None, None))
    -    val scheduledExecutors = receiverSchedulingPolicy.rescheduleReceiver(
    -      0, Some("host1"), receiverTrackingInfoMap, executors = Seq("host2"))
    -    assert(scheduledExecutors.toSet === Set("host1", "host2"))
    +    val scheduledLocations = receiverSchedulingPolicy.rescheduleReceiver(
    +      0, Some("host1"), receiverTrackingInfoMap, executors)
    +    assert(scheduledLocations.toSet === Set(HostTaskLocation("host1"), executors(0)))
       }
     
       test("rescheduleReceiver: return all idle executors if there are any idle executors") {
    -    val executors = Seq("host1", "host2", "host3", "host4", "host5")
    -    // host3 is idle
    +    val executors = Seq(
    +      ExecutorCacheTaskLocation("host1", "1"),
    +      ExecutorCacheTaskLocation("host2", "2"),
    +      ExecutorCacheTaskLocation("host3", "3"),
    +      ExecutorCacheTaskLocation("host4", "4"),
    +      ExecutorCacheTaskLocation("host5", "5")
    +    )
    --- End diff --
    
    I this can be replaced with `(1 to 5).map { i => ExecutorCacheTaskLocation(s"host$i", s"$i") }`


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149580488
  
    **[Test build #43982 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43982/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r42553779
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskLocation.scala ---
    @@ -65,7 +70,15 @@ private[spark] object TaskLocation {
       def apply(str: String): TaskLocation = {
         val hstr = str.stripPrefix(inMemoryLocationTag)
         if (hstr.equals(str)) {
    -      new HostTaskLocation(str)
    +      if (str.startsWith(executorLocationTag)) {
    +        val splits = str.split("_")
    +        if (splits.length != 3) {
    +          throw new IllegalArgumentException("Illegal executor location format: " + str)
    +        }
    +        new ExecutorCacheTaskLocation(splits(1), splits(2))
    +      } else {
    +        new HostTaskLocation(str)
    +      }
         } else {
    --- End diff --
    
    Is this necessary because previously, we didn't allow the user to pass in ExecutorCacheTaskLocations and we just tried to figure them out automatically? (and why doesn't that work here?)


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151341950
  
     Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by tdas <gi...@git.apache.org>.
Github user tdas commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-151311797
  
    Overall, LGTM, except a few minor refactorings.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r42563250
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/TaskLocation.scala ---
    @@ -65,7 +70,15 @@ private[spark] object TaskLocation {
       def apply(str: String): TaskLocation = {
         val hstr = str.stripPrefix(inMemoryLocationTag)
         if (hstr.equals(str)) {
    -      new HostTaskLocation(str)
    +      if (str.startsWith(executorLocationTag)) {
    +        val splits = str.split("_")
    +        if (splits.length != 3) {
    +          throw new IllegalArgumentException("Illegal executor location format: " + str)
    +        }
    +        new ExecutorCacheTaskLocation(splits(1), splits(2))
    +      } else {
    +        new HostTaskLocation(str)
    +      }
         } else {
    --- End diff --
    
    Ok sounds good -- can you add this description to the JIRA and to the pull request description (so that it will be in the commit message)?  Scheduler changes LGTM.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

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


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151441532
  
     Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149741013
  
    Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by zsxwing <gi...@git.apache.org>.
Github user zsxwing commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-149771567
  
    retest this please


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149754547
  
    Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149771656
  
     Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r43065282
  
    --- Diff: streaming/src/main/scala/org/apache/spark/streaming/scheduler/ReceiverTrackingInfo.scala ---
    @@ -47,7 +48,7 @@ private[streaming] case class ReceiverTrackingInfo(
         receiverId,
         name.getOrElse(""),
         state == ReceiverState.ACTIVE,
    -    location = runningExecutor.getOrElse(""),
    +    location = runningExecutor.map(_.host).getOrElse(""),
    --- End diff --
    
    Its probably a good idea to also add executor information, not just the host. 


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149755965
  
    **[Test build #44028 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44028/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

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


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by srowen <gi...@git.apache.org>.
Github user srowen commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-150180536
  
    @zsxwing I merged #9096 


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r42498602
  
    --- Diff: streaming/src/main/scala/org/apache/spark/streaming/scheduler/ReceiverSchedulingPolicy.scala ---
    @@ -69,9 +69,12 @@ private[streaming] class ReceiverSchedulingPolicy {
        * </ol>
        *
        * This method is called when we start to launch receivers at the first time.
    +   *
    +   * @return a map for receivers and their scheduled locations
        */
       def scheduleReceivers(
    -      receivers: Seq[Receiver[_]], executors: Seq[String]): Map[Int, Seq[String]] = {
    +      receivers: Seq[Receiver[_]],
    +      executors: Seq[ExecutorCacheTaskLocation]): Map[Int, Seq[TaskLocation]] = {
    --- End diff --
    
    Use `TaskLocation` in the return type because the locations could be host from `Receiver.preferredLocation`, or `ExecutorCacheTaskLocation`.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149791747
  
     Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149754506
  
    **[Test build #44022 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44022/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

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


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149791758
  
    Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151442220
  
    **[Test build #44420 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44420/consoleFull)** for PR 9181 at commit [`46c5197`](https://github.com/apache/spark/commit/46c5197c946cbed75ac28e1b60e64266ca070ee1).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by zsxwing <gi...@git.apache.org>.
Github user zsxwing commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-151345061
  
    > For this one, I prefer to add the executor info in a separate PR and also add it to UI.
    
    Created https://issues.apache.org/jira/browse/SPARK-11333 to track it


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151476236
  
    Merged build finished. Test PASSed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149741288
  
    **[Test build #44022 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44022/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149784741
  
    Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149740994
  
     Merged build triggered.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149810630
  
    **[Test build #44048 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44048/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-150233670
  
    Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#discussion_r43093391
  
    --- Diff: streaming/src/main/scala/org/apache/spark/streaming/scheduler/ReceiverSchedulingPolicy.scala ---
    @@ -163,40 +169,59 @@ private[streaming] class ReceiverSchedulingPolicy {
           receiverId: Int,
           preferredLocation: Option[String],
           receiverTrackingInfoMap: Map[Int, ReceiverTrackingInfo],
    -      executors: Seq[String]): Seq[String] = {
    +      executors: Seq[ExecutorCacheTaskLocation]): Seq[TaskLocation] = {
         if (executors.isEmpty) {
           return Seq.empty
         }
     
         // Always try to schedule to the preferred locations
    -    val scheduledExecutors = mutable.Set[String]()
    -    scheduledExecutors ++= preferredLocation
    -
    -    val executorWeights = receiverTrackingInfoMap.values.flatMap { receiverTrackingInfo =>
    -      receiverTrackingInfo.state match {
    -        case ReceiverState.INACTIVE => Nil
    -        case ReceiverState.SCHEDULED =>
    -          val scheduledExecutors = receiverTrackingInfo.scheduledExecutors.get
    -          // The probability that a scheduled receiver will run in an executor is
    -          // 1.0 / scheduledLocations.size
    -          scheduledExecutors.map(location => location -> (1.0 / scheduledExecutors.size))
    -        case ReceiverState.ACTIVE => Seq(receiverTrackingInfo.runningExecutor.get -> 1.0)
    -      }
    -    }.groupBy(_._1).mapValues(_.map(_._2).sum) // Sum weights for each executor
    +    val scheduledLocations = mutable.Set[TaskLocation]()
    +    // Note: preferredLocation could be `HDFSCacheTaskLocation`, so use `TaskLocation.apply` to
    +    // handle this case
    +    scheduledLocations ++= preferredLocation.map(TaskLocation(_))
    +
    +    val executorWeights: Map[ExecutorCacheTaskLocation, Double] = {
    +      receiverTrackingInfoMap.values.flatMap(convertReceiverTrackingInfoToExecutorWeights)
    +        .groupBy(_._1).mapValues(_.map(_._2).sum) // Sum weights for each executor
    +    }
     
         val idleExecutors = executors.toSet -- executorWeights.keys
         if (idleExecutors.nonEmpty) {
    -      scheduledExecutors ++= idleExecutors
    +      scheduledLocations ++= idleExecutors
         } else {
           // There is no idle executor. So select all executors that have the minimum weight.
           val sortedExecutors = executorWeights.toSeq.sortBy(_._2)
           if (sortedExecutors.nonEmpty) {
             val minWeight = sortedExecutors(0)._2
    -        scheduledExecutors ++= sortedExecutors.takeWhile(_._2 == minWeight).map(_._1)
    +        scheduledLocations ++= sortedExecutors.takeWhile(_._2 == minWeight).map(_._1)
           } else {
             // This should not happen since "executors" is not empty
           }
         }
    -    scheduledExecutors.toSeq
    +    scheduledLocations.toSeq
    +  }
    +
    +  /**
    +   * This method tries to convert a receiver tracking info to executor weights. Every executor will
    +   * be assigned to a weight according to the receivers running or scheduling on it:
    +   *
    +   * - If a receiver is running on an executor, it contributes 1.0 to the executor's weight.
    +   * - If a receiver is scheduled to an executor but has not yet run, it contributes
    +   * `1.0 / #candidate_executors_of_this_receiver` to the executor's weight.
    +   */
    +  private def convertReceiverTrackingInfoToExecutorWeights(
    +      receiverTrackingInfo: ReceiverTrackingInfo): Seq[(ExecutorCacheTaskLocation, Double)] = {
    +    receiverTrackingInfo.state match {
    +      case ReceiverState.INACTIVE => Nil
    +      case ReceiverState.SCHEDULED =>
    +        val scheduledLocations = receiverTrackingInfo.scheduledLocations.get
    +        // The probability that a scheduled receiver will run in an executor is
    +        // 1.0 / scheduledLocations.size
    +        scheduledLocations.filter(_.isInstanceOf[ExecutorCacheTaskLocation]).
    +          map { location =>
    --- End diff --
    
    nit:shouldnt this map be in the line above? I think `.map { loc =>` would fit.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149627252
  
    Merged build finished. Test FAILed.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149626226
  
    **[Test build #43982 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43982/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-151475461
  
    **[Test build #44420 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44420/consoleFull)** for PR 9181 at commit [`46c5197`](https://github.com/apache/spark/commit/46c5197c946cbed75ac28e1b60e64266ca070ee1).
     * This patch passes all tests.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by tdas <gi...@git.apache.org>.
Github user tdas commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-151672088
  
    Merging this to master. Thanks @zsxwing 


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149784692
  
    **[Test build #44035 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44035/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).
     * This patch **fails Spark unit tests**.
     * This patch merges cleanly.
     * This patch adds no public classes.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149754854
  
    Merged build started.


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

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


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149772110
  
    **[Test build #44035 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44035/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

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

    https://github.com/apache/spark/pull/9181#issuecomment-149792826
  
    **[Test build #44048 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/44048/consoleFull)** for PR 9181 at commit [`f5e7c4f`](https://github.com/apache/spark/commit/f5e7c4f0fd24efd179b96725f8b5b0ed3450b4b2).


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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


[GitHub] spark pull request: [SPARK-11212][Core][Streaming]Make preferred l...

Posted by zsxwing <gi...@git.apache.org>.
Github user zsxwing commented on the pull request:

    https://github.com/apache/spark/pull/9181#issuecomment-149740564
  
    retest this please


---
If your project is set up for it, you can reply to this email and have your
reply appear on GitHub as well. If your project does not have this feature
enabled and wishes so, or if the feature is enabled but not working, please
contact infrastructure at infrastructure@apache.org or file a JIRA ticket
with INFRA.
---

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