Skip to content
Snippets Groups Projects
  1. Jan 15, 2015
    • Kousuke Saruta's avatar
      [Minor] Fix tiny typo in BlockManager · 65858ba5
      Kousuke Saruta authored
      In BlockManager, there is a word `BlockTranserService` but I think it's typo for `BlockTransferService`.
      
      Author: Kousuke Saruta <sarutak@oss.nttdata.co.jp>
      
      Closes #4046 from sarutak/fix-tiny-typo and squashes the following commits:
      
      a3e2a2f [Kousuke Saruta] Fixed tiny typo in BlockManager
      65858ba5
    • Reynold Xin's avatar
      [SPARK-5274][SQL] Reconcile Java and Scala UDFRegistration. · 1881431d
      Reynold Xin authored
      As part of SPARK-5193:
      
      1. Removed UDFRegistration as a mixin in SQLContext and made it a field ("udf").
      2. For Java UDFs, renamed dataType to returnType.
      3. For Scala UDFs, added type tags.
      4. Added all Java UDF registration methods to Scala's UDFRegistration.
      5. Documentation
      
      Author: Reynold Xin <rxin@databricks.com>
      
      Closes #4056 from rxin/udf-registration and squashes the following commits:
      
      ae9c556 [Reynold Xin] Updated example.
      675a3c9 [Reynold Xin] Style fix
      47c24ff [Reynold Xin] Python fix.
      5f00c45 [Reynold Xin] Restore data type position in java udf and added typetags.
      032f006 [Reynold Xin] [SPARK-5193][SQL] Reconcile Java and Scala UDFRegistration.
      1881431d
    • Davies Liu's avatar
      [SPARK-5224] [PySpark] improve performance of parallelize list/ndarray · 3c8650c1
      Davies Liu authored
      After the default batchSize changed to 0 (batched based on the size of object), but parallelize() still use BatchedSerializer with batchSize=1, this PR will use batchSize=1024 for parallelize by default.
      
      Also, BatchedSerializer did not work well with list and numpy.ndarray, this improve BatchedSerializer by using __len__ and __getslice__.
      
      Here is the benchmark for parallelize 1 millions int with list or ndarray:
      
          |          before     |   after  | improvements
       ------- | ------------ | ------------- | -------
      list |   11.7 s  | 0.8 s |  14x
      numpy.ndarray     |  32 s  |   0.7 s | 40x
      
      Author: Davies Liu <davies@databricks.com>
      
      Closes #4024 from davies/opt_numpy and squashes the following commits:
      
      7618c7c [Davies Liu] improve performance of parallelize list/ndarray
      3c8650c1
  2. Jan 14, 2015
    • Reynold Xin's avatar
      [SPARK-5193][SQL] Tighten up HiveContext API · 4b325c77
      Reynold Xin authored
      1. Removed the deprecated LocalHiveContext
      2. Made private[sql] fields protected[sql] so they don't show up in javadoc.
      3. Added javadoc to refreshTable.
      4. Added Experimental tag to analyze command.
      
      Author: Reynold Xin <rxin@databricks.com>
      
      Closes #4054 from rxin/hivecontext-api and squashes the following commits:
      
      25cc00a [Reynold Xin] Add implicit conversion back.
      cbca886 [Reynold Xin] [SPARK-5193][SQL] Tighten up HiveContext API
      4b325c77
    • Xiangrui Meng's avatar
      [SPARK-5254][MLLIB] remove developers section from spark.ml guide · 6abc45e3
      Xiangrui Meng authored
      Forgot to remove this section in #4052.
      
      Author: Xiangrui Meng <meng@databricks.com>
      
      Closes #4053 from mengxr/SPARK-5254-update and squashes the following commits:
      
      f295bde [Xiangrui Meng] remove developers section from spark.ml guide
      6abc45e3
    • Reynold Xin's avatar
      [SPARK-5193][SQL] Tighten up SQLContext API · cfa397c1
      Reynold Xin authored
      1. Removed 2 implicits (logicalPlanToSparkQuery and baseRelationToSchemaRDD)
      2. Moved extraStrategies into ExperimentalMethods.
      3. Made private methods protected[sql] so they don't show up in javadocs.
      4. Removed createParquetFile.
      5. Added Java version of applySchema to SQLContext.
      
      Author: Reynold Xin <rxin@databricks.com>
      
      Closes #4049 from rxin/sqlContext-refactor and squashes the following commits:
      
      a326a1a [Reynold Xin] Remove createParquetFile and add applySchema for Java to SQLContext.
      ecd6685 [Reynold Xin] Added baseRelationToSchemaRDD back.
      4a38c9b [Reynold Xin] [SPARK-5193][SQL] Tighten up SQLContext API
      cfa397c1
    • Xiangrui Meng's avatar
      [SPARK-5254][MLLIB] Update the user guide to position spark.ml better · 13d24067
      Xiangrui Meng authored
      The current statement in the user guide may deliver confusing messages to users. spark.ml contains high-level APIs for building ML pipelines. But it doesn't mean that spark.mllib is being deprecated.
      
      First of all, the pipeline API is in its alpha stage and we need to see more use cases from the community to stabilizes it, which may take several releases. Secondly, the components in spark.ml are simple wrappers over spark.mllib implementations. Neither the APIs or the implementations from spark.mllib are being deprecated. We expect users use spark.ml pipeline APIs to build their ML pipelines, but we will keep supporting and adding features to spark.mllib. For example, there are many features in review at https://spark-prs.appspot.com/#mllib. So users should be comfortable with using spark.mllib features and expect more coming. The user guide needs to be updated to make the message clear.
      
      Author: Xiangrui Meng <meng@databricks.com>
      
      Closes #4052 from mengxr/SPARK-5254 and squashes the following commits:
      
      6d5f1d3 [Xiangrui Meng] typo
      0cc935b [Xiangrui Meng] update user guide to position spark.ml better
      13d24067
    • Yuhao Yang's avatar
      [SPARK-5234][ml]examples for ml don't have sparkContext.stop · 76389c5b
      Yuhao Yang authored
      JIRA issue: https://issues.apache.org/jira/browse/SPARK-5234
      
      simply add the call.
      
      Author: Yuhao Yang <yuhao@yuhaodevbox.sh.intel.com>
      
      Closes #4044 from hhbyyh/addscStop and squashes the following commits:
      
      c1f75ac [Yuhao Yang] add SparkContext.stop to 3 ml examples
      76389c5b
    • Alex Baretta's avatar
      [SPARK-5235] Make SQLConf Serializable · 2fd7f72b
      Alex Baretta authored
      Declare SQLConf to be serializable to fix "Task not serializable" exceptions in SparkSQL
      
      Author: Alex Baretta <alexbaretta@gmail.com>
      
      Closes #4031 from alexbaretta/SPARK-5235-SQLConf and squashes the following commits:
      
      c2103f5 [Alex Baretta] [SPARK-5235] Make SQLConf Serializable
      2fd7f72b
    • Josh Rosen's avatar
      [SPARK-4014] Add TaskContext.attemptNumber and deprecate TaskContext.attemptId · 259936be
      Josh Rosen authored
      `TaskContext.attemptId` is misleadingly-named, since it currently returns a taskId, which uniquely identifies a particular task attempt within a particular SparkContext, instead of an attempt number, which conveys how many times a task has been attempted.
      
      This patch deprecates `TaskContext.attemptId` and add `TaskContext.taskId` and `TaskContext.attemptNumber` fields.  Prior to this change, it was impossible to determine whether a task was being re-attempted (or was a speculative copy), which made it difficult to write unit tests for tasks that fail on early attempts or speculative tasks that complete faster than original tasks.
      
      Earlier versions of the TaskContext docs suggest that `attemptId` behaves like `attemptNumber`, so there's an argument to be made in favor of changing this method's implementation.  Since we've decided against making that change in maintenance branches, I think it's simpler to add better-named methods and retain the old behavior for `attemptId`; if `attemptId` behaved differently in different branches, then this would cause confusing build-breaks when backporting regression tests that rely on the new `attemptId` behavior.
      
      Most of this patch is fairly straightforward, but there is a bit of trickiness related to Mesos tasks: since there's no field in MesosTaskInfo to encode the attemptId, I packed it into the `data` field alongside the task binary.
      
      Author: Josh Rosen <joshrosen@databricks.com>
      
      Closes #3849 from JoshRosen/SPARK-4014 and squashes the following commits:
      
      89d03e0 [Josh Rosen] Merge remote-tracking branch 'origin/master' into SPARK-4014
      5cfff05 [Josh Rosen] Introduce wrapper for serializing Mesos task launch data.
      38574d4 [Josh Rosen] attemptId -> taskAttemptId in PairRDDFunctions
      a180b88 [Josh Rosen] Merge remote-tracking branch 'origin/master' into SPARK-4014
      1d43aa6 [Josh Rosen] Merge remote-tracking branch 'origin/master' into SPARK-4014
      eee6a45 [Josh Rosen] Merge remote-tracking branch 'origin/master' into SPARK-4014
      0b10526 [Josh Rosen] Use putInt instead of putLong (silly mistake)
      8c387ce [Josh Rosen] Use local with maxRetries instead of local-cluster.
      cbe4d76 [Josh Rosen] Preserve attemptId behavior and deprecate it:
      b2dffa3 [Josh Rosen] Address some of Reynold's minor comments
      9d8d4d1 [Josh Rosen] Doc typo
      1e7a933 [Josh Rosen] [SPARK-4014] Change TaskContext.attemptId to return attempt number instead of task ID.
      fd515a5 [Josh Rosen] Add failing test for SPARK-4014
      259936be
    • Kousuke Saruta's avatar
      [SPARK-5228][WebUI] Hide tables for "Active Jobs/Completed Jobs/Failed Jobs" when they are empty · 9d4449c4
      Kousuke Saruta authored
      In current WebUI, tables for Active Stages, Completed Stages, Skipped Stages and Failed Stages are hidden when they are empty while tables for Active Jobs, Completed Jobs and Failed Jobs are not hidden though they are empty.
      
      This is before my patch is applied.
      
      ![2015-01-13 14 13 03](https://cloud.githubusercontent.com/assets/4736016/5730793/2b73d6f4-9b32-11e4-9a24-1784d758c644.png)
      
      And this is after my patch is applied.
      
      ![2015-01-13 14 38 13](https://cloud.githubusercontent.com/assets/4736016/5730797/359ea2da-9b32-11e4-97b0-544739ddbf4c.png)
      
      Author: Kousuke Saruta <sarutak@oss.nttdata.co.jp>
      
      Closes #4028 from sarutak/SPARK-5228 and squashes the following commits:
      
      b1e6e8b [Kousuke Saruta] Fixed a small typo
      daab563 [Kousuke Saruta] Merge branch 'master' of git://git.apache.org/spark into SPARK-5228
      9493a1d [Kousuke Saruta] Modified AllJobPage.scala so that hide Active Jobs/Completed Jobs/Failed Jobs when they are empty
      9d4449c4
    • MechCoder's avatar
      [SPARK-2909] [MLlib] [PySpark] SparseVector in pyspark now supports indexing · 5840f546
      MechCoder authored
      Slightly different than the scala code which converts the sparsevector into a densevector and then checks the index.
      
      I also hope I've added tests in the right place.
      
      Author: MechCoder <manojkumarsivaraj334@gmail.com>
      
      Closes #4025 from MechCoder/spark-2909 and squashes the following commits:
      
      07d0f26 [MechCoder] STY: Rename item to index
      f02148b [MechCoder] [SPARK-2909] [Mlib] SparseVector in pyspark now supports indexing
      5840f546
    • Daoyuan Wang's avatar
      [SQL] some comments fix for GROUPING SETS · 38bdc992
      Daoyuan Wang authored
      Author: Daoyuan Wang <daoyuan.wang@intel.com>
      
      Closes #4000 from adrian-wang/comment and squashes the following commits:
      
      9c24fc4 [Daoyuan Wang] some comments
      38bdc992
    • Yin Huai's avatar
      [SPARK-5211][SQL]Restore HiveMetastoreTypes.toDataType · 81f72a0d
      Yin Huai authored
      jira: https://issues.apache.org/jira/browse/SPARK-5211
      
      Author: Yin Huai <yhuai@databricks.com>
      
      Closes #4026 from yhuai/SPARK-5211 and squashes the following commits:
      
      15ee32b [Yin Huai] Remove extra line.
      c6c1651 [Yin Huai] Get back HiveMetastoreTypes.toDataType.
      81f72a0d
    • Daoyuan Wang's avatar
      [SPARK-5248] [SQL] move sql.types.decimal.Decimal to sql.types.Decimal · a3f7421b
      Daoyuan Wang authored
      rxin follow up of #3732
      
      Author: Daoyuan Wang <daoyuan.wang@intel.com>
      
      Closes #4041 from adrian-wang/decimal and squashes the following commits:
      
      aa3d738 [Daoyuan Wang] fix auto refactor
      7777a58 [Daoyuan Wang] move sql.types.decimal.Decimal to sql.types.Decimal
      a3f7421b
    • Reynold Xin's avatar
      [SPARK-5167][SQL] Move Row into sql package and make it usable for Java. · d5eeb351
      Reynold Xin authored
      Mostly just moving stuff around. This should still be source compatible since we type aliased Row previously in org.apache.spark.sql.Row.
      
      Added the following APIs to Row:
      ```scala
      def getMap[K, V](i: Int): scala.collection.Map[K, V]
      def getJavaMap[K, V](i: Int): java.util.Map[K, V]
      def getSeq[T](i: Int): Seq[T]
      def getList[T](i: Int): java.util.List[T]
      def getStruct(i: Int): StructType
      ```
      
      Author: Reynold Xin <rxin@databricks.com>
      
      Closes #4030 from rxin/sql-row and squashes the following commits:
      
      6c85c29 [Reynold Xin] Fixed style violation by adding a new line to Row.scala.
      82b064a [Reynold Xin] [SPARK-5167][SQL] Move Row into sql package and make it usable for Java.
      d5eeb351
  3. Jan 13, 2015
    • Reynold Xin's avatar
      [SPARK-5123][SQL] Reconcile Java/Scala API for data types. · f9969098
      Reynold Xin authored
      Having two versions of the data type APIs (one for Java, one for Scala) requires downstream libraries to also have two versions of the APIs if the library wants to support both Java and Scala. I took a look at the Scala version of the data type APIs - it can actually work out pretty well for Java out of the box.
      
      As part of the PR, I created a sql.types package and moved all type definitions there. I then removed the Java specific data type API along with a lot of the conversion code.
      
      This subsumes https://github.com/apache/spark/pull/3925
      
      Author: Reynold Xin <rxin@databricks.com>
      
      Closes #3958 from rxin/SPARK-5123-datatype-2 and squashes the following commits:
      
      66505cc [Reynold Xin] [SPARK-5123] Expose only one version of the data type APIs (i.e. remove the Java-specific API).
      f9969098
    • Reynold Xin's avatar
      [SPARK-5168] Make SQLConf a field rather than mixin in SQLContext · 14e3f114
      Reynold Xin authored
      This change should be binary and source backward compatible since we didn't change any user facing APIs.
      
      Author: Reynold Xin <rxin@databricks.com>
      
      Closes #3965 from rxin/SPARK-5168-sqlconf and squashes the following commits:
      
      42eec09 [Reynold Xin] Fix default conf value.
      0ef86cc [Reynold Xin] Fix constructor ordering.
      4d7f910 [Reynold Xin] Properly override config.
      ccc8e6a [Reynold Xin] [SPARK-5168] Make SQLConf a field rather than mixin in SQLContext
      14e3f114
    • Yin Huai's avatar
      [SPARK-4912][SQL] Persistent tables for the Spark SQL data sources api · 6463e0b9
      Yin Huai authored
      With changes in this PR, users can persist metadata of tables created based on the data source API in metastore through DDLs.
      
      Author: Yin Huai <yhuai@databricks.com>
      Author: Michael Armbrust <michael@databricks.com>
      
      Closes #3960 from yhuai/persistantTablesWithSchema2 and squashes the following commits:
      
      069c235 [Yin Huai] Make exception messages user friendly.
      c07cbc6 [Yin Huai] Get the location of test file in a correct way.
      4456e98 [Yin Huai] Test data.
      5315dfc [Yin Huai] rxin's comments.
      7fc4b56 [Yin Huai] Add DDLStrategy and HiveDDLStrategy to plan DDLs based on the data source API.
      aeaf4b3 [Yin Huai] Add comments.
      06f9b0c [Yin Huai] Revert unnecessary changes.
      feb88aa [Yin Huai] Merge remote-tracking branch 'apache/master' into persistantTablesWithSchema2
      172db80 [Yin Huai] Fix unit test.
      49bf1ac [Yin Huai] Unit tests.
      8f8f1a1 [Yin Huai] [SPARK-4574][SQL] Adding support for defining schema in foreign DDL commands. #3431
      f47fda1 [Yin Huai] Unit tests.
      2b59723 [Michael Armbrust] Set external when creating tables
      c00bb1b [Michael Armbrust] Don't use reflection to read options
      1ea6e7b [Michael Armbrust] Don't fail when trying to uncache a table that doesn't exist
      6edc710 [Michael Armbrust] Add tests.
      d7da491 [Michael Armbrust] First draft of persistent tables.
      6463e0b9
    • Davies Liu's avatar
      [SPARK-5223] [MLlib] [PySpark] fix MapConverter and ListConverter in MLlib · 8ead999f
      Davies Liu authored
      It will introduce problems if the object in dict/list/tuple can not support by py4j, such as Vector.
      Also, pickle may have better performance for larger object (less RPC).
      
      In some cases that the object in dict/list can not be pickled (such as JavaObject), we should still use MapConvert/ListConvert.
      
      This PR should be ported into branch-1.2
      
      Author: Davies Liu <davies@databricks.com>
      
      Closes #4023 from davies/listconvert and squashes the following commits:
      
      55d4ab2 [Davies Liu] fix MapConverter and ListConverter in MLlib
      8ead999f
    • uncleGen's avatar
      [SPARK-5131][Streaming][DOC]: There is a discrepancy in WAL implementation and configuration doc. · 39e333ec
      uncleGen authored
      There is a discrepancy in WAL implementation and configuration doc.
      
      Author: uncleGen <hustyugm@gmail.com>
      
      Closes #3930 from uncleGen/master-clean-doc and squashes the following commits:
      
      3a4245f [uncleGen] doc typo
      8e407d3 [uncleGen] doc typo
      39e333ec
    • WangTaoTheTonic's avatar
      [SPARK-4697][YARN]System properties should override environment variables · 9dea64e5
      WangTaoTheTonic authored
      I found some arguments in yarn module take environment variables before system properties while the latter override the former in core module.
      
      Author: WangTaoTheTonic <barneystinson@aliyun.com>
      Author: WangTao <barneystinson@aliyun.com>
      
      Closes #3557 from WangTaoTheTonic/SPARK4697 and squashes the following commits:
      
      836b9ef [WangTaoTheTonic] fix type mismatch
      e3e486a [WangTaoTheTonic] remove the comma
      1262d57 [WangTaoTheTonic] handle spark.app.name and SPARK_YARN_APP_NAME in SparkSubmitArguments
      bee9447 [WangTaoTheTonic] wrong brace
      81833bb [WangTaoTheTonic] rebase
      40934b4 [WangTaoTheTonic] just switch blocks
      5f43f45 [WangTao] System property can override environment variable
      9dea64e5
    • WangTaoTheTonic's avatar
      [SPARK-5006][Deploy]spark.port.maxRetries doesn't work · f7741a9a
      WangTaoTheTonic authored
      https://issues.apache.org/jira/browse/SPARK-5006
      
      I think the issue is produced in https://github.com/apache/spark/pull/1777.
      
      Not digging mesos's backend yet. Maybe should add same logic either.
      
      Author: WangTaoTheTonic <barneystinson@aliyun.com>
      Author: WangTao <barneystinson@aliyun.com>
      
      Closes #3841 from WangTaoTheTonic/SPARK-5006 and squashes the following commits:
      
      8cdf96d [WangTao] indent thing
      2d86d65 [WangTaoTheTonic] fix line length
      7cdfd98 [WangTaoTheTonic] fit for new HttpServer constructor
      61a370d [WangTaoTheTonic] some minor fixes
      bc6e1ec [WangTaoTheTonic] rebase
      67bcb46 [WangTaoTheTonic] put conf at 3rd position, modify suite class, add comments
      f450cd1 [WangTaoTheTonic] startServiceOnPort will use a SparkConf arg
      29b751b [WangTaoTheTonic] rebase as ExecutorRunnableUtil changed to ExecutorRunnable
      396c226 [WangTaoTheTonic] make the grammar more like scala
      191face [WangTaoTheTonic] invalid value name
      62ec336 [WangTaoTheTonic] spark.port.maxRetries doesn't work
      f7741a9a
  4. Jan 12, 2015
    • Gabe Mulley's avatar
      [SPARK-5138][SQL] Ensure schema can be inferred from a namedtuple · 1e42e96e
      Gabe Mulley authored
      When attempting to infer the schema of an RDD that contains namedtuples, pyspark fails to identify the records as namedtuples, resulting in it raising an error.
      
      Example:
      
      ```python
      from pyspark import SparkContext
      from pyspark.sql import SQLContext
      from collections import namedtuple
      import os
      
      sc = SparkContext()
      rdd = sc.textFile(os.path.join(os.getenv('SPARK_HOME'), 'README.md'))
      TextLine = namedtuple('TextLine', 'line length')
      tuple_rdd = rdd.map(lambda l: TextLine(line=l, length=len(l)))
      tuple_rdd.take(5)  # This works
      
      sqlc = SQLContext(sc)
      
      # The following line raises an error
      schema_rdd = sqlc.inferSchema(tuple_rdd)
      ```
      
      The error raised is:
      ```
        File "/opt/spark-1.2.0-bin-hadoop2.4/python/pyspark/worker.py", line 107, in main
          process()
        File "/opt/spark-1.2.0-bin-hadoop2.4/python/pyspark/worker.py", line 98, in process
          serializer.dump_stream(func(split_index, iterator), outfile)
        File "/opt/spark-1.2.0-bin-hadoop2.4/python/pyspark/serializers.py", line 227, in dump_stream
          vs = list(itertools.islice(iterator, batch))
        File "/opt/spark-1.2.0-bin-hadoop2.4/python/pyspark/rdd.py", line 1107, in takeUpToNumLeft
          yield next(iterator)
        File "/opt/spark-1.2.0-bin-hadoop2.4/python/pyspark/sql.py", line 816, in convert_struct
          raise ValueError("unexpected tuple: %s" % obj)
      TypeError: not all arguments converted during string formatting
      ```
      
      Author: Gabe Mulley <gabe@edx.org>
      
      Closes #3978 from mulby/inferschema-namedtuple and squashes the following commits:
      
      98c61cc [Gabe Mulley] Ensure exception message is populated correctly
      375d96b [Gabe Mulley] Ensure schema can be inferred from a namedtuple
      1e42e96e
    • Michael Armbrust's avatar
      [SPARK-5049][SQL] Fix ordering of partition columns in ParquetTableScan · 5d9fa550
      Michael Armbrust authored
      Followup to #3870.  Props to rahulaggarwalguavus for identifying the issue.
      
      Author: Michael Armbrust <michael@databricks.com>
      
      Closes #3990 from marmbrus/SPARK-5049 and squashes the following commits:
      
      dd03e4e [Michael Armbrust] Fill in the partition values of parquet scans instead of using JoinedRow
      5d9fa550
    • jerryshao's avatar
      [SPARK-4999][Streaming] Change storeInBlockManager to false by default · 3aed3051
      jerryshao authored
      Currently WAL-backed block is read out from HDFS and put into BlockManger with storage level MEMORY_ONLY_SER by default, since WAL-backed block is already materialized in HDFS with fault-tolerance, no need to put into BlockManger again by default.
      
      Author: jerryshao <saisai.shao@intel.com>
      
      Closes #3906 from jerryshao/SPARK-4999 and squashes the following commits:
      
      b95f95e [jerryshao] Change storeInBlockManager to false by default
      3aed3051
    • Sean Owen's avatar
      SPARK-5172 [BUILD] spark-examples-***.jar shades a wrong Hadoop distribution · aff49a3e
      Sean Owen authored
      In addition to the `hadoop-2.x` profiles in the parent POM, there is actually another set of profiles in `examples` that has to be activated differently to get the right Hadoop 1 vs 2 flavor of HBase. This wasn't actually used in making Hadoop 2 distributions, hence the problem.
      
      To reduce complexity, I suggest merging them with the parent POM profiles, which is possible now.
      
      You'll see this changes appears to update the HBase version, but actually, the default 0.94 version was not being used. HBase is only used in examples, and the examples POM always chose one profile or the other that updated the version to 0.98.x anyway.
      
      Author: Sean Owen <sowen@cloudera.com>
      
      Closes #3992 from srowen/SPARK-5172 and squashes the following commits:
      
      17830d9 [Sean Owen] Control hbase hadoop1/2 flavor in the parent POM with existing hadoop-2.x profiles
      aff49a3e
    • Michael Armbrust's avatar
      [SPARK-5078] Optionally read from SPARK_LOCAL_HOSTNAME · a3978f3e
      Michael Armbrust authored
      Current spark lets you set the ip address using SPARK_LOCAL_IP, but then this is given to akka after doing a reverse DNS lookup. This makes it difficult to run spark in Docker. You can already change the hostname that is used programmatically, but it would be nice to be able to do this with an environment variable as well.
      
      Author: Michael Armbrust <michael@databricks.com>
      
      Closes #3893 from marmbrus/localHostnameEnv and squashes the following commits:
      
      85045b6 [Michael Armbrust] Optionally read from SPARK_LOCAL_HOSTNAME
      a3978f3e
    • Sean Owen's avatar
      SPARK-4159 [BUILD] Addendum: improve running of single test after enabling Java tests · 13e610b8
      Sean Owen authored
      https://issues.apache.org/jira/browse/SPARK-4159 was resolved but as Sandy points out, the guidance in https://cwiki.apache.org/confluence/display/SPARK/Useful+Developer+Tools under "Running Individual Tests" no longer quite works, not optimally.
      
      This minor change is not really the important change, which is an update to the wiki text. The correct way to run one Scala test suite in Maven is now:
      
      ```
      mvn test -DwildcardSuites=org.apache.spark.io.CompressionCodecSuite -Dtests=none
      ```
      
      The correct way to run one Java test is
      
      ```
      mvn test -DwildcardSuites=none -Dtests=org.apache.spark.streaming.JavaAPISuite
      ```
      
      Basically, you have to set two properties in order to suppress all of one type of test (with a non-existent test name like 'none') and all but one test of the other type.
      
      The change in the PR just prevents Surefire from barfing when it finds no "none" test.
      
      Author: Sean Owen <sowen@cloudera.com>
      
      Closes #3993 from srowen/SPARK-4159 and squashes the following commits:
      
      83106d7 [Sean Owen] Default failIfNoTests to false to enable the -DwildcardSuites=... -Dtests=... syntax for running one test to work
      13e610b8
    • lianhuiwang's avatar
      [SPARK-5102][Core]subclass of MapStatus needs to be registered with Kryo · ef9224e0
      lianhuiwang authored
      CompressedMapStatus and HighlyCompressedMapStatus needs to be registered with Kryo, because they are subclass of MapStatus.
      
      Author: lianhuiwang <lianhuiwang09@gmail.com>
      
      Closes #4007 from lianhuiwang/SPARK-5102 and squashes the following commits:
      
      9d2238a [lianhuiwang] remove register of MapStatus
      05a285d [lianhuiwang] subclass of MapStatus needs to be registered with Kryo
      ef9224e0
    • Josh Rosen's avatar
      [SPARK-5200] Disable web UI in Hive ThriftServer tests · 82fd38dc
      Josh Rosen authored
      Disables the Spark web UI in HiveThriftServer2Suite in order to prevent Jenkins test failures due to port contention.
      
      Author: Josh Rosen <joshrosen@databricks.com>
      
      Closes #3998 from JoshRosen/SPARK-5200 and squashes the following commits:
      
      a384416 [Josh Rosen] [SPARK-5200] Disable web UI in Hive Thriftserver tests.
      82fd38dc
  5. Jan 11, 2015
    • Travis Galoppo's avatar
      SPARK-5018 [MLlib] [WIP] Make MultivariateGaussian public · 2130de9d
      Travis Galoppo authored
      Moving MutlivariateGaussian from private[mllib] to public.  The class uses Breeze vectors internally, so this involves creating a public interface using MLlib vectors and matrices.
      
      This initial commit provides public construction, accessors for mean/covariance, density and log-density.
      
      Other potential methods include entropy and sample generation.
      
      Author: Travis Galoppo <tjg2107@columbia.edu>
      
      Closes #3923 from tgaloppo/spark-5018 and squashes the following commits:
      
      2b15587 [Travis Galoppo] Style correction
      b4121b4 [Travis Galoppo] Merge remote-tracking branch 'upstream/master' into spark-5018
      e30a100 [Travis Galoppo] Made mu, sigma private[mllib] members of MultivariateGaussian Moved MultivariateGaussian (and test suite) from stat.impl to stat.distribution (required updates in GaussianMixture{EM,Model}.scala) Marked MultivariateGaussian as @DeveloperApi Fixed style error
      9fa3bb7 [Travis Galoppo] Style improvements
      91a5fae [Travis Galoppo] Rearranged equation for part of density function
      8c35381 [Travis Galoppo] Fixed accessor methods to match member variable names. Modified calculations to avoid log(pow(x,y)) calculations
      0943dc4 [Travis Galoppo] SPARK-5018
      4dee9e1 [Travis Galoppo] SPARK-5018
      2130de9d
    • huangzhaowei's avatar
      [SPARK-4033][Examples]Input of the SparkPi too big causes the emption exception · f38ef658
      huangzhaowei authored
      If input of the SparkPi args is larger than the 25000, the integer 'n' inside the code will be overflow, and may be a negative number.
      And it causes  the (0 until n) Seq as an empty seq, then doing the action 'reduce'  will throw the UnsupportedOperationException("empty collection").
      
      The max size of the input of sc.parallelize is Int.MaxValue - 1, not the Int.MaxValue.
      
      Author: huangzhaowei <carlmartinmax@gmail.com>
      
      Closes #2874 from SaintBacchus/SparkPi and squashes the following commits:
      
      62d7cd7 [huangzhaowei] Add a commit to explain the modify
      4cdc388 [huangzhaowei] Update SparkPi.scala
      9a2fb7b [huangzhaowei] Input of the SparkPi is too big
      f38ef658
    • zsxwing's avatar
      [SPARK-4951][Core] Fix the issue that a busy executor may be killed · 6942b974
      zsxwing authored
      A few changes to fix this issue:
      
      1. Handle the case that receiving `SparkListenerTaskStart` before `SparkListenerBlockManagerAdded`.
      2. Don't add `executorId` to `removeTimes` when the executor is busy.
      3. Use `HashMap.retain` to safely traverse the HashMap and remove items.
      4. Use the same lock in ExecutorAllocationManager and ExecutorAllocationListener to fix the race condition in `totalPendingTasks`.
      5. Move the blocking codes out of the message processing code in YarnSchedulerActor.
      
      Author: zsxwing <zsxwing@gmail.com>
      
      Closes #3783 from zsxwing/SPARK-4951 and squashes the following commits:
      
      d51fa0d [zsxwing] Add comments
      2e365ce [zsxwing] Remove expired executors from 'removeTimes' and add idle executors back when a new executor joins
      49f61a9 [zsxwing] Eliminate duplicate executor registered warnings
      d4c4e9a [zsxwing] Minor fixes for the code style
      05f6238 [zsxwing] Move the blocking codes out of the message processing code
      105ba3a [zsxwing] Fix the race condition in totalPendingTasks
      d5c615d [zsxwing] Fix the issue that a busy executor may be killed
      6942b974
    • lewuathe's avatar
      [SPARK-5073] spark.storage.memoryMapThreshold have two default value · 1656aae2
      lewuathe authored
      Because major OS page sizes is about 4KB, the default value of spark.storage.memoryMapThreshold is integrated to 2 * 4096
      
      Author: lewuathe <lewuathe@me.com>
      
      Closes #3900 from Lewuathe/integrate-memoryMapThreshold and squashes the following commits:
      
      e417acd [lewuathe] [SPARK-5073] Update docs/configuration
      834aba4 [lewuathe] [SPARK-5073] Fix style
      adcea33 [lewuathe] [SPARK-5073] Integrate memory map threshold to 2MB
      fcce2e5 [lewuathe] [SPARK-5073] spark.storage.memoryMapThreshold have two default value
      1656aae2
  6. Jan 10, 2015
    • Joseph K. Bradley's avatar
      [SPARK-5032] [graphx] Remove GraphX MIMA exclude for 1.3 · 33132609
      Joseph K. Bradley authored
      Since GraphX is no longer alpha as of 1.2, MimaExcludes should not exclude GraphX for 1.3
      
      Here are the individual excludes I had to add + the associated commits:
      
      ```
                  // SPARK-4444
                  ProblemFilters.exclude[IncompatibleResultTypeProblem](
                    "org.apache.spark.graphx.EdgeRDD.fromEdges"),
                  ProblemFilters.exclude[MissingMethodProblem]("org.apache.spark.graphx.EdgeRDD.filter"),
                  ProblemFilters.exclude[IncompatibleResultTypeProblem](
                    "org.apache.spark.graphx.impl.EdgeRDDImpl.filter"),
      ```
      [https://github.com/apache/spark/commit/9ac2bb18ede2e9f73c255fa33445af89aaf8a000]
      
      ```
                  // SPARK-3623
                  ProblemFilters.exclude[MissingMethodProblem]("org.apache.spark.graphx.Graph.checkpoint")
      ```
      [https://github.com/apache/spark/commit/e895e0cbecbbec1b412ff21321e57826d2d0a982]
      
      ```
                  // SPARK-4620
                  ProblemFilters.exclude[MissingMethodProblem]("org.apache.spark.graphx.Graph.unpersist"),
      ```
      [https://github.com/apache/spark/commit/8817fc7fe8785d7b11138ca744f22f7e70f1f0a0]
      
      CC: rxin
      
      Author: Joseph K. Bradley <joseph@databricks.com>
      
      Closes #3856 from jkbradley/graphx-mima and squashes the following commits:
      
      1eea2f6 [Joseph K. Bradley] moved cleanup to run-tests
      527ccd9 [Joseph K. Bradley] fixed jenkins script to remove ivy2 cache
      802e252 [Joseph K. Bradley] Removed GraphX MIMA excludes and added line to clear spark from .m2 dir before Jenkins tests.  This may not work yet...
      30f8bb4 [Joseph K. Bradley] added individual mima excludes for graphx
      a3fea42 [Joseph K. Bradley] removed graphx mima exclude for 1.3
      33132609
    • scwf's avatar
      [SPARK-5029][SQL] Enable from follow multiple brackets · d22a31f5
      scwf authored
      Enable from follow multiple brackets:
      ```
      select key from ((select * from testData limit 1) union all (select * from testData limit 1)) x limit 1
      ```
      
      Author: scwf <wangfei1@huawei.com>
      
      Closes #3853 from scwf/from and squashes the following commits:
      
      14f110a [scwf] enable from follow multiple brackets
      d22a31f5
    • wangfei's avatar
      [SPARK-4871][SQL] Show sql statement in spark ui when run sql with spark-sql · 92d9a704
      wangfei authored
      Author: wangfei <wangfei1@huawei.com>
      
      Closes #3718 from scwf/sparksqlui and squashes the following commits:
      
      e0d6b5d [wangfei] format fix
      383b505 [wangfei] fix conflicts
      4d2038a [wangfei] using setJobDescription
      df79837 [wangfei] fix compile error
      92ce834 [wangfei] show sql statement in spark ui when run sql use spark-sql
      92d9a704
    • GuoQiang Li's avatar
      [Minor]Resolve sbt warnings during build (MQTTStreamSuite.scala). · 8a29dc71
      GuoQiang Li authored
      cc andrewor14
      
      Author: GuoQiang Li <witgo@qq.com>
      
      Closes #3989 from witgo/MQTTStreamSuite and squashes the following commits:
      
      a6e967e [GuoQiang Li] Resolve sbt warnings during build (MQTTStreamSuite.scala).
      8a29dc71
    • CodingCat's avatar
      [SPARK-5181] do not print writing WAL log when WAL is disabled · f0d558b6
      CodingCat authored
      https://issues.apache.org/jira/browse/SPARK-5181
      
      Currently, even the logManager is not created, we still see the log entry
      s"Writing to log $record"
      
      a simple fix to make log more accurate
      
      Author: CodingCat <zhunansjtu@gmail.com>
      
      Closes #3985 from CodingCat/SPARK-5181 and squashes the following commits:
      
      0e27dc5 [CodingCat] do not print writing WAL log when WAL is disabled
      f0d558b6
Loading