Skip to content
Snippets Groups Projects
  1. Jan 27, 2015
    • Sean Owen's avatar
      SPARK-5308 [BUILD] MD5 / SHA1 hash format doesn't match standard Maven output · ff356e2a
      Sean Owen authored
      Here's one way to make the hashes match what Maven's plugins would create. It takes a little extra footwork since OS X doesn't have the same command line tools. An alternative is just to make Maven output these of course - would that be better? I ask in case there is a reason I'm missing, like, we need to hash files that Maven doesn't build.
      
      Author: Sean Owen <sowen@cloudera.com>
      
      Closes #4161 from srowen/SPARK-5308 and squashes the following commits:
      
      70d09d0 [Sean Owen] Use $(...) syntax
      e25eff8 [Sean Owen] Generate MD5, SHA1 hashes in a format like Maven's plugin
      ff356e2a
    • Burak Yavuz's avatar
      [SPARK-5321] Support for transposing local matrices · 91426748
      Burak Yavuz authored
      Support for transposing local matrices added. The `.transpose` function creates a new object re-using the backing array(s) but switches `numRows` and `numCols`. Operations check the flag `.isTransposed` to see whether the indexing in `values` should be modified.
      
      This PR will pave the way for transposing `BlockMatrix`.
      
      Author: Burak Yavuz <brkyvz@gmail.com>
      
      Closes #4109 from brkyvz/SPARK-5321 and squashes the following commits:
      
      87ab83c [Burak Yavuz] fixed scalastyle
      caf4438 [Burak Yavuz] addressed code review v3
      c524770 [Burak Yavuz] address code review comments 2
      77481e8 [Burak Yavuz] fixed MiMa
      f1c1742 [Burak Yavuz] small refactoring
      ccccdec [Burak Yavuz] fixed failed test
      dd45c88 [Burak Yavuz] addressed code review
      a01bd5f [Burak Yavuz] [SPARK-5321] Fixed MiMa issues
      2a63593 [Burak Yavuz] [SPARK-5321] fixed bug causing failed gemm test
      c55f29a [Burak Yavuz] [SPARK-5321] Support for transposing local matrices cleaned up
      c408c05 [Burak Yavuz] [SPARK-5321] Support for transposing local matrices added
      91426748
    • Liang-Chi Hsieh's avatar
      [SPARK-5419][Mllib] Fix the logic in Vectors.sqdist · 7b0ed797
      Liang-Chi Hsieh authored
      The current implementation in Vectors.sqdist is not efficient because of allocating temp arrays. There is also a bug in the code `v1.indices.length / v1.size < 0.5`. This pr fixes the bug and refactors sqdist without allocating new arrays.
      
      Author: Liang-Chi Hsieh <viirya@gmail.com>
      
      Closes #4217 from viirya/fix_sqdist and squashes the following commits:
      
      e8b0b3d [Liang-Chi Hsieh] For review comments.
      314c424 [Liang-Chi Hsieh] Fix sqdist bug.
      7b0ed797
  2. Jan 26, 2015
    • MechCoder's avatar
      [SPARK-3726] [MLlib] Allow sampling_rate not equal to 1.0 in RandomForests · d6894b1c
      MechCoder authored
      I've added support for sampling_rate not equal to 1.0 . I have two major questions.
      
      1. A Scala style test is failing, since the number of parameters now exceed 10.
      2. I would like suggestions to understand how to test this.
      
      Author: MechCoder <manojkumarsivaraj334@gmail.com>
      
      Closes #4073 from MechCoder/spark-3726 and squashes the following commits:
      
      8012fb2 [MechCoder] Add test in Strategy
      e0e0d9c [MechCoder] TST: Add better test
      d1df1b2 [MechCoder] Add test to verify subsampling behavior
      a7bfc70 [MechCoder] [SPARK-3726] Allow sampling_rate not equal to 1.0
      d6894b1c
    • lewuathe's avatar
      [SPARK-5119] java.lang.ArrayIndexOutOfBoundsException on trying to train... · f2ba5c6f
      lewuathe authored
      ... decision tree model
      
      Labels loaded from libsvm files are mapped to 0.0 if they are negative labels because they should be nonnegative value.
      
      Author: lewuathe <lewuathe@me.com>
      
      Closes #3975 from Lewuathe/map-negative-label-to-positive and squashes the following commits:
      
      12d1d59 [lewuathe] [SPARK-5119] Fix code styles
      6d9a18a [lewuathe] [SPARK-5119] Organize test codes
      62a150c [lewuathe] [SPARK-5119] Modify Impurities throw exceptions with negatie labels
      3336c21 [lewuathe] [SPARK-5119] java.lang.ArrayIndexOutOfBoundsException on trying to train decision tree model
      f2ba5c6f
    • Elmer Garduno's avatar
      [SPARK-5052] Add common/base classes to fix guava methods signatures. · 661e0fca
      Elmer Garduno authored
      Fixes problems with incorrect method signatures related to shaded classes. For discussion see the jira issue.
      
      Author: Elmer Garduno <elmerg@google.com>
      
      Closes #3874 from elmer-garduno/fix_guava_signatures and squashes the following commits:
      
      aa5d8e0 [Elmer Garduno] Unshade common/base[Function|Supplier] classes to fix guava methods signatures.
      661e0fca
    • Sean Owen's avatar
      SPARK-960 [CORE] [TEST] JobCancellationSuite "two jobs sharing the same stage" is broken · 0497ea51
      Sean Owen authored
      This reenables and fixes this test, after addressing two issues:
      
      - The Semaphore that was intended to be shared locally was being serialized and copied; it's now a static member in the companion object as in other tests
      - Later changes to Spark means that cancelling the first task will not cancel the shared stage and therefore the second task should succeed
      
      Author: Sean Owen <sowen@cloudera.com>
      
      Closes #4180 from srowen/SPARK-960 and squashes the following commits:
      
      43da66f [Sean Owen] Fix 'two jobs sharing the same stage' test and reenable it: truly share a Semaphore locally as intended, and update expectation of failure in non-cancelled task
      0497ea51
    • David Y. Ross's avatar
      Fix command spaces issue in make-distribution.sh · b38034e8
      David Y. Ross authored
      Storing command in variables is tricky in bash, use an array
      to handle all issues with spaces, quoting, etc.
      See: http://mywiki.wooledge.org/BashFAQ/050
      
      Author: David Y. Ross <dyross@gmail.com>
      
      Closes #4126 from dyross/dyr-fix-make-distribution and squashes the following commits:
      
      4ce522b [David Y. Ross] Fix command spaces issue in make-distribution.sh
      b38034e8
    • Sean Owen's avatar
      SPARK-4147 [CORE] Reduce log4j dependency · 54e7b456
      Sean Owen authored
      Defer use of log4j class until it's known that log4j 1.2 is being used. This may avoid dealing with log4j dependencies for callers that reroute slf4j to another logging framework. The only change is to push one half of the check in the original `if` condition inside. This is a trivial change, may or may not actually solve a problem, but I think it's all that makes sense to do for SPARK-4147.
      
      Author: Sean Owen <sowen@cloudera.com>
      
      Closes #4190 from srowen/SPARK-4147 and squashes the following commits:
      
      4e99942 [Sean Owen] Defer use of log4j class until it's known that log4j 1.2 is being used. This may avoid dealing with log4j dependencies for callers that reroute slf4j to another logging framework.
      54e7b456
    • Kousuke Saruta's avatar
      [SPARK-5339][BUILD] build/mvn doesn't work because of invalid URL for maven's tgz. · c094c732
      Kousuke Saruta authored
      build/mvn will automatically download tarball of maven. But currently, the URL is invalid.
      
      Author: Kousuke Saruta <sarutak@oss.nttdata.co.jp>
      
      Closes #4124 from sarutak/SPARK-5339 and squashes the following commits:
      
      6e96121 [Kousuke Saruta] Merge branch 'master' of git://git.apache.org/spark into SPARK-5339
      0e012d1 [Kousuke Saruta] Updated Maven version to 3.2.5
      ca26499 [Kousuke Saruta] Fixed URL of the tarball of Maven
      c094c732
    • Davies Liu's avatar
      [SPARK-5355] use j.u.c.ConcurrentHashMap instead of TrieMap · 14209317
      Davies Liu authored
      j.u.c.ConcurrentHashMap is more battle tested.
      
      cc rxin JoshRosen pwendell
      
      Author: Davies Liu <davies@databricks.com>
      
      Closes #4208 from davies/safe-conf and squashes the following commits:
      
      c2182dc [Davies Liu] address comments, fix tests
      3a1d821 [Davies Liu] fix test
      da14ced [Davies Liu] Merge branch 'master' of github.com:apache/spark into safe-conf
      ae4d305 [Davies Liu] change to j.u.c.ConcurrentMap
      f8fa1cf [Davies Liu] change to TrieMap
      a1d769a [Davies Liu] make SparkConf thread-safe
      14209317
    • Yuhao Yang's avatar
      [SPARK-5384][mllib] Vectors.sqdist returns inconsistent results for... · 81251682
      Yuhao Yang authored
      [SPARK-5384][mllib] Vectors.sqdist returns inconsistent results for sparse/dense vectors when the vectors have different lengths
      
      JIRA issue: https://issues.apache.org/jira/browse/SPARK-5384
      Currently `Vectors.sqdist` return inconsistent result for sparse/dense vectors when the vectors have different lengths, please refer to JIRA for sample
      
      PR scope:
      Unify the sqdist logic for dense/sparse vectors and fix the inconsistency, also remove the possible sparse to dense conversion in the original code.
      
      For reviewers:
      Maybe we should first discuss what's the correct behavior.
      1. Vectors for sqdist must have the same length, like in breeze?
      2. If they can have different lengths, what's the correct result for sqdist? (should the extra part get into calculation?)
      
      I'll update PR with more optimization and additional ut afterwards. Thanks.
      
      Author: Yuhao Yang <hhbyyh@gmail.com>
      
      Closes #4183 from hhbyyh/fixDouble and squashes the following commits:
      
      1f17328 [Yuhao Yang] limit PR scope to size constraints only
      54cbf97 [Yuhao Yang] fix Vectors.sqdist inconsistence
      81251682
  3. Jan 25, 2015
    • CodingCat's avatar
      [SPARK-5268] don't stop CoarseGrainedExecutorBackend for irrelevant DisassociatedEvent · 8df94355
      CodingCat authored
      https://issues.apache.org/jira/browse/SPARK-5268
      
      In CoarseGrainedExecutorBackend, we subscribe DisassociatedEvent in executor backend actor and exit the program upon receive such event...
      
      let's consider the following case
      
      The user may develop an Akka-based program which starts the actor with Spark's actor system and communicate with an external actor system (e.g. an Akka-based receiver in spark streaming which communicates with an external system) If the external actor system fails or disassociates with the actor within spark's system with purpose, we may receive DisassociatedEvent and the executor is restarted.
      
      This is not the expected behavior.....
      
      ----
      
      This is a simple fix to check the event before making the quit decision
      
      Author: CodingCat <zhunansjtu@gmail.com>
      
      Closes #4063 from CodingCat/SPARK-5268 and squashes the following commits:
      
      4d7d48e [CodingCat] simplify the log
      18c36f4 [CodingCat] more descriptive log
      f299e0b [CodingCat] clean log
      1632e79 [CodingCat] check whether DisassociatedEvent is relevant before quit
      8df94355
    • Sean Owen's avatar
      SPARK-4430 [STREAMING] [TEST] Apache RAT Checks fail spuriously on test files · 0528b85c
      Sean Owen authored
      Another trivial one. The RAT failure was due to temp files from `FailureSuite` not being cleaned up. This just makes the cleanup more reliable by using the standard temp dir mechanism.
      
      Author: Sean Owen <sowen@cloudera.com>
      
      Closes #4189 from srowen/SPARK-4430 and squashes the following commits:
      
      9ea63ff [Sean Owen] Properly acquire a temp directory to ensure it is cleaned up at shutdown, which helps avoid a RAT check failure
      0528b85c
    • Kay Ousterhout's avatar
      [SPARK-5326] Show fetch wait time as optional metric in the UI · fc2168f0
      Kay Ousterhout authored
      With this change, here's what the UI looks like:
      
      ![image](https://cloud.githubusercontent.com/assets/1108612/5809994/1ec8a904-9ff4-11e4-8f24-6a59a1a858f7.png)
      
      If you want to locally test this, you need to spin up multiple executors, because the shuffle read metrics are only shown for data read remotely.
      
      Author: Kay Ousterhout <kayousterhout@gmail.com>
      
      Closes #4110 from kayousterhout/SPARK-5326 and squashes the following commits:
      
      610051e [Kay Ousterhout] Josh style comments
      5feaa28 [Kay Ousterhout] What is the difference here??
      aa129cb [Kay Ousterhout] Removed inadvertent change
      721c742 [Kay Ousterhout] Improved tooltip
      f3a7111 [Kay Ousterhout] Style fix
      679b4e9 [Kay Ousterhout] [SPARK-5326] Show fetch wait time as optional metric in the UI
      fc2168f0
    • Kousuke Saruta's avatar
      [SPARK-5344][WebUI] HistoryServer cannot recognize that inprogress file was... · 8f5c827b
      Kousuke Saruta authored
      [SPARK-5344][WebUI] HistoryServer cannot recognize that inprogress file was renamed to completed file
      
      `FsHistoryProvider` tries to update application status but if `checkForLogs` is called before `.inprogress` file is renamed to completed file, the file is not recognized as completed.
      
      Author: Kousuke Saruta <sarutak@oss.nttdata.co.jp>
      
      Closes #4132 from sarutak/SPARK-5344 and squashes the following commits:
      
      9658008 [Kousuke Saruta] Merge branch 'master' of git://git.apache.org/spark into SPARK-5344
      d2c72b6 [Kousuke Saruta] Fixed update issue of FsHistoryProvider
      8f5c827b
    • Sean Owen's avatar
      SPARK-4506 [DOCS] Addendum: Update more docs to reflect that standalone works in cluster mode · 9f643576
      Sean Owen authored
      This is a trivial addendum to SPARK-4506, which was already resolved. noted by Asim Jalis in SPARK-4506.
      
      Author: Sean Owen <sowen@cloudera.com>
      
      Closes #4160 from srowen/SPARK-4506 and squashes the following commits:
      
      5f5f7df [Sean Owen] Update more docs to reflect that standalone works in cluster mode
      9f643576
    • Jacek Lewandowski's avatar
      SPARK-5382: Use SPARK_CONF_DIR in spark-class if it is defined · 1c30afdf
      Jacek Lewandowski authored
      Author: Jacek Lewandowski <lewandowski.jacek@gmail.com>
      
      Closes #4179 from jacek-lewandowski/SPARK-5382-1.3 and squashes the following commits:
      
      55d7791 [Jacek Lewandowski] SPARK-5382: Use SPARK_CONF_DIR in spark-class if it is defined
      1c30afdf
    • Sean Owen's avatar
      SPARK-3782 [CORE] Direct use of log4j in AkkaUtils interferes with certain logging configurations · 383425ab
      Sean Owen authored
      Although the underlying issue can I think be solved by having user code use slf4j 1.7.6+, it might be helpful and consistent to update Spark's slf4j too. I see no reason to believe it would be incompatible with other 1.7.x releases: http://www.slf4j.org/news.html  Lots of different version of slf4j are in use in the wild and anecdotally I have never seen an issue mixing them.
      
      Author: Sean Owen <sowen@cloudera.com>
      
      Closes #4184 from srowen/SPARK-3782 and squashes the following commits:
      
      5608d28 [Sean Owen] Update slf4j to 1.7.10
      383425ab
    • Sean Owen's avatar
      SPARK-3852 [DOCS] Document spark.driver.extra* configs · c586b45d
      Sean Owen authored
      As per the JIRA. I copied the `spark.executor.extra*` text, but removed info that appears to be specific to the `executor` config and not `driver`.
      
      Author: Sean Owen <sowen@cloudera.com>
      
      Closes #4185 from srowen/SPARK-3852 and squashes the following commits:
      
      f60a8a1 [Sean Owen] Document spark.driver.extra* configs
      c586b45d
    • Ryan Williams's avatar
      [SPARK-5402] log executor ID at executor-construction time · aea25482
      Ryan Williams authored
      also rename "slaveHostname" to "executorHostname"
      
      Author: Ryan Williams <ryan.blake.williams@gmail.com>
      
      Closes #4195 from ryan-williams/exec and squashes the following commits:
      
      e60a7bb [Ryan Williams] log executor ID at executor-construction time
      aea25482
    • Ryan Williams's avatar
      [SPARK-5401] set executor ID before creating MetricsSystem · 2d9887ba
      Ryan Williams authored
      Author: Ryan Williams <ryan.blake.williams@gmail.com>
      
      Closes #4194 from ryan-williams/metrics and squashes the following commits:
      
      7c5a33f [Ryan Williams] set executor ID before creating MetricsSystem
      2d9887ba
    • Idan Zalzberg's avatar
      Add comment about defaultMinPartitions · 412a58e1
      Idan Zalzberg authored
      Added a comment about using math.min for choosing default partition count
      
      Author: Idan Zalzberg <idanzalz@gmail.com>
      
      Closes #4102 from idanz/patch-2 and squashes the following commits:
      
      50e9d58 [Idan Zalzberg] Update SparkContext.scala
      412a58e1
    • Reynold Xin's avatar
      Closes #4157 · d22ca1e9
      Reynold Xin authored
      d22ca1e9
  4. Jan 24, 2015
  5. Jan 23, 2015
    • Takeshi Yamamuro's avatar
      [SPARK-5351][GraphX] Do not use Partitioner.defaultPartitioner as a partitioner of EdgeRDDImp... · e224dbb0
      Takeshi Yamamuro authored
      If the value of 'spark.default.parallelism' does not match the number of partitoins in EdgePartition(EdgeRDDImpl),
      the following error occurs in ReplicatedVertexView.scala:72;
      
      object GraphTest extends Logging {
        def run[VD: ClassTag, ED: ClassTag](graph: Graph[VD, ED]): VertexRDD[Int] = {
          graph.aggregateMessages(
            ctx => {
              ctx.sendToSrc(1)
              ctx.sendToDst(2)
            },
            _ + _)
        }
      }
      
      val g = GraphLoader.edgeListFile(sc, "graph.txt")
      val rdd = GraphTest.run(g)
      
      java.lang.IllegalArgumentException: Can't zip RDDs with unequal numbers of partitions
      	at org.apache.spark.rdd.ZippedPartitionsBaseRDD.getPartitions(ZippedPartitionsRDD.scala:57)
      	at org.apache.spark.rdd.RDD$$anonfun$partitions$2.apply(RDD.scala:206)
      	at org.apache.spark.rdd.RDD$$anonfun$partitions$2.apply(RDD.scala:204)
      	at scala.Option.getOrElse(Option.scala:120)
      	at org.apache.spark.rdd.RDD.partitions(RDD.scala:204)
      	at org.apache.spark.rdd.MapPartitionsRDD.getPartitions(MapPartitionsRDD.scala:32)
      	at org.apache.spark.rdd.RDD$$anonfun$partitions$2.apply(RDD.scala:206)
      	at org.apache.spark.rdd.RDD$$anonfun$partitions$2.apply(RDD.scala:204)
      	at scala.Option.getOrElse(Option.scala:120)
      	at org.apache.spark.rdd.RDD.partitions(RDD.scala:204)
      	at org.apache.spark.ShuffleDependency.<init>(Dependency.scala:82)
      	at org.apache.spark.rdd.ShuffledRDD.getDependencies(ShuffledRDD.scala:80)
      	at org.apache.spark.rdd.RDD$$anonfun$dependencies$2.apply(RDD.scala:193)
      	at org.apache.spark.rdd.RDD$$anonfun$dependencies$2.apply(RDD.scala:191)
          ...
      
      Author: Takeshi Yamamuro <linguin.m.s@gmail.com>
      
      Closes #4136 from maropu/EdgePartitionBugFix and squashes the following commits:
      
      0cd8942 [Ankur Dave] Use more concise getOrElse
      aad4a2c [Ankur Dave] Add unit test for non-default number of edge partitions
      0a2f32b [Takeshi Yamamuro] Do not use Partitioner.defaultPartitioner as a partitioner of EdgeRDDImpl
      e224dbb0
    • Josh Rosen's avatar
      [SPARK-5063] More helpful error messages for several invalid operations · cef1f092
      Josh Rosen authored
      This patch adds more helpful error messages for invalid programs that define nested RDDs, broadcast RDDs, perform actions inside of transformations (e.g. calling `count()` from inside of `map()`), and call certain methods on stopped SparkContexts.  Currently, these invalid programs lead to confusing NullPointerExceptions at runtime and have been a major source of questions on the mailing list and StackOverflow.
      
      In a few cases, I chose to log warnings instead of throwing exceptions in order to avoid any chance that this patch breaks programs that worked "by accident" in earlier Spark releases (e.g. programs that define nested RDDs but never run any jobs with them).
      
      In SparkContext, the new `assertNotStopped()` method is used to check whether methods are being invoked on a stopped SparkContext.  In some cases, user programs will not crash in spite of calling methods on stopped SparkContexts, so I've only added `assertNotStopped()` calls to methods that always throw exceptions when called on stopped contexts (e.g. by dereferencing a null `dagScheduler` pointer).
      
      Author: Josh Rosen <joshrosen@databricks.com>
      
      Closes #3884 from JoshRosen/SPARK-5063 and squashes the following commits:
      
      a38774b [Josh Rosen] Fix spelling typo
      a943e00 [Josh Rosen] Convert two exceptions into warnings in order to avoid breaking user programs in some edge-cases.
      2d0d7f7 [Josh Rosen] Fix test to reflect 1.2.1 compatibility
      3f0ea0c [Josh Rosen] Revert two unintentional formatting changes
      8e5da69 [Josh Rosen] Remove assertNotStopped() calls for methods that were sometimes safe to call on stopped SC's in Spark 1.2
      8cff41a [Josh Rosen] IllegalStateException fix
      6ef68d0 [Josh Rosen] Fix Python line length issues.
      9f6a0b8 [Josh Rosen] Add improved error messages to PySpark.
      13afd0f [Josh Rosen] SparkException -> IllegalStateException
      8d404f3 [Josh Rosen] Merge remote-tracking branch 'origin/master' into SPARK-5063
      b39e041 [Josh Rosen] Fix BroadcastSuite test which broadcasted an RDD
      99cc09f [Josh Rosen] Guard against calling methods on stopped SparkContexts.
      34833e8 [Josh Rosen] Add more descriptive error message.
      57cc8a1 [Josh Rosen] Add error message when directly broadcasting RDD.
      15b2e6b [Josh Rosen] [SPARK-5063] Useful error messages for nested RDDs and actions inside of transformations
      cef1f092
    • Xiangrui Meng's avatar
      [SPARK-3541][MLLIB] New ALS implementation with improved storage · ea74365b
      Xiangrui Meng authored
      This PR adds a new ALS implementation to `spark.ml` using the pipeline API, which should be able to scale to billions of ratings. Compared with the ALS under `spark.mllib`, the new implementation
      
      1. uses the same algorithm,
      2. uses float type for ratings,
      3. uses primitive arrays to avoid GC,
      4. sorts and compresses ratings on each block so that we can solve least squares subproblems one by one using only one normal equation instance.
      
      The following figure shows performance comparison on copies of the Amazon Reviews dataset using a 16-node (m3.2xlarge) EC2 cluster (the same setup as in http://databricks.com/blog/2014/07/23/scalable-collaborative-filtering-with-spark-mllib.html):
      ![als-wip](https://cloud.githubusercontent.com/assets/829644/5659447/4c4ff8e0-96c7-11e4-87a9-73c1c63d07f3.png)
      
      I keep the `spark.mllib`'s ALS untouched for easy comparison. If the new implementation works well, I'm going to match the features of the ALS under `spark.mllib` and then make it a wrapper of the new implementation, in a separate PR.
      
      TODO:
      - [X] Add unit tests for implicit preferences.
      
      Author: Xiangrui Meng <meng@databricks.com>
      
      Closes #3720 from mengxr/SPARK-3541 and squashes the following commits:
      
      1b9e852 [Xiangrui Meng] fix compile
      5129be9 [Xiangrui Meng] Merge remote-tracking branch 'apache/master' into SPARK-3541
      dd0d0e8 [Xiangrui Meng] simplify test code
      c627de3 [Xiangrui Meng] add tests for implicit feedback
      b84f41c [Xiangrui Meng] address comments
      a76da7b [Xiangrui Meng] update ALS tests
      2a8deb3 [Xiangrui Meng] add some ALS tests
      857e876 [Xiangrui Meng] add tests for rating block and encoded block
      d3c1ac4 [Xiangrui Meng] rename some classes for better code readability add more doc and comments
      213d163 [Xiangrui Meng] org imports
      771baf3 [Xiangrui Meng] chol doc update
      ca9ad9d [Xiangrui Meng] add unit tests for chol
      b4fd17c [Xiangrui Meng] add unit tests for NormalEquation
      d0f99d3 [Xiangrui Meng] add tests for LocalIndexEncoder
      80b8e61 [Xiangrui Meng] fix imports
      4937fd4 [Xiangrui Meng] update ALS example
      56c253c [Xiangrui Meng] rename product to item
      bce8692 [Xiangrui Meng] doc for parameters and project the output columns
      3f2d81a [Xiangrui Meng] add doc
      1efaecf [Xiangrui Meng] add example code
      8ae86b5 [Xiangrui Meng] add a working copy of the new ALS implementation
      ea74365b
    • jerryshao's avatar
      [SPARK-5315][Streaming] Fix reduceByWindow Java API not work bug · e0f7fb7f
      jerryshao authored
      `reduceByWindow` for Java API is actually not Java compatible, change to make it Java compatible.
      
      Current solution is to deprecate the old one and add a new API, but since old API actually is not correct, so is keeping the old one meaningful? just to keep the binary compatible? Also even adding new API still need to add to Mima exclusion, I'm not sure to change the API, or deprecate the old API and add a new one, which is the best solution?
      
      Author: jerryshao <saisai.shao@intel.com>
      
      Closes #4104 from jerryshao/SPARK-5315 and squashes the following commits:
      
      5bc8987 [jerryshao] Address the comment
      c7aa1b4 [jerryshao] Deprecate the old one to keep binary compatible
      8e9dc67 [jerryshao] Fix JavaDStream reduceByWindow signature error
      e0f7fb7f
  6. Jan 22, 2015
    • jerryshao's avatar
      [SPARK-5233][Streaming] Fix error replaying of WAL introduced bug · 3c3fa632
      jerryshao authored
      Because of lacking of `BlockAllocationEvent` in WAL recovery, the dangled event will mix into the new batch, which will lead to the wrong result. Details can be seen in [SPARK-5233](https://issues.apache.org/jira/browse/SPARK-5233).
      
      Author: jerryshao <saisai.shao@intel.com>
      
      Closes #4032 from jerryshao/SPARK-5233 and squashes the following commits:
      
      f0b0c0b [jerryshao] Further address the comments
      a237c75 [jerryshao] Address the comments
      e356258 [jerryshao] Fix bug in unit test
      558bdc3 [jerryshao] Correctly replay the WAL log when recovering from failure
      3c3fa632
    • Sandy Ryza's avatar
      SPARK-5370. [YARN] Remove some unnecessary synchronization in YarnAlloca... · 820ce035
      Sandy Ryza authored
      ...tor
      
      Author: Sandy Ryza <sandy@cloudera.com>
      
      Closes #4164 from sryza/sandy-spark-5370 and squashes the following commits:
      
      0c8d736 [Sandy Ryza] SPARK-5370. [YARN] Remove some unnecessary synchronization in YarnAllocator
      820ce035
    • Liang-Chi Hsieh's avatar
      [SPARK-5365][MLlib] Refactor KMeans to reduce redundant data · 246111d1
      Liang-Chi Hsieh authored
      If a point is selected as new centers for many runs, it would collect many redundant data. This pr refactors it.
      
      Author: Liang-Chi Hsieh <viirya@gmail.com>
      
      Closes #4159 from viirya/small_refactor_kmeans and squashes the following commits:
      
      25487e6 [Liang-Chi Hsieh] Refactor codes to reduce redundant data.
      246111d1
    • Tathagata Das's avatar
      [SPARK-5147][Streaming] Delete the received data WAL log periodically · 3027f06b
      Tathagata Das authored
      This is a refactored fix based on jerryshao 's PR #4037
      This enabled deletion of old WAL files containing the received block data.
      Improvements over #4037
      - Respecting the rememberDuration of all receiver streams. In #4037, if there were two receiver streams with multiple remember durations, the deletion would have delete based on the shortest remember duration, thus deleting data prematurely for the receiver stream with longer remember duration.
      - Added unit test to test creation of receiver WAL, automatic deletion, and respecting of remember duration.
      
      jerryshao I am going to merge this ASAP to make it 1.2.1 Thanks for the initial draft of this PR. Made my job much easier.
      
      Author: Tathagata Das <tathagata.das1565@gmail.com>
      Author: jerryshao <saisai.shao@intel.com>
      
      Closes #4149 from tdas/SPARK-5147 and squashes the following commits:
      
      730798b [Tathagata Das] Added comments.
      c4cf067 [Tathagata Das] Minor fixes
      2579b27 [Tathagata Das] Refactored the fix to make sure that the cleanup respects the remember duration of all the receiver streams
      2736fd1 [jerryshao] Delete the old WAL log periodically
      3027f06b
    • Basin's avatar
      [SPARK-5317]Set BoostingStrategy.defaultParams With Enumeration... · fcb3e186
      Basin authored
      [SPARK-5317]Set BoostingStrategy.defaultParams With Enumeration Algo.Classification or Algo.Regression
      
      JIRA Issue: https://issues.apache.org/jira/browse/SPARK-5317
      When setting the BoostingStrategy.defaultParams("Classification"), It's more straightforward to set it with the Enumeration Algo.Classification, just like BoostingStragety.defaultParams(Algo.Classification).
      I overload the method BoostingStragety.defaultParams().
      
      Author: Basin <jpsachilles@gmail.com>
      
      Closes #4103 from Peishen-Jia/stragetyAlgo and squashes the following commits:
      
      87bab1c [Basin] Docs and Code documentations updated.
      3b72875 [Basin] defaultParams(algoStr: String) call defaultParams(algo: Algo).
      7c1e6ee [Basin] Doc of Java updated. algo -> algoStr instead.
      d5c8a2e [Basin] Merge branch 'stragetyAlgo' of github.com:Peishen-Jia/spark into stragetyAlgo
      65f96ce [Basin] mllib-ensembles doc modified.
      e04a5aa [Basin] boostingstrategy.defaultParam string algo to enumeration.
      68cf544 [Basin] mllib-ensembles doc modified.
      a4aea51 [Basin] boostingstrategy.defaultParam string algo to enumeration.
      fcb3e186
  7. Jan 21, 2015
Loading