aboutsummaryrefslogtreecommitdiff
path: root/core/src/main/scala/org/apache/spark/SparkContext.scala
diff options
context:
space:
mode:
authorjerryshao <sshao@hortonworks.com>2016-02-22 00:57:10 -0800
committerReynold Xin <rxin@databricks.com>2016-02-22 00:57:10 -0800
commit39ff15457026767a4d9ff191174fc85e7907f489 (patch)
treec53bffeb5174fc07987a9ec2878829cbc77985c7 /core/src/main/scala/org/apache/spark/SparkContext.scala
parent8a4ed78869e99c7de7062c3baa0ddb9d28c8e9b1 (diff)
downloadspark-39ff15457026767a4d9ff191174fc85e7907f489.tar.gz
spark-39ff15457026767a4d9ff191174fc85e7907f489.tar.bz2
spark-39ff15457026767a4d9ff191174fc85e7907f489.zip
[SPARK-13426][CORE] Remove the support of SIMR
## What changes were proposed in this pull request? This PR removes the support of SIMR, since SIMR is not actively used and maintained for a long time, also is not supported from `SparkSubmit`, so here propose to remove it. ## How was the this patch tested? This patch is tested locally by running unit tests. Author: jerryshao <sshao@hortonworks.com> Closes #11296 from jerryshao/SPARK-13426.
Diffstat (limited to 'core/src/main/scala/org/apache/spark/SparkContext.scala')
-rw-r--r--core/src/main/scala/org/apache/spark/SparkContext.scala10
1 files changed, 1 insertions, 9 deletions
diff --git a/core/src/main/scala/org/apache/spark/SparkContext.scala b/core/src/main/scala/org/apache/spark/SparkContext.scala
index fa8c0f524b..c001df31aa 100644
--- a/core/src/main/scala/org/apache/spark/SparkContext.scala
+++ b/core/src/main/scala/org/apache/spark/SparkContext.scala
@@ -56,7 +56,7 @@ import org.apache.spark.partial.{ApproximateEvaluator, PartialResult}
import org.apache.spark.rdd._
import org.apache.spark.rpc.RpcEndpointRef
import org.apache.spark.scheduler._
-import org.apache.spark.scheduler.cluster.{CoarseGrainedSchedulerBackend, SimrSchedulerBackend,
+import org.apache.spark.scheduler.cluster.{CoarseGrainedSchedulerBackend,
SparkDeploySchedulerBackend}
import org.apache.spark.scheduler.cluster.mesos.{CoarseMesosSchedulerBackend, MesosSchedulerBackend}
import org.apache.spark.scheduler.local.LocalBackend
@@ -2453,12 +2453,6 @@ object SparkContext extends Logging {
scheduler.initialize(backend)
(backend, scheduler)
- case SIMR_REGEX(simrUrl) =>
- val scheduler = new TaskSchedulerImpl(sc)
- val backend = new SimrSchedulerBackend(scheduler, sc, simrUrl)
- scheduler.initialize(backend)
- (backend, scheduler)
-
case zkUrl if zkUrl.startsWith("zk://") =>
logWarning("Master URL for a multi-master Mesos cluster managed by ZooKeeper should be " +
"in the form mesos://zk://host:port. Current Master URL will stop working in Spark 2.0.")
@@ -2484,8 +2478,6 @@ private object SparkMasterRegex {
val SPARK_REGEX = """spark://(.*)""".r
// Regular expression for connection to Mesos cluster by mesos:// or mesos://zk:// url
val MESOS_REGEX = """mesos://(.*)""".r
- // Regular expression for connection to Simr cluster
- val SIMR_REGEX = """simr://(.*)""".r
}
/**