You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by felixb <gi...@git.apache.org> on 2015/09/07 10:30:25 UTC

[GitHub] spark pull request: [SPARK-10471] [CORE] [MESOS] prevent getting o...

GitHub user felixb opened a pull request:

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

    [SPARK-10471] [CORE] [MESOS] prevent getting offers for unmet constraints

    this change rejects offers for slaves with unmet constraints for 120s to mitigate offer starvation.
    this prevents mesos to send us these offers again and again.
    in return, we get more offers for slaves which might meet our constraints.
    and it enables mesos to send the rejected offers to other frameworks.

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

    $ git pull https://github.com/felixb/spark decline_offers_constraint_mismatch

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

    https://github.com/apache/spark/pull/8639.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 #8639
    
----
commit c1efb1fdd20f45260040d7f4dd5cd3aef13c5558
Author: Felix Bechstein <fe...@otto.de>
Date:   2015-09-04T12:29:22Z

    [SPARK-10471] [CORE] [MESOS] prevent getting offers for unmet constraints
    
    this change rejects offers for slaves with unmet constraints for 120s to mitigate offer starvation.
    this prevents mesos to send us these offers again and again.
    in return, we get more offers for slaves which might meet our constraints.
    and it enables mesos to send the rejected offers to other frameworks.

----


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140373792
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r39017029
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/CoarseMesosSchedulerBackend.scala ---
    @@ -240,48 +241,56 @@ private[spark] class CoarseMesosSchedulerBackend(
             val mem = getResource(offer.getResourcesList, "mem")
             val cpus = getResource(offer.getResourcesList, "cpus").toInt
             val id = offer.getId.getValue
    -        if (taskIdToSlaveId.size < executorLimit &&
    -            totalCoresAcquired < maxCores &&
    -            meetsConstraints &&
    -            mem >= calculateTotalMemory(sc) &&
    -            cpus >= 1 &&
    -            failuresBySlaveId.getOrElse(slaveId, 0) < MAX_SLAVE_FAILURES &&
    -            !slaveIdsWithExecutors.contains(slaveId)) {
    -          // Launch an executor on the slave
    -          val cpusToUse = math.min(cpus, maxCores - totalCoresAcquired)
    -          totalCoresAcquired += cpusToUse
    -          val taskId = newMesosTaskId()
    -          taskIdToSlaveId.put(taskId, slaveId)
    -          slaveIdsWithExecutors += slaveId
    -          coresByTaskId(taskId) = cpusToUse
    -          // Gather cpu resources from the available resources and use them in the task.
    -          val (remainingResources, cpuResourcesToUse) =
    -            partitionResources(offer.getResourcesList, "cpus", cpusToUse)
    -          val (_, memResourcesToUse) =
    -            partitionResources(remainingResources.asJava, "mem", calculateTotalMemory(sc))
    -          val taskBuilder = MesosTaskInfo.newBuilder()
    -            .setTaskId(TaskID.newBuilder().setValue(taskId.toString).build())
    -            .setSlaveId(offer.getSlaveId)
    -            .setCommand(createCommand(offer, cpusToUse + extraCoresPerSlave, taskId))
    -            .setName("Task " + taskId)
    -            .addAllResources(cpuResourcesToUse.asJava)
    -            .addAllResources(memResourcesToUse.asJava)
    -
    -          sc.conf.getOption("spark.mesos.executor.docker.image").foreach { image =>
    -            MesosSchedulerBackendUtil
    -              .setupContainerBuilderDockerInfo(image, sc.conf, taskBuilder.getContainerBuilder())
    +        if (meetsConstraints) {
    +          if (taskIdToSlaveId.size < executorLimit &&
    +              totalCoresAcquired < maxCores &&
    +              mem >= calculateTotalMemory(sc) &&
    +              cpus >= 1 &&
    +              failuresBySlaveId.getOrElse(slaveId, 0) < MAX_SLAVE_FAILURES &&
    +              !slaveIdsWithExecutors.contains(slaveId)) {
    +            // Launch an executor on the slave
    +            val cpusToUse = math.min(cpus, maxCores - totalCoresAcquired)
    +            totalCoresAcquired += cpusToUse
    +            val taskId = newMesosTaskId()
    +            taskIdToSlaveId.put(taskId, slaveId)
    +            slaveIdsWithExecutors += slaveId
    +            coresByTaskId(taskId) = cpusToUse
    +            // Gather cpu resources from the available resources and use them in the task.
    +            val (remainingResources, cpuResourcesToUse) =
    +              partitionResources(offer.getResourcesList, "cpus", cpusToUse)
    +            val (_, memResourcesToUse) =
    +              partitionResources(remainingResources.asJava, "mem", calculateTotalMemory(sc))
    +            val taskBuilder = MesosTaskInfo.newBuilder()
    +              .setTaskId(TaskID.newBuilder().setValue(taskId.toString).build())
    +              .setSlaveId(offer.getSlaveId)
    +              .setCommand(createCommand(offer, cpusToUse + extraCoresPerSlave, taskId))
    +              .setName("Task " + taskId)
    +              .addAllResources(cpuResourcesToUse.asJava)
    +              .addAllResources(memResourcesToUse.asJava)
    +
    +            sc.conf.getOption("spark.mesos.executor.docker.image").foreach { image =>
    +              MesosSchedulerBackendUtil
    +                .setupContainerBuilderDockerInfo(image, sc.conf, taskBuilder.getContainerBuilder())
    +            }
    +
    +            // accept the offer and launch the task
    --- End diff --
    
    Nit: Capitalize the first word as you did in all other 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-141053573
  
    @tnachen @andrewor14 friendly reminder..


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-138821818
  
    I think the change makes sense, we're planning to add dynamic attribute changes on the slave but that's not merged yet in Mesos. as @dragos mentioned please add this to coarse grain mode too.
    And once you make this a configuration please also update the spark on mesos docs in docs folder .


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r42299145
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/MesosSchedulerBackend.scala ---
    @@ -63,6 +63,10 @@ private[spark] class MesosSchedulerBackend(
       private[this] val slaveOfferConstraints =
         parseConstraintString(sc.conf.get("spark.mesos.constraints", ""))
     
    +  // reject offers with mismatched constraints in seconds
    +  private val rejectOfferDurationForUnmetConstraints =
    +    sc.conf.getDouble("spark.mesos.rejectOfferDurationForUnmetConstraints", 120)
    --- End diff --
    
    can you put this in `trait MesosSchedulerUtils` to avoid duplicating 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r39016904
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/CoarseMesosSchedulerBackend.scala ---
    @@ -56,6 +56,7 @@ private[spark] class CoarseMesosSchedulerBackend(
       with MesosSchedulerUtils {
     
       val MAX_SLAVE_FAILURES = 2     // Blacklist a slave after this many failures
    +  val CONSTRAINT_MISMATCH_REJECT_OFFER_DURATION = 120000   // reject offers with mismatched constraints
    --- End diff --
    
    Can we make this configurable? Also please comment on the unit as well.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139376508
  
      [Test build #42277 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42277/console) for   PR 8639 at commit [`bb79444`](https://github.com/apache/spark/commit/bb7944446c4b7e5f23dd13d94803ea44f2661d6d).
     * This patch **fails PySpark 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r42299061
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/CoarseMesosSchedulerBackend.scala ---
    @@ -101,6 +101,10 @@ private[spark] class CoarseMesosSchedulerBackend(
       private val slaveOfferConstraints =
         parseConstraintString(sc.conf.get("spark.mesos.constraints", ""))
     
    +  // reject offers with mismatched constraints in seconds
    +  private val rejectOfferDurationForUnmetConstraints =
    +    sc.conf.getDouble("spark.mesos.rejectOfferDurationForUnmetConstraints", 120)
    --- End diff --
    
    please use `conf.getTimeAsSeconds` instead, and maybe I would call this `spark.mesos.unmetConstraintsRejectOfferDuration`


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r42439180
  
    --- Diff: docs/running-on-mesos.md ---
    @@ -194,6 +194,10 @@ conf.set("spark.mesos.constraints", "tachyon:true;us-east-1:false")
     
     For example, Let's say `spark.mesos.constraints` is set to `tachyon:true;us-east-1:false`, then the resource offers will be checked to see if they meet both these constraints and only then will be accepted to start new executors.
     
    +Spark rejects offers for slaves with unmet constraints for 120 seconds by default.
    +This makes mesos not sending the rejected offers again and again.
    +The reject offer duration is configurable using `conf.set("spark.mesos.rejectOfferDurationForUnmetConstraints", "60")` (for example).
    --- End diff --
    
    it doesn't make sense to document how to set this without documenting the configuration myself. I would just revert the changes here altogether since this seems too low level for the user to care about.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-155203528
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139331306
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139485764
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140691897
  
      [Test build #42527 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42527/console) for   PR 8639 at commit [`9e00071`](https://github.com/apache/spark/commit/9e000717fafe1cf6660e3d90d17a6db67e720f21).
     * 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-155202360
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-138641241
  
    You should probably modify the fine-grained scheduler in the same way.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r42299119
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/CoarseMesosSchedulerBackend.scala ---
    @@ -244,48 +248,56 @@ private[spark] class CoarseMesosSchedulerBackend(
             val mem = getResource(offer.getResourcesList, "mem")
             val cpus = getResource(offer.getResourcesList, "cpus").toInt
             val id = offer.getId.getValue
    -        if (taskIdToSlaveId.size < executorLimit &&
    -            totalCoresAcquired < maxCores &&
    -            meetsConstraints &&
    -            mem >= calculateTotalMemory(sc) &&
    -            cpus >= 1 &&
    -            failuresBySlaveId.getOrElse(slaveId, 0) < MAX_SLAVE_FAILURES &&
    -            !slaveIdsWithExecutors.contains(slaveId)) {
    -          // Launch an executor on the slave
    -          val cpusToUse = math.min(cpus, maxCores - totalCoresAcquired)
    -          totalCoresAcquired += cpusToUse
    -          val taskId = newMesosTaskId()
    -          taskIdToSlaveId.put(taskId, slaveId)
    -          slaveIdsWithExecutors += slaveId
    -          coresByTaskId(taskId) = cpusToUse
    -          // Gather cpu resources from the available resources and use them in the task.
    -          val (remainingResources, cpuResourcesToUse) =
    -            partitionResources(offer.getResourcesList, "cpus", cpusToUse)
    -          val (_, memResourcesToUse) =
    -            partitionResources(remainingResources.asJava, "mem", calculateTotalMemory(sc))
    -          val taskBuilder = MesosTaskInfo.newBuilder()
    -            .setTaskId(TaskID.newBuilder().setValue(taskId.toString).build())
    -            .setSlaveId(offer.getSlaveId)
    -            .setCommand(createCommand(offer, cpusToUse + extraCoresPerSlave, taskId))
    -            .setName("Task " + taskId)
    -            .addAllResources(cpuResourcesToUse.asJava)
    -            .addAllResources(memResourcesToUse.asJava)
    -
    -          sc.conf.getOption("spark.mesos.executor.docker.image").foreach { image =>
    -            MesosSchedulerBackendUtil
    -              .setupContainerBuilderDockerInfo(image, sc.conf, taskBuilder.getContainerBuilder())
    +        if (meetsConstraints) {
    +          if (taskIdToSlaveId.size < executorLimit &&
    +              totalCoresAcquired < maxCores &&
    +              mem >= calculateTotalMemory(sc) &&
    +              cpus >= 1 &&
    +              failuresBySlaveId.getOrElse(slaveId, 0) < MAX_SLAVE_FAILURES &&
    +              !slaveIdsWithExecutors.contains(slaveId)) {
    +            // Launch an executor on the slave
    +            val cpusToUse = math.min(cpus, maxCores - totalCoresAcquired)
    +            totalCoresAcquired += cpusToUse
    +            val taskId = newMesosTaskId()
    +            taskIdToSlaveId.put(taskId, slaveId)
    +            slaveIdsWithExecutors += slaveId
    +            coresByTaskId(taskId) = cpusToUse
    +            // Gather cpu resources from the available resources and use them in the task.
    +            val (remainingResources, cpuResourcesToUse) =
    +              partitionResources(offer.getResourcesList, "cpus", cpusToUse)
    +            val (_, memResourcesToUse) =
    +              partitionResources(remainingResources.asJava, "mem", calculateTotalMemory(sc))
    +            val taskBuilder = MesosTaskInfo.newBuilder()
    +              .setTaskId(TaskID.newBuilder().setValue(taskId.toString).build())
    +              .setSlaveId(offer.getSlaveId)
    +              .setCommand(createCommand(offer, cpusToUse + extraCoresPerSlave, taskId))
    +              .setName("Task " + taskId)
    +              .addAllResources(cpuResourcesToUse.asJava)
    +              .addAllResources(memResourcesToUse.asJava)
    +
    +            sc.conf.getOption("spark.mesos.executor.docker.image").foreach { image =>
    +              MesosSchedulerBackendUtil
    +                .setupContainerBuilderDockerInfo(image, sc.conf, taskBuilder.getContainerBuilder())
    +            }
    +
    +            // Accept the offer and launch the task
    +            logDebug(s"Accepting offer: $id with attributes: $offerAttributes mem: $mem cpu: $cpus")
    +            slaveIdToHost(offer.getSlaveId.getValue) = offer.getHostname
    +            d.launchTasks(
    +              Collections.singleton(offer.getId),
    +              Collections.singleton(taskBuilder.build()), filters)
    +          } else {
    +            // Decline the offer
    +            logDebug(s"Declining offer: $id with attributes: $offerAttributes mem: $mem cpu: $cpus")
    +            d.declineOffer(offer.getId)
               }
    -
    -          // accept the offer and launch the task
    -          logDebug(s"Accepting offer: $id with attributes: $offerAttributes mem: $mem cpu: $cpus")
    -          slaveIdToHost(offer.getSlaveId.getValue) = offer.getHostname
    -          d.launchTasks(
    -            Collections.singleton(offer.getId),
    -            Collections.singleton(taskBuilder.build()), filters)
             } else {
    -          // Decline the offer
    -          logDebug(s"Declining offer: $id with attributes: $offerAttributes mem: $mem cpu: $cpus")
    -          d.declineOffer(offer.getId)
    +          // This offer does not meet constraints. We don't need to see it again.
    +          // Decline the offer for a long period of time.
    +          logDebug(s"Declining offer: $id with attributes: $offerAttributes mem: $mem cpu: $cpus"
    +              + s" for $rejectOfferDurationForUnmetConstraints")
    --- End diff --
    
    this needs to say `for X seconds`. Right now it looks like `Declining offer for 120`.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139492905
  
      [Test build #42321 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42321/console) for   PR 8639 at commit [`7626d45`](https://github.com/apache/spark/commit/7626d4587cfb29687e0b7f9c2c02ae24af54e043).
     * This patch **fails Scala style 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r40213360
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/CoarseMesosSchedulerBackend.scala ---
    @@ -244,48 +248,56 @@ private[spark] class CoarseMesosSchedulerBackend(
             val mem = getResource(offer.getResourcesList, "mem")
             val cpus = getResource(offer.getResourcesList, "cpus").toInt
             val id = offer.getId.getValue
    -        if (taskIdToSlaveId.size < executorLimit &&
    -            totalCoresAcquired < maxCores &&
    -            meetsConstraints &&
    -            mem >= calculateTotalMemory(sc) &&
    -            cpus >= 1 &&
    -            failuresBySlaveId.getOrElse(slaveId, 0) < MAX_SLAVE_FAILURES &&
    -            !slaveIdsWithExecutors.contains(slaveId)) {
    -          // Launch an executor on the slave
    -          val cpusToUse = math.min(cpus, maxCores - totalCoresAcquired)
    -          totalCoresAcquired += cpusToUse
    -          val taskId = newMesosTaskId()
    -          taskIdToSlaveId.put(taskId, slaveId)
    -          slaveIdsWithExecutors += slaveId
    -          coresByTaskId(taskId) = cpusToUse
    -          // Gather cpu resources from the available resources and use them in the task.
    -          val (remainingResources, cpuResourcesToUse) =
    -            partitionResources(offer.getResourcesList, "cpus", cpusToUse)
    -          val (_, memResourcesToUse) =
    -            partitionResources(remainingResources.asJava, "mem", calculateTotalMemory(sc))
    -          val taskBuilder = MesosTaskInfo.newBuilder()
    -            .setTaskId(TaskID.newBuilder().setValue(taskId.toString).build())
    -            .setSlaveId(offer.getSlaveId)
    -            .setCommand(createCommand(offer, cpusToUse + extraCoresPerSlave, taskId))
    -            .setName("Task " + taskId)
    -            .addAllResources(cpuResourcesToUse.asJava)
    -            .addAllResources(memResourcesToUse.asJava)
    -
    -          sc.conf.getOption("spark.mesos.executor.docker.image").foreach { image =>
    -            MesosSchedulerBackendUtil
    -              .setupContainerBuilderDockerInfo(image, sc.conf, taskBuilder.getContainerBuilder())
    +        if (meetsConstraints) {
    --- End diff --
    
    I had already done some refactoring around this specific area in patch #8771 


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r42300493
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/MesosSchedulerBackend.scala ---
    @@ -207,23 +211,44 @@ private[spark] class MesosSchedulerBackend(
        */
       override def resourceOffers(d: SchedulerDriver, offers: JList[Offer]) {
         inClassLoader() {
    +      // Fail first on offers with unmet constraints
    +      val (offersMatchingConstraints, offersNotMatchingConstraints) =
    +        offers.asScala.partition { o =>
    +          val offerAttributes = toAttributeMap(o.getAttributesList)
    +          val meetsConstraints =
    +            matchesAttributeRequirements(slaveOfferConstraints, offerAttributes)
    +
    +          // add some debug messaging
    +          if (!meetsConstraints) {
    +            val id = o.getId.getValue
    +            logDebug(s"Declining offer: $id with attributes: $offerAttributes")
    --- End diff --
    
    nit: just inline it
    ```
    logDebug(s"Declining offer: ${o.getId.getValue} with attributes: $offerAttributes")
    ```


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139492064
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-147971302
  
    friendly reminder.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149108977
  
    **[Test build #43914 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43914/consoleFull)** for PR 8639 at commit [`72a2855`](https://github.com/apache/spark/commit/72a2855f894c185ffe2e7f231ba1539293175551).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-144391953
  
    @andrewor14 Can you take a look at this and merge this patch? 


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139499531
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139492209
  
      [Test build #42321 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42321/consoleFull) for   PR 8639 at commit [`7626d45`](https://github.com/apache/spark/commit/7626d4587cfb29687e0b7f9c2c02ae24af54e043).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-141349042
  
      [Test build #42646 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42646/consoleFull) for   PR 8639 at commit [`58aaa79`](https://github.com/apache/spark/commit/58aaa79095143187175f0292d71b772b944440db).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139330353
  
    ok to 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139527733
  
      [Test build #42324 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42324/console) for   PR 8639 at commit [`66a1a73`](https://github.com/apache/spark/commit/66a1a73990ca4e93a2f4051d414379c86ff07f99).
     * 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149103542
  
    I worked in all your 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149531419
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43971/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140345570
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139376592
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42277/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-141375249
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139500642
  
      [Test build #42324 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42324/consoleFull) for   PR 8639 at commit [`66a1a73`](https://github.com/apache/spark/commit/66a1a73990ca4e93a2f4051d414379c86ff07f99).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139333863
  
      [Test build #42277 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42277/consoleFull) for   PR 8639 at commit [`bb79444`](https://github.com/apache/spark/commit/bb7944446c4b7e5f23dd13d94803ea44f2661d6d).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149106558
  
      [Test build #43912 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43912/console) for   PR 8639 at commit [`69c3e52`](https://github.com/apache/spark/commit/69c3e520fb2edcdb4501fbcfb33b8a27dd1feb35).
     * This patch **fails Scala style 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149477387
  
    **[Test build #43971 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43971/consoleFull)** for PR 8639 at commit [`785e4ae`](https://github.com/apache/spark/commit/785e4ae05149c49cb5b246be6fb707c2f8e78692).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139485761
  
      [Test build #42320 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42320/console) for   PR 8639 at commit [`5acfd65`](https://github.com/apache/spark/commit/5acfd65cc2b8ff8d1cfa39633b2273a3310f6a4e).
     * This patch **fails Scala style 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-141348570
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r39504753
  
    --- Diff: docs/running-on-mesos.md ---
    @@ -194,6 +194,10 @@ conf.set("spark.mesos.constraints", "tachyon=true;us-east-1=false")
     
     For example, Let's say `spark.mesos.constraints` is set to `tachyon=true;us-east-1=false`, then the resource offers will be checked to see if they meet both these constraints and only then will be accepted to start new executors.
     
    +Spark rejects offers for for slaves with unmet constraints for 120 seconds by default.
    --- End diff --
    
    Also, typo: `for for`.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-146421117
  
    Is there anything I can do to get this 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139492039
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-155203572
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r42300566
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/MesosSchedulerBackend.scala ---
    @@ -207,23 +211,44 @@ private[spark] class MesosSchedulerBackend(
        */
       override def resourceOffers(d: SchedulerDriver, offers: JList[Offer]) {
         inClassLoader() {
    +      // Fail first on offers with unmet constraints
    +      val (offersMatchingConstraints, offersNotMatchingConstraints) =
    +        offers.asScala.partition { o =>
    +          val offerAttributes = toAttributeMap(o.getAttributesList)
    +          val meetsConstraints =
    +            matchesAttributeRequirements(slaveOfferConstraints, offerAttributes)
    +
    +          // add some debug messaging
    +          if (!meetsConstraints) {
    +            val id = o.getId.getValue
    +            logDebug(s"Declining offer: $id with attributes: $offerAttributes")
    +          }
    +
    +          meetsConstraints
    +        }
    +
    +      // These offers do not meet constraints. We don't need to see them again.
    +      // Decline the offer for a long period of time.
    +      offersNotMatchingConstraints.foreach { o =>
    +        d.declineOffer(o.getId, Filters.newBuilder()
    +          .setRefuseSeconds(rejectOfferDurationForUnmetConstraints).build())
    +      }
    +
           // Fail-fast on offers we know will be rejected
    --- End diff --
    
    this comment is outdated:
    ```
    // Of the matching constraints, see which ones give us enough memory and cores
    ```


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149477186
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-148865280
  
    @felixb sorry for slipping. This looks pretty good. My comments are mostly minor. Thanks for taking the time to fix 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-155204419
  
    LGTM merging into master and 1.6. Thanks for your work and patience!


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140652394
  
      [Test build #42527 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42527/consoleFull) for   PR 8639 at commit [`9e00071`](https://github.com/apache/spark/commit/9e000717fafe1cf6660e3d90d17a6db67e720f21).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-141348557
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139485766
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42320/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139376589
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149104888
  
      [Test build #43912 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43912/consoleFull) for   PR 8639 at commit [`69c3e52`](https://github.com/apache/spark/commit/69c3e520fb2edcdb4501fbcfb33b8a27dd1feb35).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-155243910
  
    **[Test build #45416 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/45416/consoleFull)** for PR 8639 at commit [`785e4ae`](https://github.com/apache/spark/commit/785e4ae05149c49cb5b246be6fb707c2f8e78692).
     * 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140692018
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139499552
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-141115147
  
    There is a big HTML table in the bottom of this file, can you also add it
    to that list?
    
    On Thu, Sep 17, 2015 at 4:55 AM, Akash Mishra <no...@github.com>
    wrote:
    
    > @tnachen <https://github.com/tnachen> @andrewor14
    > <https://github.com/andrewor14> friendly reminder..
    >
    > —
    > Reply to this email directly or view it on GitHub
    > <https://github.com/apache/spark/pull/8639#issuecomment-141053573>.
    >



---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r42300656
  
    --- Diff: docs/running-on-mesos.md ---
    @@ -194,6 +194,10 @@ conf.set("spark.mesos.constraints", "tachyon=true;us-east-1=false")
     
     For example, Let's say `spark.mesos.constraints` is set to `tachyon=true;us-east-1=false`, then the resource offers will be checked to see if they meet both these constraints and only then will be accepted to start new executors.
     
    +Spark rejects offers for slaves with unmet constraints for 120 seconds by default.
    +This makes mesos not sending the rejected offers again and again.
    +The reject offer duration is configurable using `conf.set("spark.mesos.rejectOfferDurationForUnmetConstraints", "60")` (for example).
    +
    --- End diff --
    
    I actually don't think this is worth documenting. I can't imagine anyone who wants to set this explicitly as long as we pick a sane enough default.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

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


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139483713
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140374652
  
    They're probably just flaky.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139527895
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42324/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-146478502
  
    @rxin @andrewor14 can we get your attention 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149106574
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r39193893
  
    --- Diff: docs/running-on-mesos.md ---
    @@ -194,6 +194,10 @@ conf.set("spark.mesos.constraints", "tachyon=true;us-east-1=false")
     
     For example, Let's say `spark.mesos.constraints` is set to `tachyon=true;us-east-1=false`, then the resource offers will be checked to see if they meet both these constraints and only then will be accepted to start new executors.
     
    +Spark rejects offers for for slaves with unmet constraints for 120 seconds by default.
    --- End diff --
    
    There is also a configurations.md that you should add this too.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149108157
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149531417
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140373794
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42483/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140345616
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r42439071
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/MesosSchedulerUtils.scala ---
    @@ -336,4 +336,8 @@ private[mesos] trait MesosSchedulerUtils extends Logging {
         }
       }
     
    +  def getRejectOfferDurationForUnmetConstraints(sc: SparkContext): Long = {
    --- End diff --
    
    please keep this protected


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149477174
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-141348584
  
    added to table of parameters.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140373726
  
      [Test build #42483 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42483/console) for   PR 8639 at commit [`ce84b1a`](https://github.com/apache/spark/commit/ce84b1a9b3ab871de8656a50ad8f7e4d7e337843).
     * 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-141375112
  
      [Test build #42646 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42646/console) for   PR 8639 at commit [`58aaa79`](https://github.com/apache/spark/commit/58aaa79095143187175f0292d71b772b944440db).
     * 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140651404
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149106578
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43912/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140650576
  
    fixed typo.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-155244104
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-138234371
  
    Can one of the admins verify this patch?


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139492914
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149130357
  
    **[Test build #43914 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43914/consoleFull)** for PR 8639 at commit [`72a2855`](https://github.com/apache/spark/commit/72a2855f894c185ffe2e7f231ba1539293175551).
     * 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149130618
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43914/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139482353
  
    Added the same logic for fine grained scheduler.
    All mesos configuration is only available in `running-on-mesos.md`. So we skipped adding it to `configurations.md`


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139331270
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139485435
  
      [Test build #42320 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42320/consoleFull) for   PR 8639 at commit [`5acfd65`](https://github.com/apache/spark/commit/5acfd65cc2b8ff8d1cfa39633b2273a3310f6a4e).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139483660
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149103624
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r39504737
  
    --- Diff: docs/running-on-mesos.md ---
    @@ -194,6 +194,10 @@ conf.set("spark.mesos.constraints", "tachyon=true;us-east-1=false")
     
     For example, Let's say `spark.mesos.constraints` is set to `tachyon=true;us-east-1=false`, then the resource offers will be checked to see if they meet both these constraints and only then will be accepted to start new executors.
     
    +Spark rejects offers for for slaves with unmet constraints for 120 seconds by default.
    --- End diff --
    
    @tnachen, none of the Yarn or Mesos specific settings are listed in there.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r40182209
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/CoarseMesosSchedulerBackend.scala ---
    @@ -244,48 +248,56 @@ private[spark] class CoarseMesosSchedulerBackend(
             val mem = getResource(offer.getResourcesList, "mem")
             val cpus = getResource(offer.getResourcesList, "cpus").toInt
             val id = offer.getId.getValue
    -        if (taskIdToSlaveId.size < executorLimit &&
    -            totalCoresAcquired < maxCores &&
    -            meetsConstraints &&
    -            mem >= calculateTotalMemory(sc) &&
    -            cpus >= 1 &&
    -            failuresBySlaveId.getOrElse(slaveId, 0) < MAX_SLAVE_FAILURES &&
    -            !slaveIdsWithExecutors.contains(slaveId)) {
    -          // Launch an executor on the slave
    -          val cpusToUse = math.min(cpus, maxCores - totalCoresAcquired)
    -          totalCoresAcquired += cpusToUse
    -          val taskId = newMesosTaskId()
    -          taskIdToSlaveId.put(taskId, slaveId)
    -          slaveIdsWithExecutors += slaveId
    -          coresByTaskId(taskId) = cpusToUse
    -          // Gather cpu resources from the available resources and use them in the task.
    -          val (remainingResources, cpuResourcesToUse) =
    -            partitionResources(offer.getResourcesList, "cpus", cpusToUse)
    -          val (_, memResourcesToUse) =
    -            partitionResources(remainingResources.asJava, "mem", calculateTotalMemory(sc))
    -          val taskBuilder = MesosTaskInfo.newBuilder()
    -            .setTaskId(TaskID.newBuilder().setValue(taskId.toString).build())
    -            .setSlaveId(offer.getSlaveId)
    -            .setCommand(createCommand(offer, cpusToUse + extraCoresPerSlave, taskId))
    -            .setName("Task " + taskId)
    -            .addAllResources(cpuResourcesToUse.asJava)
    -            .addAllResources(memResourcesToUse.asJava)
    -
    -          sc.conf.getOption("spark.mesos.executor.docker.image").foreach { image =>
    -            MesosSchedulerBackendUtil
    -              .setupContainerBuilderDockerInfo(image, sc.conf, taskBuilder.getContainerBuilder())
    +        if (meetsConstraints) {
    --- End diff --
    
    It's getting a bit messy now, but I think we can refactor this later as I'd like to introduce more fine grained reasons around rejecting offers.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149108166
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149130615
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139492915
  
    Test FAILed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42321/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-141375251
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42646/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149103615
  
     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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-155204647
  
    **[Test build #45416 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/45416/consoleFull)** for PR 8639 at commit [`785e4ae`](https://github.com/apache/spark/commit/785e4ae05149c49cb5b246be6fb707c2f8e78692).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140345999
  
      [Test build #42483 has started](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42483/consoleFull) for   PR 8639 at commit [`ce84b1a`](https://github.com/apache/spark/commit/ce84b1a9b3ab871de8656a50ad8f7e4d7e337843).


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#discussion_r42300506
  
    --- Diff: core/src/main/scala/org/apache/spark/scheduler/cluster/mesos/MesosSchedulerBackend.scala ---
    @@ -207,23 +211,44 @@ private[spark] class MesosSchedulerBackend(
        */
       override def resourceOffers(d: SchedulerDriver, offers: JList[Offer]) {
         inClassLoader() {
    +      // Fail first on offers with unmet constraints
    +      val (offersMatchingConstraints, offersNotMatchingConstraints) =
    +        offers.asScala.partition { o =>
    +          val offerAttributes = toAttributeMap(o.getAttributesList)
    +          val meetsConstraints =
    +            matchesAttributeRequirements(slaveOfferConstraints, offerAttributes)
    +
    +          // add some debug messaging
    --- End diff --
    
    remove (doesn't add any value)


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140651423
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139127892
  
    I made the duration configurable. Still need to add it to fine grained scheduler.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-139527892
  
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140692019
  
    Test PASSed.
    Refer to this link for build results (access rights to CI server needed): 
    https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/42527/
    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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-142533073
  
    @tnachen @andrewor14 friendly reminder..


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-149530425
  
    **[Test build #43971 has finished](https://amplab.cs.berkeley.edu/jenkins/job/SparkPullRequestBuilder/43971/consoleFull)** for PR 8639 at commit [`785e4ae`](https://github.com/apache/spark/commit/785e4ae05149c49cb5b246be6fb707c2f8e78692).
     * 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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-140345640
  
    I just rebased to the current upstream/master.
    Any hint, why the tests keep failing?


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-142533822
  
    Thanks overall this LGTM. I know constraints is not yet supported for the cluster scheduler, so ideally when we add that we should also apply this too.


---
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-10471] [CORE] [MESOS] prevent getting o...

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

    https://github.com/apache/spark/pull/8639#issuecomment-150916898
  
    Is there anything else I can do?


---
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