Skip to content
Closed
Show file tree
Hide file tree
Changes from all commits
Commits
Show all changes
6667 commits
Select commit Hold shift + click to select a range
29496c9
YARN-2308. Changed CapacityScheduler to explicitly throw exception if…
jian-he Oct 13, 2014
da3e84b
Missing Changes.txt for YARN-2308
jian-he Oct 13, 2014
e6102b1
YARN-2566. DefaultContainerExecutor should pick a working directory r…
kambatla Oct 13, 2014
834533f
HADOOP-11176. KMSClientProvider authentication fails when both curren…
atm Oct 14, 2014
20fc34e
HDFS-7237. The command "hdfs namenode -rollingUpgrade" throws ArrayIn…
Oct 14, 2014
21fa0f6
HADOOP-11198. Fix typo in javadoc for FileSystem#listStatus(). Contri…
Oct 14, 2014
3d2d501
HDFS-7228. Add an SSD policy into the default BlockStoragePolicySuite…
Jing9 Oct 14, 2014
e71fa82
HADOOP-11181. Generalized o.a.h.s.t.d.DelegationTokenManager to handl…
zjshen14 Oct 14, 2014
eb055ea
YARN-2656. Made RM web services authentication filter support proxy u…
zjshen14 Oct 15, 2014
9203ea7
MAPREDUCE-5873. Shuffle bandwidth computation includes time spent wai…
jlowe Oct 15, 2014
439560d
HDFS-7185. The active NameNode will not accept an fsimage sent from t…
Jing9 Oct 15, 2014
ec38eec
MAPREDUCE-5970. Provide a boolean switch to enable MR-AM profiling. C…
jlowe Oct 15, 2014
bd45dba
YARN-2312. Deprecated old ContainerId#getId API and updated MapReduce…
jian-he Oct 15, 2014
7b53ab7
HADOOP-11181. GraphiteSink emits wrong timestamps (Sascha Coenen via …
raviprak Oct 15, 2014
fe80fd5
YARN-2496. Enhanced Capacity Scheduler to have basic support for allo…
vinoduec Oct 16, 2014
8a09fdc
YARN-2685. Fixed a bug in CommonNodeLabelsManager that caused wrong r…
vinoduec Oct 16, 2014
253e3eb
HDFS-7208. NN doesn't schedule replication when a DN storage fails. …
Oct 16, 2014
fd03689
HDFS-5089. When a LayoutVersion support SNAPSHOT, it must support FSI…
Oct 16, 2014
b0a72f3
YARN-2689 TestSecureRMRegistryOperations failing on windows: secure Z…
steveloughran Oct 16, 2014
6be8330
YARN-2621. Simplify the output when the user doesn't have the access …
jian-he Oct 16, 2014
d4606bf
HADOOP-11182. GraphiteSink emits wrong timestamps (Sascha Coenen via …
raviprak-altiscale Oct 16, 2014
778fbcd
YARN-2699. Fixed a bug in CommonNodeLabelsManager that caused tests t…
vinoduec Oct 17, 2014
b7504f0
YARN-2588. Standby RM fails to transitionToActive if previous transit…
jian-he Oct 17, 2014
8217665
MAPREDUCE-5542. Killing a job just as it finishes can generate an NPE…
jlowe Oct 17, 2014
db2bfed
HADOOP-11207. Enhanced common DelegationTokenAuthenticationHandler to…
vinoduec Oct 17, 2014
d09f316
HDFS-6924. Add new RAM_DISK storage type. (Arpit Agarwal)
arp7 Aug 27, 2014
1d9d29a
HDFS-6922. Add LazyPersist flag to INodeFile, save it in FsImage and …
arp7 Aug 27, 2014
8c3c0ec
HDFS-6923. Propagate LazyPersist flag to DNs via DataTransferProtocol…
arp7 Aug 27, 2014
34d0088
HDFS-6925. DataNode should attempt to place replicas on transient sto…
arp7 Aug 27, 2014
8e01a89
HDFS-6926. DN support for saving replicas to persistent storage and e…
arp7 Aug 27, 2014
c2721ed
HDFS-6927. Initial unit tests for Lazy Persist files. (Arpit Agarwal)
arp7 Aug 27, 2014
15372df
HDFS-6929. NN periodically unlinks lazy persist files with missing re…
arp7 Aug 27, 2014
2079d4b
HDFS-6928. 'hdfs put' command should accept lazyPersist flag for test…
arp7 Aug 28, 2014
d973656
HDFS-6960. Bugfix in LazyWriter, fix test case and some refactoring. …
arp7 Aug 29, 2014
754ba3a
HDFS-6931. Move lazily persisted replicas to finalized directory on D…
arp7 Aug 29, 2014
4609ba0
HDFS-6950. Add Additional unit tests for HDFS-6581. (Contributed by X…
arp7 Sep 3, 2014
34f28ea
HDFS-6930. Improve replica eviction from RAM disk. (Arpit Agarwal)
arp7 Sep 3, 2014
186d195
HDFS-6977. Delete all copies when a block is deleted from the block s…
arp7 Sep 8, 2014
bcec658
HDFS-6991. Notify NN of evicted block before deleting it from RAM dis…
arp7 Sep 8, 2014
2fdd9f5
HDFS-7066. LazyWriter#evictBlocks misses a null check for replicaStat…
arp7 Sep 15, 2014
6cc206b
HDFS-6978. Directory scanner should correctly reconcile blocks on RAM…
arp7 Sep 13, 2014
d3ccbd8
HDFS-7064. Fix unit test failures in HDFS-6581 branch. (Contributed b…
arp7 Sep 16, 2014
7d168d9
HDFS-7079. Few more unit test fixes for HDFS-6581. (Arpit Agarwal)
arp7 Sep 17, 2014
b7062e8
HDFS-7080. Fix finalize and upgrade unit test failures. (Arpit Agarwal)
arp7 Sep 17, 2014
d32ce57
HDFS-7084. FsDatasetImpl#copyBlockFiles debug log can be improved. (C…
arp7 Sep 18, 2014
ebdbb5e
HDFS-7091. Add forwarding constructor for INodeFile for existing call…
arp7 Sep 19, 2014
1441988
HDFS-7108. Fix unit test failures in SimulatedFsDataset. (Arpit Agarwal)
arp7 Sep 20, 2014
e9eebaa
HDFS-7100. Make eviction scheme pluggable. (Arpit Agarwal)
arp7 Sep 20, 2014
a59ce50
HDFS-6990. Add unit test for evict/delete RAM_DISK block with open ha…
arp7 Sep 23, 2014
9de4d18
HDFS-6932. Balancer and Mover tools should ignore replicas on RAM_DIS…
arp7 Sep 25, 2014
05cfd68
HDFS-7143. Fix findbugs warnings in HDFS-6581 branch. (Contributed by…
arp7 Sep 25, 2014
3481f5d
HDFS-7155. Bugfix in createLocatedFileStatus caused by bad merge. (Ar…
arp7 Sep 26, 2014
ba31a95
HDFS-7144. Fix findbugs warnings in RamDiskReplicaTracker. (Contribut…
arp7 Sep 25, 2014
d61daff
HDFS-7159. Use block storage policy to set lazy persist preference. (…
arp7 Sep 30, 2014
e6457a0
HDFS-7129. Metrics to track usage of memory for writes. (Contributed …
arp7 Sep 30, 2014
137f0b8
HDFS-7171. Fix Jenkins failures in HDFS-6581 branch. (Arpit Agarwal)
arp7 Oct 1, 2014
1b6d115
HDFS-7112. LazyWriter should use either async IO or one thread per ph…
cnauroth Oct 8, 2014
2e98379
HDFS-7090. Use unbuffered writes when persisting in-memory replicas. …
cnauroth Oct 13, 2014
9183dad
HDFS-6921. Add LazyPersist flag to FileStatus. (Arpit Agarwal)
arp7 Aug 27, 2014
4d03915
YARN-1879. Marked Idempotent/AtMostOnce annotations to ApplicationMas…
jian-he Oct 17, 2014
ce42210
YARN-2705. Fixed bugs in ResourceManager node-label manager that were…
vinoduec Oct 18, 2014
0ee6ddb
HDFS-7260. Change DFSOutputStream.MAX_PACKETS to be configurable.
Oct 18, 2014
24b0529
YARN-2676. Enhanced Timeline auth-filter to support proxy users. Cont…
vinoduec Oct 18, 2014
88b7e5c
YARN-2504. Enhanced RM Admin CLI to support management of node-labels…
vinoduec Oct 18, 2014
71e05b1
MAPREDUCE-5911. Terasort TeraOutputFormat does not check for output d…
Oct 19, 2014
a78dd99
Revert "MAPREDUCE-5911. Terasort TeraOutputFormat does not check for …
Oct 20, 2014
cdf265d
HADOOP-11194. Ignore .keep files (kasha)
kambatla Oct 20, 2014
6d78dc3
YARN-2673. Made timeline client put APIs retry if ConnectException ha…
zjshen14 Oct 20, 2014
2af7f48
YARN-2582. Fixed Log CLI and Web UI for showing aggregated logs of LR…
zjshen14 Oct 20, 2014
debb368
YARN-1972. Added a secure container-executor for Windows. Contributed…
vinoduec Oct 2, 2014
c7db305
YARN-2701. Potential race condition in startLocalizer when using Linu…
jian-he Oct 21, 2014
23b4af4
Missing file for YARN-2701
jian-he Oct 21, 2014
852ffea
Missing file for YARN-1879
jian-he Oct 21, 2014
fcdeba2
YARN-2717. Avoided duplicate logging when container logs are not foun…
zjshen14 Oct 21, 2014
413fe4c
YARN-90. NodeManager should identify failed disks becoming good again…
jlowe Oct 21, 2014
3fa1ee2
HDFS-7259. Unresponseive NFS mount point due to deferred COMMIT respo…
Oct 21, 2014
2010826
HDFS-7215.Add JvmPauseMonitor to NFS gateway. Contributed by Brandon Li
Oct 21, 2014
8727f9e
YARN-2720. Windows: Wildcard classpath variables not expanded against…
cnauroth Oct 21, 2014
1ec2dbf
HDFS-7154. Fix returning value of starting reconfiguration task (Lei …
Oct 21, 2014
7df8cbd
YARN-2709. Made timeline client getDelegationToken API retry if Conne…
zjshen14 Oct 21, 2014
a1c5d4c
YARN-2715. Fixed ResourceManager to respect common configurations for…
vinoduec Oct 22, 2014
b1ca12b
YARN-2721. Suppress NodeExist exception thrown by ZKRMStateStore when…
zjshen14 Oct 22, 2014
8fdff5b
YARN-2692 ktutil test hanging on some machines/ktutil versions (stevel)
steveloughran Oct 22, 2014
cca473a
MAPREDUCE-6126. Fixed Rumen JobBuilder to ignore NormalizedResourceEv…
jian-he Oct 22, 2014
ada23f3
YARN-2700 TestSecureRMRegistryOperations failing on windows: auth pro…
steveloughran Oct 22, 2014
6064b9d
HADOOP-11122. Fix findbugs in ZK DelegationTokenSecretManagers. (Arun…
kambatla Oct 22, 2014
e282805
YARN-1063. Augmented Hadoop common winutils to have the ability to cr…
vinoduec Oct 1, 2014
a057552
YARN-2682. Updated WindowsSecureContainerExecutor to not use DefaultC…
jian-he Oct 17, 2014
29d0164
YARN-2198. Remove the need to run NodeManager as privileged account f…
jian-he Oct 22, 2014
78efd4f
YARN-2732. Fixed syntax error in SecureContainer.apt.vm. Contributed …
zjshen14 Oct 23, 2014
e1baa3a
HDFS-7180. NFSv3 gateway frequently gets stuck due to GC. Contributed…
Oct 23, 2014
82ac5c9
HDFS-7243. HDFS concat operation should not be allowed in Encryption …
y-liu Oct 24, 2014
09e4223
YARN-2209. Replaced AM resync/shutdown command with corresponding exc…
zjshen14 Oct 24, 2014
38fa39a
YARN-2724. Skipped uploading a local log file to HDFS if exception is…
zjshen14 Oct 24, 2014
327db15
HDFS-6904. YARN unable to renew delegation token fetched via webhdfs …
Oct 24, 2014
abb28fb
HDFS-6904. Added files missing in previous commit.
Oct 24, 2014
f236e17
HADOOP-11228. Winutils task: unsecure path should not call AddNodeMan…
jian-he Oct 24, 2014
62f23d0
HDFS-6988. Improve HDFS-6581 eviction configuration (Xiaoyu Yao via C…
Oct 24, 2014
a41371e
YARN-2703. Added logUploadedTime into LogValue for better display. Co…
zjshen14 Oct 24, 2014
728cc23
YARN-1915. Fixed a race condition that client could use the ClientToA…
jian-he Oct 25, 2014
c8d48d2
YARN-2314. Disable ContainerManagementProtocolProxy cache by default …
jian-he Oct 25, 2014
cccfc27
YARN-2723. Fix rmadmin -replaceLabelsOnNode does not correctly parse …
xgong Oct 25, 2014
7bb5071
HADOOP-11170. ZKDelegationTokenSecretManager fails to renewToken crea…
kambatla Oct 24, 2014
259db7a
YARN-2743. Fixed a bug in ResourceManager that was causing RMDelegati…
vinoduec Oct 26, 2014
ab7a215
YARN-2734. Skipped sub-folders in the local log dir when aggregating …
zjshen14 Oct 26, 2014
55c5612
YARN-2726. CapacityScheduler should explicitly log when an accessible…
xgong Oct 27, 2014
ba1e549
YARN-2591. Fixed AHSWebServices to return FORBIDDEN(403) if the reque…
jian-he Oct 27, 2014
6724c2f
HDFS-7296. HdfsConstants#MEMORY_STORAGE_POLICY_ID and HdfsConstants#M…
Jing9 Oct 27, 2014
a9f31af
HDFS-6934. Move checksum computation off the hot path when writing to…
cnauroth Oct 27, 2014
e8d7759
HDFS-6934. Revert files accidentally committed.
cnauroth Oct 27, 2014
0af8cc9
YARN-2704. Changed ResourceManager to optionally obtain tokens itself…
vinoduec Oct 27, 2014
c03cca7
HDFS-7128. Decommission slows way down when it gets towards the end. …
cnauroth Oct 7, 2014
8d4c93a
YARN-2502. Changed DistributedShell to support node labels. Contribut…
jian-he Oct 28, 2014
71ab776
MAPREDUCE-5933. Enabled MR AM to post history events to the timeline …
zjshen14 Oct 28, 2014
d92d4e3
MAPREDUCE-6018. Added an MR specific config to enable emitting job hi…
zjshen14 Oct 28, 2014
043364f
HDFS-6995. Block should be placed in the client's 'rack-local' node i…
vinayakumarb Oct 6, 2014
3e4e6e3
HDFS-6995. Block should be placed in the client's 'rack-local' node i…
vinayakumarb Oct 17, 2014
fe4da80
HADOOP-11233. hadoop.security.kms.client.encrypted.key.cache.expiry p…
y-liu Oct 28, 2014
9465da3
HDFS-6606. Optimize HDFS Encrypted Transport performance. (yliu)
y-liu Oct 28, 2014
f5361a8
YARN-2760. Remove 'experimental' from FairScheduler docs. (Harsh J vi…
kambatla Oct 28, 2014
615af9e
YARN-2279. Add UTs to cover timeline server authentication. Contribut…
xgong Oct 28, 2014
126d1b9
YARN-2758. Update TestApplicationHistoryClientService to use the new …
xgong Oct 28, 2014
ae62fe2
YARN-2741. Made NM web UI serve logs on the drive other than C: on Wi…
zjshen14 Oct 28, 2014
905b339
HDFS-7291. Persist in-memory replicas with appropriate unbuffered cop…
cnauroth Oct 28, 2014
3e901e6
HADOOP-11217. Disable SSLv3 in KMS. (Robert Kanter via kasha)
kambatla Oct 29, 2014
c0b17bf
HDFS-7274. Disable SSLv3 in HttpFS. (Robert Kanter via kasha)
kambatla Oct 29, 2014
e181498
YARN-2503. Added node lablels in web UI. Contributed by Wangda Tan
jian-he Oct 29, 2014
d8212c0
HADOOP-11243. SSLFactory shouldn't allow SSLv3. (Wei Yan via kasha)
kambatla Oct 29, 2014
dcb484f
YARN-2747. Fixed the test failure of TestAggregatedLogFormat when nat…
zjshen14 Oct 29, 2014
6add7b1
MAPREDUCE-6142. Fixed test failures in TestJobHistoryEventHandler and…
vinoduec Oct 29, 2014
afbb279
MAPREDUCE-6022. map_input_file is missing from streaming job
kihwal Oct 29, 2014
19ec421
HADOOP-11195. Move Id-Name mapping in NFS to the hadoop-common area f…
Oct 29, 2014
de1044f
HADOOP-11068. Match hadoop.auth cookie format to jetty output. Contri…
cnauroth Oct 29, 2014
2f62716
YARN-2769. Fixed the problem that timeline domain is not set in distr…
zjshen14 Oct 29, 2014
5a0285f
HDFS-7287. The OfflineImageViewer (OIV) can output invalid XML depend…
Oct 29, 2014
ba86f06
HADOOP-9740. Fix FsShell '-text' command to be able to read Avro file…
jlowe Oct 29, 2014
1354ec1
HDFS-7300. The getMaxNodesPerRack() method in
kihwal Oct 29, 2014
c8dfc91
HDFS-7305. NPE seen in wbhdfs FS while running SLive. Contributed by …
Jing9 Oct 29, 2014
2f313cf
HADOOP-11216. Improve Openssl library finding. (cmccabe via yliu)
y-liu Oct 30, 2014
773ba8b
YARN-2755. NM fails to clean up usercache_DEL_<timestamp> dirs after …
jlowe Oct 30, 2014
a4b54df
HADOOP-11250. fix endmacro of set_find_shared_library_without_version…
Oct 30, 2014
b2a7bbf
HDFS-7230. Add rolling downgrade documentation. Contributed by Tsz Wo…
Jing9 Oct 30, 2014
c3de2fc
HADOOP-11221. IdentityHashStore assumes System.identityHashCode() is …
Oct 30, 2014
4e419b6
HADOOP-11247. Fix a couple javac warnings in NFS. Contributed by Bran…
Oct 30, 2014
b69ebef
YARN-2677 registry punycoding of usernames doesn't fix all usernames …
steveloughran Oct 30, 2014
3283268
HDFS-6385. Show when block deletion will start after NameNode startup…
cnauroth Oct 31, 2014
d3dd1ac
HDFS-7313. Support optional configuration of AES cipher suite on Data…
cnauroth Oct 31, 2014
85fcdaf
YARN-2698. Moved some node label APIs to be correctly placed in clien…
vinoduec Oct 31, 2014
a3f0320
YARN-2779. Fixed ResourceManager to not require delegation tokens for…
vinoduec Oct 31, 2014
16511ef
YARN-2778. Moved node-lables' reports to the yarn nodes CLI from the …
vinoduec Oct 31, 2014
b7296ee
HDFS-7309. XMLUtils.mangleXmlString doesn't seem to handle less than …
raviprak-altiscale Oct 31, 2014
2bb845d
HADOOP-11253. Hadoop streaming test TestStreamXmlMultipleRecords fail…
Oct 31, 2014
a859adc
YARN-2770. Added functionality to renew/cancel TimeLineDelegationToke…
jian-he Oct 31, 2014
aa13977
YARN-2701. Addendum patch. Potential race condition in startLocalizer…
xgong Oct 31, 2014
f71d940
YARN-2789. Re-instated the NodeReport.newInstance private unstable AP…
vinoduec Oct 31, 2014
239c4cc
YARN-2707. Potential null dereference in FSDownload. Contributed by G…
jlowe Oct 31, 2014
5492370
YARN-2711. Fixed TestDefaultContainerExecutor#testContainerLaunchErro…
zjshen14 Nov 1, 2014
eb1718b
HADOOP-11241. Fixed intermittent TestNMSimulator failure due to timin…
zjshen14 Nov 1, 2014
7180167
MAPREDUCE-6052. Supported overriding the default container-log4j.prop…
zjshen14 Nov 1, 2014
5d4d114
HADOOP-11254. Changed visibility of AccessControlList to be public fo…
vinoduec Nov 1, 2014
a4dca48
HDFS-7276. Limit the number of byte arrays used by DFSOutputStream an…
Nov 1, 2014
5a0aac5
YARN-2790. Fixed a NodeManager bug that was causing log-aggregation t…
vinoduec Nov 1, 2014
3e41828
YARN-2785. Fixed intermittent TestContainerResourceUsage failure. Con…
zjshen14 Nov 2, 2014
2098c68
YARN-2730. DefaultContainerExecutor runs only one localizer at a time…
jlowe Nov 3, 2014
dd82a1e
YARN-2798. Fixed YarnClient to populate the renewer correctly for Tim…
vinoduec Nov 3, 2014
c205841
YARN-2788. Fixed backwards compatiblity issues with log-aggregation f…
vinoduec Nov 3, 2014
f2ef8c7
YARN-2795. Fixed ResourceManager to not crash loading node-label data…
vinoduec Nov 3, 2014
e94a044
HDFS-7147. Update archival storage user documentation. Contributed by…
Nov 3, 2014
0b73606
YARN-1922. Fixed NodeManager to kill process-trees correctly in the p…
vinoduec Nov 4, 2014
ff361e7
HDFS-7328. TestTraceAdmin assumes Unix line endings. Contributed by C…
cnauroth Nov 4, 2014
f354b0f
HDFS-7340. Make rollingUpgrade start/finalize idempotent. Contributed…
Jing9 Nov 4, 2014
1b54fa6
HDFS-7334. Fix periodic failures of TestCheckpoint#testTooManyEditRep…
Nov 4, 2014
0fde606
HDFS-7355. TestDataNodeVolumeFailure#testUnderReplicationAfterVolFail…
Nov 4, 2014
1550617
YARN-2752. Made ContainerExecutor append "nice -n" arg only when prio…
zjshen14 Nov 4, 2014
1ca1a03
HDFS-7233. NN logs unnecessary org.apache.hadoop.hdfs.protocol.Unreso…
Jing9 Nov 5, 2014
c7b3356
HADOOP-11260. Patch up Jetty to disable SSLv3. (Mike Yoder via kasha)
kambatla Nov 5, 2014
d76756d
Adding release 2.5.2 to CHANGES.txt
kambatla Nov 5, 2014
36993e3
YARN-2010. Handle app-recovery failures gracefully. (Jian He and Kart…
kambatla Nov 5, 2014
87e880b
YARN-2804. Fixed Timeline service to not fill the logs with JAXB bind…
vinoduec Nov 5, 2014
d57dfac
MAPREDUCE-6048. Fixed TestJavaSerialization failure. Contributed by V…
jian-he Nov 5, 2014
3faabf2
HDFS-7218. FSNamesystem ACL operations should write to audit log on f…
y-liu Nov 5, 2014
0d573cc
HADOOP-11265. Credential and Key Shell Commands not available on Wind…
cnauroth Nov 5, 2014
8702cc2
HDFS-7199. DFSOutputStream should not silently drop data if DataStrea…
Nov 5, 2014
a1764e4
YARN-2767. Added a test case to verify that http static user cannot k…
zjshen14 Nov 5, 2014
e041de4
HDFS-7359. NameNode in secured HA cluster fails to start if dfs.namen…
cnauroth Nov 5, 2014
812ddc3
YARN-2805. Fixed ResourceManager to load HA configs correctly before …
vinoduec Nov 5, 2014
e29e864
YARN-2579. Fixed a deadlock issue when EmbeddedElectorService and Fat…
jian-he Nov 6, 2014
888fc4a
YARN-2813. Fixed NPE from MemoryTimelineStore.getDomains. Contributed…
xgong Nov 6, 2014
83ed42f
HDFS-7367. HDFS short-circuit read cannot negotiate shared memory slo…
Nov 6, 2014
4385476
YARN-2812. TestApplicationHistoryServer is likely to fail on less pow…
xgong Nov 6, 2014
7be74ea
MAPREDUCE-5960. JobSubmitter's check whether job.jar is local is inco…
jlowe Nov 6, 2014
b557f68
YARN-2818. Removed the now unnecessary user entity injection from Tim…
vinoduec Nov 6, 2014
e333584
YARN-2768 Improved Yarn Registry service record structure (stevel)
steveloughran Nov 6, 2014
c38c575
MAPREDUCE-5958. Wrong reduce task progress if map output is compresse…
kihwal Nov 6, 2014
bc6bc80
HADOOP-11274. ConcurrentModificationException in Configuration Copy C…
Jing9 Nov 7, 2014
21ef5af
YARN-2744. Fixed CapacityScheduler to validate node-labels correctly …
vinoduec Nov 7, 2014
a9b0436
HDFS-7364. Balancer always shows zero Bytes Already Moved. Contribute…
Jing9 Nov 7, 2014
a081bdc
Revert "HADOOP-11274. ConcurrentModificationException in Configuratio…
Jing9 Nov 7, 2014
8c3a0d5
YARN-2647. Added a queue CLI for getting queue information. Contribut…
vinoduec Nov 7, 2014
a2b46a7
HDFS-7221. TestDNFencingWithReplication fails consistently. Contribut…
umbrant Oct 21, 2014
92337e1
HDFS-7228. Fix TestDNFencing.testQueueingWithAppend. Contributed by Y…
Jing9 Oct 22, 2014
e398048
HADOOP-11280. TestWinUtils#testChmod fails after removal of NO_PROPAG…
cnauroth Nov 7, 2014
9f7396b
YARN-2823. Fixed ResourceManager app-attempt state machine to inform …
vinoduec Nov 7, 2014
09955ea
YARN-2810. TestRMProxyUsersConf fails on Windows VMs. Contributed by …
xgong Nov 7, 2014
71a18a5
YARN-2824. Fixed Capacity Scheduler to not crash when some node-label…
vinoduec Nov 7, 2014
326c722
YARN-2827. Fixed bugs in "yarn queue" CLI. Contributed by Wangda Tan.
vinoduec Nov 7, 2014
9adb31b
YARN-2803. MR distributed cache not working correctly on Windows afte…
cnauroth Nov 7, 2014
9fe9ee1
HDFS-7379. TestBalancer#testBalancerWithRamDisk creates test files in…
Nov 7, 2014
6593aaf
YARN-2753. Fixed a bunch of bugs in the NodeLabelsManager classes. Co…
vinoduec Nov 7, 2014
a07f478
HADOOP-11282. Skip NFS TestShellBasedIdMapping tests that are irrelev…
cnauroth Nov 7, 2014
e5c0fa2
YARN-2825. Container leak on NM. Contributed by Jian He
jlowe Nov 7, 2014
dcc1ab1
YARN-2632. Document NM Restart feature. Contributed by Junping Du and…
jlowe Nov 7, 2014
629274c
YARN-2819. NPE in ATS Timeline Domains when upgrading from 2.4 to 2.6…
xgong Nov 8, 2014
6ff765b
YARN-2826. Fixed user-groups mappings' refresh bug caused by YARN-282…
vinoduec Nov 8, 2014
33da0f8
YARN-2505. Supported get/add/remove/change labels in RM REST API. Con…
zjshen14 Nov 8, 2014
f098b26
YARN-2607. Fixed issues in TestDistributedShell. Contributed by Wangd…
vinoduec Nov 8, 2014
539ef7f
HDFS-7382. DataNode in secure mode may throw NullPointerException if …
cnauroth Nov 9, 2014
8553183
HADOOP-11286. Copied LimitInputStream from guava-0.14 to hadoop to av…
acmurthy Nov 8, 2014
c2cc879
YARN-2830. Add backwords compatible ContainerId.newInstance construct…
acmurthy Nov 9, 2014
35bd0f3
HADOOP-10786. Fix UGI#reloginFromKeytab on Java 8. Contributed by Ste…
Nov 10, 2014
e1608c2
Revert "HADOOP-10786. Fix UGI#reloginFromKeytab on Java 8. Contribute…
acmurthy Nov 10, 2014
c98fcd1
HDFS-7383. DataNode.requestShortCircuitFdsForRead may throw NullPoint…
Nov 10, 2014
e9f7079
Fix broken download of directories
kambatla Nov 5, 2014
be31db8
Updated CHANGES.txt to reflect hadoop-2.6.0 release dates.
acmurthy Nov 10, 2014
6a9534e
YARN-2834. Fixed ResourceManager to ignore token-renewal failures on …
vinoduec Nov 10, 2014
0ac7424
Release Notes for hadoop-2.6.0.
acmurthy Nov 10, 2014
60584c7
Preparing to release hadoop-2.6.0: Set version in branch-2.6 to 2.6.1…
acmurthy Nov 10, 2014
fc70bb3
Preparing to release hadoop-2.6.0: Set version in branch-2.6.0 to 2.6.0.
acmurthy Nov 10, 2014
90061f2
Set the release date for 2.5.2
kambatla Nov 10, 2014
3dad831
HADOOP-9576. Changed NetUtils#wrapException to throw EOFException ins…
jian-he Nov 11, 2014
fcd3067
HADOOP-9576. Merging to branch-2.6 for hadoop-2.6.0-rc1.
acmurthy Nov 12, 2014
28702a9
YARN-1964. Create Docker analog of the LinuxContainerExecutor in YARN
raviprak Nov 12, 2014
2261e67
YARN-2841. RMProxy should retry EOFException. Contributed by Jian He
xgong Nov 11, 2014
601aba7
YARN-2843. Fixed NodeLabelsManager to trim inputs for hosts and label…
vinoduec Nov 11, 2014
9d1bc9b
YARN-2843. Merging to branch-2.6 for hadoop-2.6.0-rc1.
acmurthy Nov 12, 2014
5278cff
YARN-2794. Fixed log messages about distributing system-credentials. …
zjshen14 Nov 12, 2014
1498dcc
HDFS-7387. NFS may only do partial commit due to a race between COMMI…
Nov 11, 2014
5847583
HDFS-7387. Merging to branch-2.6 for hadoop-2.6.0-rc1.
acmurthy Nov 12, 2014
4cd37ff
HADOOP-11217. (Addendum to allow SSLv2Hello) Disable SSLv3 in KMS. (R…
kambatla Nov 13, 2014
d530460
HDFS-7391. Renable SSLv2Hello in HttpFS. Contributed by Robert Kanter.
acmurthy Nov 13, 2014
a672d75
Fix CHANGES.txt to keep it consistent with trunk.
Nov 13, 2014
33031c9
YARN-2635. TestRM, TestRMRestart, TestClientToAMTokens should run wit…
kambatla Oct 3, 2014
86722bd
YARN-2635. Merging to branch-2.6 for hadoop-2.6.0-rc1.
acmurthy Nov 13, 2014
bf4d080
YARN-2853. Fixed a bug in ResourceManager causing apps to hang when t…
vinoduec Nov 13, 2014
9820c47
YARN-2846. Incorrect persist exit code for running containers in reac…
jlowe Nov 13, 2014
a97e9c0
YARN-2853. Merging to branch-2.6 for hadoop-2.6.0-rc1.
acmurthy Nov 13, 2014
9e8d1d7
MAPREDUCE-6156. Fetcher - connect() doesn't handle connection refused…
jlowe Nov 13, 2014
2254e81
YARN-1964. Adding changelog back in.
acmurthy Nov 13, 2014
8bcff27
HDFS-7385. ThreadLocal used in FSEditLog class causes FSImage permiss…
cnauroth Nov 13, 2014
e349649
Preparing to release hadoop-2.6.0-rc1.
acmurthy Nov 13, 2014
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.
20 changes: 20 additions & 0 deletions .gitattributes
Original file line number Diff line number Diff line change
@@ -0,0 +1,20 @@
# Auto detect text files and perform LF normalization
* text=auto

*.cs text diff=csharp
*.java text diff=java
*.html text diff=html
*.py text diff=python
*.pl text diff=perl
*.pm text diff=perl
*.css text
*.js text
*.sql text

*.sh text eol=lf

*.bat text eol=crlf
*.cmd text eol=crlf
*.vcxproj text merge=union eol=crlf
*.csproj text merge=union eol=crlf
*.sln text merge=union eol=crlf
14 changes: 14 additions & 0 deletions .gitignore
Original file line number Diff line number Diff line change
@@ -1,9 +1,23 @@
*.iml
*.ipr
*.iws
*.orig
*.rej
**/.keep
*.sdf
*.suo
*.vcxproj.user
.idea
.svn
.classpath
.project
.settings
target
build
hadoop-common-project/hadoop-kms/downloads/
hadoop-hdfs-project/hadoop-hdfs/downloads
hadoop-hdfs-project/hadoop-hdfs-httpfs/downloads
hadoop-common-project/hadoop-common/src/test/resources/contract-test-options.xml
hadoop-tools/hadoop-openstack/src/test/resources/contract-test-options.xml
hadoop-yarn-project/hadoop-yarn/hadoop-yarn-registry/src/main/tla/yarnregistry.toolbox
yarnregistry.pdf
253 changes: 235 additions & 18 deletions BUILDING.txt
Original file line number Diff line number Diff line change
@@ -1,27 +1,32 @@

Build instructions for Hadoop Common/HDFS using Maven
Build instructions for Hadoop

----------------------------------------------------------------------------------
Requirements:

* Unix System
* JDK 1.6
* Maven 3.0
* Forrest 0.8 (if generating docs)
* JDK 1.6+
* Maven 3.0 or later
* Findbugs 1.3.9 (if running findbugs)
* Autotools (if compiling native code)
* ProtocolBuffer 2.5.0
* CMake 2.6 or newer (if compiling native code), must be 3.0 or newer on Mac
* Zlib devel (if compiling native code)
* openssl devel ( if compiling native hadoop-pipes )
* Internet connection for first build (to fetch all Maven and Hadoop dependencies)

----------------------------------------------------------------------------------
Maven modules:
Maven main modules:

hadoop (Main Hadoop project)
- hadoop-project (Parent POM for all Hadoop Maven modules. )
(All plugins & dependencies versions are defined here.)
- hadoop-project-dist (Parent POM for modules that generate distributions.)
- hadoop-annotations (Generates the Hadoop doclet used to generated the Javadocs)
- hadoop-common (Hadoop Common)
- hadoop-hdfs (Hadoop HDFS)
hadoop (Main Hadoop project)
- hadoop-project (Parent POM for all Hadoop Maven modules. )
(All plugins & dependencies versions are defined here.)
- hadoop-project-dist (Parent POM for modules that generate distributions.)
- hadoop-annotations (Generates the Hadoop doclet used to generated the Javadocs)
- hadoop-assemblies (Maven assemblies used by the different modules)
- hadoop-common-project (Hadoop Common)
- hadoop-hdfs-project (Hadoop HDFS)
- hadoop-mapreduce-project (Hadoop MapReduce)
- hadoop-tools (Hadoop tools like Streaming, Distcp, etc.)
- hadoop-dist (Hadoop distribution assembler)

----------------------------------------------------------------------------------
Where to run Maven from?
Expand All @@ -45,22 +50,234 @@ Maven build goals:
* Run Rat : mvn apache-rat:check
* Build javadocs : mvn javadoc:javadoc
* Build distribution : mvn package [-Pdist][-Pdocs][-Psrc][-Pnative][-Dtar]
* Change Hadoop version : mvn versions:set -DnewVersion=NEWVERSION

Build options:

* Use -Pnative to compile/bundle native code
* Use -Dsnappy.prefix=(/usr/local) & -Dbundle.snappy=(false) to compile
Snappy JNI bindings and to bundle Snappy SO files
* Use -Pdocs to generate & bundle the documentation in the distribution (using -Pdist)
* Use -Psrc to bundle the source in the distribution (using -Pdist)
* Use -Psrc to create a project source TAR.GZ
* Use -Dtar to create a TAR with the distribution (using -Pdist)

Snappy build options:

Snappy is a compression library that can be utilized by the native code.
It is currently an optional component, meaning that Hadoop can be built with
or without this dependency.

* Use -Drequire.snappy to fail the build if libsnappy.so is not found.
If this option is not specified and the snappy library is missing,
we silently build a version of libhadoop.so that cannot make use of snappy.
This option is recommended if you plan on making use of snappy and want
to get more repeatable builds.

* Use -Dsnappy.prefix to specify a nonstandard location for the libsnappy
header files and library files. You do not need this option if you have
installed snappy using a package manager.
* Use -Dsnappy.lib to specify a nonstandard location for the libsnappy library
files. Similarly to snappy.prefix, you do not need this option if you have
installed snappy using a package manager.
* Use -Dbundle.snappy to copy the contents of the snappy.lib directory into
the final tar file. This option requires that -Dsnappy.lib is also given,
and it ignores the -Dsnappy.prefix option.

OpenSSL build options:

OpenSSL includes a crypto library that can be utilized by the native code.
It is currently an optional component, meaning that Hadoop can be built with
or without this dependency.

* Use -Drequire.openssl to fail the build if libcrypto.so is not found.
If this option is not specified and the openssl library is missing,
we silently build a version of libhadoop.so that cannot make use of
openssl. This option is recommended if you plan on making use of openssl
and want to get more repeatable builds.
* Use -Dopenssl.prefix to specify a nonstandard location for the libcrypto
header files and library files. You do not need this option if you have
installed openssl using a package manager.
* Use -Dopenssl.lib to specify a nonstandard location for the libcrypto library
files. Similarly to openssl.prefix, you do not need this option if you have
installed openssl using a package manager.
* Use -Dbundle.openssl to copy the contents of the openssl.lib directory into
the final tar file. This option requires that -Dopenssl.lib is also given,
and it ignores the -Dopenssl.prefix option.

Tests options:

* Use -DskipTests to skip tests when running the following Maven goals:
'package', 'install', 'deploy' or 'verify'
* -Dtest=<TESTCLASSNAME>,....
* -Dtest=<TESTCLASSNAME>,<TESTCLASSNAME#METHODNAME>,....
* -Dtest.exclude=<TESTCLASSNAME>
* -Dtest.exclude.pattern=**/<TESTCLASSNAME1>.java,**/<TESTCLASSNAME2>.java

----------------------------------------------------------------------------------
Building components separately

If you are building a submodule directory, all the hadoop dependencies this
submodule has will be resolved as all other 3rd party dependencies. This is,
from the Maven cache or from a Maven repository (if not available in the cache
or the SNAPSHOT 'timed out').
An alternative is to run 'mvn install -DskipTests' from Hadoop source top
level once; and then work from the submodule. Keep in mind that SNAPSHOTs
time out after a while, using the Maven '-nsu' will stop Maven from trying
to update SNAPSHOTs from external repos.

----------------------------------------------------------------------------------
Protocol Buffer compiler

The version of Protocol Buffer compiler, protoc, must match the version of the
protobuf JAR.

If you have multiple versions of protoc in your system, you can set in your
build shell the HADOOP_PROTOC_PATH environment variable to point to the one you
want to use for the Hadoop build. If you don't define this environment variable,
protoc is looked up in the PATH.
----------------------------------------------------------------------------------
Importing projects to eclipse

When you import the project to eclipse, install hadoop-maven-plugins at first.

$ cd hadoop-maven-plugins
$ mvn install

Then, generate eclipse project files.

$ mvn eclipse:eclipse -DskipTests

At last, import to eclipse by specifying the root directory of the project via
[File] > [Import] > [Existing Projects into Workspace].

----------------------------------------------------------------------------------
Building distributions:

Create binary distribution without native code and without documentation:

$ mvn package -Pdist -DskipTests -Dtar

Create binary distribution with native code and with documentation:

$ mvn package -Pdist,native,docs -DskipTests -Dtar

Create source distribution:

$ mvn package -Psrc -DskipTests

Create source and binary distributions with native code and documentation:

$ mvn package -Pdist,native,docs,src -DskipTests -Dtar

Create a local staging version of the website (in /tmp/hadoop-site)

$ mvn clean site; mvn site:stage -DstagingDirectory=/tmp/hadoop-site

----------------------------------------------------------------------------------
Installing Hadoop

Look for these HTML files after you build the document by the above commands.

* Single Node Setup:
hadoop-project-dist/hadoop-common/SingleCluster.html

* Cluster Setup:
hadoop-project-dist/hadoop-common/ClusterSetup.html

----------------------------------------------------------------------------------

Handling out of memory errors in builds

----------------------------------------------------------------------------------

If the build process fails with an out of memory error, you should be able to fix
it by increasing the memory used by maven -which can be done via the environment
variable MAVEN_OPTS.

Here is an example setting to allocate between 256 and 512 MB of heap space to
Maven

export MAVEN_OPTS="-Xms256m -Xmx512m"

----------------------------------------------------------------------------------

Building on OS/X

----------------------------------------------------------------------------------

A one-time manual step is required to enable building Hadoop OS X with Java 7
every time the JDK is updated.
see: https://issues.apache.org/jira/browse/HADOOP-9350

$ sudo mkdir `/usr/libexec/java_home`/Classes
$ sudo ln -s `/usr/libexec/java_home`/lib/tools.jar `/usr/libexec/java_home`/Classes/classes.jar

----------------------------------------------------------------------------------

Building on Windows

----------------------------------------------------------------------------------
Requirements:

* Windows System
* JDK 1.6+
* Maven 3.0 or later
* Findbugs 1.3.9 (if running findbugs)
* ProtocolBuffer 2.5.0
* CMake 2.6 or newer
* Windows SDK or Visual Studio 2010 Professional
* Unix command-line tools from GnuWin32 or Cygwin: sh, mkdir, rm, cp, tar, gzip
* zlib headers (if building native code bindings for zlib)
* Internet connection for first build (to fetch all Maven and Hadoop dependencies)

If using Visual Studio, it must be Visual Studio 2010 Professional (not 2012).
Do not use Visual Studio Express. It does not support compiling for 64-bit,
which is problematic if running a 64-bit system. The Windows SDK is free to
download here:

http://www.microsoft.com/en-us/download/details.aspx?id=8279

----------------------------------------------------------------------------------
Building:

Keep the source code tree in a short path to avoid running into problems related
to Windows maximum path length limitation. (For example, C:\hdc).

Run builds from a Windows SDK Command Prompt. (Start, All Programs,
Microsoft Windows SDK v7.1, Windows SDK 7.1 Command Prompt.)

JAVA_HOME must be set, and the path must not contain spaces. If the full path
would contain spaces, then use the Windows short path instead.

You must set the Platform environment variable to either x64 or Win32 depending
on whether you're running a 64-bit or 32-bit system. Note that this is
case-sensitive. It must be "Platform", not "PLATFORM" or "platform".
Environment variables on Windows are usually case-insensitive, but Maven treats
them as case-sensitive. Failure to set this environment variable correctly will
cause msbuild to fail while building the native code in hadoop-common.

set Platform=x64 (when building on a 64-bit system)
set Platform=Win32 (when building on a 32-bit system)

Several tests require that the user must have the Create Symbolic Links
privilege.

All Maven goals are the same as described above with the exception that
native code is built by enabling the 'native-win' Maven profile. -Pnative-win
is enabled by default when building on Windows since the native components
are required (not optional) on Windows.

If native code bindings for zlib are required, then the zlib headers must be
deployed on the build machine. Set the ZLIB_HOME environment variable to the
directory containing the headers.

set ZLIB_HOME=C:\zlib-1.2.7

At runtime, zlib1.dll must be accessible on the PATH. Hadoop has been tested
with zlib 1.2.7, built using Visual Studio 2010 out of contrib\vstudio\vc10 in
the zlib 1.2.7 source tree.

http://www.zlib.net/

----------------------------------------------------------------------------------
Building distributions:

* Build distribution with native code : mvn package [-Pdist][-Pdocs][-Psrc][-Dtar]

Loading