Skip to content
Closed
Show file tree
Hide file tree
Changes from all commits
Commits
Show all changes
5455 commits
Select commit Hold shift + click to select a range
18ee55d
[SPARK-19148][SQL] do not expose the external table concept in Catalog
cloud-fan Jan 17, 2017
84f0b64
[MINOR][YARN] Move YarnSchedulerBackendSuite to resource-managers/yar…
yanboliang Jan 17, 2017
a774bca
[SPARK-19240][SQL][TEST] add test for setting location for managed table
cloud-fan Jan 17, 2017
0019005
[SPARK-19219][SQL] Fix Parquet log output defaults
nicklavers Jan 17, 2017
6c00c06
[SPARK-3249][DOC] Fix links in ScalaDoc that cause warning messages i…
HyukjinKwon Jan 17, 2017
b79cc7c
[SPARK-19179][YARN] Change spark.yarn.access.namenodes config and upd…
jerryshao Jan 17, 2017
20e6280
[SPARK-19019] [PYTHON] Fix hijacked `collections.namedtuple` and port…
HyukjinKwon Jan 17, 2017
a83accf
[SPARK-19065][SQL] Don't inherit expression id in dropDuplicates
zsxwing Jan 17, 2017
a23debd
[SPARK-19129][SQL] SessionCatalog: Disallow empty part col values in …
gatorsmile Jan 17, 2017
843ec8e
[SPARK-19239][PYSPARK] Check parameters whether equals None when spec…
Jan 17, 2017
fee20df
[MINOR][SQL] Remove duplicate call of reset() function in CurrentOrig…
jiangxb1987 Jan 17, 2017
83dff87
[SPARK-18917][SQL] Remove schema check in appending data
rxin Jan 17, 2017
2992a0e
[SPARK-13721][SQL] Support outer generators in DataFrame API
Jan 17, 2017
e7f982b
[SPARK-18206][ML] Add instrumentation for MLP,NB,LDA,AFT,GLM,Isotonic…
zhengruifeng Jan 17, 2017
4494cd9
[SPARK-18243][SQL] Port Hive writing to use FileFormat interface
cloud-fan Jan 18, 2017
eefdf9f
[SPARK-19227][SPARK-19251] remove unused imports and outdated comments
uncleGen Jan 18, 2017
17ce0b5
[SPARK-18782][BUILD] Bump Hadoop 2.6 version to use Hadoop 2.6.5
a-roberts Jan 18, 2017
f85f296
[SPARK-19024][SQL] Implement new approach to write a permanent view
jiangxb1987 Jan 18, 2017
d06172b
[SPARK-19223][SQL][PYSPARK] Fix InputFileBlockHolder for datasources …
viirya Jan 18, 2017
278fa1e
[SPARK-19231][SPARKR] add error handling for download and untar for S…
felixcheung Jan 18, 2017
33791a8
[SPARK-18113] Use ask to replace askWithRetry in canCommit and make r…
Jan 18, 2017
c050c12
[SPARK-19113][SS][TESTS] Ignore StreamingQueryException thrown from a…
zsxwing Jan 18, 2017
569e506
[SPARK-19168][STRUCTURED STREAMING] StateStore should be aborted upon…
lw-lin Jan 18, 2017
a81e336
[SPARK-19182][DSTREAM] Optimize the lock in StreamingJobProgressListe…
uncleGen Jan 18, 2017
fe409f3
[SPARK-14975][ML] Fixed GBTClassifier to predict probability per trai…
imatiach-msft Jan 18, 2017
0c92318
Update known_translations for contributor names
yhuai Jan 19, 2017
2e62560
[SPARK-19265][SQL] make table relation cache general and does not dep…
cloud-fan Jan 19, 2017
8ccca91
[SPARK-14272][ML] Add Loglikelihood in GaussianMixtureSummary
zhengruifeng Jan 19, 2017
064fadd
[SPARK-19059][SQL] Unable to retrieve data from parquet table whose n…
jayadevanmurali Jan 19, 2017
640f942
[SPARK-16654][CORE] Add UI coverage for Application Level Blacklisting
Jan 19, 2017
63d8390
[SPARK-19295][SQL] IsolatedClientLoader's downloadVersion should log …
yhuai Jan 19, 2017
148a84b
[SPARK-17912] [SQL] Refactor code generation to get data for ColumnVe…
kiszk Jan 19, 2017
0bf605c
[SPARK-19292][SQL] filter with partition columns should be case-insen…
cloud-fan Jan 20, 2017
039ed9f
[SPARK-19271][SQL] Change non-cbo estimation of aggregate
Jan 20, 2017
d50d12b
[SPARK-19302][DOC][MINOR] Fix the wrong item format in security.md
sarutak Jan 20, 2017
e20d9b1
[SPARK-19069][CORE] Expose task 'status' and 'duration' in spark hist…
Jan 20, 2017
552e5f0
[SPARK-19314][SS][CATALYST] Do not allow sort before aggregation in S…
tdas Jan 20, 2017
9b7a03f
[SPARK-18589][SQL] Fix Python UDF accessing attributes from both side…
Jan 21, 2017
ea31f92
[SPARK-19267][SS] Fix a race condition when stopping StateStore
zsxwing Jan 21, 2017
54268b4
[SPARK-16101][SQL] Refactoring CSV write path to be consistent with J…
HyukjinKwon Jan 21, 2017
f174cdc
[SPARK-14536][SQL] fix to handle null value in array type column for …
sureshthalamati Jan 21, 2017
3c2ba9f
[SPARK-19305][SQL] partitioned table should always put partition colu…
cloud-fan Jan 21, 2017
bcdabaa
[SPARK-17724][STREAMING][WEBUI] Unevaluated new lines in tooltip in D…
keypointt Jan 21, 2017
6113fe7
[SPARK-19117][SPARK-18922][TESTS] Fix the rest of flaky, newly introd…
HyukjinKwon Jan 21, 2017
aa014eb
[SPARK-19153][SQL] DataFrameWriter.saveAsTable work with create parti…
windpiger Jan 22, 2017
3dcad9f
[SPARK-19155][ML] MLlib GeneralizedLinearRegression family and link s…
yanboliang Jan 22, 2017
0c589e3
[SPARK-19291][SPARKR][ML] spark.gaussianMixture supports output log-l…
yanboliang Jan 22, 2017
74e65cb
[SPARK-16101][SQL] Refactoring CSV read path to be consistent with JS…
HyukjinKwon Jan 23, 2017
772035e
[SPARK-19229][SQL] Disallow Creating Hive Source Tables when Hive Sup…
gatorsmile Jan 23, 2017
de6ad3d
[SPARK-19309][SQL] disable common subexpression elimination for condi…
cloud-fan Jan 23, 2017
f067ace
[SPARK-19155][ML] Make family case insensitive in GLM
actuaryzhang Jan 23, 2017
c4a6519
[SPARK-19218][SQL] Fix SET command to show a result correctly and in …
dongjoon-hyun Jan 23, 2017
c994921
[SPARK-19146][CORE] Drop more elements when stageData.taskData.size >…
wangyum Jan 23, 2017
0ef1421
[SPARK-19284][SQL] append to partitioned datasource table should with…
windpiger Jan 23, 2017
4a11d02
[SPARK-14709][ML] spark.ml API for linear SVM
YY-OnCall Jan 23, 2017
c8aea74
[SPARK-17455][MLLIB] Improve PAVA implementation in IsotonicRegression
neggert Jan 23, 2017
5b258b8
[SPARK-16473][MLLIB] Fix BisectingKMeans Algorithm failing in edge case
imatiach-msft Jan 23, 2017
e497472
[SPARK-19306][CORE] Fix inconsistent state in DiskBlockObject when ex…
jerryshao Jan 23, 2017
49f5b0a
[SPARK-17747][ML] WeightCol support non-double numeric datatypes
zhengruifeng Jan 24, 2017
fcfd5d0
[SPARK-19290][SQL] add a new extending interface in Analyzer for post…
cloud-fan Jan 24, 2017
3bdf3ee
[SPARK-19272][SQL] Remove the param `viewOriginalText` from `CatalogT…
jiangxb1987 Jan 24, 2017
e576c1e
[SPARK-9435][SQL] Reuse function in Java UDF to correctly support exp…
HyukjinKwon Jan 24, 2017
60bd91a
[SPARK-19268][SS] Disallow adaptive query execution for streaming que…
zsxwing Jan 24, 2017
ec9493b
[SPARK-16101][HOTFIX] Fix the build with Scala 2.10 by explicit typed…
HyukjinKwon Jan 24, 2017
f27e024
[SPARK-18823][SPARKR] add support for assigning to column
felixcheung Jan 24, 2017
7c61c2a
[DOCS] Fix typo in docs
uncleGen Jan 24, 2017
cca8680
delete useless var “j”
xiaoyesoso Jan 24, 2017
3c86fdd
[SPARK-19152][SQL] DataFrameWriter.saveAsTable support hive append
windpiger Jan 24, 2017
752502b
[SPARK-19246][SQL] CataLogTable's partitionSchema order and exist check
windpiger Jan 24, 2017
0ff67a1
[SPARK-14049][CORE] Add functionality in spark history sever API to q…
Jan 24, 2017
59c184e
[SPARK-17913][SQL] compare atomic and string type column may return c…
cloud-fan Jan 24, 2017
d978338
[SPARK-18036][ML][MLLIB] Fixing decision trees handling edge cases
imatiach-msft Jan 24, 2017
8f3f73a
[SPARK-19139][CORE] New auth mechanism for transport library.
Jan 24, 2017
cdb691e
[SPARK-19017][SQL] NOT IN subquery with more than one column may retu…
nsyca Jan 24, 2017
15ef374
[SPARK-19334][SQL] Fix the code injection vulnerability related to Ge…
sarutak Jan 24, 2017
40a4cfc
[SPARK-19330][DSTREAMS] Also show tooltip for successful batches
lw-lin Jan 25, 2017
3fdce81
[SPARK-16046][DOCS] Aggregations in the Spark SQL programming guide
Jan 25, 2017
76db394
[SPARK-18750][YARN] Avoid using "mapValues" when allocating containers.
Jan 25, 2017
0e821ec
[SPARK-19313][ML][MLLIB] GaussianMixture should limit the number of f…
sethah Jan 25, 2017
f1ddca5
[SPARK-18863][SQL] Output non-aggregate expressions without GROUP BY …
nsyca Jan 25, 2017
f6480b1
[SPARK-19311][SQL] fix UDT hierarchy issue
Jan 25, 2017
92afaa9
[SPARK-19307][PYSPARK] Make sure user conf is propagated to SparkCont…
Jan 25, 2017
965c82d
[SPARK-19064][PYSPARK] Fix pip installing of sub components
holdenk Jan 25, 2017
47d5d0d
[SPARK-14804][SPARK][GRAPHX] Fix checkpointing of VertexRDD/EdgeRDD
tdas Jan 26, 2017
2338451
[SPARK-18495][UI] Document meaning of green dot in DAG visualization
uncleGen Jan 26, 2017
256a3a8
[SPARK-18020][STREAMING][KINESIS] Checkpoint SHARD_END to finish read…
maropu Jan 26, 2017
9effc2c
[TESTS][SQL] Setup testdata at the beginning for tests to run indepen…
dilipbiswal Jan 26, 2017
d3dcb63
[SPARK-19220][UI] Make redirection to HTTPS apply to all URIs.
Jan 26, 2017
7045b8b
[CORE][DOCS] Update a help message for --files in spark-submit
maropu Jan 26, 2017
2969fb4
[SPARK-18936][SQL] Infrastructure for session local timezone support.
ueshin Jan 26, 2017
9f523d3
[SPARK-19338][SQL] Add UDF names in explain
maropu Jan 26, 2017
1191fe2
[SPARK-18218][ML][MLLIB] Reduce shuffled data size of BlockMatrix mul…
WeichenXu123 Jan 27, 2017
c0ba284
[SPARK-18821][SPARKR] Bisecting k-means wrapper in SparkR
wangmiao1981 Jan 27, 2017
90817a6
[SPARK-18788][SPARKR] Add API for getNumPartitions
felixcheung Jan 27, 2017
4172ff8
[SPARK-18929][ML] Add Tweedie distribution in GLM
actuaryzhang Jan 27, 2017
4e35c5a
[SPARK-12970][DOCS] Fix the example in SturctType APIs for Scala and …
HyukjinKwon Jan 27, 2017
385d738
[SPARK-19333][SPARKR] Add Apache License headers to R files
felixcheung Jan 27, 2017
a7ab6f9
[SPARK-19324][SPARKR] Spark VJM stdout output is getting dropped in S…
felixcheung Jan 27, 2017
21aa8c3
[SPARK-19365][CORE] Optimize RequestMessage serialization
zsxwing Jan 27, 2017
bb1a1fe
[SPARK-19336][ML][PYSPARK] LinearSVC Python API
wangmiao1981 Jan 28, 2017
1b5ee20
[SPARK-19359][SQL] clear useless path after rename a partition with u…
windpiger Jan 28, 2017
42ad93b
[SPARK-19384][ML] forget unpersist input dataset in IsotonicRegression
zhengruifeng Jan 28, 2017
cfcfc92
[SPARK-19359][SQL] Revert Clear useless path after rename a partition…
gatorsmile Jan 28, 2017
f7c07db
[SPARK-19152][SQL][FOLLOWUP] simplify CreateHiveTableAsSelectCommand
cloud-fan Jan 29, 2017
e2e7b12
[SPARK-18872][SQL][TESTS] New test cases for EXISTS subquery
dilipbiswal Jan 29, 2017
ade075a
[SPARK-19385][SQL] During canonicalization, `NOT(...(l, r))` should n…
lw-lin Jan 29, 2017
06fbc35
[SPARK-19403][PYTHON][SQL] Correct pyspark.sql.column.__all__ list.
zero323 Jan 30, 2017
c0eda7e
[SPARK-19396][DOC] JDBC Options are Case In-sensitive
gatorsmile Jan 30, 2017
f9156d2
[SPARK-19406][SQL] Fix function to_json to respect user-provided options
gatorsmile Jan 31, 2017
be7425e
[SPARKR][DOCS] update R API doc for subset/extract
felixcheung Jan 31, 2017
26a4cba
[SPARK-19409][BUILD] Bump parquet version to 1.8.2
dongjoon-hyun Jan 31, 2017
ce112ce
[SPARK-19395][SPARKR] Convert coefficients in summary to matrix
actuaryzhang Jan 31, 2017
57d70d2
[SPARK-17161][PYSPARK][ML] Add PySpark-ML JavaWrapper convenience fun…
BryanCutler Jan 31, 2017
081b7ad
[SPARK-19378][SS] Ensure continuity of stateOperator and eventTime me…
brkyvz Feb 1, 2017
9063835
[SPARK-19163][PYTHON][SQL] Delay _judf initialization to the __call__
zero323 Feb 1, 2017
9ac0522
[SPARK-19319][SPARKR] SparkR Kmeans summary returns error when the cl…
wangmiao1981 Feb 1, 2017
f1a1f26
[SPARK-19402][DOCS] Support LaTex inline formula correctly and fix wa…
HyukjinKwon Feb 1, 2017
04ee8cf
[SPARK-19410][DOC] Fix brokens links in ml-pipeline and ml-tuning
zhengruifeng Feb 1, 2017
5ed397b
[SPARK-19296][SQL] Deduplicate url and table in JdbcUtils
HyukjinKwon Feb 1, 2017
df4a27c
[SPARK-19377][WEBUI][CORE] Killed tasks should have the status as KILLED
Feb 1, 2017
c5fcb7f
[SPARK-19347] ReceiverSupervisorImpl can add block to ReceiverTracker…
Feb 1, 2017
b098576
[SPARK-14352][SQL] approxQuantile should support multi columns
zhengruifeng Feb 1, 2017
8303e20
[SPARK-19432][CORE] Fix an unexpected failure when connecting timeout
zsxwing Feb 2, 2017
1d5d2a9
[SPARK-19389][ML][PYTHON][DOC] Minor doc fixes for ML Python Params a…
jkbradley Feb 2, 2017
c86a57f
[SPARK-19437] Rectify spark executor id in HeartbeatReceiverSuite.
Feb 3, 2017
bf49368
[SPARK-19411][SQL] Remove the metadata used to mark optional columns …
viirya Feb 3, 2017
20b4ca1
[BUILD] Close stale PRs
srowen Feb 3, 2017
52d4f61
[SPARK-18909][SQL] The error messages in `ExpressionEncoder.toRow/fro…
dongjoon-hyun Feb 3, 2017
2f523fa
[SPARK-19244][CORE] Sort MemoryConsumers according to their memory us…
viirya Feb 3, 2017
48aafed
[SPARK-19386][SPARKR][DOC] Bisecting k-means in SparkR documentation
krishnakalyan3 Feb 3, 2017
050c20c
[SPARK-19386][SPARKR][FOLLOWUP] fix error in vignettes
actuaryzhang Feb 4, 2017
22d4aae
[SPARK-10063] Follow-up: remove dead code related to an old output co…
rxin Feb 4, 2017
2f3c20b
[SPARK-19446][SQL] Remove unused findTightestCommonType in TypeCoercion
HyukjinKwon Feb 4, 2017
0674e7e
[SPARK-19425][SQL] Make ExtractEquiJoinKeys support UDT columns
viirya Feb 4, 2017
b94f4b6
[SPARK-19452][SPARKR] Fix bug in the name assignment method
actuaryzhang Feb 5, 2017
b3e8980
[SPARK-19247][ML] Save large word2vec models
Feb 6, 2017
317fa75
[SPARK-19421][ML][PYSPARK] Remove numClasses and numFeatures methods …
zhengruifeng Feb 6, 2017
65b10ff
[SPARK-19279][SQL] Infer Schema for Hive Serde Tables and Block Creat…
gatorsmile Feb 6, 2017
7730426
[SPARK-19409][SPARK-17213] Cleanup Parquet workarounds/hacks due to b…
liancheng Feb 6, 2017
7beb227
[SPARK-17663][CORE] SchedulableBuilder should handle invalid data acc…
erenavsarogullari Feb 6, 2017
0f16ff5
[SPARK-17213][SQL][FOLLOWUP] Re-enable Parquet filter tests for binar…
HyukjinKwon Feb 6, 2017
aff5302
[SPARK-19080][SQL] simplify data source analysis
cloud-fan Feb 6, 2017
d33021b
[SPARK-19398] Change one misleading log in TaskSetManager.
Feb 6, 2017
cb2677b
[SPARK-19472][SQL] Parser should not mistake CASE WHEN(...) for a fun…
hvanhovell Feb 6, 2017
d6dc603
[SPARK-19441][SQL] Remove IN type coercion from PromoteStrings
gatorsmile Feb 7, 2017
fab0d62
[SPARK-19467][ML][PYTHON] Remove cyclic imports from pyspark.ml.pipeline
zero323 Feb 7, 2017
7a0a630
[SPARK-19407][SS] defaultFS is used FileSystem.get instead of getting…
uncleGen Feb 7, 2017
d904309
[SPARK-18967][SCHEDULER] compute locality levels even if delay = 0
squito Feb 7, 2017
a97edc2
[SPARK-18601][SQL] Simplify Create/Get complex expression pairs in op…
Feb 7, 2017
aee2bd2
[SPARK-19444][ML][DOCUMENTATION] Fix imports not being present in doc…
anshbansal Feb 7, 2017
8fd178d
[SPARK-19260] Spaces or "%20" in path parameter are not correctly han…
Feb 7, 2017
3d314d0
[SPARK-16101][SQL] Refactoring CSV schema inference path to be consis…
HyukjinKwon Feb 7, 2017
e99e34d
[SPARK-19118][SQL] Percentile support for frequency distribution table
Feb 7, 2017
6ed285c
[SPARK-19447] Fixing input metrics for range operator.
ala Feb 7, 2017
7a7ce27
[SPARK-16609] Add to_date/to_timestamp with format functions
bllchmbrs Feb 7, 2017
b7277e0
[SPARK-19495][SQL] Make SQLConf slightly more extensible
rxin Feb 7, 2017
73ee739
[SPARK-18609][SPARK-18841][SQL] Fix redundant Alias removal in the op…
hvanhovell Feb 7, 2017
8df4444
[SPARK-18682][SS] Batch Source for Kafka
Feb 7, 2017
e33aaa2
[SPARK-19397][SQL] Make option names of LIBSVM and TEXT case insensitive
gatorsmile Feb 8, 2017
aeb8034
[SPARK-19413][SS] MapGroupsWithState for arbitrary stateful operations
tdas Feb 8, 2017
d4cd975
[SPARK-19499][SS] Add more notes in the comments of Sink.addBatch()
CodingCat Feb 8, 2017
266c1e7
[SPARK-18873][SQL][TEST] New test cases for scalar subquery (part 1 o…
nsyca Feb 8, 2017
5a0569c
[MINOR][DOC] Remove parenthesis in readStream() on kafka structured s…
manugarri Feb 8, 2017
d60dde2
[SPARK-19488][SQL] fix csv infer schema when the field is Nan/Inf etc
windpiger Feb 8, 2017
e8d3fca
[SPARK-19464][CORE][YARN][TEST-HADOOP2.6] Remove support for Hadoop 2…
srowen Feb 8, 2017
0077bfc
[SPARK-19409][BUILD][TEST-MAVEN] Fix ParquetAvroCompatibilitySuite fa…
dongjoon-hyun Feb 8, 2017
4d4d0de
[SPARK-19279][SQL][FOLLOW-UP] Infer Schema for Hive Serde Tables
gatorsmile Feb 8, 2017
15627ac
[SPARK-19464][BUILD][HOTFIX][TEST-HADOOP2.6] Add back mockito test de…
srowen Feb 8, 2017
1aeb9f6
[SPARK-19400][ML] Allow GLM to handle intercept only model
actuaryzhang Feb 8, 2017
c618ccd
[SPARK-19464][BUILD][HOTFIX] run-tests should use hadoop2.6
dongjoon-hyun Feb 8, 2017
64cae22
[SPARK-18872][SQL][TESTS] New test cases for EXISTS subquery (Aggrega…
dilipbiswal Feb 9, 2017
50a9912
[SPARK-19359][SQL] renaming partition should not leave useless direct…
cloud-fan Feb 9, 2017
9d9d67c
[SPARK-19265][SQL][FOLLOW-UP] Configurable `tableRelationCache` maxim…
lw-lin Feb 9, 2017
1a09cd6
[MINOR][CORE] Fix incorrect documentation of WritableConverter
dongjinleekr Feb 9, 2017
3fc8e8c
[SPARK-17874][CORE] Add SSL port configuration.
Feb 9, 2017
4064574
[SPARK-19514] Making range interruptible.
ala Feb 9, 2017
1af0dee
[SPARK-19512][SQL] codegen for compare structs fails
Feb 9, 2017
af63c52
[SPARK-19025][SQL] Remove SQL builder for operators
jiangxb1987 Feb 9, 2017
6287c94
[SPARK-16554][CORE] Automatically Kill Executors and Nodes when they …
Feb 9, 2017
303f00a
[SPARK-19481] [REPL] [MAVEN] Avoid to leak SparkContext in Signaling.…
zsxwing Feb 9, 2017
fd6c3a0
[SPARK-19263] Fix race in SchedulerIntegrationSuite.
Feb 10, 2017
d5593f7
[SPARK-19543] from_json fails when the input row is empty
brkyvz Feb 10, 2017
8e8afb3
[SPARK-19545][YARN] Fix compile issue for Spark on Yarn when building…
jerryshao Feb 10, 2017
8640dc0
[SPARK-10748][MESOS] Log error instead of crashing Spark Mesos dispat…
Feb 10, 2017
c5a6635
Encryption of shuffle files
dud225 Feb 10, 2017
dadff5f
[SPARK-19466][CORE][SCHEDULER] Improve Fair Scheduler Logging
erenavsarogullari Feb 10, 2017
de8a03e
[SPARK-19459][SQL] Add Hive datatype (char/varchar) to StructField me…
hvanhovell Feb 10, 2017
3a43ae7
[SPARK-18613][ML] make spark.mllib LDA dependencies in spark.ml LDA p…
sueann Feb 10, 2017
d785217
[SPARK-19549] Allow providing reason for stage/job cancelling
ala Feb 10, 2017
226d388
[SPARK-19548][SQL] Support Hive UDFs which return typed Lists/Maps
hvanhovell Feb 10, 2017
0fbecc7
[SPARK-19537] Move pendingPartitions to ShuffleMapStage.
kayousterhout Feb 11, 2017
3881f34
[SPARK-19448][SQL] optimize some duplication functions between HiveCl…
windpiger Feb 12, 2017
bc0a0e6
[SPARK-19342][SPARKR] bug fixed in collect method for collecting time…
titicaca Feb 12, 2017
2bdbc87
[SPARK-19564][SPARK-19559][SS][KAFKA] KafkaOffsetReader's consumers s…
lw-lin Feb 13, 2017
855a1b7
[SPARK-19574][ML][DOCUMENTATION] Fix Liquid Exception: Start indices …
gatorsmile Feb 13, 2017
8f03ad5
[SPARK-19562][BUILD] Added exclude for dev/pr-deps to gitignore
original-brownbear Feb 13, 2017
04ad822
[SPARK-19496][SQL] to_date udf to return null when input date is invalid
windpiger Feb 13, 2017
4321ff9
[SPARK-19544][SQL] Improve error message when some column types are c…
HyukjinKwon Feb 13, 2017
5e7cd33
[SPARK-19506][ML][PYTHON] Import warnings in pyspark.ml.util
zero323 Feb 13, 2017
ab88b24
[SPARK-19427][PYTHON][SQL] Support data type string as a returnType a…
zero323 Feb 13, 2017
1c4d10b
[SPARK-19529] TransportClientFactory.createClient() shouldn't call aw…
JoshRosen Feb 13, 2017
0417ce8
[SPARK-19514] Enhancing the test for Range interruption.
ala Feb 13, 2017
3dbff9b
[SPARK-19542][SS] Delete the temp checkpoint if a query is stopped wi…
zsxwing Feb 13, 2017
905fdf0
[SPARK-17714][CORE][TEST-MAVEN][TEST-HADOOP2.6] Avoid using ExecutorC…
zsxwing Feb 13, 2017
9af8f74
[SPARK-19435][SQL] Type coercion between ArrayTypes
HyukjinKwon Feb 13, 2017
0169360
[SPARK-19520][STREAMING] Do not encrypt data written to the WAL.
Feb 13, 2017
e02ac30
[SPARK-19429][PYTHON][SQL] Support slice arguments in Column.__getitem__
zero323 Feb 13, 2017
6e45b54
[SPARK-19115][SQL] Supporting Create Table Like Location
Feb 14, 2017
1ab9731
[SPARK-19539][SQL] Block duplicate temp table during creation
xwu0226 Feb 14, 2017
9b5e460
[SPARK-19585][DOC][SQL] Fix the cacheTable and uncacheTable api call …
skambha Feb 14, 2017
457850e
[SPARK-19589][SQL] Removal of SQLGEN files
gatorsmile Feb 14, 2017
9c4405e
[SPARK-19453][PYTHON][SQL][DOC] Correct and extend DataFrame.replace …
zero323 Feb 14, 2017
e0eeb0f
[SPARK-19162][PYTHON][SQL] UserDefinedFunction should validate that f…
zero323 Feb 14, 2017
7b64f7a
[SPARK-18541][PYTHON] Add metadata parameter to pyspark.sql.Column.al…
shea-parkes Feb 14, 2017
f776e3b
[SPARK-19571][R] Fix SparkR test break on Windows via AppVeyor
HyukjinKwon Feb 14, 2017
ab9872d
[SPARK-19501][YARN] Reduce the number of HDFS RPCs during YARN deploy…
jongwook Feb 14, 2017
a3626ca
[SPARK-19387][SPARKR] Tests do not run with SparkR source package in …
felixcheung Feb 14, 2017
da7aef7
[SPARK-16475][SQL] Broadcast hint for SQL Queries
rxin Feb 14, 2017
f48c5a5
[SPARK-19318][SQL] Fix to treat JDBC connection properties specified …
sureshthalamati Feb 14, 2017
447b2b5
[SPARK-19584][SS][DOCS] update structured streaming documentation aro…
Feb 15, 2017
3973403
[SPARK-19456][SPARKR] Add LinearSVC R API
wangmiao1981 Feb 15, 2017
b55563c
[SPARK-19607] Finding QueryExecution that matches provided executionId
ala Feb 15, 2017
733c59e
[SPARK-16475][SQL] broadcast hint for SQL queries - follow up
rxin Feb 15, 2017
8b75f8c
[SPARK-19587][SQL] bucket sorting columns should not be picked from p…
cloud-fan Feb 15, 2017
601b9c3
[SPARK-17076][SQL] Cardinality estimation for join based on basic col…
wzhfy Feb 15, 2017
d22db62
[SPARK-18871][SQL][TESTS] New test cases for IN/NOT IN subquery 2nd b…
kevinyu98 Feb 15, 2017
5ad10c5
[SPARK-18873][SQL][TEST] New test cases for scalar subquery (part 2 o…
nsyca Feb 15, 2017
a8a1398
[SPARK-18872][SQL][TESTS] New test cases for EXISTS subquery (Joins +…
dilipbiswal Feb 15, 2017
acf71c6
[SPARK-16475][SQL] broadcast hint for SQL queries - disallow space as…
viirya Feb 15, 2017
6eca21b
[SPARK-19590][PYSPARK][ML] Update the document for QuantileDiscretize…
Feb 15, 2017
c97f4e1
[SPARK-19160][PYTHON][SQL] Add udf decorator
zero323 Feb 15, 2017
671bc08
[SPARK-19399][SPARKR] Add R coalesce API for DataFrame and Column
felixcheung Feb 15, 2017
3755da7
[SPARK-19331][SQL][TESTS] Improve the test coverage of SQLViewSuite
jiangxb1987 Feb 15, 2017
59dc26e
[SPARK-19607][HOTFIX] Finding QueryExecution that matches provided ex…
dongjoon-hyun Feb 15, 2017
6a9a85b
[SPARK-19329][SQL] Reading from or writing to a datasource table with…
windpiger Feb 15, 2017
865b2fd
[SPARK-18937][SQL] Timezone support in CSV/JSON parsing
ueshin Feb 15, 2017
f6c3bba
[SPARK-19604][TESTS] Log the start of every Python test
yhuai Feb 15, 2017
21b4ba2
[SPARK-19599][SS] Clean up HDFSMetadataLog
zsxwing Feb 16, 2017
08c1972
[SPARK-18080][ML][PYTHON] Python API & Examples for Locality Sensitiv…
Feb 16, 2017
fc02ef9
[SPARK-19603][SS] Fix StreamingQuery explain command
zsxwing Feb 16, 2017
8487902
[SPARK-18871][SQL][TESTS] New test cases for IN/NOT IN subquery 4th b…
kevinyu98 Feb 16, 2017
f041e55
[SPARK-19618][SQL] Inconsistency wrt max. buckets allowed from Datafr…
tejasapatil Feb 16, 2017
3871d94
[SPARK-18871][SQL][TESTS] New test cases for IN/NOT IN subquery 3rd b…
kevinyu98 Feb 16, 2017
0e24054
[SPARK-19550][BUILD][CORE][WIP] Remove Java 7 support
srowen Feb 16, 2017
3b43768
[MINOR][BUILD] Fix javadoc8 break
HyukjinKwon Feb 16, 2017
54a30c8
[SPARK-19436][SQL] Add missing tests for approxQuantile
zhengruifeng Feb 16, 2017
dcc2d54
[SPARK-19550][HOTFIX][BUILD] Use JAVA_HOME/bin/java if JAVA_HOME is s…
srowen Feb 16, 2017
21fde57
[SPARK-18352][SQL] Support parsing multiline json files
Feb 17, 2017
54d2359
[SPARK-18120][SPARK-19557][SQL] Call QueryExecutionListener callback …
cloud-fan Feb 17, 2017
ed338f7
[BUILD] Close stale PRs
HyukjinKwon Feb 17, 2017
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
  •  
  •  
  •  
The diff you're trying to view is too large. We only load the first 3000 changed files.
10 changes: 10 additions & 0 deletions .github/PULL_REQUEST_TEMPLATE
Original file line number Diff line number Diff line change
@@ -0,0 +1,10 @@
## What changes were proposed in this pull request?

(Please fill in changes proposed in this fix)

## How was this patch tested?

(Please explain how this patch was tested. E.g. unit tests, integration tests, manual tests)
(If this patch involves UI changes, please attach a screenshot; otherwise, remove this)

Please review http://spark.apache.org/contributing.html before opening a pull request.
110 changes: 62 additions & 48 deletions .gitignore
Original file line number Diff line number Diff line change
@@ -1,76 +1,90 @@
*~
*.#*
*#*#
*.swp
*.ipr
*.#*
*.iml
*.ipr
*.iws
*.pyc
*.pyo
*.swp
*~
.DS_Store
.cache
.classpath
.ensime
.ensime_cache/
.ensime_lucene
.generated-mima*
.idea/
.idea_modules/
build/*.jar
.project
.pydevproject
.scala_dependencies
.settings
.cache
cache
.generated-mima*
work/
out/
.DS_Store
third_party/libmesos.so
third_party/libmesos.dylib
/lib/
R-unit-tests.log
R/unit-tests.out
R/cran-check.out
R/pkg/vignettes/sparkr-vignettes.html
build/*.jar
build/apache-maven*
build/zinc*
build/scala*
conf/java-opts
conf/*.sh
build/zinc*
cache
checkpoint
conf/*.cmd
conf/*.properties
conf/*.conf
conf/*.properties
conf/*.sh
conf/*.xml
conf/java-opts
conf/slaves
dependency-reduced-pom.xml
derby.log
dev/create-release/*final
dev/create-release/*txt
dev/pr-deps/
dist/
docs/_site
docs/api
target/
reports/
.project
.classpath
.scala_dependencies
lib_managed/
src_managed/
lint-r-report.log
log/
logs/
out/
project/boot/
project/plugins/project/build.properties
project/build/target/
project/plugins/target/
project/plugins/lib_managed/
project/plugins/project/build.properties
project/plugins/src_managed/
logs/
log/
project/plugins/target/
python/lib/pyspark.zip
python/deps
python/pyspark/python
reports/
scalastyle-on-compile.generated.xml
scalastyle-output.xml
scalastyle.txt
spark-*-bin-*.tgz
spark-tests.log
src_managed/
streaming-tests.log
dependency-reduced-pom.xml
.ensime
.ensime_lucene
checkpoint
derby.log
dist/
dev/create-release/*txt
dev/create-release/*final
spark-*-bin-*.tgz
target/
unit-tests.log
/lib/
ec2/lib/
rat-results.txt
scalastyle.txt
scalastyle-output.xml
R-unit-tests.log
R/unit-tests.out
python/lib/pyspark.zip
lint-r-report.log
work/

# For Hive
metastore_db/
metastore/
warehouse/
TempStatsStore/
metastore/
metastore_db/
sql/hive-thriftserver/test_warehouses
warehouse/
spark-warehouse/

# For R session data
.RData
.RHistory
.Rhistory
*.Rproj
*.Rproj.*

.Rproj.user
85 changes: 0 additions & 85 deletions .rat-excludes

This file was deleted.

51 changes: 51 additions & 0 deletions .travis.yml
Original file line number Diff line number Diff line change
@@ -0,0 +1,51 @@
# Licensed to the Apache Software Foundation (ASF) under one or more
# contributor license agreements. See the NOTICE file distributed with
# this work for additional information regarding copyright ownership.
# The ASF licenses this file to You under the Apache License, Version 2.0
# (the "License"); you may not use this file except in compliance with
# the License. You may obtain a copy of the License at
#
# http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing, software
# distributed under the License is distributed on an "AS IS" BASIS,
# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
# See the License for the specific language governing permissions and
# limitations under the License.

# Spark provides this Travis CI configuration file to help contributors
# check Scala/Java style conformance and JDK7/8 compilation easily
# during their preparing pull requests.
# - Scalastyle is executed during `maven install` implicitly.
# - Java Checkstyle is executed by `lint-java`.
# See the related discussion here.
# https://github.com/apache/spark/pull/12980

# 1. Choose OS (Ubuntu 14.04.3 LTS Server Edition 64bit, ~2 CORE, 7.5GB RAM)
sudo: required
dist: trusty

# 2. Choose language and target JDKs for parallel builds.
language: java
jdk:
- oraclejdk7
- oraclejdk8

# 3. Setup cache directory for SBT and Maven.
cache:
directories:
- $HOME/.sbt
- $HOME/.m2

# 4. Turn off notifications.
notifications:
email: false

# 5. Run maven install before running lint-java.
install:
- export MAVEN_SKIP_RC=1
- build/mvn -T 4 -q -DskipTests -Pmesos -Pyarn -Pkinesis-asl -Phive -Phive-thriftserver install

# 6. Run lint-java.
script:
- dev/lint-java
4 changes: 2 additions & 2 deletions CONTRIBUTING.md
Original file line number Diff line number Diff line change
@@ -1,12 +1,12 @@
## Contributing to Spark

*Before opening a pull request*, review the
[Contributing to Spark wiki](https://cwiki.apache.org/confluence/display/SPARK/Contributing+to+Spark).
[Contributing to Spark guide](http://spark.apache.org/contributing.html).
It lists steps that are required before creating a PR. In particular, consider:

- Is the change important and ready enough to ask the community to spend time reviewing?
- Have you searched for existing, related JIRAs and pull requests?
- Is this a new feature that can stand alone as a package on http://spark-packages.org ?
- Is this a new feature that can stand alone as a [third party project](http://spark.apache.org/third-party-projects.html) ?
- Is the change being proposed clearly explained and motivated?

When you contribute code, you affirm that the contribution is your original work and that you
Expand Down
37 changes: 21 additions & 16 deletions LICENSE
Original file line number Diff line number Diff line change
@@ -1,4 +1,3 @@

Apache License
Version 2.0, January 2004
http://www.apache.org/licenses/
Expand Down Expand Up @@ -237,9 +236,9 @@ The following components are provided under a BSD-style license. See project lin
The text of each license is also included at licenses/LICENSE-[project].txt.

(BSD 3 Clause) netlib core (com.github.fommil.netlib:core:1.1.2 - https://github.com/fommil/netlib-java/core)
(BSD 3 Clause) JPMML-Model (org.jpmml:pmml-model:1.1.15 - https://github.com/jpmml/jpmml-model)
(BSD 3-clause style license) jblas (org.jblas:jblas:1.2.4 - http://jblas.org/)
(BSD 3 Clause) JPMML-Model (org.jpmml:pmml-model:1.2.7 - https://github.com/jpmml/jpmml-model)
(BSD License) AntLR Parser Generator (antlr:antlr:2.7.7 - http://www.antlr.org/)
(BSD License) ANTLR 4.5.2-1 (org.antlr:antlr4:4.5.2-1 - http://wwww.antlr.org/)
(BSD licence) ANTLR ST4 4.0.4 (org.antlr:ST4:4.0.4 - http://www.stringtemplate.org)
(BSD licence) ANTLR StringTemplate (org.antlr:stringtemplate:3.2.1 - http://www.stringtemplate.org)
(BSD License) Javolution (javolution:javolution:5.5.1 - http://javolution.org)
Expand All @@ -250,22 +249,21 @@ The text of each license is also included at licenses/LICENSE-[project].txt.
(Interpreter classes (all .scala files in repl/src/main/scala
except for Main.Scala, SparkHelper.scala and ExecutorClassLoader.scala),
and for SerializableMapWrapper in JavaUtils.scala)
(BSD-like) Scala Actors library (org.scala-lang:scala-actors:2.10.5 - http://www.scala-lang.org/)
(BSD-like) Scala Compiler (org.scala-lang:scala-compiler:2.10.5 - http://www.scala-lang.org/)
(BSD-like) Scala Compiler (org.scala-lang:scala-reflect:2.10.5 - http://www.scala-lang.org/)
(BSD-like) Scala Library (org.scala-lang:scala-library:2.10.5 - http://www.scala-lang.org/)
(BSD-like) Scalap (org.scala-lang:scalap:2.10.5 - http://www.scala-lang.org/)
(BSD-style) scalacheck (org.scalacheck:scalacheck_2.10:1.10.0 - http://www.scalacheck.org)
(BSD-style) spire (org.spire-math:spire_2.10:0.7.1 - http://spire-math.org)
(BSD-style) spire-macros (org.spire-math:spire-macros_2.10:0.7.1 - http://spire-math.org)
(New BSD License) Kryo (com.esotericsoftware.kryo:kryo:2.21 - http://code.google.com/p/kryo/)
(New BSD License) MinLog (com.esotericsoftware.minlog:minlog:1.2 - http://code.google.com/p/minlog/)
(New BSD License) ReflectASM (com.esotericsoftware.reflectasm:reflectasm:1.07 - http://code.google.com/p/reflectasm/)
(BSD-like) Scala Actors library (org.scala-lang:scala-actors:2.11.7 - http://www.scala-lang.org/)
(BSD-like) Scala Compiler (org.scala-lang:scala-compiler:2.11.7 - http://www.scala-lang.org/)
(BSD-like) Scala Compiler (org.scala-lang:scala-reflect:2.11.7 - http://www.scala-lang.org/)
(BSD-like) Scala Library (org.scala-lang:scala-library:2.11.7 - http://www.scala-lang.org/)
(BSD-like) Scalap (org.scala-lang:scalap:2.11.7 - http://www.scala-lang.org/)
(BSD-style) scalacheck (org.scalacheck:scalacheck_2.11:1.10.0 - http://www.scalacheck.org)
(BSD-style) spire (org.spire-math:spire_2.11:0.7.1 - http://spire-math.org)
(BSD-style) spire-macros (org.spire-math:spire-macros_2.11:0.7.1 - http://spire-math.org)
(New BSD License) Kryo (com.esotericsoftware:kryo:3.0.3 - https://github.com/EsotericSoftware/kryo)
(New BSD License) MinLog (com.esotericsoftware:minlog:1.3.0 - https://github.com/EsotericSoftware/minlog)
(New BSD license) Protocol Buffer Java API (com.google.protobuf:protobuf-java:2.5.0 - http://code.google.com/p/protobuf)
(New BSD license) Protocol Buffer Java API (org.spark-project.protobuf:protobuf-java:2.4.1-shaded - http://code.google.com/p/protobuf)
(The BSD License) Fortran to Java ARPACK (net.sourceforge.f2j:arpack_combined_all:0.1 - http://f2j.sourceforge.net)
(The BSD License) xmlenc Library (xmlenc:xmlenc:0.52 - http://xmlenc.sourceforge.net)
(The New BSD License) Py4J (net.sf.py4j:py4j:0.9 - http://py4j.sourceforge.net/)
(The New BSD License) Py4J (net.sf.py4j:py4j:0.10.4 - http://py4j.sourceforge.net/)
(Two-clause BSD-style license) JUnit-Interface (com.novocode:junit-interface:0.10 - http://github.com/szeiger/junit-interface/)
(BSD licence) sbt and sbt-launch-lib.bash
(BSD 3 Clause) d3.min.js (https://github.com/mbostock/d3/blob/master/LICENSE)
Expand All @@ -284,11 +282,18 @@ The text of each license is also included at licenses/LICENSE-[project].txt.
(MIT License) SLF4J API Module (org.slf4j:slf4j-api:1.7.5 - http://www.slf4j.org)
(MIT License) SLF4J LOG4J-12 Binding (org.slf4j:slf4j-log4j12:1.7.5 - http://www.slf4j.org)
(MIT License) pyrolite (org.spark-project:pyrolite:2.0.1 - http://pythonhosted.org/Pyro4/)
(MIT License) scopt (com.github.scopt:scopt_2.10:3.2.0 - https://github.com/scopt/scopt)
(MIT License) scopt (com.github.scopt:scopt_2.11:3.2.0 - https://github.com/scopt/scopt)
(The MIT License) Mockito (org.mockito:mockito-core:1.9.5 - http://www.mockito.org)
(MIT License) jquery (https://jquery.org/license/)
(MIT License) AnchorJS (https://github.com/bryanbraun/anchorjs)
(MIT License) graphlib-dot (https://github.com/cpettitt/graphlib-dot)
(MIT License) dagre-d3 (https://github.com/cpettitt/dagre-d3)
(MIT License) sorttable (https://github.com/stuartlangridge/sorttable)
(MIT License) boto (https://github.com/boto/boto/blob/develop/LICENSE)
(MIT License) datatables (http://datatables.net/license)
(MIT License) mustache (https://github.com/mustache/mustache/blob/master/LICENSE)
(MIT License) cookies (http://code.google.com/p/cookies/wiki/License)
(MIT License) blockUI (http://jquery.malsup.com/block/)
(MIT License) RowsGroup (http://datatables.net/license/mit)
(MIT License) jsonFormatter (http://www.jqueryscript.net/other/jQuery-Plugin-For-Pretty-JSON-Formatting-jsonFormatter.html)
(MIT License) modernizr (https://github.com/Modernizr/Modernizr/blob/master/LICENSE)
Loading