You are viewing a plain text version of this content. The canonical link for it is here.
- spark git commit: [SPARK-21779][PYTHON] Simpler DataFrame.sample API in Python - posted by gu...@apache.org on 2017/09/01 04:01:35 UTC, 0 replies.
- spark git commit: [SPARK-21789][PYTHON] Remove obsolete codes for parsing abstract schema strings - posted by gu...@apache.org on 2017/09/01 04:09:39 UTC, 0 replies.
- spark git commit: [SPARK-21728][CORE] Follow up: fix user config, auth in SparkSubmit logging. - posted by va...@apache.org on 2017/09/01 17:29:42 UTC, 0 replies.
- spark git commit: [SPARK-21880][WEB UI] In the SQL table page, modify jobs trace information - posted by zs...@apache.org on 2017/09/01 17:47:13 UTC, 0 replies.
- spark git commit: [SPARK-14280][BUILD][WIP] Update change-version.sh and pom.xml to add Scala 2.12 profiles and enable 2.12 compilation - posted by sr...@apache.org on 2017/09/01 18:21:25 UTC, 0 replies.
- spark git commit: [SPARK-21895][SQL] Support changing database in HiveClient - posted by li...@apache.org on 2017/09/01 20:21:09 UTC, 0 replies.
- spark git commit: [SPARK-21884][SPARK-21477][BACKPORT-2.2][SQL] Mark LocalTableScanExec's input data transient - posted by li...@apache.org on 2017/09/01 20:48:53 UTC, 0 replies.
- spark git commit: [SPARK-21729][ML][TEST] Generic test for ProbabilisticClassifier to ensure consistent output columns - posted by jk...@apache.org on 2017/09/02 00:32:36 UTC, 0 replies.
- spark git commit: [SPARK-21891][SQL] Add TBLPROPERTIES to DDL statement: CREATE TABLE USING - posted by li...@apache.org on 2017/09/02 21:53:44 UTC, 0 replies.
- spark git commit: [SPARK-21897][PYTHON][R] Add unionByName API to DataFrame in Python and R - posted by gu...@apache.org on 2017/09/03 12:03:24 UTC, 0 replies.
- spark git commit: [SPARK-21654][SQL] Complement SQL predicates expression description - posted by li...@apache.org on 2017/09/04 04:55:22 UTC, 0 replies.
- spark git commit: [SPARK-21418][SQL] NoSuchElementException: None.get in DataSourceScanExec with sun.io.serialization.extendedDebugInfo=true - posted by hv...@apache.org on 2017/09/04 21:03:03 UTC, 1 replies.
- spark git commit: [SPARK-21913][SQL][TEST] withDatabase` should drop database with CASCADE - posted by li...@apache.org on 2017/09/05 07:20:19 UTC, 0 replies.
- spark git commit: [SPARK-21903][BUILD] Upgrade scalastyle to 1.0.0. - posted by gu...@apache.org on 2017/09/05 10:40:11 UTC, 0 replies.
- spark git commit: [SPARK-20978][SQL] Bump up Univocity version to 2.5.4 - posted by we...@apache.org on 2017/09/05 15:21:55 UTC, 0 replies.
- spark git commit: [SPARK-21845][SQL][TEST-MAVEN] Make codegen fallback of expressions configurable - posted by li...@apache.org on 2017/09/05 16:04:06 UTC, 0 replies.
- spark git commit: [SPARK-21925] Update trigger interval documentation in docs with behavior change in Spark 2.2 - posted by td...@apache.org on 2017/09/05 20:10:36 UTC, 1 replies.
- spark git commit: [SPARK-21652][SQL] Fix rule confliction between InferFiltersFromConstraints and ConstantPropagation - posted by li...@apache.org on 2017/09/05 20:12:42 UTC, 0 replies.
- spark git commit: [MINOR][DOC] Update `Partition Discovery` section to enumerate all available file sources - posted by li...@apache.org on 2017/09/05 21:35:12 UTC, 1 replies.
- spark git commit: [SPARK-18061][THRIFTSERVER] Add spnego auth support for ThriftServer thrift/http protocol - posted by js...@apache.org on 2017/09/06 01:40:01 UTC, 0 replies.
- spark git commit: [SPARK-9104][CORE] Expose Netty memory metrics in Spark - posted by zs...@apache.org on 2017/09/06 04:28:58 UTC, 0 replies.
- spark git commit: [SPARK-21924][DOCS] Update structured streaming programming guide doc - posted by sr...@apache.org on 2017/09/06 07:23:01 UTC, 1 replies.
- spark git commit: [SPARK-19357][ML] Adding parallel model evaluation in ML tuning - posted by ml...@apache.org on 2017/09/06 12:12:38 UTC, 0 replies.
- spark git commit: [SPARK-21903][BUILD][FOLLOWUP] Upgrade scalastyle-maven-plugin and scalastyle as well in POM and SparkBuild.scala - posted by gu...@apache.org on 2017/09/06 14:28:17 UTC, 0 replies.
- spark git commit: [SPARK-21835][SQL] RewritePredicateSubquery should not produce unresolved query plans - posted by li...@apache.org on 2017/09/06 14:42:25 UTC, 0 replies.
- spark git commit: [SPARK-21801][SPARKR][TEST] set random seed for predictable test - posted by fe...@apache.org on 2017/09/06 16:53:58 UTC, 0 replies.
- spark git commit: [SPARK-21765] Check that optimization doesn't affect isStreaming bit. - posted by td...@apache.org on 2017/09/06 18:19:51 UTC, 0 replies.
- spark git commit: [SPARK-21901][SS] Define toString for StateOperatorProgress - posted by zs...@apache.org on 2017/09/06 22:48:54 UTC, 1 replies.
- spark git commit: Fixed pandoc dependency issue in python/setup.py - posted by gu...@apache.org on 2017/09/07 00:38:05 UTC, 1 replies.
- spark git commit: [SPARK-21835][SQL][FOLLOW-UP] RewritePredicateSubquery should not produce unresolved query plans - posted by li...@apache.org on 2017/09/07 05:15:28 UTC, 0 replies.
- spark git commit: [SPARK-21912][SQL] ORC/Parquet table should not create invalid column names - posted by li...@apache.org on 2017/09/07 05:20:52 UTC, 0 replies.
- spark git commit: [SPARK-21890] Credentials not being passed to add the tokens - posted by tg...@apache.org on 2017/09/07 16:25:35 UTC, 1 replies.
- spark git commit: [SPARK-13656][SQL] Delete spark.sql.parquet.cacheMetadata from SQLConf and docs - posted by li...@apache.org on 2017/09/07 23:26:58 UTC, 0 replies.
- spark git commit: [SPARK-21939][TEST] Use TimeLimits instead of Timeouts - posted by js...@apache.org on 2017/09/08 01:31:41 UTC, 0 replies.
- spark git commit: [SPARK-21950][SQL][PYTHON][TEST] pyspark.sql.tests.SQLTests2 should stop SparkContext. - posted by ue...@apache.org on 2017/09/08 05:26:15 UTC, 3 replies.
- spark git commit: [SPARK-21949][TEST] Tables created in unit tests should be dropped after use - posted by li...@apache.org on 2017/09/08 06:09:30 UTC, 0 replies.
- spark git commit: [SPARK-21726][SQL] Check for structural integrity of the plan in Optimzer in test mode. - posted by li...@apache.org on 2017/09/08 06:12:23 UTC, 0 replies.
- spark git commit: [SPARK-21936][SQL] backward compatibility test framework for HiveExternalCatalog - posted by li...@apache.org on 2017/09/08 06:21:53 UTC, 0 replies.
- spark git commit: [SPARK-21915][ML][PYSPARK] Model 1 and Model 2 ParamMaps Missing - posted by sr...@apache.org on 2017/09/08 07:08:14 UTC, 0 replies.
- [1/5] spark-website git commit: Added CVE-2017-12612 - posted by sr...@apache.org on 2017/09/08 11:20:53 UTC, 0 replies.
- [2/5] spark-website git commit: Use HTTPS for all apache.org links - posted by sr...@apache.org on 2017/09/08 11:20:54 UTC, 0 replies.
- [3/5] spark-website git commit: Use HTTPS for all apache.org links - posted by sr...@apache.org on 2017/09/08 11:20:55 UTC, 0 replies.
- [4/5] spark-website git commit: Use HTTPS for all apache.org links - posted by sr...@apache.org on 2017/09/08 11:20:56 UTC, 0 replies.
- [5/5] spark-website git commit: Use HTTPS for all apache.org links - posted by sr...@apache.org on 2017/09/08 11:20:57 UTC, 0 replies.
- spark git commit: [SPARK-21726][SQL][FOLLOW-UP] Check for structural integrity of the plan in Optimzer in test mode - posted by gu...@apache.org on 2017/09/08 11:21:44 UTC, 0 replies.
- spark git commit: [SPARK-21936][SQL][2.2] backward compatibility test framework for HiveExternalCatalog - posted by li...@apache.org on 2017/09/08 16:35:51 UTC, 0 replies.
- spark git commit: [SPARK-21946][TEST] fix flaky test: "alter table: rename cached table" in InMemoryCatalogedDDLSuite - posted by li...@apache.org on 2017/09/08 16:39:26 UTC, 1 replies.
- spark git commit: [SPARK-21128][R][BACKPORT-2.2] Remove both "spark-warehouse" and "metastore_db" before listing files in R tests - posted by fe...@apache.org on 2017/09/08 16:47:50 UTC, 0 replies.
- spark git commit: [SPARK-15243][ML][SQL][PYTHON] Add missing support for unicode in Param methods & functions in dataframe - posted by ho...@apache.org on 2017/09/08 18:57:40 UTC, 0 replies.
- spark git commit: [SPARK-19866][ML][PYSPARK] Add local version of Word2Vec findSynonyms for spark.ml: Python API - posted by ho...@apache.org on 2017/09/08 19:09:04 UTC, 0 replies.
- spark git commit: [SPARK-21941] Stop storing unused attemptId in SQLTaskMetrics - posted by li...@apache.org on 2017/09/09 06:33:20 UTC, 0 replies.
- spark git commit: [SPARK-21954][SQL] JacksonUtils should verify MapType's value type instead of key type - posted by gu...@apache.org on 2017/09/09 10:10:57 UTC, 1 replies.
- spark git commit: [MINOR][SQL] Correct DataFrame doc. - posted by li...@apache.org on 2017/09/09 16:25:16 UTC, 0 replies.
- [1/2] spark git commit: [SPARK-4131] Support "Writing data into the filesystem from queries" - posted by li...@apache.org on 2017/09/09 18:48:39 UTC, 0 replies.
- [2/2] spark git commit: [SPARK-4131] Support "Writing data into the filesystem from queries" - posted by li...@apache.org on 2017/09/09 18:48:40 UTC, 0 replies.
- spark git commit: [SPARK-20098][PYSPARK] dataType's typeName fix - posted by gu...@apache.org on 2017/09/10 08:47:50 UTC, 1 replies.
- [1/9] spark git commit: [SPARKR][BACKPORT-2.1] backporting package and test changes - posted by fe...@apache.org on 2017/09/10 17:24:51 UTC, 0 replies.
- [2/9] spark git commit: [SPARKR][BACKPORT-2.1] backporting package and test changes - posted by fe...@apache.org on 2017/09/10 17:24:52 UTC, 0 replies.
- [3/9] spark git commit: [SPARKR][BACKPORT-2.1] backporting package and test changes - posted by fe...@apache.org on 2017/09/10 17:24:53 UTC, 0 replies.
- [4/9] spark git commit: [SPARKR][BACKPORT-2.1] backporting package and test changes - posted by fe...@apache.org on 2017/09/10 17:24:54 UTC, 0 replies.
- [5/9] spark git commit: [SPARKR][BACKPORT-2.1] backporting package and test changes - posted by fe...@apache.org on 2017/09/10 17:24:55 UTC, 0 replies.
- [6/9] spark git commit: [SPARKR][BACKPORT-2.1] backporting package and test changes - posted by fe...@apache.org on 2017/09/10 17:24:56 UTC, 0 replies.
- [7/9] spark git commit: [SPARKR][BACKPORT-2.1] backporting package and test changes - posted by fe...@apache.org on 2017/09/10 17:24:57 UTC, 0 replies.
- [8/9] spark git commit: [SPARKR][BACKPORT-2.1] backporting package and test changes - posted by fe...@apache.org on 2017/09/10 17:24:58 UTC, 0 replies.
- [9/9] spark git commit: [SPARKR][BACKPORT-2.1] backporting package and test changes - posted by fe...@apache.org on 2017/09/10 17:24:59 UTC, 0 replies.
- spark git commit: [SPARK-21610][SQL] Corrupt records are not handled properly when creating a dataframe from a file - posted by li...@apache.org on 2017/09/11 00:26:46 UTC, 0 replies.
- spark git commit: [BUILD][TEST][SPARKR] add sparksubmitsuite to appveyor tests - posted by gu...@apache.org on 2017/09/11 00:32:30 UTC, 0 replies.
- spark git commit: [SPARK-21856] Add probability and rawPrediction to MLPC for Python - posted by yl...@apache.org on 2017/09/11 08:52:52 UTC, 0 replies.
- spark git commit: [MINOR][SQL] remove unuse import class - posted by sr...@apache.org on 2017/09/11 09:09:24 UTC, 0 replies.
- spark git commit: [SPARK-21976][DOC] Fix wrong documentation for Mean Absolute Error. - posted by sr...@apache.org on 2017/09/12 09:33:38 UTC, 2 replies.
- spark git commit: [SPARK-14516][ML] Adding ClusteringEvaluator with the implementation of Cosine silhouette and squared Euclidean silhouette. - posted by yl...@apache.org on 2017/09/12 10:00:00 UTC, 0 replies.
- spark git commit: [SPARK-21610][SQL][FOLLOWUP] Corrupt records are not handled properly when creating a dataframe from a file - posted by gu...@apache.org on 2017/09/12 13:47:33 UTC, 0 replies.
- spark git commit: [DOCS] Fix unreachable links in the document - posted by sr...@apache.org on 2017/09/12 14:07:07 UTC, 1 replies.
- spark git commit: [SPARK-17642][SQL] support DESC EXTENDED/FORMATTED table column commands - posted by li...@apache.org on 2017/09/12 15:59:59 UTC, 0 replies.
- spark git commit: [SPARK-21027][ML][PYTHON] Added tunable parallelism to one vs. rest in both Scala mllib and Pyspark - posted by jk...@apache.org on 2017/09/12 17:02:42 UTC, 0 replies.
- spark git commit: [SPARK-21368][SQL] TPCDSQueryBenchmark can't refer query files. - posted by li...@apache.org on 2017/09/12 17:49:48 UTC, 0 replies.
- spark git commit: [SPARK-18608][ML] Fix double caching - posted by jk...@apache.org on 2017/09/12 18:37:07 UTC, 1 replies.
- spark git commit: [SPARK-21979][SQL] Improve QueryPlanConstraints framework - posted by li...@apache.org on 2017/09/12 20:02:32 UTC, 0 replies.
- spark git commit: [SPARK-21513][SQL] Allow UDF to_json support converting MapType to json - posted by gu...@apache.org on 2017/09/13 00:43:05 UTC, 0 replies.
- spark git commit: [SPARK-21027][MINOR][FOLLOW-UP] add missing since tag - posted by sr...@apache.org on 2017/09/13 08:48:07 UTC, 0 replies.
- spark-website git commit: Update Yourkit usage - posted by sr...@apache.org on 2017/09/13 08:50:37 UTC, 0 replies.
- spark git commit: [BUILD] Close stale PRs - posted by sr...@apache.org on 2017/09/13 08:51:52 UTC, 1 replies.
- spark git commit: [SPARK-21982] Set locale to US - posted by sr...@apache.org on 2017/09/13 08:52:48 UTC, 0 replies.
- spark git commit: [SPARK-21893][BUILD][STREAMING][WIP] Put Kafka 0.8 behind a profile - posted by sr...@apache.org on 2017/09/13 09:10:43 UTC, 0 replies.
- spark git commit: [SPARK-21963][CORE][TEST] Create temp file should be delete after use - posted by sr...@apache.org on 2017/09/13 12:01:34 UTC, 0 replies.
- spark git commit: [SPARK-21690][ML] one-pass imputer - posted by yl...@apache.org on 2017/09/13 12:12:27 UTC, 0 replies.
- spark git commit: [SPARK-21970][CORE] Fix Redundant Throws Declarations in Java Codebase - posted by sr...@apache.org on 2017/09/13 13:04:30 UTC, 0 replies.
- spark git commit: [SPARK-21980][SQL] References in grouping functions should be indexed with semanticEquals - posted by li...@apache.org on 2017/09/13 17:06:56 UTC, 1 replies.
- spark git commit: [SPARK-4131] Merge HiveTmpFile.scala to SaveAsHiveFile.scala - posted by li...@apache.org on 2017/09/13 22:12:41 UTC, 0 replies.
- spark git commit: [SPARK-20427][SQL] Read JDBC table use custom schema - posted by li...@apache.org on 2017/09/13 23:34:22 UTC, 0 replies.
- [spark] Git Push Summary - posted by pw...@apache.org on 2017/09/14 02:34:31 UTC, 2 replies.
- [1/2] spark git commit: Preparing Spark release v2.1.2-rc1 - posted by pw...@apache.org on 2017/09/14 02:34:34 UTC, 0 replies.
- [2/2] spark git commit: Preparing development version 2.1.3-SNAPSHOT - posted by pw...@apache.org on 2017/09/14 02:34:35 UTC, 2 replies.
- spark git commit: [SPARK-21973][SQL] Add an new option to filter queries in TPC-DS - posted by li...@apache.org on 2017/09/14 04:54:12 UTC, 0 replies.
- spark git commit: [MINOR][SQL] Only populate type metadata for required types such as CHAR/VARCHAR. - posted by li...@apache.org on 2017/09/14 05:45:46 UTC, 0 replies.
- spark git commit: [SPARK-21854] Added LogisticRegressionTrainingSummary for MultinomialLogisticRegression in Python API - posted by yl...@apache.org on 2017/09/14 05:53:42 UTC, 0 replies.
- spark git commit: [MINOR][DOC] Add missing call of `update()` in examples of PeriodicGraphCheckpointer & PeriodicRDDCheckpointer - posted by yl...@apache.org on 2017/09/14 06:05:11 UTC, 0 replies.
- spark git commit: [SPARK-18608][ML][FOLLOWUP] Fix double caching for PySpark OneVsRest. - posted by yl...@apache.org on 2017/09/14 06:09:53 UTC, 1 replies.
- spark git commit: [SPARK-4131][FOLLOW-UP] Support "Writing data into the filesystem from queries" - posted by we...@apache.org on 2017/09/14 06:48:12 UTC, 0 replies.
- Voice Message from 011304814234 - name unavailable - posted by Voice Message <Vo...@spark.apache.org> on 2017/09/14 09:29:37 UTC, 0 replies.
- spark git commit: [SPARK-21922] Fix duration always updating when task failed but status is still RUN… - posted by js...@apache.org on 2017/09/14 12:40:53 UTC, 0 replies.
- spark git commit: [SPARK-17642][SQL][FOLLOWUP] drop test tables and improve comments - posted by we...@apache.org on 2017/09/14 15:14:29 UTC, 0 replies.
- spark git commit: [SPARK-21988] Add default stats to StreamingExecutionRelation. - posted by zs...@apache.org on 2017/09/14 18:06:28 UTC, 0 replies.
- spark git commit: [SPARK-21513][SQL][FOLLOWUP] Allow UDF to_json support converting MapType to json for PySpark and SparkR - posted by gu...@apache.org on 2017/09/15 02:53:15 UTC, 0 replies.
- spark git commit: [SPARK-22018][SQL] Preserve top-level alias metadata when collapsing projects - posted by td...@apache.org on 2017/09/15 05:32:25 UTC, 0 replies.
- spark git commit: [SPARK-21902][CORE] Print root cause for BlockManager#doPut - posted by js...@apache.org on 2017/09/15 06:03:41 UTC, 0 replies.
- spark git commit: [SPARK-22002][SQL] Read JDBC table use custom schema support specify partial fields. - posted by li...@apache.org on 2017/09/15 06:35:58 UTC, 0 replies.
- spark git commit: [SPARK-21987][SQL] fix a compatibility issue of sql event logs - posted by li...@apache.org on 2017/09/15 07:47:47 UTC, 0 replies.
- spark git commit: [SPARK-21958][ML] Word2VecModel save: transform data in the cluster - posted by ml...@apache.org on 2017/09/15 13:17:23 UTC, 0 replies.
- spark git commit: [SPARK-15689][SQL] data source v2 read path - posted by we...@apache.org on 2017/09/15 14:18:47 UTC, 0 replies.
- spark-website git commit: Added JIRA to CVEs on security page - posted by sr...@apache.org on 2017/09/15 21:12:39 UTC, 0 replies.
- spark git commit: [SPARK-22017] Take minimum of all watermark execs in StreamExecution. - posted by td...@apache.org on 2017/09/16 04:10:14 UTC, 0 replies.
- spark git commit: [SPARK-21967][CORE] org.apache.spark.unsafe.types.UTF8String#compareTo Should Compare 8 Bytes at a Time for Better Performance - posted by sr...@apache.org on 2017/09/16 08:18:16 UTC, 0 replies.
- spark git commit: [SPARK-22032][PYSPARK] Speed up StructType conversion - posted by gu...@apache.org on 2017/09/17 17:34:49 UTC, 0 replies.
- spark git commit: [SPARK-21985][PYSPARK] PairDeserializer is broken for double-zipped RDDs - posted by gu...@apache.org on 2017/09/17 17:46:34 UTC, 2 replies.
- spark git commit: [SPARK-21953] Show both memory and disk bytes spilled if either is present - posted by we...@apache.org on 2017/09/18 02:42:31 UTC, 2 replies.
- spark git commit: [SPARK-22043][PYTHON] Improves error message for show_profiles and dump_profiles - posted by gu...@apache.org on 2017/09/18 04:20:19 UTC, 2 replies.
- spark git commit: [SPARK-21113][CORE] Read ahead input stream to amortize disk IO cost … - posted by zs...@apache.org on 2017/09/18 06:15:12 UTC, 0 replies.
- spark git commit: [SPARK-22047][TEST] ignore HiveExternalCatalogVersionsSuite - posted by we...@apache.org on 2017/09/18 08:42:14 UTC, 1 replies.
- spark git commit: [SPARK-22003][SQL] support array column in vectorized reader with UDF - posted by li...@apache.org on 2017/09/18 15:49:37 UTC, 0 replies.
- spark git commit: [SPARK-14878][SQL] Trim characters string function support - posted by li...@apache.org on 2017/09/18 19:12:38 UTC, 0 replies.
- spark git commit: [SPARK-22030][CORE] GraphiteSink fails to re-connect to Graphite instances behind an ELB or any other auto-scaled LB - posted by js...@apache.org on 2017/09/19 02:06:05 UTC, 0 replies.
- spark git commit: [SPARK-22047][FLAKY TEST] HiveExternalCatalogVersionsSuite - posted by we...@apache.org on 2017/09/19 03:53:54 UTC, 1 replies.
- spark git commit: [SPARK-21923][CORE] Avoid calling reserveUnrollMemoryForThisTask for every record - posted by we...@apache.org on 2017/09/19 06:51:34 UTC, 0 replies.
- spark git commit: [MINOR][CORE] Cleanup dead code and duplication in Mem. Management - posted by sr...@apache.org on 2017/09/19 09:06:36 UTC, 0 replies.
- spark git commit: [SPARK-22052] Incorrect Metric assigned in MetricsReporter.scala - posted by sr...@apache.org on 2017/09/19 09:20:09 UTC, 2 replies.
- spark git commit: [SPARK-21428][SQL][FOLLOWUP] CliSessionState should point to the actual metastore not a dummy one - posted by we...@apache.org on 2017/09/19 11:35:46 UTC, 0 replies.
- spark git commit: [SPARK-21917][CORE][YARN] Supporting adding http(s) resources in yarn mode - posted by we...@apache.org on 2017/09/19 14:20:16 UTC, 0 replies.
- spark git commit: [MINOR][ML] Remove unnecessary default value setting for evaluators. - posted by yl...@apache.org on 2017/09/19 14:22:41 UTC, 0 replies.
- spark git commit: [SPARK-21338][SQL] implement isCascadingTruncateTable() method in AggregatedDialect - posted by li...@apache.org on 2017/09/19 16:27:09 UTC, 0 replies.
- spark git commit: [SPARK-21969][SQL] CommandUtils.updateTableStats should call refreshTable - posted by li...@apache.org on 2017/09/19 21:19:16 UTC, 0 replies.
- spark git commit: [SPARK-19318][SPARK-22041][SPARK-16625][BACKPORT-2.1][SQL] Docker test case failure: `: General data types to be mapped to Oracle` - posted by li...@apache.org on 2017/09/19 23:55:25 UTC, 0 replies.
- spark git commit: [SPARK-22067][SQL] ArrowWriter should use position when setting UTF8String ByteBuffer - posted by ue...@apache.org on 2017/09/20 01:51:08 UTC, 0 replies.
- spark git commit: [SPARK-18838][CORE] Add separate listener queues to LiveListenerBus. - posted by we...@apache.org on 2017/09/20 05:42:04 UTC, 0 replies.
- spark git commit: [SPARK-21977] SinglePartition optimizations break certain Streaming Stateful Aggregation requirements - posted by br...@apache.org on 2017/09/20 07:01:27 UTC, 0 replies.
- spark git commit: [SPARK-22066][BUILD] Update checkstyle to 8.2, enable it, fix violations - posted by sr...@apache.org on 2017/09/20 09:01:51 UTC, 0 replies.
- spark git commit: [SPARK-22066][BUILD][HOTFIX] Revert scala-maven-plugin to 3.2.2 to work with Maven+zinc again - posted by sr...@apache.org on 2017/09/20 09:49:11 UTC, 0 replies.
- spark git commit: [SPARK-22049][DOCS] Confusing behavior of from_utc_timestamp and to_utc_timestamp - posted by gu...@apache.org on 2017/09/20 11:47:22 UTC, 0 replies.
- spark git commit: [SPARK-22076][SQL] Expand.projections should not be a Stream - posted by li...@apache.org on 2017/09/20 16:00:46 UTC, 1 replies.
- spark git commit: [SPARK-18838][HOTFIX][YARN] Check internal context state before stopping it. - posted by va...@apache.org on 2017/09/20 22:53:34 UTC, 0 replies.
- spark git commit: [SPARK-21384][YARN] Spark + YARN fails with LocalFileSystem as default FS - posted by va...@apache.org on 2017/09/20 23:22:42 UTC, 1 replies.
- spark git commit: [SPARK-22076][SQL][FOLLOWUP] Expand.projections should not be a Stream - posted by li...@apache.org on 2017/09/21 04:13:50 UTC, 0 replies.
- spark git commit: [SPARK-21934][CORE] Expose Shuffle Netty memory usage to MetricsSystem - posted by js...@apache.org on 2017/09/21 05:54:38 UTC, 0 replies.
- spark git commit: [SPARK-21780][R] Simpler Dataset.sample API in R - posted by gu...@apache.org on 2017/09/21 11:16:29 UTC, 0 replies.
- [1/4] spark git commit: [SPARK-17997][SQL] Add an aggregation function for counting distinct values for multiple intervals - posted by we...@apache.org on 2017/09/21 13:43:18 UTC, 0 replies.
- [2/4] spark git commit: [SPARK-17997][SQL] Add an aggregation function for counting distinct values for multiple intervals - posted by we...@apache.org on 2017/09/21 13:43:19 UTC, 0 replies.
- [3/4] spark git commit: [SPARK-17997][SQL] Add an aggregation function for counting distinct values for multiple intervals - posted by we...@apache.org on 2017/09/21 13:43:20 UTC, 0 replies.
- [4/4] spark git commit: [SPARK-17997][SQL] Add an aggregation function for counting distinct values for multiple intervals - posted by we...@apache.org on 2017/09/21 13:43:21 UTC, 0 replies.
- spark git commit: [SPARK-22086][DOCS] Add expression description for CASE WHEN - posted by gu...@apache.org on 2017/09/21 13:45:11 UTC, 0 replies.
- spark git commit: [SPARK-21977][HOTFIX] Adjust EnsureStatefulOpPartitioningSuite to use scalatest lifecycle normally instead of constructor - posted by sr...@apache.org on 2017/09/21 17:00:22 UTC, 0 replies.
- spark git commit: [SPARK-21928][CORE] Set classloader on SerializerManager's private kryo - posted by va...@apache.org on 2017/09/21 17:20:24 UTC, 2 replies.
- spark git commit: [INFRA] Close stale PRs. - posted by va...@apache.org on 2017/09/21 17:24:33 UTC, 0 replies.
- spark git commit: [SPARK-22088][SQL] Incorrect scalastyle comment causes wrong styles in stringExpressions - posted by li...@apache.org on 2017/09/21 18:51:06 UTC, 0 replies.
- spark git commit: [SPARK-22075][ML] GBTs unpersist datasets cached by Checkpointer - posted by sr...@apache.org on 2017/09/21 19:05:47 UTC, 0 replies.
- spark git commit: [SPARK-22009][ML] Using treeAggregate improve some algs - posted by sr...@apache.org on 2017/09/21 19:06:45 UTC, 0 replies.
- [1/2] spark git commit: [SPARK-22053][SS] Stream-stream inner join in Append Mode - posted by td...@apache.org on 2017/09/21 22:39:12 UTC, 0 replies.
- [2/2] spark git commit: [SPARK-22053][SS] Stream-stream inner join in Append Mode - posted by td...@apache.org on 2017/09/21 22:39:13 UTC, 0 replies.
- spark git commit: [SPARK-22094][SS] processAllAvailable should check the query state - posted by zs...@apache.org on 2017/09/22 04:55:11 UTC, 1 replies.
- spark git commit: [SPARK-21981][PYTHON][ML] Added Python interface for ClusteringEvaluator - posted by yl...@apache.org on 2017/09/22 05:12:41 UTC, 0 replies.
- spark git commit: [SPARK-21998][SQL] SortMergeJoinExec did not calculate its outputOrdering correctly during physical planning - posted by li...@apache.org on 2017/09/22 06:54:19 UTC, 0 replies.
- spark git commit: [SPARK-22072][SPARK-22071][BUILD] Improve release build scripts - posted by ho...@apache.org on 2017/09/22 07:15:04 UTC, 2 replies.
- spark git commit: [SPARK-21190][PYSPARK] Python Vectorized UDFs - posted by we...@apache.org on 2017/09/22 08:20:28 UTC, 0 replies.
- spark git commit: [UI][STREAMING] Modify the title, 'Records' instead of 'Input Size' - posted by sr...@apache.org on 2017/09/22 10:52:00 UTC, 0 replies.
- spark git commit: [SPARK-22092] Reallocation in OffHeapColumnVector.reserveInternal corrupts struct and array data - posted by hv...@apache.org on 2017/09/22 13:31:50 UTC, 1 replies.
- spark git commit: [SPARK-21766][PYSPARK][SQL] DataFrame toPandas() raises ValueError with nullable int columns - posted by gu...@apache.org on 2017/09/22 13:39:53 UTC, 0 replies.
- [1/2] spark git commit: Preparing Spark release v2.1.2-rc2 - posted by ho...@apache.org on 2017/09/22 15:07:52 UTC, 0 replies.
- spark git commit: [SPARK-22060][ML] Fix CrossValidator/TrainValidationSplit param persist/load bug - posted by jk...@apache.org on 2017/09/23 01:15:06 UTC, 0 replies.
- spark git commit: [SPARK-18136] Fix SPARK_JARS_DIR for Python pip install on Windows - posted by gu...@apache.org on 2017/09/23 12:04:16 UTC, 2 replies.
- spark git commit: [SPARK-22099] The 'job ids' list style needs to be changed in the SQL page. - posted by sr...@apache.org on 2017/09/23 14:39:57 UTC, 0 replies.
- spark git commit: [SPARK-22033][CORE] BufferHolder, other size checks should account for the specific VM array size limitations - posted by sr...@apache.org on 2017/09/23 14:41:03 UTC, 0 replies.
- spark git commit: [SPARK-22109][SQL] Resolves type conflicts between strings and timestamps in partition column - posted by ue...@apache.org on 2017/09/23 15:05:28 UTC, 0 replies.
- spark git commit: [SPARK-20448][DOCS] Document how FileInputDStream works with object storage - posted by sr...@apache.org on 2017/09/23 16:08:44 UTC, 0 replies.
- spark git commit: [SPARK-22110][SQL][DOCUMENTATION] Add usage and improve documentation with arguments and examples for trim function - posted by li...@apache.org on 2017/09/23 17:27:44 UTC, 0 replies.
- spark git commit: [SPARK-22109][SQL][BRANCH-2.2] Resolves type conflicts between strings and timestamps in partition column - posted by ue...@apache.org on 2017/09/23 17:51:23 UTC, 0 replies.
- spark git commit: [SPARK-21338][SQL][FOLLOW-UP] Implement isCascadingTruncateTable() method in AggregatedDialect - posted by li...@apache.org on 2017/09/24 04:51:06 UTC, 0 replies.
- spark git commit: [SPARK-22093][TESTS] Fixes `assume` in `UtilsSuite` and `HiveDDLSuite` - posted by gu...@apache.org on 2017/09/24 08:11:32 UTC, 0 replies.
- spark git commit: [SPARK-22058][CORE] the BufferedInputStream will not be closed if an exception occurs. - posted by sr...@apache.org on 2017/09/24 08:38:49 UTC, 0 replies.
- [1/2] spark git commit: [SPARK-22087][SPARK-14650][WIP][BUILD][REPL][CORE] Compile Spark REPL for Scala 2.12 + other 2.12 fixes - posted by sr...@apache.org on 2017/09/24 08:40:18 UTC, 0 replies.
- [2/2] spark git commit: [SPARK-22087][SPARK-14650][WIP][BUILD][REPL][CORE] Compile Spark REPL for Scala 2.12 + other 2.12 fixes - posted by sr...@apache.org on 2017/09/24 08:40:19 UTC, 0 replies.
- spark git commit: [SPARK-22107] Change as to alias in python quickstart - posted by gu...@apache.org on 2017/09/25 00:16:32 UTC, 1 replies.
- spark git commit: [SPARK-22100][SQL] Make percentile_approx support date/timestamp type and change the output type to be the same as input type - posted by li...@apache.org on 2017/09/25 16:28:47 UTC, 0 replies.
- spark git commit: [SPARK-22083][CORE] Release locks in MemoryStore.evictBlocksToFreeSpace - posted by va...@apache.org on 2017/09/25 19:02:36 UTC, 2 replies.
- spark git commit: [SPARK-22103] Move HashAggregateExec parent consume to a separate function in codegen - posted by li...@apache.org on 2017/09/25 19:50:28 UTC, 0 replies.
- spark git commit: [SPARK-22120][SQL] TestHiveSparkSession.reset() should clean out Hive warehouse directory - posted by li...@apache.org on 2017/09/25 21:16:14 UTC, 1 replies.
- spark git commit: [SPARK-22106][PYSPARK][SQL] Disable 0-parameter pandas_udf and add doctests - posted by gu...@apache.org on 2017/09/26 01:54:06 UTC, 0 replies.
- spark git commit: [SPARK-22124][SQL] Sample and Limit should also defer input evaluation under codegen - posted by we...@apache.org on 2017/09/26 07:23:18 UTC, 0 replies.
- spark git commit: [SPARK-22103][FOLLOWUP] Rename addExtraCode to addInnerClass - posted by li...@apache.org on 2017/09/26 17:04:36 UTC, 0 replies.
- spark git commit: [SPARK-22112][PYSPARK] Supports RDD of strings as input in spark.read.csv in PySpark - posted by gu...@apache.org on 2017/09/27 02:19:51 UTC, 0 replies.
- spark git commit: [SPARK-22141][SQL] Propagate empty relation before checking Cartesian products - posted by hv...@apache.org on 2017/09/27 10:44:13 UTC, 0 replies.
- spark git commit: [SPARK-20642][CORE] Store FsHistoryProvider listing data in a KVStore. - posted by we...@apache.org on 2017/09/27 12:33:52 UTC, 0 replies.
- spark git commit: [SAPRK-20785][WEB-UI][SQL] Spark should provide jump links and add (count) in the SQL web ui. - posted by js...@apache.org on 2017/09/27 12:49:07 UTC, 0 replies.
- spark git commit: [SPARK-22130][CORE] UTF8String.trim() scans " " twice - posted by gu...@apache.org on 2017/09/27 14:19:16 UTC, 0 replies.
- spark git commit: [SPARK-22125][PYSPARK][SQL] Enable Arrow Stream format for vectorized UDF. - posted by gu...@apache.org on 2017/09/27 14:21:50 UTC, 0 replies.
- spark git commit: [SPARK-22141][BACKPORT][SQL] Propagate empty relation before checking Cartesian products - posted by hv...@apache.org on 2017/09/27 15:40:34 UTC, 0 replies.
- spark git commit: [HOTFIX][BUILD] Fix finalizer checkstyle error and re-disable checkstyle - posted by va...@apache.org on 2017/09/27 20:40:27 UTC, 0 replies.
- spark git commit: [SPARK-22143][SQL] Fix memory leak in OffHeapColumnVector - posted by hv...@apache.org on 2017/09/27 21:08:35 UTC, 0 replies.
- spark git commit: [SPARK-22140] Add TPCDSQuerySuite - posted by li...@apache.org on 2017/09/28 00:03:45 UTC, 1 replies.
- spark git commit: [MINOR] Fixed up pandas_udf related docs and formatting - posted by gu...@apache.org on 2017/09/28 01:24:57 UTC, 0 replies.
- spark git commit: [SPARK-22123][CORE] Add latest failure reason for task set blacklist - posted by js...@apache.org on 2017/09/28 01:25:32 UTC, 0 replies.
- spark git commit: [SPARK-22135][MESOS] metrics in spark-dispatcher not being registered properly - posted by js...@apache.org on 2017/09/28 06:43:41 UTC, 1 replies.
- spark git commit: [SPARK-22128][CORE] Update paranamer to 2.8 to avoid BytecodeReadingParanamer ArrayIndexOutOfBoundsException with Scala 2.12 + Java 8 lambda - posted by sr...@apache.org on 2017/09/28 07:22:52 UTC, 0 replies.
- spark git commit: [SPARK-22143][SQL][BRANCH-2.2] Fix memory leak in OffHeapColumnVector - posted by hv...@apache.org on 2017/09/28 15:51:45 UTC, 0 replies.
- spark git commit: [SPARK-22153][SQL] Rename ShuffleExchange -> ShuffleExchangeExec - posted by li...@apache.org on 2017/09/28 16:20:42 UTC, 0 replies.
- spark-website git commit: Adding `tejasp` to committer page - posted by te...@apache.org on 2017/09/28 22:45:42 UTC, 0 replies.
- spark git commit: [SPARK-22159][SQL] Make config names consistently end with "enabled". - posted by li...@apache.org on 2017/09/28 22:59:08 UTC, 0 replies.
- spark git commit: [SPARK-22160][SQL] Make sample points per partition (in range partitioner) configurable and bump the default value up to 100 - posted by rx...@apache.org on 2017/09/29 04:07:17 UTC, 0 replies.
- spark git commit: [SPARK-22146] FileNotFoundException while reading ORC files containing special characters - posted by li...@apache.org on 2017/09/29 06:14:59 UTC, 1 replies.
- spark git commit: [SPARK-22141][FOLLOWUP][SQL] Add comments for the order of batches - posted by li...@apache.org on 2017/09/29 06:23:33 UTC, 0 replies.
- spark git commit: [SPARK-22142][BUILD][STREAMING] Move Flume support behind a profile - posted by sr...@apache.org on 2017/09/29 07:26:57 UTC, 0 replies.
- spark git commit: [SPARK-22129][SPARK-22138] Release script improvements - posted by ho...@apache.org on 2017/09/29 15:04:19 UTC, 2 replies.
- spark git commit: [SPARK-22161][SQL] Add Impala-modified TPC-DS queries - posted by li...@apache.org on 2017/09/29 15:59:46 UTC, 1 replies.
- [1/2] spark git commit: Preparing Spark release v2.1.2-rc3 - posted by ho...@apache.org on 2017/09/29 16:04:40 UTC, 0 replies.
- spark git commit: Revert "[SPARK-22142][BUILD][STREAMING] Move Flume support behind a profile" - posted by li...@apache.org on 2017/09/29 18:46:25 UTC, 0 replies.
- spark git commit: [SPARK-21904][SQL] Rename tempTables to tempViews in SessionCatalog - posted by li...@apache.org on 2017/09/30 02:35:36 UTC, 0 replies.
- spark git commit: [SPARK-22122][SQL] Use analyzed logical plans to count input rows in TPCDSQueryBenchmark - posted by li...@apache.org on 2017/09/30 04:36:56 UTC, 0 replies.