Skip to content
Closed
Show file tree
Hide file tree
Changes from all commits
Commits
Show all changes
1824 commits
Select commit Hold shift + click to select a range
10e315c
Fix style violation for b63938a8b04
rxin Nov 27, 2015
a374e20
[SPARK-11997] [SQL] NPE when save a DataFrame as parquet and partitio…
dilipbiswal Nov 27, 2015
ba02f6c
[SPARK-12025][SPARKR] Rename some window rank function names for SparkR
yanboliang Nov 27, 2015
f57e6c9
[SPARK-12021][STREAMING][TESTS] Fix the potential dead-lock in Stream…
zsxwing Nov 27, 2015
b992152
[SPARK-12020][TESTS][TEST-HADOOP2.0] PR builder cannot trigger hadoop…
yhuai Nov 27, 2015
149cd69
[SPARK-12028] [SQL] get_json_object returns an incorrect result when …
gatorsmile Nov 28, 2015
28e46ab
[SPARK-12029][SPARKR] Improve column functions signature, param check…
felixcheung Nov 29, 2015
c793d2d
[SPARK-9319][SPARKR] Add support for setting column names, types
felixcheung Nov 29, 2015
cc7a1bc
[SPARK-11781][SPARKR] SparkR has problem in inferring type of raw type.
Nov 29, 2015
3d28081
[SPARK-12024][SQL] More efficient multi-column counting.
hvanhovell Nov 29, 2015
0ddfe78
[SPARK-12039] [SQL] Ignore HiveSparkSubmitSuite's "SPARK-9757 Persist…
yhuai Nov 30, 2015
e074944
[SPARK-11859][MESOS] SparkContext accepts invalid Master URLs in the …
toddwan Nov 30, 2015
953e8e6
[MINOR][BUILD] Changed the comment to reflect the plugin project is t…
ScrapCodes Nov 30, 2015
26c3581
[DOC] Explicitly state that top maintains the order of elements
mineo Nov 30, 2015
bf0e85a
[SPARK-12023][BUILD] Fix warnings while packaging spark with maven.
ScrapCodes Nov 30, 2015
2db4662
[SPARK-11989][SQL] Only use commit in JDBC data source if the underly…
CK50 Nov 30, 2015
17275fa
[SPARK-11700] [SQL] Remove thread local SQLContext in SparkPlan
Nov 30, 2015
8df584b
[SPARK-11982] [SQL] improve performance of cartesian product
Nov 30, 2015
f2fbfa4
[MINOR][DOCS] fixed list display in ml-ensembles
BenFradet Nov 30, 2015
2c5dee0
Revert "[SPARK-11206] Support SQL UI on the history server"
JoshRosen Nov 30, 2015
a8ceec5
[SPARK-12053][CORE] EventLoggingListener.getLogPath needs 4 parameters
chutium Nov 30, 2015
e232720
[SPARK-11689][ML] Add user guide and example code for LDA under spark.ml
hhbyyh Nov 30, 2015
de64b65
[SPARK-11975][ML] Remove duplicate mllib example (DT/RF/GBT in Java/P…
yanboliang Nov 30, 2015
5535888
[SPARK-11960][MLLIB][DOC] User guide for streaming tests
feynmanliang Nov 30, 2015
ecc00ec
fix Maven build
davies Nov 30, 2015
edb26e7
[SPARK-12058][HOTFIX] Disable KinesisStreamTests
zsxwing Dec 1, 2015
d3ca8cf
[SPARK-12000] Fix API doc generation issues
JoshRosen Dec 1, 2015
e6dc89a
[SPARK-12035] Add more debug information in include_example tag of Je…
yinxusen Dec 1, 2015
0a46e43
[SPARK-12037][CORE] initialize heartbeatReceiverRef before calling st…
CodingCat Dec 1, 2015
9bf2120
[SPARK-12007][NETWORK] Avoid copies in the network lib's RPC layer.
Dec 1, 2015
96bf468
[SPARK-12049][CORE] User JVM shutdown hook can cause deadlock at shut…
srowen Dec 1, 2015
f73379b
[HOTFIX][SPARK-12000] Add missing quotes in Jekyll API docs plugin.
JoshRosen Dec 1, 2015
9693b0d
[SPARK-12018][SQL] Refactor common subexpression elimination code
viirya Dec 1, 2015
a0af0e3
[SPARK-11898][MLLIB] Use broadcast for the global tables in Word2Vec
hhbyyh Dec 1, 2015
c87531b
[SPARK-11949][SQL] Set field nullable property for GroupingSets to ge…
viirya Dec 1, 2015
1401166
[SPARK-12060][CORE] Avoid memory copy in JavaSerializerInstance.seria…
zsxwing Dec 1, 2015
69dbe6b
[SPARK-12046][DOC] Fixes various ScalaDoc/JavaDoc issues
liancheng Dec 1, 2015
8ddc55f
[SPARK-12068][SQL] use a single column in Dataset.groupBy and count w…
cloud-fan Dec 1, 2015
9df2462
[SPARK-11856][SQL] add type cast if the real type is different but co…
cloud-fan Dec 1, 2015
fd95eea
[SPARK-11954][SQL] Encoder for JavaBeans
cloud-fan Dec 1, 2015
0a7bca2
[SPARK-11905][SQL] Support Persist/Cache and Unpersist in Dataset APIs
gatorsmile Dec 1, 2015
6a8cf80
[SPARK-11821] Propagate Kerberos keytab for all environments
woj-i Dec 1, 2015
34e7093
[SPARK-12065] Upgrade Tachyon from 0.8.1 to 0.8.2
JoshRosen Dec 1, 2015
2cef1cd
[SPARK-12030] Fix Platform.copyMemory to handle overlapping regions.
nongli Dec 1, 2015
60b541e
[SPARK-12004] Preserve the RDD partitioner through RDD checkpointing
tdas Dec 1, 2015
328b757
Revert "[SPARK-12060][CORE] Avoid memory copy in JavaSerializerInstan…
zsxwing Dec 1, 2015
e76431f
[SPARK-11961][DOC] Add docs of ChiSqSelector
yinxusen Dec 1, 2015
f292018
[SPARK-12002][STREAMING][PYSPARK] Fix python direct stream checkpoint…
jerryshao Dec 1, 2015
ef6790f
[SPARK-12075][SQL] Speed up HiveComparisionTest by avoiding / speedin…
JoshRosen Dec 1, 2015
47a0abc
[SPARK-11328][SQL] Improve error message when hitting this issue
nongli Dec 1, 2015
5a8b5fd
[SPARK-11788][SQL] surround timestamp/date value with quotes in JDBC …
Dec 1, 2015
5872a9d
[SPARK-11352][SQL] Escape */ in the generated comments.
yhuai Dec 2, 2015
e96a70d
[SPARK-11596][SQL] In TreeNode's argString, if a TreeNode is not a ch…
yhuai Dec 2, 2015
1ce4adf
[SPARK-8414] Ensure context cleaner periodic cleanups
Dec 2, 2015
d96f8c9
[SPARK-12081] Make unified memory manager work with small heaps
Dec 2, 2015
96691fe
[SPARK-12077][SQL] change the default plan for single distinct
Dec 2, 2015
8a75a30
[SPARK-12087][STREAMING] Create new JobConf for every batch in saveAs…
tdas Dec 2, 2015
0f37d1d
[SPARK-11949][SQL] Check bitmasks to set nullable property
viirya Dec 2, 2015
4375eb3
[SPARK-12090] [PYSPARK] consider shuffle in coalesce()
Dec 2, 2015
128c290
[SPARK-3580][CORE] Add Consistent Method To Get Number of RDD Partiti…
Dec 2, 2015
a1542ce
[SPARK-12094][SQL] Prettier tree string for TreeNode
liancheng Dec 2, 2015
452690b
[SPARK-12001] Allow partially-stopped StreamingContext to be complete…
JoshRosen Dec 2, 2015
de07d06
[SPARK-10266][DOCUMENTATION, ML] Fixed @Since annotation for ml.tunning
yu-iskw Dec 2, 2015
d0d7ec5
[SPARK-12093][SQL] Fix the error of comment in DDLParser
watermen Dec 3, 2015
9bb695b
[SPARK-12000] do not specify arg types when reference a method in Sca…
mengxr Dec 3, 2015
ae40253
[SPARK-12082][FLAKY-TEST] Increase timeouts in NettyBlockTransferSecu…
JoshRosen Dec 3, 2015
ec2b6c2
[SPARK-12109][SQL] Expressions's simpleString should delegate to its …
yhuai Dec 3, 2015
5349851
[SPARK-12088][SQL] check connection.isClosed before calling connection…
Dec 3, 2015
7470d9e
[DOCUMENTATION][MLLIB] typo in mllib doc
zjffdu Dec 3, 2015
95b3cf1
[DOCUMENTATION][KAFKA] fix typo in kafka/OffsetRange.scala
microwishing Dec 3, 2015
43c575c
[SPARK-12116][SPARKR][DOCS] document how to workaround function name …
felixcheung Dec 3, 2015
8fa3e47
[SPARK-11314][YARN] add service API and test service for Yarn Cluster…
steveloughran Dec 3, 2015
7bc9e1d
[SPARK-12059][CORE] Avoid assertion error when unexpected state trans…
jerryshao Dec 3, 2015
649be4f
[SPARK-12101][CORE] Fix thread pools that cannot cache tasks in Worke…
zsxwing Dec 3, 2015
688e521
[SPARK-12108] Make event logs smaller
Dec 3, 2015
d576e76
[MINOR][ML] Use coefficients replace weights
yanboliang Dec 3, 2015
ad7cea6
[SPARK-12107][EC2] Update spark-ec2 versions
nchammas Dec 3, 2015
a02d472
[FLAKY-TEST-FIX][STREAMING][TEST] Make sure StreamingContexts are shu…
tdas Dec 3, 2015
2213441
[SPARK-12019][SPARKR] Support character vector for sparkR.init(), che…
felixcheung Dec 3, 2015
f434f36
[SPARK-12056][CORE] Create a TaskAttemptContext only after calling se…
Dec 4, 2015
b6e9963
[SPARK-11206] Support SQL UI on the history server (resubmit)
carsonwang Dec 4, 2015
5011f26
[SPARK-12104][SPARKR] collect() does not handle multiple columns with…
Dec 4, 2015
4106d80
[SPARK-12122][STREAMING] Prevent batches from being submitted twice a…
tdas Dec 4, 2015
17e4e02
Add links howto to setup IDEs for developing spark
kaklakariada Dec 4, 2015
95296d9
[SPARK-12089] [SQL] Fix memory corrupt due to freeing a page being re…
Dec 4, 2015
d0d8222
[SPARK-6990][BUILD] Add Java linting script; fix minor warnings
dskrvk Dec 4, 2015
302d68d
[SPARK-12058][STREAMING][KINESIS][TESTS] fix Kinesis python tests
brkyvz Dec 4, 2015
d64806b
[SPARK-11314][BUILD][HOTFIX] Add exclusion for moved YARN classes.
Dec 4, 2015
b7204e1
[SPARK-12112][BUILD] Upgrade to SBT 0.13.9
JoshRosen Dec 5, 2015
bbfc16e
[SPARK-12142][CORE]Reply false when container allocator is not ready …
XuTingjun Dec 5, 2015
f30373f
[SPARK-12080][CORE] Kryo - Support multiple user registrators
Dec 5, 2015
3af53e6
[SPARK-12084][CORE] Fix codes that uses ByteBuffer.array incorrectly
zsxwing Dec 5, 2015
ee94b70
[SPARK-12096][MLLIB] remove the old constraint in word2vec
hhbyyh Dec 5, 2015
e9c9ae2
[SPARK-11994][MLLIB] Word2VecModel load and save cause SparkException…
tmnd1991 Dec 5, 2015
7da6748
[SPARK-11988][ML][MLLIB] Update JPMML to 1.2.7
srowen Dec 5, 2015
c8d0e16
[SPARK-11774][SPARKR] Implement struct(), encode(), decode() function…
Dec 5, 2015
895b6c4
[SPARK-11715][SPARKR] Add R support corr for Column Aggregration
felixcheung Dec 6, 2015
6979edf
[SPARK-12115][SPARKR] Change numPartitions() to getNumPartitions() to…
yanboliang Dec 6, 2015
b6e8e63
[SPARK-12044][SPARKR] Fix usage of isnan, isNaN
yanboliang Dec 6, 2015
04b6799
[SPARK-12048][SQL] Prevent to close JDBC resources twice
Dec 6, 2015
49efd03
[SPARK-12138][SQL] Escape \u in the generated comments of codegen
gatorsmile Dec 6, 2015
80a824d
[SPARK-12152][PROJECT-INFRA] Speed up Scalastyle checks by only invok…
JoshRosen Dec 7, 2015
6fd9e70
[SPARK-12106][STREAMING][FLAKY-TEST] BatchedWAL test transiently flak…
brkyvz Dec 7, 2015
9cde7d5
[SPARK-12032] [SQL] Re-order inner joins to do join with conditions f…
Dec 7, 2015
39d677c
[SPARK-12034][SPARKR] Eliminate warnings in SparkR test cases.
Dec 7, 2015
ef3f047
[SPARK-12132] [PYSPARK] raise KeyboardInterrupt inside SIGINT handler
Dec 7, 2015
5d80d8c
[SPARK-11932][STREAMING] Partition previous TrackStateRDD if partitio…
tdas Dec 7, 2015
3f4efb5
[SPARK-12060][CORE] Avoid memory copy in JavaSerializerInstance.seria…
zsxwing Dec 7, 2015
871e85d
[SPARK-11963][DOC] Add docs for QuantileDiscretizer
yinxusen Dec 7, 2015
84b8094
[SPARK-11884] Drop multiple columns in the DataFrame API
tedyu Dec 7, 2015
36282f7
[SPARK-12184][PYTHON] Make python api doc for pivot consistant with s…
aray Dec 7, 2015
3e7e05f
[SPARK-12160][MLLIB] Use SQLContext.getOrCreate in MLlib
jkbradley Dec 8, 2015
78209b0
[SPARK-11551][DOC][EXAMPLE] Replace example code in ml-features.md us…
somideshmukh Dec 8, 2015
7389658
Closes #10098
mengxr Dec 8, 2015
7d05a62
[SPARK-10259][ML] Add @since annotation to ml.classification
Dec 8, 2015
4a39b5a
[SPARK-11958][SPARK-11957][ML][DOC] SQLTransformer user guide and exa…
yanboliang Dec 8, 2015
48a9804
[SPARK-12103][STREAMING][KAFKA][DOC] document that K means Key and V …
koeninger Dec 8, 2015
7081291
[SPARK-12166][TEST] Unset hadoop related environment in testing
zjffdu Dec 8, 2015
037b7e7
[SPARK-11439][ML] Optimization of creating sparse feature without den…
Dec 8, 2015
da2012a
[SPARK-11551][DOC][EXAMPLE] Revert PR #10002
liancheng Dec 8, 2015
e3735ce
[SPARK-11652][CORE] Remote code execution with InvokerTransformer
srowen Dec 8, 2015
6cb06e8
[SPARK-11155][WEB UI] Stage summary json should include stage duration
keypointt Dec 8, 2015
75c60bf
[SPARK-12074] Avoid memory copy involving ByteBuffer.wrap(ByteArrayOu…
tedyu Dec 8, 2015
381f17b
[SPARK-12201][SQL] add type coercion rule for greatest/least
cloud-fan Dec 8, 2015
c0b13d5
[SPARK-12195][SQL] Adding BigDecimal, Date and Timestamp into Encoder
gatorsmile Dec 8, 2015
5d96a71
[SPARK-12188][SQL] Code refactoring and comment correction in Dataset…
gatorsmile Dec 8, 2015
872a2ee
[SPARK-10393] use ML pipeline in LDA example
hhbyyh Dec 8, 2015
4bcb894
[SPARK-12205][SQL] Pivot fails Analysis when aggregate is UnresolvedF…
aray Dec 8, 2015
5cb4695
[SPARK-11605][MLLIB] ML 1.6 QA: API: Java compatibility, docs
hhbyyh Dec 8, 2015
06746b3
[SPARK-12159][ML] Add user guide section for IndexToString transformer
BenFradet Dec 8, 2015
2ff17bc
[SPARK-3873][BUILD] Add style checker to enforce import ordering.
Dec 8, 2015
9494521
[SPARK-12187] *MemoryPool classes should not be fully public
Dec 8, 2015
3959489
[SPARK-12069][SQL] Update documentation with Datasets
marmbrus Dec 8, 2015
765c67f
[SPARK-8517][ML][DOC] Reorganizes the spark.ml user guide
thunterdb Dec 9, 2015
a0046e3
[SPARK-11343][ML] Documentation of float and double prediction/label …
dahlem Dec 9, 2015
3934562
[SPARK-12222] [CORE] Deserialize RoaringBitmap using Kryo serializer …
scwf Dec 9, 2015
f6883bb
[SPARK-11676][SQL] Parquet filter tests all pass if filters are not r…
HyukjinKwon Dec 9, 2015
a113216
[SPARK-12031][CORE][BUG] Integer overflow when do sampling
uncleGen Dec 9, 2015
6e1c55e
[SPARK-12012][SQL] Show more comprehensive PhysicalRDD metadata when …
liancheng Dec 9, 2015
22b9a87
[SPARK-10299][ML] word2vec should allow users to specify the window size
holdenk Dec 9, 2015
6900f01
[SPARK-10582][YARN][CORE] Fix AM failure situation for dynamic alloca…
jerryshao Dec 9, 2015
442a771
[SPARK-12241][YARN] Improve failure reporting in Yarn client obtainTo…
steveloughran Dec 9, 2015
aec5ea0
[SPARK-12165][SPARK-12189] Fix bugs in eviction of storage memory by …
JoshRosen Dec 9, 2015
1eb7c22
[SPARK-11824][WEBUI] WebUI does not render descriptions with 'bad' HT…
srowen Dec 9, 2015
051c6a0
[SPARK-11551][DOC] Replace example code in ml-features.md using inclu…
yinxusen Dec 9, 2015
7a8e587
[SPARK-12211][DOC][GRAPHX] Fix version number in graphx doc for migra…
aray Dec 10, 2015
8770bd1
[SPARK-12165][ADDENDUM] Fix outdated comments on unroll test
Dec 10, 2015
ac8cdf1
[SPARK-11678][SQL][DOCS] Document basePath in the programming guide.
yhuai Dec 10, 2015
2166c2a
[SPARK-11796] Fix httpclient and httpcore depedency issues related to…
Dec 10, 2015
bd2cd4f
[SPARK-12244][SPARK-12245][STREAMING] Rename trackStateByKey to mapWi…
tdas Dec 10, 2015
d8ec081
[SPARK-12252][SPARK-12131][SQL] refactor MapObjects to make it less h…
cloud-fan Dec 10, 2015
e29704f
[SPARK-12136][STREAMING] rddToFileName does not properly handle prefi…
Dec 10, 2015
21b3d2a
[SPARK-11530][MLLIB] Return eigenvalues with PCA model
srowen Dec 10, 2015
76540b6
[SPARK-12242][SQL] Add DataFrame.transform method
rxin Dec 10, 2015
db51652
[SPARK-11832][CORE] Process arguments in spark-shell for Scala 2.11
jodersky Dec 10, 2015
eeb5872
[SPARK-12198][SPARKR] SparkR support read.parquet and deprecate parqu…
yanboliang Dec 10, 2015
9fba9c8
[SPARK-11602][MLLIB] Refine visibility for 1.6 scala API audit
hhbyyh Dec 10, 2015
d9d354e
[SPARK-12234][SPARKR] Fix ```subset``` function error when only set `…
yanboliang Dec 10, 2015
bc5f56a
[SPARK-12250][SQL] Allow users to define a UDAF without providing det…
yhuai Dec 10, 2015
ec5f9ed
[SPARK-12228][SQL] Try to run execution hive's derby in memory.
yhuai Dec 10, 2015
2ecbe02
[SPARK-12212][ML][DOC] Clarifies the difference between spark.ml, spa…
thunterdb Dec 10, 2015
4a46b88
[SPARK-11563][CORE][REPL] Use RpcEnv to transfer REPL-generated classes.
Dec 10, 2015
6a6c1fc
[SPARK-11713] [PYSPARK] [STREAMING] Initial RDD updateStateByKey for …
BryanCutler Dec 10, 2015
23a9e62
[SPARK-12251] Document and improve off-heap memory configurations
JoshRosen Dec 10, 2015
5030923
[SPARK-12155][SPARK-12253] Fix executor OOM in unified memory management
Dec 10, 2015
24d3357
[STREAMING][DOC][MINOR] Update the description of direct Kafka stream…
jerryshao Dec 10, 2015
b1b4ee7
[SPARK-12258][SQL] passing null into ScalaUDF
Dec 11, 2015
518ab51
[SPARK-10991][ML] logistic regression training summary handle empty p…
holdenk Dec 11, 2015
c119a34
[SPARK-12258] [SQL] passing null into ScalaUDF (follow-up)
Dec 11, 2015
0fb9825
[SPARK-12146][SPARKR] SparkR jsonFile should support multiple input f…
yanboliang Dec 11, 2015
aa305dc
[SPARK-11964][DOCS][ML] Add in Pipeline Import/Export Documentation
bllchmbrs Dec 11, 2015
713e695
[SPARK-12273][STREAMING] Make Spark Streaming web UI list Receivers i…
lw-lin Dec 11, 2015
1b82203
[SPARK-11497][MLLIB][PYTHON] PySpark RowMatrix Constructor Has Type E…
dusenberrymw Dec 11, 2015
aea676c
[SPARK-12217][ML] Document invalid handling for StringIndexer
BenFradet Dec 11, 2015
a0ff6d1
[SPARK-11978][ML] Move dataset_example.py to examples/ml and rename t…
yanboliang Dec 12, 2015
1e799d6
[SPARK-12298][SQL] Fix infinite loop in DataFrame.sortWithinPartitions
ankurdave Dec 12, 2015
1e3526c
[SPARK-12158][SPARKR][SQL] Fix 'sample' functions that break R unit t…
gatorsmile Dec 12, 2015
03138b6
[SPARK-11193] Use Java ConcurrentHashMap instead of SynchronizedMap t…
jbonofre Dec 12, 2015
98b212d
[SPARK-12199][DOC] Follow-up: Refine example code in ml-features.md
yinxusen Dec 13, 2015
8af2f8c
[SPARK-12267][CORE] Store the remote RpcEnv address to send the corre…
zsxwing Dec 13, 2015
2aecda2
[SPARK-12281][CORE] Fix a race condition when reporting ExecutorState…
zsxwing Dec 14, 2015
834e714
[SPARK-12213][SQL] use multiple partitions for single distinct query
Dec 14, 2015
ed87f6d
[SPARK-12275][SQL] No plan for BroadcastHint in some condition
Dec 14, 2015
e25f1fe
[MINOR][DOC] Fix broken word2vec link
BenFradet Dec 14, 2015
b51a4cd
[SPARK-12016] [MLLIB] [PYSPARK] Wrap Word2VecModel when loading it in…
viirya Dec 14, 2015
fb3778d
[SPARK-12327] Disable commented code lintr temporarily
shivaram Dec 15, 2015
9ea1a8e
[SPARK-12274][SQL] WrapOption should not have type constraint for child
cloud-fan Dec 15, 2015
d13ff82
[SPARK-12188][SQL][FOLLOW-UP] Code refactoring and comment correction…
gatorsmile Dec 15, 2015
606f99b
[SPARK-12288] [SQL] Support UnsafeRow in Coalesce/Except/Intersect.
gatorsmile Dec 15, 2015
c59df8c
[SPARK-12332][TRIVIAL][TEST] Fix minor typo in ResetSystemProperties
holdenk Dec 15, 2015
bc1ff9f
[STREAMING][MINOR] Fix typo in function name of StateImpl
jerryshao Dec 15, 2015
b24c12d
[MINOR][ML] Rename weights to coefficients for examples/DeveloperApiE…
yanboliang Dec 16, 2015
86ea64d
[SPARK-12271][SQL] Improve error message when Dataset.as[ ] has incom…
nongli Dec 16, 2015
2811265
[SPARK-12236][SQL] JDBC filter tests all pass if filters are not real…
HyukjinKwon Dec 16, 2015
31b3910
[SPARK-12105] [SQL] add convenient show functions
jbonofre Dec 16, 2015
840bd2e
[HOTFIX] Compile error from commit 31b3910
Dec 16, 2015
f725b2e
[SPARK-12056][CORE] Part 2 Create a TaskAttemptContext only after cal…
tedyu Dec 16, 2015
369127f
[SPARK-12130] Replace shuffleManagerClass with shortShuffleMgrNames i…
lianhuiwang Dec 16, 2015
c2de99a
[SPARK-12351][MESOS] Add documentation about submitting Spark with me…
tnachen Dec 16, 2015
a63d9ed
[SPARK-9516][UI] Improvement of Thread Dump Page
CodingCat Dec 16, 2015
765a488
[SPARK-9026][SPARK-4514] Modifications to JobWaiter, FutureAction, an…
reggert Dec 16, 2015
63ccdef
[SPARK-10123][DEPLOY] Support specifying deploy mode from configuration
jerryshao Dec 16, 2015
8a215d2
[SPARK-9886][CORE] Fix to use ShutdownHookManager in
naveenminchu Dec 16, 2015
c5b6b39
[SPARK-12062][CORE] Change Master to asyc rebuild UI when application…
BryanCutler Dec 16, 2015
a89e8b6
[SPARK-10477][SQL] using DSL in ColumnPruningSuite to improve readabi…
cloud-fan Dec 16, 2015
ca0690b
[SPARK-4117][YARN] Spark on Yarn handle AM being told command from RM
Dec 16, 2015
d52bf47
[SPARK-12304][STREAMING] Make Spark Streaming web UI display more fri…
lw-lin Dec 16, 2015
0f6936b
[SPARK-12249][SQL] JDBC non-equality comparison operator not pushed d…
HyukjinKwon Dec 16, 2015
7f443a6
[SPARK-12314][SQL] isnull operator not pushed down for JDBC datasource.
HyukjinKwon Dec 16, 2015
2aad2d3
[SPARK-12315][SQL] isnotnull operator not pushed down for JDBC dataso…
HyukjinKwon Dec 16, 2015
554d840
Style fix for the previous 3 JDBC filter push down commits.
rxin Dec 16, 2015
18ea11c
Revert "[HOTFIX] Compile error from commit 31b3910"
rxin Dec 16, 2015
1a3d0cd
Revert "[SPARK-12105] [SQL] add convenient show functions"
rxin Dec 16, 2015
a6325fc
[SPARK-12324][MLLIB][DOC] Fixes the sidebar in the ML documentation
thunterdb Dec 16, 2015
54c512b
[SPARK-8745] [SQL] remove GenerateProjection
Dec 16, 2015
2eb5af5
[SPARK-12318][SPARKR] Save mode in SparkR should be error by default
zjffdu Dec 16, 2015
22f6cd8
[SPARK-12310][SPARKR] Add write.json and write.parquet for SparkR
yanboliang Dec 16, 2015
26d70bd
[SPARK-12215][ML][DOC] User guide section for KMeans in spark.ml
yu-iskw Dec 16, 2015
ad8c1f0
[SPARK-12345][MESOS] Filter SPARK_HOME when submitting Spark jobs wit…
tnachen Dec 16, 2015
7b6dc29
[SPARK-6518][MLLIB][EXAMPLE][DOC] Add example code and user guide for…
yu-iskw Dec 16, 2015
860dc7f
[SPARK-9694][ML] Add random seed Param to Scala CrossValidator
yanboliang Dec 16, 2015
d252b2d
[SPARK-12309][ML] Use sqlContext from MLlibTestSparkContext for spark…
yanboliang Dec 16, 2015
6a880af
[SPARK-12361][PYSPARK][TESTS] Should set PYSPARK_DRIVER_PYTHON before…
zjffdu Dec 16, 2015
8148cc7
[SPARK-11608][MLLIB][DOC] Added migration guide for MLlib 1.6
jkbradley Dec 16, 2015
1a8b2a1
[SPARK-12364][ML][SPARKR] Add ML example for SparkR
yanboliang Dec 16, 2015
a783a8e
[SPARK-12320][SQL] throw exception if the number of fields does not l…
cloud-fan Dec 16, 2015
edf65cd
[SPARK-12164][SQL] Decode the encoded values and then display
gatorsmile Dec 16, 2015
9657ee8
[SPARK-11677][SQL] ORC filter tests all pass if filters are actually …
HyukjinKwon Dec 16, 2015
3a44aeb
[SPARK-9690][ML][PYTHON] pyspark CrossValidator random seed
mmenestret Dec 16, 2015
27b98e9
[SPARK-12380] [PYSPARK] use SQLContext.getOrCreate in mllib
Dec 16, 2015
861549a
[MINOR] Add missing interpolation in NettyRPCEnv
Dec 17, 2015
ce5fd40
MAINTENANCE: Automated closing of pull requests.
Dec 17, 2015
38d9795
[SPARK-10248][CORE] track exceptions in dagscheduler event loop in tests
squito Dec 17, 2015
f590178
[SPARK-12365][CORE] Use ShutdownHookManager where Runtime.getRuntime.…
tedyu Dec 17, 2015
fdb3822
[SPARK-12186][WEB UI] Send the complete request URI including the que…
Dec 17, 2015
d1508dd
[SPARK-12386][CORE] Fix NPE when spark.executor.port is set.
Dec 17, 2015
97678ed
[SPARK-12390] Clean up unused serializer parameter in BlockManager
Dec 17, 2015
437583f
[SPARK-11904][PYSPARK] reduceByKeyAndWindow does not require checkpoi…
dtolpin Dec 17, 2015
9d66c42
[SPARK-12057][SQL] Prevent failure on corrupt JSON records
yhuai Dec 17, 2015
5a514b6
Once driver register successfully, stop it to connect to master.
echoTomei Dec 17, 2015
cd3d937
Revert "Once driver register successfully, stop it to connect to mast…
davies Dec 17, 2015
a170d34
[SPARK-12395] [SQL] fix resulting columns of outer join
Dec 17, 2015
6e07716
[SQL] Update SQLContext.read.text doc
yanboliang Dec 17, 2015
86e405f
[SPARK-12220][CORE] Make Utils.fetchFile support files that contain s…
zsxwing Dec 17, 2015
8184568
[SPARK-12345][MESOS] Properly filter out SPARK_HOME in the Mesos REST…
dragos Dec 17, 2015
540b5ae
[SPARK-12410][STREAMING] Fix places that use '.' and '|' directly in …
zsxwing Dec 17, 2015
e096a65
[SPARK-12397][SQL] Improve error messages for data sources when they …
rxin Dec 17, 2015
ed6ebda
[SPARK-12376][TESTS] Spark Streaming Java8APISuite fails in assertOrd…
Dec 17, 2015
658f66e
[SPARK-8641][SQL] Native Spark Window functions
hvanhovell Dec 17, 2015
cdde93d
Messos scheduler does not respect all args from the Submit request
jayv Nov 17, 2015
File filter

Filter by extension

Filter by extension


Conversations
Failed to load comments.
Loading
Jump to
The table of contents is too big for display.
Diff view
Diff view
  •  
  •  
  •  
5 changes: 5 additions & 0 deletions .gitignore
Original file line number Diff line number Diff line change
Expand Up @@ -50,6 +50,7 @@ spark-tests.log
streaming-tests.log
dependency-reduced-pom.xml
.ensime
.ensime_cache/
.ensime_lucene
checkpoint
derby.log
Expand All @@ -74,3 +75,7 @@ metastore/
warehouse/
TempStatsStore/
sql/hive-thriftserver/test_warehouses

# For R session data
.RHistory
.RData
15 changes: 3 additions & 12 deletions .rat-excludes
Original file line number Diff line number Diff line change
Expand Up @@ -15,20 +15,8 @@ TAGS
RELEASE
control
docs
docker.properties.template
fairscheduler.xml.template
spark-defaults.conf.template
log4j.properties
log4j.properties.template
metrics.properties
metrics.properties.template
slaves
slaves.template
spark-env.sh
spark-env.cmd
spark-env.sh.template
log4j-defaults.properties
log4j-defaults-repl.properties
bootstrap-tooltip.js
jquery-1.11.1.min.js
d3.min.js
Expand Down Expand Up @@ -93,3 +81,6 @@ INDEX
.lintr
gen-java.*
.*avpr
org.apache.spark.sql.sources.DataSourceRegister
org.apache.spark.scheduler.SparkHistoryListenerFactory
.*parquet
714 changes: 27 additions & 687 deletions LICENSE

Large diffs are not rendered by default.

42 changes: 42 additions & 0 deletions NOTICE
Original file line number Diff line number Diff line change
Expand Up @@ -572,3 +572,45 @@ Copyright 2009-2013 The Apache Software Foundation

Apache Avro IPC
Copyright 2009-2013 The Apache Software Foundation


Vis.js
Copyright 2010-2015 Almende B.V.

Vis.js is dual licensed under both

* The Apache 2.0 License
http://www.apache.org/licenses/LICENSE-2.0

and

* The MIT License
http://opensource.org/licenses/MIT

Vis.js may be distributed under either license.


Vis.js uses and redistributes the following third-party libraries:

- component-emitter
https://github.com/component/emitter
The MIT License

- hammer.js
http://hammerjs.github.io/
The MIT License

- moment.js
http://momentjs.com/
The MIT License

- keycharm
https://github.com/AlexDM0/keycharm
The MIT License

===============================================================================

The CSS style for the navigation sidebar of the documentation was originally
submitted by Óscar Nájera for the scikit-learn project. The scikit-learn project
is distributed under the 3-Clause BSD license.
===============================================================================
2 changes: 1 addition & 1 deletion R/create-docs.sh
Original file line number Diff line number Diff line change
Expand Up @@ -39,7 +39,7 @@ pushd $FWDIR
mkdir -p pkg/html
pushd pkg/html

Rscript -e 'library(SparkR, lib.loc="../../lib"); library(knitr); knit_rd("SparkR")'
Rscript -e 'libDir <- "../../lib"; library(SparkR, lib.loc=libDir); library(knitr); knit_rd("SparkR", links = tools::findHTMLlinks(paste(libDir, "SparkR", sep="/")))'

popd

Expand Down
1 change: 1 addition & 0 deletions R/install-dev.bat
Original file line number Diff line number Diff line change
Expand Up @@ -30,3 +30,4 @@ rem Zip the SparkR package so that it can be distributed to worker nodes on YARN
pushd %SPARK_HOME%\R\lib
%JAVA_HOME%\bin\jar.exe cfM "%SPARK_HOME%\R\lib\sparkr.zip" SparkR
popd

2 changes: 1 addition & 1 deletion R/pkg/.lintr
Original file line number Diff line number Diff line change
@@ -1,2 +1,2 @@
linters: with_defaults(line_length_linter(100), camel_case_linter = NULL, open_curly_linter(allow_single_line = TRUE), closed_curly_linter(allow_single_line = TRUE))
linters: with_defaults(line_length_linter(100), camel_case_linter = NULL, open_curly_linter(allow_single_line = TRUE), closed_curly_linter(allow_single_line = TRUE), commented_code_linter = NULL)
exclusions: list("inst/profile/general.R" = 1, "inst/profile/shell.R")
5 changes: 4 additions & 1 deletion R/pkg/DESCRIPTION
Original file line number Diff line number Diff line change
@@ -1,7 +1,7 @@
Package: SparkR
Type: Package
Title: R frontend for Spark
Version: 1.4.0
Version: 1.6.0
Date: 2013-09-09
Author: The Apache Software Foundation
Maintainer: Shivaram Venkataraman <[email protected]>
Expand Down Expand Up @@ -29,7 +29,10 @@ Collate:
'client.R'
'context.R'
'deserialize.R'
'functions.R'
'mllib.R'
'serialize.R'
'sparkR.R'
'stats.R'
'types.R'
'utils.R'
135 changes: 129 additions & 6 deletions R/pkg/NAMESPACE
Original file line number Diff line number Diff line change
Expand Up @@ -23,10 +23,18 @@ export("setJobGroup",
exportClasses("DataFrame")

exportMethods("arrange",
"as.data.frame",
"attach",
"cache",
"collect",
"colnames",
"colnames<-",
"coltypes",
"coltypes<-",
"columns",
"count",
"cov",
"corr",
"crosstab",
"describe",
"dim",
Expand All @@ -38,6 +46,7 @@ exportMethods("arrange",
"fillna",
"filter",
"first",
"freqItems",
"group_by",
"groupBy",
"head",
Expand All @@ -47,12 +56,13 @@ exportMethods("arrange",
"join",
"limit",
"merge",
"mutate",
"na.omit",
"names",
"names<-",
"ncol",
"nrow",
"orderBy",
"mutate",
"names",
"persist",
"printSchema",
"rbind",
Expand All @@ -61,6 +71,7 @@ exportMethods("arrange",
"repartition",
"sample",
"sample_frac",
"sampleBy",
"saveAsParquetFile",
"saveAsTable",
"saveDF",
Expand All @@ -69,88 +80,200 @@ exportMethods("arrange",
"selectExpr",
"show",
"showDF",
"subset",
"summarize",
"summary",
"take",
"transform",
"unionAll",
"unique",
"unpersist",
"where",
"with",
"withColumn",
"withColumnRenamed",
"write.df")
"write.df",
"write.json",
"write.parquet")

exportClasses("Column")

exportMethods("abs",
exportMethods("%in%",
"abs",
"acos",
"add_months",
"alias",
"approxCountDistinct",
"array_contains",
"asc",
"ascii",
"asin",
"atan",
"atan2",
"avg",
"base64",
"between",
"bin",
"bitwiseNOT",
"cast",
"cbrt",
"ceil",
"ceiling",
"column",
"concat",
"concat_ws",
"contains",
"conv",
"cos",
"cosh",
"count",
"countDistinct",
"crc32",
"cume_dist",
"date_add",
"date_format",
"date_sub",
"datediff",
"dayofmonth",
"dayofyear",
"decode",
"dense_rank",
"desc",
"encode",
"endsWith",
"exp",
"explode",
"expm1",
"expr",
"factorial",
"first",
"floor",
"format_number",
"format_string",
"from_unixtime",
"from_utc_timestamp",
"getField",
"getItem",
"greatest",
"hex",
"hour",
"hypot",
"ifelse",
"initcap",
"instr",
"isNaN",
"isNotNull",
"isNull",
"kurtosis",
"lag",
"last",
"last_day",
"lead",
"least",
"length",
"levenshtein",
"like",
"lit",
"locate",
"log",
"log10",
"log1p",
"log2",
"lower",
"lpad",
"ltrim",
"max",
"md5",
"mean",
"min",
"minute",
"month",
"months_between",
"n",
"n_distinct",
"nanvl",
"negate",
"next_day",
"ntile",
"otherwise",
"percent_rank",
"pmod",
"quarter",
"rand",
"randn",
"rank",
"regexp_extract",
"regexp_replace",
"reverse",
"rint",
"rlike",
"round",
"row_number",
"rpad",
"rtrim",
"second",
"sha1",
"sha2",
"shiftLeft",
"shiftRight",
"shiftRightUnsigned",
"sd",
"sign",
"signum",
"sin",
"sinh",
"size",
"skewness",
"sort_array",
"soundex",
"stddev",
"stddev_pop",
"stddev_samp",
"struct",
"sqrt",
"startsWith",
"substr",
"substring_index",
"sum",
"sumDistinct",
"tan",
"tanh",
"toDegrees",
"toRadians",
"upper")
"to_date",
"to_utc_timestamp",
"translate",
"trim",
"unbase64",
"unhex",
"unix_timestamp",
"upper",
"var",
"variance",
"var_pop",
"var_samp",
"weekofyear",
"when",
"year")

exportClasses("GroupedData")
exportMethods("agg")

export("sparkRSQL.init",
"sparkRHive.init")

export("cacheTable",
export("as.DataFrame",
"cacheTable",
"clearCache",
"createDataFrame",
"createExternalTable",
"dropTempTable",
"jsonFile",
"read.json",
"loadDF",
"parquetFile",
"read.df",
"read.parquet",
"sql",
"table",
"tableNames",
Expand Down
Loading