You are viewing a plain text version of this content. The canonical link for it is here.
- spark git commit: [SPARK-17180][SPARK-17309][SPARK-17323][SQL][2.0] create AlterViewAsCommand to handle ALTER VIEW AS - posted by we...@apache.org on 2016/09/01 00:55:00 UTC, 0 replies.
- spark git commit: [SPARKR][MINOR] Fix windowPartitionBy example - posted by sh...@apache.org on 2016/09/01 04:28:57 UTC, 1 replies.
- spark git commit: [SPARK-17241][SPARKR][MLLIB] SparkR spark.glm should have configurable regularization parameter - posted by sh...@apache.org on 2016/09/01 04:39:37 UTC, 0 replies.
- spark git commit: revert PR#10896 and PR#14865 - posted by we...@apache.org on 2016/09/01 05:19:13 UTC, 0 replies.
- spark git commit: [SPARK-17318][TESTS] Fix ReplSuite replicating blocks of object with class defined in repl again - posted by zs...@apache.org on 2016/09/01 06:25:23 UTC, 1 replies.
- spark git commit: [SPARK-17329][BUILD] Don't build PRs with -Pyarn unless YARN code changed - posted by sr...@apache.org on 2016/09/01 08:10:05 UTC, 0 replies.
- spark git commit: [SPARK-16283][SQL] Implements percentile_approx aggregation function which supports partial aggregation. - posted by we...@apache.org on 2016/09/01 08:31:14 UTC, 0 replies.
- spark git commit: fixed typos - posted by sr...@apache.org on 2016/09/01 08:32:09 UTC, 0 replies.
- spark git commit: [SPARK-17353][SPARK-16943][SPARK-16942][SQL] Fix multiple bugs in CREATE TABLE LIKE command - posted by we...@apache.org on 2016/09/01 08:36:11 UTC, 0 replies.
- spark git commit: [SPARK-17257][SQL] the physical plan of CREATE TABLE or CTAS should take CatalogTable - posted by we...@apache.org on 2016/09/01 08:45:24 UTC, 0 replies.
- spark git commit: [SPARK-17271][SQL] Remove redundant `semanticEquals()` from `SortOrder` - posted by we...@apache.org on 2016/09/01 08:47:35 UTC, 0 replies.
- spark git commit: [SPARK-17271][SQL] Planner adds un-necessary Sort even if child orde… - posted by hv...@apache.org on 2016/09/01 16:49:52 UTC, 0 replies.
- spark git commit: [SPARK-16533][CORE] resolve deadlocking in driver when executors die - posted by va...@apache.org on 2016/09/01 17:35:37 UTC, 0 replies.
- spark git commit: [SPARK-17263][SQL] Add hexadecimal literal parsing - posted by jo...@apache.org on 2016/09/01 19:01:53 UTC, 0 replies.
- spark git commit: [SPARK-17331][CORE][MLLIB] Avoid allocating 0-length arrays - posted by jo...@apache.org on 2016/09/01 19:15:43 UTC, 0 replies.
- spark git commit: [SPARK-16533][HOTFIX] Fix compilation on Scala 2.10. - posted by va...@apache.org on 2016/09/01 21:03:04 UTC, 0 replies.
- spark git commit: [SPARK-16926] [SQL] Remove partition columns from partition metadata. - posted by da...@apache.org on 2016/09/01 21:13:21 UTC, 1 replies.
- spark git commit: [SPARK-16732][SQL] Remove unused codes in subexpressionEliminationForWholeStageCodegen - posted by jo...@apache.org on 2016/09/01 21:13:45 UTC, 0 replies.
- spark git commit: [SPARK-16461][SQL] Support partition batch pruning with `<=>` predicate in InMemoryTableScanExec - posted by jo...@apache.org on 2016/09/01 22:32:17 UTC, 0 replies.
- spark git commit: [SPARK-17355] Workaround for HIVE-14684 / HiveResultSetMetaData.isSigned exception - posted by jo...@apache.org on 2016/09/01 23:45:38 UTC, 1 replies.
- spark git commit: [SPARK-16525] [SQL] Enable Row Based HashMap in HashAggregateExec - posted by da...@apache.org on 2016/09/01 23:56:38 UTC, 0 replies.
- spark git commit: [SPARK-16619] Add shuffle service metrics entry in monitoring docs - posted by jo...@apache.org on 2016/09/02 00:01:39 UTC, 0 replies.
- spark git commit: [SPARK-16302][SQL] Set the right number of partitions for reading data from a local collection. - posted by jo...@apache.org on 2016/09/02 00:14:11 UTC, 0 replies.
- spark git commit: [SPARK-16926][SQL] Add unit test to compare table and partition column metadata. - posted by we...@apache.org on 2016/09/02 03:12:31 UTC, 0 replies.
- spark git commit: [SPARK-17342][WEBUI] Style of event timeline is broken - posted by sr...@apache.org on 2016/09/02 07:46:15 UTC, 1 replies.
- spark git commit: [SPARK-16883][SPARKR] SQL decimal type is not properly cast to number when collecting SparkDataFrame - posted by fe...@apache.org on 2016/09/02 08:47:25 UTC, 1 replies.
- spark git commit: [SPARK-15509][ML][SPARKR] R MLlib algorithms should support input columns "features" and "label" - posted by fe...@apache.org on 2016/09/02 08:54:34 UTC, 0 replies.
- spark git commit: [SQL][DOC][MINOR] Add (Scala-specific) and (Java-specific) - posted by sr...@apache.org on 2016/09/02 09:25:56 UTC, 0 replies.
- spark git commit: [SPARK-17352][WEBUI] Executor computing time can be negative-number because of calculation error - posted by sr...@apache.org on 2016/09/02 09:26:44 UTC, 1 replies.
- spark git commit: [SPARK-16935][SQL] Verification of Function-related ExternalCatalog APIs - posted by we...@apache.org on 2016/09/02 14:31:18 UTC, 1 replies.
- spark git commit: [SPARK-16984][SQL] don't try whole dataset immediately when first partition doesn't have… - posted by hv...@apache.org on 2016/09/02 15:14:49 UTC, 0 replies.
- spark git commit: [SPARK-17351] Refactor JDBCRDD to expose ResultSet -> Seq[Row] utility methods - posted by hv...@apache.org on 2016/09/02 16:53:18 UTC, 0 replies.
- spark git commit: [SPARK-17261] [PYSPARK] Using HiveContext after re-creating SparkContext in Spark 2.0 throws "Java.lang.illegalStateException: Cannot call methods on a stopped sparkContext" - posted by da...@apache.org on 2016/09/02 17:08:18 UTC, 1 replies.
- spark git commit: [SPARK-17376][SPARKR] Spark version should be available in R - posted by sh...@apache.org on 2016/09/02 17:12:15 UTC, 1 replies.
- spark git commit: [SPARKR][DOC] regexp_extract should doc that it returns empty string when match fails - posted by sh...@apache.org on 2016/09/02 17:28:43 UTC, 1 replies.
- spark git commit: [SPARK-16711] YarnShuffleService doesn't re-init properly on YARN rolling upgrade - posted by va...@apache.org on 2016/09/02 17:42:22 UTC, 1 replies.
- spark git commit: [SPARK-17376][SPARKR] followup - change since version - posted by fe...@apache.org on 2016/09/02 18:08:30 UTC, 1 replies.
- spark git commit: [SPARK-17316][CORE] Make CoarseGrainedSchedulerBackend.removeExecutor non-blocking - posted by zs...@apache.org on 2016/09/02 19:54:05 UTC, 0 replies.
- spark git commit: [SPARK-17230] [SQL] Should not pass optimized query into QueryExecution in DataFrameWriter - posted by da...@apache.org on 2016/09/02 22:10:20 UTC, 1 replies.
- spark git commit: [SPARK-16334] Reusing same dictionary column for decoding consecutive row groups shouldn't throw an error - posted by da...@apache.org on 2016/09/02 22:16:21 UTC, 1 replies.
- spark git commit: [SPARK-17298][SQL] Require explicit CROSS join for cartesian products - posted by hv...@apache.org on 2016/09/02 22:20:49 UTC, 0 replies.
- spark git commit: Fix build - posted by da...@apache.org on 2016/09/02 22:40:06 UTC, 0 replies.
- spark git commit: Revert "[SPARK-16334] Reusing same dictionary column for decoding consecutive row groups shouldn't throw an error" - posted by da...@apache.org on 2016/09/02 23:05:43 UTC, 0 replies.
- spark git commit: [SPARKR][MINOR] Fix docs for sparkR.session and count - posted by sh...@apache.org on 2016/09/03 04:12:02 UTC, 1 replies.
- spark git commit: [SPARK-17363][ML][MLLIB] fix MultivariantOnlineSummerizer.numNonZeros - posted by sr...@apache.org on 2016/09/03 08:52:57 UTC, 0 replies.
- spark git commit: [SPARK-17347][SQL][EXAMPLES] Encoder in Dataset example has incorrect type - posted by sr...@apache.org on 2016/09/03 09:03:43 UTC, 1 replies.
- spark git commit: [MINOR][SQL] Not dropping all necessary tables - posted by sr...@apache.org on 2016/09/03 14:35:35 UTC, 1 replies.
- spark git commit: [SPARK-16959][SQL] Rebuild Table Comment when Retrieving Metadata from Hive Metastore - posted by we...@apache.org on 2016/09/03 16:10:42 UTC, 0 replies.
- spark git commit: [SPARK-16663][SQL] desc table should be consistent between data source and hive serde tables - posted by we...@apache.org on 2016/09/03 16:16:13 UTC, 0 replies.
- spark git commit: [SPARK-17335][SQL] Fix ArrayType and MapType CatalogString. - posted by hv...@apache.org on 2016/09/03 17:02:27 UTC, 1 replies.
- spark git commit: [SPARK-17315][SPARKR] Kolmogorov-Smirnov test SparkR wrapper - posted by fe...@apache.org on 2016/09/03 19:26:36 UTC, 0 replies.
- spark git commit: [SPARK-16829][SPARKR] sparkR sc.setLogLevel doesn't work - posted by sh...@apache.org on 2016/09/03 20:57:04 UTC, 0 replies.
- spark git commit: [SPARK-17324][SQL] Remove Direct Usage of HiveClient in InsertIntoHiveTable - posted by we...@apache.org on 2016/09/04 07:04:45 UTC, 0 replies.
- spark git commit: [SPARK-17308] Improved the spark core code by replacing all pattern match on boolean value by if/else block. - posted by sr...@apache.org on 2016/09/04 11:39:28 UTC, 0 replies.
- spark git commit: [SPARK-17311][MLLIB] Standardize Python-Java MLlib API to accept optional long seeds in all cases - posted by sr...@apache.org on 2016/09/04 11:40:52 UTC, 0 replies.
- spark git commit: [MINOR][ML][MLLIB] Remove work around for breeze sparse matrix. - posted by yl...@apache.org on 2016/09/04 12:38:57 UTC, 0 replies.
- spark git commit: [SPARK-17391][TEST][2.0] Fix Two Test Failures After Backport - posted by we...@apache.org on 2016/09/05 03:17:53 UTC, 0 replies.
- spark git commit: [SPARK-17393][SQL] Error Handling when CTAS Against the Same Data Source Table Using Overwrite Mode - posted by we...@apache.org on 2016/09/05 03:28:29 UTC, 0 replies.
- spark git commit: [SPARK-17394][SQL] should not allow specify database in table/view name after RENAME TO - posted by we...@apache.org on 2016/09/05 05:09:29 UTC, 0 replies.
- spark git commit: [SPARK-17072][SQL] support table-level statistics generation and storing into/loading from metastore - posted by hv...@apache.org on 2016/09/05 15:32:37 UTC, 0 replies.
- spark git commit: [SPARK-15091][SPARKR] Fix warnings and a failure in SparkR test cases with testthat version 1.0.1 - posted by sh...@apache.org on 2016/09/05 23:00:05 UTC, 0 replies.
- spark git commit: [SPARK-17279][SQL] better error message for exceptions during ScalaUDF execution - posted by we...@apache.org on 2016/09/06 02:36:09 UTC, 1 replies.
- spark git commit: [SPARK-17353][SPARK-16943][SPARK-16942][BACKPORT-2.0][SQL] Fix multiple bugs in CREATE TABLE LIKE command - posted by we...@apache.org on 2016/09/06 02:46:06 UTC, 0 replies.
- spark git commit: [SPARK-17369][SQL] MetastoreRelation toJSON throws AssertException due to missing otherCopyArgs - posted by we...@apache.org on 2016/09/06 02:50:21 UTC, 1 replies.
- spark git commit: [SPARK-17358][SQL] Cached table(parquet/orc) should be shard between beelines - posted by we...@apache.org on 2016/09/06 02:57:33 UTC, 1 replies.
- spark git commit: Revert "[SPARK-17369][SQL] MetastoreRelation toJSON throws AssertException due to missing otherCopyArgs" - posted by yh...@apache.org on 2016/09/06 04:13:43 UTC, 0 replies.
- spark git commit: [SPARK-17361][SQL] file-based external table without path should not be created - posted by we...@apache.org on 2016/09/06 06:17:57 UTC, 0 replies.
- spark git commit: [SPARK-17369][SQL][2.0] MetastoreRelation toJSON throws AssertException due to missing otherCopyArgs - posted by we...@apache.org on 2016/09/06 07:43:00 UTC, 0 replies.
- spark git commit: [SPARK-17356][SQL] Fix out of memory issue when generating JSON for TreeNode - posted by we...@apache.org on 2016/09/06 08:06:03 UTC, 1 replies.
- spark git commit: [MINOR][ML] Correct weights doc of MultilayerPerceptronClassificationModel. - posted by yl...@apache.org on 2016/09/06 10:30:47 UTC, 0 replies.
- spark git commit: [SPARK-11301][SQL] Fix case sensitivity for filter on partitioned col… - posted by we...@apache.org on 2016/09/06 11:36:20 UTC, 0 replies.
- spark git commit: [SPARK-17356][SQL][1.6] Fix out of memory issue when generating JSON for TreeNode - posted by we...@apache.org on 2016/09/06 12:07:51 UTC, 0 replies.
- spark git commit: [SPARK-17374][SQL] Better error messages when parsing JSON using DataFrameReader - posted by we...@apache.org on 2016/09/06 14:21:09 UTC, 0 replies.
- spark git commit: [SPARK-16922] [SPARK-17211] [SQL] make the address of values portable in LongToUnsafeRowMap - posted by da...@apache.org on 2016/09/06 17:46:43 UTC, 1 replies.
- spark git commit: [SPARK-16334] [BACKPORT] Reusing same dictionary column for decoding consecutive row groups shouldn't throw an error - posted by da...@apache.org on 2016/09/06 17:48:57 UTC, 0 replies.
- spark git commit: [SPARK-17378][BUILD] Upgrade snappy-java to 1.1.2.6 - posted by sr...@apache.org on 2016/09/06 21:13:31 UTC, 2 replies.
- spark git commit: [SPARK-17299] TRIM/LTRIM/RTRIM should not strips characters other than spaces - posted by sr...@apache.org on 2016/09/06 21:18:33 UTC, 1 replies.
- spark git commit: [MINOR] Remove unnecessary check in MLSerDe - posted by jk...@apache.org on 2016/09/06 21:21:03 UTC, 0 replies.
- spark git commit: [SPARK-17110] Fix StreamCorruptionException in BlockManager.getRemoteValues() - posted by jo...@apache.org on 2016/09/06 22:07:35 UTC, 1 replies.
- spark git commit: [SPARK-17296][SQL] Simplify parser join processing. - posted by hv...@apache.org on 2016/09/06 22:44:13 UTC, 0 replies.
- spark git commit: [SPARK-15891][YARN] Clean up some logging in the YARN AM. - posted by va...@apache.org on 2016/09/06 22:55:00 UTC, 0 replies.
- spark git commit: [SPARK-17316][CORE] Fix the 'ask' type parameter in 'removeExecutor' - posted by zs...@apache.org on 2016/09/06 23:49:10 UTC, 2 replies.
- spark git commit: [SPARK-17371] Resubmitted shuffle outputs can get deleted by zombie map tasks - posted by jo...@apache.org on 2016/09/06 23:55:51 UTC, 0 replies.
- spark git commit: [SPARK-17408][TEST] Flaky test: org.apache.spark.sql.hive.StatisticsSuite - posted by we...@apache.org on 2016/09/07 00:13:17 UTC, 0 replies.
- spark git commit: [SPARK-17238][SQL] simplify the logic for converting data source table into hive compatible format - posted by we...@apache.org on 2016/09/07 01:36:58 UTC, 0 replies.
- spark git commit: [SPARK-17372][SQL][STREAMING] Avoid serialization issues by using Arrays to save file names in FileStreamSource - posted by td...@apache.org on 2016/09/07 02:34:17 UTC, 1 replies.
- spark git commit: [SPARK-16785] R dapply doesn't return array or raw columns - posted by sh...@apache.org on 2016/09/07 06:40:43 UTC, 1 replies.
- spark git commit: [SPARK-17296][SQL] Simplify parser join processing [BACKPORT 2.0] - posted by hv...@apache.org on 2016/09/07 08:39:03 UTC, 0 replies.
- spark git commit: [SPARK-17359][SQL][MLLIB] Use ArrayBuffer.+=(A) instead of ArrayBuffer.append(A) in performance critical paths - posted by sr...@apache.org on 2016/09/07 09:04:06 UTC, 0 replies.
- spark git commit: [SPARK-17339][SPARKR][CORE] Fix some R tests and use Path.toUri in SparkContext for Windows paths in SparkR - posted by sa...@apache.org on 2016/09/07 10:22:42 UTC, 0 replies.
- spark git commit: [SPARK-17427][SQL] function SIZE should return -1 when parameter is null - posted by hv...@apache.org on 2016/09/07 11:01:33 UTC, 0 replies.
- spark git commit: [SPARK-17378][HOTFIX] Upgrade snappy-java to 1.1.2.6 -- fix Hadoop 1 deps - posted by sr...@apache.org on 2016/09/07 11:12:36 UTC, 0 replies.
- spark git commit: [MINOR][SQL] Fixing the typo in unit test - posted by sr...@apache.org on 2016/09/07 11:41:09 UTC, 1 replies.
- spark git commit: [SPARK-17245][SQL][BRANCH-1.6] Do not rely on Hive's session state to retrieve HiveConf - posted by we...@apache.org on 2016/09/07 13:55:14 UTC, 0 replies.
- spark git commit: [SPARK-17370] Shuffle service files not invalidated when a slave is lost - posted by jo...@apache.org on 2016/09/07 19:34:28 UTC, 1 replies.
- spark git commit: [SPARK-17052][SQL] Remove Duplicate Test Cases auto_join from HiveCompatibilitySuite.scala - posted by jo...@apache.org on 2016/09/07 21:03:25 UTC, 0 replies.
- spark git commit: [SPARK-16533][CORE] - backport driver deadlock fix to 2.0 - posted by va...@apache.org on 2016/09/07 23:43:13 UTC, 0 replies.
- spark git commit: [SPARK-17339][CORE][BRANCH-2.0] Do not use path to get a filesystem in hadoopFile and newHadoopFile APIs - posted by sh...@apache.org on 2016/09/08 04:23:23 UTC, 0 replies.
- spark git commit: [SPARK-17432][SQL] PreprocessDDL should respect case sensitivity when checking duplicated columns - posted by we...@apache.org on 2016/09/08 11:42:00 UTC, 0 replies.
- spark git commit: [SPARK-17442][SPARKR] Additional arguments in write.df are not passed to data source - posted by sh...@apache.org on 2016/09/08 15:22:59 UTC, 1 replies.
- spark git commit: [SPARK-17200][PROJECT INFRA][BUILD][SPARKR] Automate building and testing on Windows (currently SparkR only) - posted by sh...@apache.org on 2016/09/08 15:27:00 UTC, 0 replies.
- spark git commit: [SPARK-17405] RowBasedKeyValueBatch should use default page size to prevent OOMs - posted by jo...@apache.org on 2016/09/08 23:47:51 UTC, 0 replies.
- spark git commit: [SPARK-15487][WEB UI] Spark Master UI to reverse proxy Application and Workers UI - posted by zs...@apache.org on 2016/09/09 00:20:25 UTC, 0 replies.
- spark git commit: [SPARK-17456][CORE] Utility for parsing Spark versions - posted by yl...@apache.org on 2016/09/09 12:35:20 UTC, 1 replies.
- spark git commit: [SPARK-17464][SPARKR][ML] SparkR spark.als argument reg should be 0.1 by default. - posted by yl...@apache.org on 2016/09/09 12:43:42 UTC, 0 replies.
- spark git commit: Streaming doc correction. - posted by sr...@apache.org on 2016/09/09 18:15:10 UTC, 0 replies.
- spark git commit: [SPARK-17433] YarnShuffleService doesn't handle moving credentials levelDb - posted by tg...@apache.org on 2016/09/09 18:43:42 UTC, 0 replies.
- spark git commit: [SPARK-17354] [SQL] Partitioning by dates/timestamps should work with Parquet vectorized reader - posted by da...@apache.org on 2016/09/09 21:23:14 UTC, 1 replies.
- spark git commit: [SPARK-15453][SQL] FileSourceScanExec to extract `outputOrdering` information - posted by we...@apache.org on 2016/09/10 01:27:32 UTC, 0 replies.
- spark git commit: [SPARK-11496][GRAPHX] Parallel implementation of personalized pagerank - posted by db...@apache.org on 2016/09/10 07:16:06 UTC, 0 replies.
- spark git commit: [SPARK-15509][FOLLOW-UP][ML][SPARKR] R MLlib algorithms should support input columns "features" and "label" - posted by yl...@apache.org on 2016/09/10 07:27:17 UTC, 0 replies.
- spark git commit: [SPARK-17396][CORE] Share the task support between UnionRDD instances. - posted by sr...@apache.org on 2016/09/10 09:19:40 UTC, 1 replies.
- spark git commit: [SPARK-16445][MLLIB][SPARKR] Fix @return description for sparkR mlp summary() method - posted by sh...@apache.org on 2016/09/10 16:53:03 UTC, 0 replies.
- spark git commit: [SPARK-17389][ML][MLLIB] KMeans speedup with better choice of k-means|| init steps = 2 - posted by sr...@apache.org on 2016/09/11 07:00:58 UTC, 0 replies.
- spark git commit: [SPARK-17439][SQL] Fixing compression issues with approximate quantiles and adding more tests - posted by sr...@apache.org on 2016/09/11 07:03:48 UTC, 1 replies.
- spark git commit: [SPARK-17330][SPARK UT] Clean up spark-warehouse in UT - posted by sr...@apache.org on 2016/09/11 09:17:58 UTC, 0 replies.
- spark git commit: [SPARK-17336][PYSPARK] Fix appending multiple times to PYTHONPATH from spark-config.sh - posted by sr...@apache.org on 2016/09/11 09:19:44 UTC, 1 replies.
- spark git commit: [SPARK-17389][FOLLOW-UP][ML] Change KMeans k-means|| default init steps from 5 to 2. - posted by sr...@apache.org on 2016/09/11 12:47:22 UTC, 0 replies.
- spark git commit: [SPARK-17415][SQL] Better error message for driver-side broadcast join OOMs - posted by hv...@apache.org on 2016/09/11 15:35:34 UTC, 0 replies.
- spark git commit: [SPARK-17486] Remove unused TaskMetricsUIData.updatedBlockStatuses field - posted by zs...@apache.org on 2016/09/12 04:51:26 UTC, 1 replies.
- spark git commit: [SPARK-17171][WEB UI] DAG will list all partitions in the graph - posted by sr...@apache.org on 2016/09/12 10:53:07 UTC, 0 replies.
- spark git commit: [SPARK-17447] Performance improvement in Partitioner.defaultPartitioner without sortBy - posted by sr...@apache.org on 2016/09/12 11:10:52 UTC, 0 replies.
- spark git commit: [SPARK-16992][PYSPARK] use map comprehension in doc - posted by sr...@apache.org on 2016/09/12 11:21:47 UTC, 0 replies.
- spark git commit: [SPARK CORE][MINOR] fix "default partitioner cannot partition array keys" error message in PairRDDfunctions - posted by sr...@apache.org on 2016/09/12 11:23:21 UTC, 0 replies.
- spark git commit: [SPARK-17503][CORE] Fix memory leak in Memory store when unable to cache the whole RDD in memory - posted by jo...@apache.org on 2016/09/12 18:30:23 UTC, 1 replies.
- spark git commit: [SPARK-17483] Refactoring in BlockManager status reporting and block removal - posted by jo...@apache.org on 2016/09/12 20:10:47 UTC, 1 replies.
- spark git commit: [SPARK-14818] Post-2.0 MiMa exclusion and build changes - posted by jo...@apache.org on 2016/09/12 22:24:42 UTC, 1 replies.
- spark git commit: [SPARK-17485] Prevent failed remote reads of cached blocks from failing entire job - posted by jo...@apache.org on 2016/09/12 22:44:07 UTC, 1 replies.
- spark git commit: [SPARK-17474] [SQL] fix python udf in TakeOrderedAndProjectExec - posted by da...@apache.org on 2016/09/12 23:35:46 UTC, 1 replies.
- spark git commit: [BUILD] Closing some stale PRs and ones suggested to be closed by committer(s) - posted by sr...@apache.org on 2016/09/13 09:42:56 UTC, 0 replies.
- spark git commit: [SPARK-17515] CollectLimit.execute() should perform per-partition limits - posted by hv...@apache.org on 2016/09/13 10:54:10 UTC, 1 replies.
- spark git commit: [SPARK-17142][SQL] Complex query triggers binding error in HashAggregateExec - posted by hv...@apache.org on 2016/09/13 15:05:01 UTC, 0 replies.
- spark git commit: [SPARK-17531] Don't initialize Hive Listeners for the Execution Client - posted by yh...@apache.org on 2016/09/13 22:12:04 UTC, 1 replies.
- spark git commit: [SPARK-17530][SQL] Add Statistics into DESCRIBE FORMATTED - posted by hv...@apache.org on 2016/09/13 22:37:49 UTC, 0 replies.
- spark git commit: [SPARK-17531][BACKPORT] Don't initialize Hive Listeners for the Execution Client - posted by yh...@apache.org on 2016/09/13 23:15:50 UTC, 0 replies.
- spark git commit: [SPARK-17317][SPARKR] Add SparkR vignette - posted by sh...@apache.org on 2016/09/14 04:01:10 UTC, 0 replies.
- spark git commit: [SPARK-17449][DOCUMENTATION] Relation between heartbeatInterval and… - posted by sr...@apache.org on 2016/09/14 08:03:19 UTC, 0 replies.
- spark git commit: [SPARK-17525][PYTHON] Remove SparkContext.clearFiles() from the PySpark API as it was removed from the Scala API prior to Spark 2.0.0 - posted by sr...@apache.org on 2016/09/14 08:38:33 UTC, 1 replies.
- spark git commit: [CORE][DOC] remove redundant comment - posted by sr...@apache.org on 2016/09/14 08:49:18 UTC, 0 replies.
- spark git commit: [SPARK-17480][SQL] Improve performance by removing or caching List.length which is O(n) - posted by sr...@apache.org on 2016/09/14 08:51:17 UTC, 1 replies.
- [1/2] spark-website git commit: Redirect third party packages link to https://cwiki.apache.org/confluence/display/SPARK/Third+Party+Projects - posted by sr...@apache.org on 2016/09/14 09:07:09 UTC, 0 replies.
- [2/2] spark-website git commit: Redirect third party packages link to https://cwiki.apache.org/confluence/display/SPARK/Third+Party+Projects - posted by sr...@apache.org on 2016/09/14 09:07:10 UTC, 0 replies.
- spark git commit: [SPARK-17445][DOCS] Reference an ASF page as the main place to find third-party packages - posted by sr...@apache.org on 2016/09/14 09:10:19 UTC, 1 replies.
- spark git commit: [SPARK-17409][SQL] Do Not Optimize Query in CTAS More Than Once - posted by we...@apache.org on 2016/09/14 15:10:54 UTC, 0 replies.
- spark git commit: [SPARK-17514] df.take(1) and df.limit(1).collect() should perform the same in Python - posted by da...@apache.org on 2016/09/14 17:09:58 UTC, 1 replies.
- spark git commit: [MINOR][SQL] Add missing functions for some options in SQLConf and use them where applicable - posted by we...@apache.org on 2016/09/14 17:34:03 UTC, 0 replies.
- [1/2] spark git commit: [SPARK-10747][SQL] Support NULLS FIRST|LAST clause in ORDER BY - posted by hv...@apache.org on 2016/09/14 19:14:43 UTC, 0 replies.
- [2/2] spark git commit: [SPARK-10747][SQL] Support NULLS FIRST|LAST clause in ORDER BY - posted by hv...@apache.org on 2016/09/14 19:14:44 UTC, 0 replies.
- spark git commit: [SPARK-17511] Yarn Dynamic Allocation: Avoid marking released container as Failed - posted by tg...@apache.org on 2016/09/14 19:19:43 UTC, 1 replies.
- spark git commit: [SPARK-17463][CORE] Make CollectionAccumulator and SetAccumulator's value can be read thread-safely - posted by jo...@apache.org on 2016/09/14 20:34:18 UTC, 1 replies.
- spark git commit: [SPARK-17472] [PYSPARK] Better error message for serialization failures of large objects in Python - posted by da...@apache.org on 2016/09/14 20:37:32 UTC, 0 replies.
- spark git commit: [SPARK-17465][SPARK CORE] Inappropriate memory management in `org.apache.spark.storage.MemoryStore` may lead to memory leak - posted by jo...@apache.org on 2016/09/14 20:47:03 UTC, 2 replies.
- spark git commit: [SPARK-17440][SPARK-17441] Fixed Multiple Bugs in ALTER TABLE - posted by we...@apache.org on 2016/09/15 06:43:21 UTC, 0 replies.
- spark git commit: [SPARK-17507][ML][MLLIB] check weight vector size in ANN - posted by sr...@apache.org on 2016/09/15 08:30:21 UTC, 0 replies.
- spark git commit: [SPARK-17524][TESTS] Use specified spark.buffer.pageSize - posted by sr...@apache.org on 2016/09/15 08:37:16 UTC, 0 replies.
- spark git commit: [SPARK-17521] Error when I use sparkContext.makeRDD(Seq()) - posted by sr...@apache.org on 2016/09/15 08:38:17 UTC, 1 replies.
- spark git commit: [SPARK-17406][WEB UI] limit timeline executor events - posted by sr...@apache.org on 2016/09/15 08:58:57 UTC, 0 replies.
- spark git commit: [SPARK-17536][SQL] Minor performance improvement to JDBC batch inserts - posted by sr...@apache.org on 2016/09/15 09:00:32 UTC, 0 replies.
- spark git commit: [SPARK-17406][BUILD][HOTFIX] MiMa excludes fix - posted by sr...@apache.org on 2016/09/15 12:54:50 UTC, 0 replies.
- spark git commit: [SPARK-17317][SPARKR] Add SparkR vignette to branch 2.0 - posted by sh...@apache.org on 2016/09/15 17:00:40 UTC, 0 replies.
- spark git commit: [SPARK-17451][CORE] CoarseGrainedExecutorBackend should inform driver before self-kill - posted by zs...@apache.org on 2016/09/15 17:23:47 UTC, 0 replies.
- spark git commit: [SPARK-17379][BUILD] Upgrade netty-all to 4.0.41 final for bug fixes - posted by zs...@apache.org on 2016/09/15 17:40:14 UTC, 0 replies.
- spark git commit: [SPARK-17547] Ensure temp shuffle data file is cleaned up after error - posted by jo...@apache.org on 2016/09/15 18:23:08 UTC, 2 replies.
- spark git commit: [SPARK-17114][SQL] Fix aggregates grouped by literals with empty input - posted by hv...@apache.org on 2016/09/15 18:24:22 UTC, 1 replies.
- spark git commit: [SPARK-17429][SQL] use ImplicitCastInputTypes with function Length - posted by hv...@apache.org on 2016/09/15 18:45:06 UTC, 0 replies.
- spark git commit: [SPARK-17364][SQL] Antlr lexer wrongly treats full qualified identifier as a decimal number token when parsing SQL string - posted by hv...@apache.org on 2016/09/15 18:53:55 UTC, 1 replies.
- spark git commit: [SPARK-17484] Prevent invalid block locations from being reported after put() exceptions - posted by jo...@apache.org on 2016/09/15 18:54:31 UTC, 1 replies.
- spark git commit: [SPARK-17458][SQL] Alias specified for aggregates in a pivot are not honored - posted by hv...@apache.org on 2016/09/15 19:45:35 UTC, 0 replies.
- spark git commit: [SPARK-17543] Missing log4j config file for tests in common/network-… - posted by sr...@apache.org on 2016/09/16 09:18:49 UTC, 0 replies.
- spark git commit: [SPARK-17534][TESTS] Increase timeouts for DirectKafkaStreamSuite tests - posted by sr...@apache.org on 2016/09/16 09:20:52 UTC, 0 replies.
- spark git commit: [SPARK-17426][SQL] Refactor `TreeNode.toJSON` to avoid OOM when converting unknown fields to JSON - posted by we...@apache.org on 2016/09/16 11:37:38 UTC, 0 replies.
- spark git commit: [SPARK-17558] Bump Hadoop 2.7 version from 2.7.2 to 2.7.3 - posted by rx...@apache.org on 2016/09/16 18:24:29 UTC, 1 replies.
- spark git commit: [SPARK-17561][DOCS] DataFrameWriter documentation formatting problems - posted by rx...@apache.org on 2016/09/16 20:43:11 UTC, 1 replies.
- spark git commit: [SPARK-17549][SQL] Only collect table size stat in driver for cached relation. - posted by yh...@apache.org on 2016/09/16 21:03:00 UTC, 1 replies.
- spark git commit: Correct fetchsize property name in docs - posted by sr...@apache.org on 2016/09/17 11:28:53 UTC, 1 replies.
- spark git commit: [SPARK-17567][DOCS] Use valid url to Spark RDD paper - posted by sr...@apache.org on 2016/09/17 11:30:30 UTC, 1 replies.
- spark git commit: [SPARK-17548][MLLIB] Word2VecModel.findSynonyms no longer spuriously rejects the best match when invoked with a vector - posted by sr...@apache.org on 2016/09/17 11:50:02 UTC, 1 replies.
- spark git commit: [SPARK-17529][CORE] Implement BitSet.clearUntil and use it during merge joins - posted by sr...@apache.org on 2016/09/17 15:22:29 UTC, 0 replies.
- spark git commit: [SPARK-17575][DOCS] Remove extra table tags in configuration document - posted by sr...@apache.org on 2016/09/17 15:25:09 UTC, 1 replies.
- spark git commit: [SPARK-17480][SQL][FOLLOWUP] Fix more instances which calls List.length/size which is O(n) - posted by sr...@apache.org on 2016/09/17 15:52:42 UTC, 2 replies.
- spark git commit: [SPARK-17491] Close serialization stream to fix wrong answer bug in putIteratorAsBytes() - posted by jo...@apache.org on 2016/09/17 18:46:29 UTC, 1 replies.
- spark git commit: Revert "[SPARK-17480][SQL][FOLLOWUP] Fix more instances which calls List.length/size which is O(n)" - posted by td...@apache.org on 2016/09/17 21:19:55 UTC, 0 replies.
- spark-website git commit: replace with valid url to rdd paper - posted by sr...@apache.org on 2016/09/17 23:23:44 UTC, 0 replies.
- spark git commit: [SPARK-17518][SQL] Block Users to Specify the Internal Data Source Provider Hive - posted by we...@apache.org on 2016/09/18 07:37:36 UTC, 0 replies.
- spark git commit: [SPARK-17541][SQL] fix some DDL bugs about table management when same-name temp view exists - posted by we...@apache.org on 2016/09/18 13:15:47 UTC, 1 replies.
- spark git commit: [SPARK-17506][SQL] Improve the check double values equality rule. - posted by sr...@apache.org on 2016/09/18 15:04:41 UTC, 0 replies.
- spark git commit: [SPARK-17546][DEPLOY] start-* scripts should use hostname -f - posted by sr...@apache.org on 2016/09/18 15:22:33 UTC, 1 replies.
- spark git commit: [SPARK-17586][BUILD] Do not call static member via instance reference - posted by sr...@apache.org on 2016/09/18 18:18:53 UTC, 1 replies.
- spark git commit: [SPARK-16462][SPARK-16460][SPARK-15144][SQL] Make CSV cast null values properly - posted by sr...@apache.org on 2016/09/18 18:26:01 UTC, 1 replies.
- spark git commit: [SPARK-17571][SQL] AssertOnQuery.condition should always return Boolean value - posted by rx...@apache.org on 2016/09/18 22:22:04 UTC, 1 replies.
- spark git commit: [SPARK-17297][DOCS] Clarify window/slide duration as absolute time, not relative to a calendar - posted by sr...@apache.org on 2016/09/19 08:38:31 UTC, 1 replies.
- spark git commit: [SPARK-17473][SQL] fixing docker integration tests error due to different versions of jars. - posted by jo...@apache.org on 2016/09/19 16:56:28 UTC, 1 replies.
- spark git commit: [SPARK-17589][TEST][2.0] Fix test case `create external table` in MetastoreDataSourcesSuite - posted by yh...@apache.org on 2016/09/19 17:21:37 UTC, 0 replies.
- spark git commit: [SPARK-17438][WEBUI] Show Application.executorLimit in the application page - posted by an...@apache.org on 2016/09/19 17:57:01 UTC, 1 replies.
- spark git commit: [SPARK-16439] [SQL] bring back the separator in SQL UI - posted by da...@apache.org on 2016/09/19 18:48:58 UTC, 1 replies.
- spark git commit: [SPARK-17100] [SQL] fix Python udf in filter on top of outer join - posted by da...@apache.org on 2016/09/19 20:23:49 UTC, 1 replies.
- spark git commit: [SPARK-17160] Properly escape field names in code-generated error messages - posted by jo...@apache.org on 2016/09/20 03:21:08 UTC, 1 replies.
- [1/3] spark git commit: [SPARK-17163][ML] Unified LogisticRegression interface - posted by db...@apache.org on 2016/09/20 04:33:59 UTC, 0 replies.
- [2/3] spark git commit: [SPARK-17163][ML] Unified LogisticRegression interface - posted by db...@apache.org on 2016/09/20 04:34:00 UTC, 0 replies.
- [3/3] spark git commit: [SPARK-17163][ML] Unified LogisticRegression interface - posted by db...@apache.org on 2016/09/20 04:34:01 UTC, 0 replies.
- spark git commit: [SPARK-17513][SQL] Make StreamExecution garbage-collect its metadata - posted by rx...@apache.org on 2016/09/20 05:19:55 UTC, 3 replies.
- spark git commit: Revert "[SPARK-17513][SQL] Make StreamExecution garbage-collect its metadata" - posted by we...@apache.org on 2016/09/20 08:14:44 UTC, 1 replies.
- spark git commit: [SPARK-17437] Add uiWebUrl to JavaSparkContext and pyspark.SparkContext - posted by sr...@apache.org on 2016/09/20 09:49:08 UTC, 0 replies.
- spark git commit: [SPARK-17502][SQL] Fix Multiple Bugs in DDL Statements on Temporary Views - posted by we...@apache.org on 2016/09/20 12:11:56 UTC, 0 replies.
- spark git commit: [SPARK-17051][SQL] we should use hadoopConf in InsertIntoHiveTable - posted by yh...@apache.org on 2016/09/20 16:53:31 UTC, 1 replies.
- spark git commit: [SPARK-15698][SQL][STREAMING] Add the ability to remove the old MetadataLog in FileStreamSource - posted by zs...@apache.org on 2016/09/20 17:24:17 UTC, 0 replies.
- spark git commit: [SPARK-17549][SQL] Revert "[] Only collect table size stat in driver for cached relation." - posted by yh...@apache.org on 2016/09/20 18:54:01 UTC, 1 replies.
- spark git commit: [SPARK-15698][SQL][STREAMING] Add the ability to remove the old MetadataLog in FileStreamSource (branch-2.0) - posted by zs...@apache.org on 2016/09/20 19:53:34 UTC, 0 replies.
- spark git commit: [SPARK-17611][YARN][TEST] Make shuffle service test really test auth. - posted by va...@apache.org on 2016/09/20 21:17:57 UTC, 0 replies.
- spark git commit: [MINOR][BUILD] Fix CheckStyle Error - posted by rx...@apache.org on 2016/09/21 04:48:28 UTC, 0 replies.
- spark git commit: [SPARK-15698][SQL][STREAMING][FOLLW-UP] Fix FileStream source and sink log get configuration issue - posted by zs...@apache.org on 2016/09/21 05:36:28 UTC, 0 replies.
- spark-website git commit: Add Israel Spark meetup to community page per request. Use https for meetup while we're here. Pick up a recent change to paper hyperlink reflected only in markdown, not HTML - posted by sr...@apache.org on 2016/09/21 07:32:35 UTC, 0 replies.
- spark git commit: [CORE][DOC] Fix errors in comments - posted by sr...@apache.org on 2016/09/21 08:33:37 UTC, 0 replies.
- spark git commit: [SPARK-17585][PYSPARK][CORE] PySpark SparkContext.addFile supports adding files recursively - posted by yl...@apache.org on 2016/09/21 08:37:12 UTC, 0 replies.
- spark git commit: [SPARK-17595][MLLIB] Use a bounded priority queue to find synonyms in Word2VecModel - posted by sr...@apache.org on 2016/09/21 08:45:11 UTC, 0 replies.
- spark git commit: [SPARK-17617][SQL] Remainder(%) expression.eval returns incorrect result on double value - posted by we...@apache.org on 2016/09/21 08:53:42 UTC, 2 replies.
- spark git commit: [SPARK-17599] Prevent ListingFileCatalog from failing if path doesn't exist - posted by we...@apache.org on 2016/09/21 09:07:24 UTC, 0 replies.
- spark git commit: [SPARK-17017][MLLIB][ML] add a chiSquare Selector based on False Positive Rate (FPR) test - posted by sr...@apache.org on 2016/09/21 09:17:45 UTC, 0 replies.
- spark git commit: [SPARK-17219][ML] Add NaN value handling in Bucketizer - posted by sr...@apache.org on 2016/09/21 09:21:03 UTC, 0 replies.
- spark git commit: [SPARK-17583][SQL] Remove uesless rowSeparator variable and set auto-expanding buffer as default for maxCharsPerColumn option in CSV - posted by sr...@apache.org on 2016/09/21 09:35:35 UTC, 0 replies.
- spark git commit: [CORE][MINOR] Add minor code change to TaskState and Task - posted by sr...@apache.org on 2016/09/21 13:47:28 UTC, 0 replies.
- spark git commit: [SPARK-17590][SQL] Analyze CTE definitions at once and allow CTE subquery to define CTE - posted by hv...@apache.org on 2016/09/21 13:53:48 UTC, 0 replies.
- spark git commit: [BACKPORT 2.0][MINOR][BUILD] Fix CheckStyle Error - posted by sr...@apache.org on 2016/09/21 14:18:08 UTC, 0 replies.
- spark git commit: [SPARK-17418] Prevent kinesis-asl-assembly artifacts from being published - posted by jo...@apache.org on 2016/09/21 18:38:46 UTC, 2 replies.
- spark git commit: [SPARK-11918][ML] Better error from WLS for cases like singular input - posted by db...@apache.org on 2016/09/21 18:56:26 UTC, 0 replies.
- spark git commit: [SPARK-4563][CORE] Allow driver to advertise a different network address. - posted by zs...@apache.org on 2016/09/21 21:42:47 UTC, 0 replies.
- spark git commit: [SPARK-17623][CORE] Clarify type of TaskEndReason with a failed task. - posted by an...@apache.org on 2016/09/21 21:45:46 UTC, 0 replies.
- spark git commit: [SPARK-17512][CORE] Avoid formatting to python path for yarn and mesos cluster mode - posted by an...@apache.org on 2016/09/21 21:53:30 UTC, 1 replies.
- spark git commit: [SPARK-17569] Make StructuredStreaming FileStreamSource batch generation faster - posted by zs...@apache.org on 2016/09/22 00:12:56 UTC, 0 replies.
- spark git commit: [SPARK-17577][SPARKR][CORE] SparkR support add files to Spark job and get by executors - posted by yl...@apache.org on 2016/09/22 03:08:37 UTC, 0 replies.
- spark git commit: [SPARK-17315][FOLLOW-UP][SPARKR][ML] Fix print of Kolmogorov-Smirnov test summary - posted by yl...@apache.org on 2016/09/22 03:14:25 UTC, 0 replies.
- spark git commit: [SPARK-17627] Mark Streaming Providers Experimental - posted by rx...@apache.org on 2016/09/22 03:59:49 UTC, 1 replies.
- spark git commit: [SPARK-17494][SQL] changePrecision() on compact decimal should respect rounding mode - posted by rx...@apache.org on 2016/09/22 04:02:34 UTC, 1 replies.
- spark git commit: Bump doc version for release 2.0.1. - posted by rx...@apache.org on 2016/09/22 04:07:03 UTC, 0 replies.
- [spark] Git Push Summary - posted by pw...@apache.org on 2016/09/22 04:09:27 UTC, 3 replies.
- [1/2] spark git commit: Preparing Spark release v2.0.1-rc1 - posted by pw...@apache.org on 2016/09/22 04:09:34 UTC, 0 replies.
- [2/2] spark git commit: Preparing development version 2.0.2-SNAPSHOT - posted by pw...@apache.org on 2016/09/22 04:09:35 UTC, 3 replies.
- spark git commit: [SPARK-17609][SQL] SessionCatalog.tableExists should not check temp view - posted by we...@apache.org on 2016/09/22 04:52:16 UTC, 0 replies.
- spark git commit: [SPARK-17425][SQL] Override sameResult in HiveTableScanExec to make ReuseExchange work in text format table - posted by we...@apache.org on 2016/09/22 05:04:49 UTC, 0 replies.
- spark git commit: [SPARK-17492][SQL] Fix Reading Cataloged Data Sources without Extending SchemaRelationProvider - posted by we...@apache.org on 2016/09/22 05:19:12 UTC, 0 replies.
- spark git commit: [SPARK-17625][SQL] set expectedOutputAttributes when converting SimpleCatalogRelation to LogicalRelation - posted by we...@apache.org on 2016/09/22 06:48:59 UTC, 0 replies.
- spark git commit: [SPARK-17421][DOCS] Documenting the current treatment of MAVEN_OPTS. - posted by sr...@apache.org on 2016/09/22 09:31:21 UTC, 1 replies.
- spark git commit: [SPARK-17281][ML][MLLIB] Add treeAggregateDepth parameter for AFTSurvivalRegression - posted by yl...@apache.org on 2016/09/22 11:36:01 UTC, 0 replies.
- spark git commit: [SQL][MINOR] correct the comment of SortBasedAggregationIterator.safeProj - posted by li...@apache.org on 2016/09/22 15:25:39 UTC, 0 replies.
- spark git commit: [SPARK-17365][CORE] Remove/Kill multiple executors together to reduce RPC call time. - posted by va...@apache.org on 2016/09/22 17:10:53 UTC, 0 replies.
- spark git commit: [SPARK-17485] Prevent failed remote reads of cached blocks from failing entire job (branch-1.6 backport) - posted by jo...@apache.org on 2016/09/22 18:05:50 UTC, 0 replies.
- spark git commit: Skip building R vignettes if Spark is not built - posted by rx...@apache.org on 2016/09/22 18:52:45 UTC, 1 replies.
- spark git commit: [SPARK-17613] S3A base paths with no '/' at the end return empty DataFrames - posted by jo...@apache.org on 2016/09/22 20:05:48 UTC, 1 replies.
- spark git commit: [SPARK-17638][STREAMING] Stop JVM StreamingContext when the Python process is dead - posted by zs...@apache.org on 2016/09/22 21:26:49 UTC, 1 replies.
- spark git commit: [SPARK-17616][SQL] Support a single distinct aggregate combined with a non-partial aggregate - posted by hv...@apache.org on 2016/09/22 21:29:31 UTC, 1 replies.
- spark git commit: [SPARK-16240][ML] ML persistence backward compatibility for LDA - posted by jk...@apache.org on 2016/09/22 23:34:51 UTC, 0 replies.
- spark git commit: [SPARK-17569][SPARK-17569][TEST] Make the unit test added for work again - posted by zs...@apache.org on 2016/09/22 23:50:24 UTC, 0 replies.
- spark git commit: [SPARK-17599][SPARK-17569] Backport and to Spark 2.0 branch - posted by rx...@apache.org on 2016/09/23 00:22:07 UTC, 0 replies.
- spark git commit: [SPARK-17635][SQL] Remove hardcode "agg_plan" in HashAggregateExec - posted by rx...@apache.org on 2016/09/23 00:22:59 UTC, 0 replies.
- [1/2] spark git commit: Preparing Spark release v2.0.1-rc2 - posted by pw...@apache.org on 2016/09/23 00:44:31 UTC, 0 replies.
- spark git commit: [SPARK-17502][17609][SQL][BACKPORT][2.0] Fix Multiple Bugs in DDL Statements on Temporary Views - posted by we...@apache.org on 2016/09/23 01:56:49 UTC, 0 replies.
- spark git commit: [SPARK-17639][BUILD] Add jce.jar to buildclasspath when building. - posted by va...@apache.org on 2016/09/23 04:35:30 UTC, 0 replies.
- spark git commit: [SPARK-16719][ML] Random Forests should communicate fewer trees on each iteration - posted by jk...@apache.org on 2016/09/23 05:27:36 UTC, 0 replies.
- spark git commit: [SPARK-16240][ML] ML persistence backward compatibility for LDA - 2.0 backport - posted by jk...@apache.org on 2016/09/23 05:44:29 UTC, 0 replies.
- spark git commit: [SPARK-17640][SQL] Avoid using -1 as the default batchId for FileStreamSource.FileEntry - posted by zs...@apache.org on 2016/09/23 06:35:11 UTC, 1 replies.
- spark git commit: [BUILD] Closes some stale PRs - posted by sr...@apache.org on 2016/09/23 08:41:52 UTC, 0 replies.
- spark git commit: [SPARK-16861][PYSPARK][CORE] Refactor PySpark accumulator API on top of Accumulator V2 - posted by sr...@apache.org on 2016/09/23 08:44:32 UTC, 0 replies.
- spark git commit: [SPARK-17499][SPARKR][ML][MLLIB] make the default params in sparkR spark.mlp consistent with MultilayerPerceptronClassifier - posted by fe...@apache.org on 2016/09/23 18:14:28 UTC, 0 replies.
- spark git commit: [SPARK-17210][SPARKR] sparkr.zip is not distributed to executors when running sparkr in RStudio - posted by fe...@apache.org on 2016/09/23 18:37:50 UTC, 1 replies.
- spark git commit: [SPARK-17643] Remove comparable requirement from Offset - posted by td...@apache.org on 2016/09/23 19:17:58 UTC, 0 replies.
- spark git commit: [SPARK-17577][CORE][2.0 BACKPORT] Update SparkContext.addFile to make it work well on Windows - posted by sa...@apache.org on 2016/09/23 19:48:32 UTC, 0 replies.
- [1/2] spark git commit: [SPARK-12221] add cpu time to metrics - posted by va...@apache.org on 2016/09/23 20:43:53 UTC, 0 replies.
- [2/2] spark git commit: [SPARK-12221] add cpu time to metrics - posted by va...@apache.org on 2016/09/23 20:43:54 UTC, 0 replies.
- spark git commit: [SPARK-17651][SPARKR] Set R package version number along with mvn - posted by rx...@apache.org on 2016/09/23 21:35:21 UTC, 1 replies.
- [1/2] spark git commit: Preparing Spark release v2.0.1-rc3 - posted by pw...@apache.org on 2016/09/23 21:38:33 UTC, 0 replies.
- spark git commit: [SPARK-15703][SCHEDULER][CORE][WEBUI] Make ListenerBus event queue size configurable (branch 2.0) - posted by zs...@apache.org on 2016/09/23 21:59:56 UTC, 0 replies.
- spark git commit: [SPARK-10835][ML] Word2Vec should accept non-null string array, in addition to existing null string array - posted by sr...@apache.org on 2016/09/24 07:06:49 UTC, 1 replies.
- spark git commit: [SPARK-17057][ML] ProbabilisticClassifierModels' thresholds should have at most one 0 - posted by sr...@apache.org on 2016/09/24 07:16:00 UTC, 0 replies.
- spark git commit: [MINOR][SPARKR] Add sparkr-vignettes.html to gitignore. - posted by yl...@apache.org on 2016/09/24 08:03:17 UTC, 0 replies.
- spark git commit: [SPARK-17551][SQL] Add DataFrame API for null ordering - posted by hv...@apache.org on 2016/09/25 23:46:17 UTC, 0 replies.
- spark git commit: [SPARK-17650] malformed url's throw exceptions before bricking Executors - posted by zs...@apache.org on 2016/09/26 05:57:36 UTC, 1 replies.
- spark git commit: [SPARK-17017][FOLLOW-UP][ML] Refactor of ChiSqSelector and add ML Python API. - posted by sr...@apache.org on 2016/09/26 08:45:37 UTC, 0 replies.
- spark git commit: [SPARK-14525][SQL] Make DataFrameWrite.save work for jdbc - posted by sr...@apache.org on 2016/09/26 08:54:25 UTC, 0 replies.
- [1/2] spark git commit: [SPARK-16356][ML] Add testImplicits for ML unit tests and promote toDF() - posted by yl...@apache.org on 2016/09/26 11:19:54 UTC, 0 replies.
- [2/2] spark git commit: [SPARK-16356][ML] Add testImplicits for ML unit tests and promote toDF() - posted by yl...@apache.org on 2016/09/26 11:19:55 UTC, 0 replies.
- spark git commit: [SPARK-17649][CORE] Log how many Spark events got dropped in LiveListenerBus - posted by zs...@apache.org on 2016/09/26 17:44:39 UTC, 1 replies.
- spark git commit: [SPARK-17649][CORE] Log how many Spark events got dropped in AsynchronousListenerBus (branch 1.6) - posted by zs...@apache.org on 2016/09/26 18:03:09 UTC, 0 replies.
- spark git commit: [SPARK-17153][SQL] Should read partition data when reading new files in filestream without globbing - posted by ma...@apache.org on 2016/09/26 20:07:17 UTC, 0 replies.
- spark git commit: [SPARK-17652] Fix confusing exception message while reserving capacity - posted by yh...@apache.org on 2016/09/26 20:21:13 UTC, 1 replies.
- spark git commit: [Docs] Update spark-standalone.md to fix link - posted by an...@apache.org on 2016/09/26 20:37:18 UTC, 1 replies.
- spark git commit: [SPARK-17577][FOLLOW-UP][SPARKR] SparkR spark.addFile supports adding directory recursively - posted by yl...@apache.org on 2016/09/26 23:48:04 UTC, 0 replies.
- spark git commit: Fix two comments since Actor is not used anymore. - posted by rx...@apache.org on 2016/09/27 06:09:56 UTC, 0 replies.
- spark git commit: [SPARK-15962][SQL] Introduce implementation with a dense format for UnsafeArrayData - posted by we...@apache.org on 2016/09/27 06:18:44 UTC, 0 replies.
- spark git commit: [SPARK-17138][ML][MLIB] Add Python API for multinomial logistic regression - posted by yl...@apache.org on 2016/09/27 07:00:30 UTC, 0 replies.
- spark git commit: [SPARK-16757] Set up Spark caller context to HDFS and YARN - posted by tg...@apache.org on 2016/09/27 13:11:15 UTC, 0 replies.
- spark git commit: [SPARK-16777][SQL] Do not use deprecated listType API in ParquetSchemaConverter - posted by li...@apache.org on 2016/09/27 16:39:54 UTC, 0 replies.
- spark git commit: [SPARK-16516][SQL] Support for pushing down filters for decimal and timestamp types in ORC - posted by li...@apache.org on 2016/09/27 16:50:20 UTC, 0 replies.
- spark git commit: [SPARK-17682][SQL] Mark children as final for unary, binary, leaf expressions and plan nodes - posted by hv...@apache.org on 2016/09/27 17:20:33 UTC, 0 replies.
- spark git commit: [SPARK-17660][SQL] DESC FORMATTED for VIEW Lacks View Definition - posted by hv...@apache.org on 2016/09/27 17:52:32 UTC, 0 replies.
- spark git commit: [SPARK-17618] Fix invalid comparisons between UnsafeRow and other row formats - posted by hv...@apache.org on 2016/09/27 17:57:23 UTC, 0 replies.
- [1/2] spark git commit: [SPARK-17677][SQL] Break WindowExec.scala into multiple files - posted by hv...@apache.org on 2016/09/27 19:37:24 UTC, 0 replies.
- [2/2] spark git commit: [SPARK-17677][SQL] Break WindowExec.scala into multiple files - posted by hv...@apache.org on 2016/09/27 19:37:25 UTC, 0 replies.
- spark git commit: [SPARK-17618] Guard against invalid comparisons between UnsafeRow and other formats - posted by jo...@apache.org on 2016/09/27 21:14:44 UTC, 1 replies.
- spark git commit: [SPARK-17056][CORE] Fix a wrong assert regarding unroll memory in MemoryStore - posted by jo...@apache.org on 2016/09/27 23:00:52 UTC, 1 replies.
- spark git commit: [SPARK-17666] Ensure that RecordReaders are closed by data source file scans - posted by rx...@apache.org on 2016/09/28 00:53:00 UTC, 0 replies.
- spark git commit: [SPARK-17499][SPARKR][FOLLOWUP] Check null first for layers in spark.mlp to avoid warnings in test results - posted by fe...@apache.org on 2016/09/28 04:20:04 UTC, 0 replies.
- spark git commit: [SPARK-17666] Ensure that RecordReaders are closed by data source file scans (backport) - posted by rx...@apache.org on 2016/09/28 07:59:03 UTC, 0 replies.
- spark git commit: [SPARK-17017][ML][MLLIB][ML][DOC] Updated the ml/mllib feature selection docs for ChiSqSelector - posted by sr...@apache.org on 2016/09/28 10:12:54 UTC, 0 replies.
- spark git commit: [MINOR][PYSPARK][DOCS] Fix examples in PySpark documentation - posted by sr...@apache.org on 2016/09/28 10:19:11 UTC, 1 replies.
- Message from "CUKPR0153001" - posted by sc...@spark.apache.org on 2016/09/28 12:58:52 UTC, 0 replies.
- spark git commit: [SPARK-17644][CORE] Do not add failedStages when abortStage for fetch failure - posted by zs...@apache.org on 2016/09/28 19:03:05 UTC, 1 replies.
- spark git commit: [SPARK-17673][SQL] Incorrect exchange reuse with RowDataSourceScan - posted by rx...@apache.org on 2016/09/28 20:22:49 UTC, 0 replies.
- spark git commit: [SPARK-17696][SPARK-12330][CORE] Partial backport of to branch-1.6. - posted by zs...@apache.org on 2016/09/28 21:39:56 UTC, 0 replies.
- spark git commit: [SPARK-17673][SQL] Incorrect exchange reuse with RowDataSourceScan (backport) - posted by rx...@apache.org on 2016/09/28 23:19:11 UTC, 0 replies.
- spark git commit: [SPARK-17713][SQL] Move row-datasource related tests out of JDBCSuite - posted by rx...@apache.org on 2016/09/28 23:20:52 UTC, 0 replies.
- spark git commit: [SPARK-17641][SQL] Collect_list/Collect_set should not collect null values. - posted by rx...@apache.org on 2016/09/28 23:25:19 UTC, 1 replies.
- [1/2] spark git commit: Preparing Spark release v2.0.1-rc4 - posted by pw...@apache.org on 2016/09/28 23:28:09 UTC, 0 replies.
- spark git commit: [SPARK-17710][HOTFIX] Fix ClassCircularityError in ReplSuite tests in Maven build: use 'Class.forName' instead of 'Utils.classForName' - posted by tg...@apache.org on 2016/09/29 01:20:18 UTC, 0 replies.
- spark git commit: [SPARK-17712][SQL] Fix invalid pushdown of data-independent filters beneath aggregates - posted by hv...@apache.org on 2016/09/29 02:03:10 UTC, 1 replies.
- spark git commit: [SPARK-16356][FOLLOW-UP][ML] Enforce ML test of exception for local/distributed Dataset. - posted by yl...@apache.org on 2016/09/29 07:54:33 UTC, 0 replies.
- spark git commit: [SPARK-17704][ML][MLLIB] ChiSqSelector performance improvement. - posted by yl...@apache.org on 2016/09/29 11:30:50 UTC, 0 replies.
- spark git commit: [SPARK-17614][SQL] sparkSession.read() .jdbc(***) use the sql syntax "where 1=0" that Cassandra does not support - posted by sr...@apache.org on 2016/09/29 12:24:39 UTC, 0 replies.
- spark git commit: [MINOR][DOCS] Fix th doc. of spark-streaming with kinesis - posted by sr...@apache.org on 2016/09/29 12:26:07 UTC, 1 replies.
- spark git commit: [DOCS] Reorganize explanation of Accumulators and Broadcast Variables - posted by va...@apache.org on 2016/09/29 17:19:02 UTC, 0 replies.
- spark git commit: [SPARK-16343][SQL] Improve the PushDownPredicate rule to pushdown predicates correctly in non-deterministic condition. - posted by jo...@apache.org on 2016/09/29 19:04:15 UTC, 0 replies.
- spark git commit: [SPARK-17648][CORE] TaskScheduler really needs offers to be an IndexedSeq - posted by an...@apache.org on 2016/09/29 19:32:30 UTC, 0 replies.
- spark git commit: [SPARK-17672] Spark 2.0 history server web Ui takes too long for a single application - posted by an...@apache.org on 2016/09/29 19:47:31 UTC, 1 replies.
- spark git commit: [SPARK-17715][SCHEDULER] Make task launch logs DEBUG - posted by an...@apache.org on 2016/09/29 19:55:05 UTC, 0 replies.
- spark git commit: [SPARK-17699] Support for parsing JSON string columns - posted by yh...@apache.org on 2016/09/29 20:01:23 UTC, 0 replies.
- spark git commit: [SPARK-17653][SQL] Remove unnecessary distincts in multiple unions - posted by hv...@apache.org on 2016/09/29 21:30:29 UTC, 0 replies.
- spark git commit: [SPARK-17612][SQL] Support `DESCRIBE table PARTITION` SQL syntax - posted by hv...@apache.org on 2016/09/29 22:30:23 UTC, 0 replies.
- spark git commit: [SPARK-17721][MLLIB][ML] Fix for multiplying transposed SparseMatrix with SparseVector - posted by jk...@apache.org on 2016/09/29 22:40:01 UTC, 1 replies.
- spark git commit: [SPARK-17676][CORE] FsHistoryProvider should ignore hidden files - posted by va...@apache.org on 2016/09/29 22:40:41 UTC, 0 replies.
- spark git commit: [SPARK-17412][DOC] All test should not be run by `root` or any admin user - posted by va...@apache.org on 2016/09/29 23:01:52 UTC, 0 replies.
- spark git commit: [SPARK-17697][ML] Fixed bug in summary calculations that pattern match against label without casting - posted by jk...@apache.org on 2016/09/29 23:31:34 UTC, 0 replies.
- spark git commit: Updated the following PR with minor changes to allow cherry-pick to branch-2.0 - posted by jk...@apache.org on 2016/09/29 23:57:09 UTC, 0 replies.
- spark git commit: [SPARK-17717][SQL] Add exist/find methods to Catalog. - posted by rx...@apache.org on 2016/09/30 00:56:35 UTC, 0 replies.
- spark git commit: [SPARK-14077][ML] Refactor NaiveBayes to support weighted instances - posted by yl...@apache.org on 2016/09/30 06:55:55 UTC, 0 replies.
- spark git commit: [SPARK-14077][ML][FOLLOW-UP] Revert change for NB Model's Load to maintain compatibility with the model stored before 2.0 - posted by yl...@apache.org on 2016/09/30 15:18:55 UTC, 0 replies.
- spark git commit: [SPARK-17738] [SQL] fix ARRAY/MAP in columnar cache - posted by da...@apache.org on 2016/09/30 16:58:01 UTC, 0 replies.