Export - CSV (All fields)
Export - CSV (Current fields)
- SPARK-5234
examples for ml don't have sparkContext.stop - SPARK-5107
A trick log info for the start of Receiver - SPARK-4685
Update JavaDoc settings to include spark.ml and all spark.mllib subpackages in the right sections - SPARK-4569
Rename "externalSorting" in Aggregator - SPARK-5382
Scripts do not use SPARK_CONF_DIR where they should - SPARK-5402
Log executor ID at executor-construction time - SPARK-5102
CompressedMapStatus needs to be registered with Kryo - SPARK-4014
TaskContext.attemptId returns taskId - SPARK-4846
When the vocabulary size is large, Word2Vec may yield "OutOfMemoryError: Requested array size exceeds VM limit" - SPARK-4914
Two sets of datanucleus versions left in lib_managed after running dev/run-tests - SPARK-4714
BlockManager should check whether blocks have already been removed Checking block is null or not after having gotten info.lock in remove block method - SPARK-4764
Ensure that files are fetched atomically - SPARK-4883
Add a name to the directoryCleaner thread - SPARK-4880
remove spark.locality.wait setting in examples/graphx/Analytics.scala - SPARK-4889
HistoryServer documentation refers to non-existent spark-history-server.sh script - SPARK-4691
Restructure a few lines in shuffle code - SPARK-2823
GraphX jobs throw IllegalArgumentException - SPARK-5254
Update the user guide to make clear that spark.mllib is not being deprecated - SPARK-5006
spark.port.maxRetries doesn't work - SPARK-5401
Executor ID should be set before MetricsSystem is created - SPARK-5267
Add a streaming module to ingest Apache Camel Messages from a configured endpoints - SPARK-5130
yarn-cluster mode should not be considered as client mode in spark-submit - SPARK-4973
Local directory in the driver of client-mode continues remaining even if application finished when external shuffle is enabled - SPARK-4320
JavaPairRDD should supply a saveAsNewHadoopDataset which takes a Job object - SPARK-4161
Spark shell class path is not correctly set if "spark.driver.extraClassPath" is set in defaults.conf - SPARK-6864
Spark's Multilabel Classifier runs out of memory on small datasets - SPARK-6771
Table alias in Spark SQL - SPARK-4140
Document the dynamic allocation feature - SPARK-4951
A busy executor may be killed when dynamicAllocation is enabled - SPARK-4963
SchemaRDD.sample may return wrong results - SPARK-4952
Handle ConcurrentModificationExceptions in SparkEnv.environmentDetails - SPARK-4730
Warn against deprecated YARN settings - SPARK-4826
Possible flaky tests in WriteAheadLogBackedBlockRDDSuite: "java.lang.IllegalStateException: File exists and there is no append support!" - SPARK-4786
Parquet filter pushdown for BYTE and SHORT types - SPARK-4754
ExecutorAllocationManager should not take in SparkContext - SPARK-4882
PySpark broadcast breaks when using KryoSerializer - SPARK-4798
Refactor Parquet test suites - SPARK-5201
ParallelCollectionRDD.slice(seq, numSlices) has int overflow when dealing with inclusive range - SPARK-5200
Disable web UI in Hive Thriftserver tests - SPARK-4821
pyspark.mllib.rand docs not generated correctly - SPARK-4772
Accumulators leak memory, both temporarily and permanently - SPARK-4771
Document standalone --supervise feature - SPARK-4750
Dynamic allocation - we need to synchronize kills - SPARK-5063
Display more helpful error messages for several invalid operations - SPARK-3926
result of JavaRDD collectAsMap() is not serializable - SPARK-3787
Assembly jar name is wrong when we build with sbt omitting -Dhadoop.version - SPARK-4694
Long-run user thread(such as HiveThriftServer2) causes the 'process leak' in yarn-client mode - SPARK-5223
Use pickle instead of MapConvert and ListConvert in MLlib Python API - SPARK-4825
CTAS fails to resolve when created using saveAsTable - SPARK-4759
Deadlock in complex spark job in local mode
{"errorMessages":["jqlTooComplex"],"errors":{}}
[{"id":-1,"name":"My open issues","jql":"assignee = currentUser() AND resolution = Unresolved order by updated DESC","isSystem":true,"sharePermissions":[],"requiresLogin":true},{"id":-2,"name":"Reported by me","jql":"reporter = currentUser() order by created DESC","isSystem":true,"sharePermissions":[],"requiresLogin":true},{"id":-4,"name":"All issues","jql":"order by created DESC","isSystem":true,"sharePermissions":[],"requiresLogin":false},{"id":-5,"name":"Open issues","jql":"resolution = Unresolved order by priority DESC,updated DESC","isSystem":true,"sharePermissions":[],"requiresLogin":false},{"id":-9,"name":"Done issues","jql":"statusCategory = Done order by updated DESC","isSystem":true,"sharePermissions":[],"requiresLogin":false},{"id":-3,"name":"Viewed recently","jql":"issuekey in issueHistory() order by lastViewed DESC","isSystem":true,"sharePermissions":[],"requiresLogin":false},{"id":-6,"name":"Created recently","jql":"created >= -1w order by created DESC","isSystem":true,"sharePermissions":[],"requiresLogin":false},{"id":-7,"name":"Resolved recently","jql":"resolutiondate >= -1w order by updated DESC","isSystem":true,"sharePermissions":[],"requiresLogin":false},{"id":-8,"name":"Updated recently","jql":"updated >= -1w order by updated DESC","isSystem":true,"sharePermissions":[],"requiresLogin":false}]
0.3
0