Return-Path: Delivered-To: apmail-hadoop-mapreduce-dev-archive@minotaur.apache.org Received: (qmail 98376 invoked from network); 23 Nov 2010 00:25:37 -0000 Received: from unknown (HELO mail.apache.org) (140.211.11.3) by 140.211.11.9 with SMTP; 23 Nov 2010 00:25:37 -0000 Received: (qmail 12977 invoked by uid 500); 23 Nov 2010 00:26:09 -0000 Delivered-To: apmail-hadoop-mapreduce-dev-archive@hadoop.apache.org Received: (qmail 12894 invoked by uid 500); 23 Nov 2010 00:26:08 -0000 Mailing-List: contact mapreduce-dev-help@hadoop.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: mapreduce-dev@hadoop.apache.org Delivered-To: mailing list mapreduce-dev@hadoop.apache.org Received: (qmail 12885 invoked by uid 99); 23 Nov 2010 00:26:08 -0000 Received: from athena.apache.org (HELO athena.apache.org) (140.211.11.136) by apache.org (qpsmtpd/0.29) with ESMTP; Tue, 23 Nov 2010 00:26:08 +0000 X-ASF-Spam-Status: No, hits=-2000.0 required=10.0 tests=ALL_TRUSTED X-Spam-Check-By: apache.org Received: from [140.211.11.8] (HELO aegis.apache.org) (140.211.11.8) by apache.org (qpsmtpd/0.29) with ESMTP; Tue, 23 Nov 2010 00:26:05 +0000 Received: from aegis (localhost [127.0.0.1]) by aegis.apache.org (Postfix) with ESMTP id A031EC0161 for ; Tue, 23 Nov 2010 00:25:45 +0000 (UTC) Date: Tue, 23 Nov 2010 00:25:45 +0000 (UTC) From: Apache Hudson Server To: mapreduce-dev@hadoop.apache.org Message-ID: <1060078305.7891290471945655.JavaMail.hudson@aegis> In-Reply-To: <111913340.6031290239371913.JavaMail.hudson@aegis> References: <111913340.6031290239371913.JavaMail.hudson@aegis> Subject: Build failed in Hudson: Hadoop-Mapreduce-trunk-Commit #553 MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 7bit See Changes: [schen] MAPREDUCE-2184. Port DistRaid.java to new mapreduce API. (Ramkumar Vadali via schen) ------------------------------------------ [...truncated 35718 lines...] [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,324 INFO util.ProcessTree (ProcessTree.java:isSetsidSupported(65)) - setsid exited with exit code 0 [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,338 INFO mapred.Task (Task.java:initialize(523)) - Using ResourceCalculatorPlugin : org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin@701a27 [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,419 INFO reduce.MergeManager (MergeManager.java:(178)) - MergerManager: memoryLimit=141387360, maxSingleShuffleLimit=35346840, mergeThreshold=93315664, ioSortFactor=10, memToMemMergeOutputsThreshold=10 [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,426 INFO reduce.EventFetcher (EventFetcher.java:run(61)) - attempt_20101123002333772_0002_r_000000_0 Thread started: EventFetcher for fetching Map Completion Events [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,439 INFO reduce.ShuffleScheduler (ShuffleScheduler.java:getHost(303)) - Assiging localhost:35218 with 1 to fetcher#3 [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,440 INFO reduce.ShuffleScheduler (ShuffleScheduler.java:getMapsForHost(333)) - assigned 1 of 1 to localhost:35218 to fetcher#3 [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,448 INFO reduce.EventFetcher (EventFetcher.java:run(69)) - attempt_20101123002333772_0002_r_000000_0: Got 1 new map-outputs [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,719 INFO reduce.Fetcher (Fetcher.java:copyFromHost(217)) - for url=35218/mapOutput?job=job_20101123002333772_0002&reduce=0&map=attempt_20101123002333772_0002_m_000000_0 sent hash and receievd reply [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,722 INFO reduce.Fetcher (Fetcher.java:copyMapOutput(314)) - fetcher#3 about to shuffle output of map attempt_20101123002333772_0002_m_000000_0 decomp: 107 len: 111 to MEMORY [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,724 INFO reduce.Fetcher (Fetcher.java:shuffleToMemory(479)) - Read 107 bytes from map-output for attempt_20101123002333772_0002_m_000000_0 [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,724 INFO reduce.MergeManager (MergeManager.java:closeInMemoryFile(277)) - closeInMemoryFile -> map-output of size: 107, inMemoryMapOutputs.size() -> 1 [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,726 INFO reduce.ShuffleScheduler (ShuffleScheduler.java:freeHost(345)) - localhost:35218 freed by fetcher#3 in 286s [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,729 INFO reduce.MergeManager (MergeManager.java:finalMerge(629)) - finalMerge called with 1 in-memory map-outputs and 0 on-disk map-outputs [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,754 INFO mapred.Merger (Merger.java:merge(549)) - Merging 1 sorted segments [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,754 INFO mapred.Merger (Merger.java:merge(648)) - Down to the last merge-pass, with 1 segments left of total size: 103 bytes [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,764 INFO reduce.MergeManager (MergeManager.java:finalMerge(701)) - Merged 1 segments, 107 bytes to disk to satisfy reduce memory limit [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,765 INFO reduce.MergeManager (MergeManager.java:finalMerge(727)) - Merging 1 files, 111 bytes from disk [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,766 INFO reduce.MergeManager (MergeManager.java:finalMerge(742)) - Merging 0 segments, 0 bytes from memory into reduce [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,766 INFO mapred.Merger (Merger.java:merge(549)) - Merging 1 sorted segments [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,769 INFO mapred.Merger (Merger.java:merge(648)) - Down to the last merge-pass, with 1 segments left of total size: 103 bytes [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,784 WARN conf.Configuration (Configuration.java:set(582)) - mapred.skip.on is deprecated. Instead, use mapreduce.job.skiprecords [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:10,800 INFO mapred.Task (Task.java:done(848)) - Task:attempt_20101123002333772_0002_r_000000_0 is done. And is in the process of commiting [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:12,842 INFO mapred.Task (Task.java:commit(1009)) - Task attempt_20101123002333772_0002_r_000000_0 is allowed to commit now [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:12,848 INFO output.FileOutputCommitter (FileOutputCommitter.java:commitTask(173)) - Saved output of task 'attempt_20101123002333772_0002_r_000000_0' to [junit] attempt_20101123002333772_0002_r_000000_0: 2010-11-23 00:24:12,881 INFO mapred.Task (Task.java:sendDone(968)) - Task 'attempt_20101123002333772_0002_r_000000_0' done. [junit] 2010-11-23 00:24:16,173 INFO mapred.TaskTracker (TaskTracker.java:getTask(3224)) - JVM with ID: jvm_20101123002333772_0002_m_-987686170 given task: attempt_20101123002333772_0002_m_000001_0 [junit] 2010-11-23 00:24:16,487 INFO mapred.TaskTracker (TaskTracker.java:reportProgress(2656)) - attempt_20101123002333772_0002_m_000001_0 0.0% [junit] 2010-11-23 00:24:16,561 INFO mapred.TaskTracker (TaskTracker.java:reportProgress(2656)) - attempt_20101123002333772_0002_m_000001_0 0.0% cleanup > map [junit] 2010-11-23 00:24:16,562 INFO mapred.TaskTracker (TaskTracker.java:reportDone(2737)) - Task attempt_20101123002333772_0002_m_000001_0 is done. [junit] 2010-11-23 00:24:16,562 INFO mapred.TaskTracker (TaskTracker.java:reportDone(2738)) - reported output size for attempt_20101123002333772_0002_m_000001_0 was -1 [junit] 2010-11-23 00:24:16,563 INFO mapred.TaskTracker (TaskTracker.java:addFreeSlots(2223)) - addFreeSlot : current free slots : 2 [junit] 2010-11-23 00:24:16,716 WARN util.ProcessTree (ProcessTree.java:sendSignal(134)) - Error executing shell command org.apache.hadoop.util.Shell$ExitCodeException: kill: No such process [junit] [junit] 2010-11-23 00:24:16,716 INFO util.ProcessTree (ProcessTree.java:sendSignal(137)) - Sending signal to all members of process group -17863: SIGTERM. Exit code 1 [junit] 2010-11-23 00:24:17,166 INFO mapreduce.Job (Job.java:monitorAndPrintJob(1099)) - map 100% reduce 100% [junit] 2010-11-23 00:24:18,053 INFO mapred.JvmManager (JvmManager.java:runChild(472)) - JVM : jvm_20101123002333772_0002_r_532540159 exited with exit code 0. Number of tasks it ran: 1 [junit] 2010-11-23 00:24:18,321 INFO mapred.JobInProgress (JobInProgress.java:completedTask(2636)) - Task 'attempt_20101123002333772_0002_m_000001_0' has completed task_20101123002333772_0002_m_000001 successfully. [junit] 2010-11-23 00:24:18,323 INFO mapred.JobInProgress (JobInProgress.java:jobComplete(2837)) - Job job_20101123002333772_0002 has completed successfully. [junit] 2010-11-23 00:24:18,324 INFO mapred.JobInProgress$JobSummary (JobInProgress.java:logJobSummary(3611)) - jobId=job_20101123002333772_0002,submitTime=1290471842004,launchTime=1290471842181,firstMapTaskLaunchTime=1290471846286,firstReduceTaskLaunchTime=1290471849299,firstJobSetupTaskLaunchTime=1290471843276,firstJobCleanupTaskLaunchTime=1290471855315,finishTime=1290471858323,numMaps=1,numSlotsPerMap=1,numReduces=1,numSlotsPerReduce=1,user=hudson,queue=default,status=SUCCEEDED,mapSlotSeconds=3,reduceSlotsSeconds=3,clusterMapCapacity=4,clusterReduceCapacity=4 [junit] 2010-11-23 00:24:18,329 INFO jobhistory.JobHistory (JobHistory.java:moveToDoneNow(354)) - Moving to [junit] 2010-11-23 00:24:18,330 INFO mapred.JobTracker (JobTracker.java:removeTaskEntry(1863)) - Removing task 'attempt_20101123002333772_0002_m_000000_0' [junit] 2010-11-23 00:24:18,330 INFO mapred.JobTracker (JobTracker.java:removeTaskEntry(1863)) - Removing task 'attempt_20101123002333772_0002_m_000001_0' [junit] 2010-11-23 00:24:18,330 INFO mapred.JobTracker (JobTracker.java:removeTaskEntry(1863)) - Removing task 'attempt_20101123002333772_0002_m_000002_0' [junit] 2010-11-23 00:24:18,331 INFO mapred.JobTracker (JobTracker.java:removeTaskEntry(1863)) - Removing task 'attempt_20101123002333772_0002_r_000000_0' [junit] 2010-11-23 00:24:18,331 INFO mapred.TaskTracker (TaskTracker.java:purgeJob(1972)) - Received 'KillJobAction' for job: job_20101123002333772_0002 [junit] 2010-11-23 00:24:18,332 INFO mapred.IndexCache (IndexCache.java:removeMap(141)) - Map ID attempt_20101123002333772_0002_m_000001_0 not found in cache [junit] 2010-11-23 00:24:18,347 INFO mapred.UserLogCleaner (UserLogCleaner.java:markJobLogsForDeletion(174)) - Adding job_20101123002333772_0002 for user-log deletion with retainTimeStamp:1290558258346 [junit] 2010-11-23 00:24:18,387 INFO jobhistory.JobHistory (JobHistory.java:moveToDoneNow(354)) - Moving to [junit] 2010-11-23 00:24:18,390 INFO mapred.TaskTracker (TaskTracker.java:purgeJob(1972)) - Received 'KillJobAction' for job: job_20101123002333772_0002 [junit] 2010-11-23 00:24:18,390 WARN mapred.TaskTracker (TaskTracker.java:purgeJob(1979)) - Unknown job job_20101123002333772_0002 being deleted. [junit] 2010-11-23 00:24:18,435 INFO mapred.JobInProgress (JobInProgress.java:cleanupLocalizedJobConf(3652)) - Deleting localized job conf at [junit] 2010-11-23 00:24:19,173 INFO mapreduce.Job (Job.java:printTaskEvents(1200)) - Task Id : attempt_20101123002333772_0002_m_000001_0, Status : SUCCEEDED [junit] attempt_20101123002333772_0002_m_000001_0: 2010-11-23 00:24:16,385 INFO jvm.JvmMetrics (JvmMetrics.java:init(76)) - Initializing JVM Metrics with processName=MAP, sessionId= [junit] attempt_20101123002333772_0002_m_000001_0: 2010-11-23 00:24:16,388 WARN conf.Configuration (Configuration.java:handleDeprecation(313)) - user.name is deprecated. Instead, use mapreduce.job.user.name [junit] attempt_20101123002333772_0002_m_000001_0: 2010-11-23 00:24:16,418 INFO util.ProcessTree (ProcessTree.java:isSetsidSupported(65)) - setsid exited with exit code 0 [junit] attempt_20101123002333772_0002_m_000001_0: 2010-11-23 00:24:16,431 INFO mapred.Task (Task.java:initialize(523)) - Using ResourceCalculatorPlugin : org.apache.hadoop.mapreduce.util.LinuxResourceCalculatorPlugin@56860b [junit] attempt_20101123002333772_0002_m_000001_0: 2010-11-23 00:24:16,488 INFO mapred.Task (Task.java:runJobCleanupTask(1057)) - Cleaning up job [junit] attempt_20101123002333772_0002_m_000001_0: 2010-11-23 00:24:16,488 INFO mapred.Task (Task.java:runJobCleanupTask(1069)) - Committing job [junit] attempt_20101123002333772_0002_m_000001_0: 2010-11-23 00:24:16,502 INFO mapred.Task (Task.java:done(848)) - Task:attempt_20101123002333772_0002_m_000001_0 is done. And is in the process of commiting [junit] attempt_20101123002333772_0002_m_000001_0: 2010-11-23 00:24:16,563 INFO mapred.Task (Task.java:sendDone(968)) - Task 'attempt_20101123002333772_0002_m_000001_0' done. [junit] 2010-11-23 00:24:19,178 INFO mapreduce.Job (Job.java:monitorAndPrintJob(1108)) - Job complete: job_20101123002333772_0002 [junit] 2010-11-23 00:24:19,179 INFO mapred.AuditLogger (AuditLogger.java:logSuccess(84)) - USER=hudson IP=127.0.0.1 OPERATION=VIEW_JOB_COUNTERS TARGET=job_20101123002333772_0002 in queue default RESULT=SUCCESS [junit] 2010-11-23 00:24:19,184 INFO mapreduce.Job (Job.java:monitorAndPrintJob(1111)) - Counters: 33 [junit] FileSystemCounters [junit] FILE_BYTES_READ=518 [junit] FILE_BYTES_WRITTEN=331 [junit] Shuffle Errors [junit] BAD_ID=0 [junit] CONNECTION=0 [junit] IO_ERROR=0 [junit] WRONG_LENGTH=0 [junit] WRONG_MAP=0 [junit] WRONG_REDUCE=0 [junit] Job Counters [junit] Total time spent by all maps waiting after reserving slots (ms)=0 [junit] Total time spent by all reduces waiting after reserving slots (ms)=0 [junit] Rack-local map tasks=1 [junit] SLOTS_MILLIS_MAPS=3758 [junit] SLOTS_MILLIS_REDUCES=3573 [junit] Launched map tasks=1 [junit] Launched reduce tasks=1 [junit] Map-Reduce Framework [junit] Combine input records=13 [junit] Combine output records=10 [junit] CPU_MILLISECONDS=1330 [junit] Failed Shuffles=0 [junit] GC time elapsed (ms)=23 [junit] Map input records=4 [junit] Map output bytes=112 [junit] Map output records=13 [junit] Merged Map outputs=1 [junit] PHYSICAL_MEMORY_BYTES=102473728 [junit] Reduce input groups=10 [junit] Reduce input records=10 [junit] Reduce output records=10 [junit] Reduce shuffle bytes=111 [junit] Shuffled Maps =1 [junit] Spilled Records=20 [junit] SPLIT_RAW_BYTES=305 [junit] VIRTUAL_MEMORY_BYTES=742445056 [junit] a 1 [junit] count 1 [junit] file 1 [junit] is 1 [junit] more 1 [junit] multi 1 [junit] of 1 [junit] test 4 [junit] this 1 [junit] word 1 [junit] [junit] 2010-11-23 00:24:19,190 INFO util.AsyncDiskService (AsyncDiskService.java:shutdown(111)) - Shutting down all AsyncDiskService threads... [junit] 2010-11-23 00:24:19,191 INFO util.AsyncDiskService (AsyncDiskService.java:awaitTermination(140)) - All AsyncDiskService threads are terminated. [junit] 2010-11-23 00:24:19,192 INFO mapred.TaskTracker (TaskTracker.java:run(865)) - Shutting down: Map-events fetcher for all reduce tasks on tracker_host0.foo.com:localhost/127.0.0.1:45828 [junit] 2010-11-23 00:24:19,194 ERROR filecache.TrackerDistributedCacheManager (TrackerDistributedCacheManager.java:run(946)) - Exception in DistributedCache CleanupThread. [junit] java.lang.InterruptedException: sleep interrupted [junit] at java.lang.Thread.sleep(Native Method) [junit] at org.apache.hadoop.mapreduce.filecache.TrackerDistributedCacheManager$CleanupThread.run(TrackerDistributedCacheManager.java:943) [junit] 2010-11-23 00:24:21,733 INFO mapred.JvmManager (JvmManager.java:runChild(472)) - JVM : jvm_20101123002333772_0002_m_-987686170 exited with exit code 0. Number of tasks it ran: 1 [junit] 2010-11-23 00:24:21,733 INFO ipc.Server (Server.java:stop(1601)) - Stopping server on 45828 [junit] 2010-11-23 00:24:21,734 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 1 on 45828: exiting [junit] 2010-11-23 00:24:21,734 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 3 on 45828: exiting [junit] 2010-11-23 00:24:21,734 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 0 on 45828: exiting [junit] 2010-11-23 00:24:21,735 INFO ipc.Server (Server.java:run(675)) - Stopping IPC Server Responder [junit] 2010-11-23 00:24:21,735 INFO ipc.Server (Server.java:run(475)) - Stopping IPC Server listener on 45828 [junit] 2010-11-23 00:24:21,735 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 2 on 45828: exiting [junit] 2010-11-23 00:24:21,735 INFO mapred.TaskTracker (TaskTracker.java:shutdown(1256)) - Shutting down StatusHttpServer [junit] 2010-11-23 00:24:21,742 ERROR mapred.TaskTracker (TaskTracker.java:offerService(1584)) - Caught exception: java.io.IOException: Call to localhost/127.0.0.1:40237 failed on local exception: java.nio.channels.ClosedByInterruptException [junit] at org.apache.hadoop.ipc.Client.wrapException(Client.java:1063) [junit] at org.apache.hadoop.ipc.Client.call(Client.java:1031) [junit] at org.apache.hadoop.ipc.WritableRpcEngine$Invoker.invoke(WritableRpcEngine.java:198) [junit] at org.apache.hadoop.mapred.$Proxy1.heartbeat(Unknown Source) [junit] at org.apache.hadoop.mapred.TaskTracker.transmitHeartBeat(TaskTracker.java:1684) [junit] at org.apache.hadoop.mapred.TaskTracker.offerService(TaskTracker.java:1515) [junit] at org.apache.hadoop.mapred.TaskTracker.run(TaskTracker.java:2420) [junit] at org.apache.hadoop.mapred.MiniMRCluster$TaskTrackerRunner.run(MiniMRCluster.java:228) [junit] at java.lang.Thread.run(Thread.java:619) [junit] Caused by: java.nio.channels.ClosedByInterruptException [junit] at java.nio.channels.spi.AbstractInterruptibleChannel.end(AbstractInterruptibleChannel.java:184) [junit] at sun.nio.ch.SocketChannelImpl.write(SocketChannelImpl.java:341) [junit] at org.apache.hadoop.net.SocketOutputStream$Writer.performIO(SocketOutputStream.java:60) [junit] at org.apache.hadoop.net.SocketIOWithTimeout.doIO(SocketIOWithTimeout.java:142) [junit] at org.apache.hadoop.net.SocketOutputStream.write(SocketOutputStream.java:151) [junit] at org.apache.hadoop.net.SocketOutputStream.write(SocketOutputStream.java:112) [junit] at java.io.BufferedOutputStream.flushBuffer(BufferedOutputStream.java:65) [junit] at java.io.BufferedOutputStream.flush(BufferedOutputStream.java:123) [junit] at java.io.DataOutputStream.flush(DataOutputStream.java:106) [junit] at org.apache.hadoop.ipc.Client$Connection.sendParam(Client.java:739) [junit] at org.apache.hadoop.ipc.Client.call(Client.java:1009) [junit] ... 7 more [junit] [junit] 2010-11-23 00:24:21,744 INFO util.AsyncDiskService (AsyncDiskService.java:shutdown(111)) - Shutting down all AsyncDiskService threads... [junit] 2010-11-23 00:24:21,744 INFO util.AsyncDiskService (AsyncDiskService.java:awaitTermination(140)) - All AsyncDiskService threads are terminated. [junit] 2010-11-23 00:24:21,747 INFO util.AsyncDiskService (AsyncDiskService.java:shutdown(111)) - Shutting down all AsyncDiskService threads... [junit] 2010-11-23 00:24:21,748 INFO util.AsyncDiskService (AsyncDiskService.java:awaitTermination(140)) - All AsyncDiskService threads are terminated. [junit] 2010-11-23 00:24:21,748 INFO mapred.TaskTracker (TaskTracker.java:run(865)) - Shutting down: Map-events fetcher for all reduce tasks on tracker_host1.foo.com:localhost/127.0.0.1:48122 [junit] 2010-11-23 00:24:21,749 ERROR filecache.TrackerDistributedCacheManager (TrackerDistributedCacheManager.java:run(946)) - Exception in DistributedCache CleanupThread. [junit] java.lang.InterruptedException: sleep interrupted [junit] at java.lang.Thread.sleep(Native Method) [junit] at org.apache.hadoop.mapreduce.filecache.TrackerDistributedCacheManager$CleanupThread.run(TrackerDistributedCacheManager.java:943) [junit] 2010-11-23 00:24:21,749 INFO ipc.Server (Server.java:stop(1601)) - Stopping server on 48122 [junit] 2010-11-23 00:24:21,749 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 0 on 48122: exiting [junit] 2010-11-23 00:24:21,749 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 2 on 48122: exiting [junit] 2010-11-23 00:24:21,749 INFO mapred.TaskTracker (TaskTracker.java:shutdown(1256)) - Shutting down StatusHttpServer [junit] 2010-11-23 00:24:21,749 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 1 on 48122: exiting [junit] 2010-11-23 00:24:21,749 INFO ipc.Server (Server.java:run(675)) - Stopping IPC Server Responder [junit] 2010-11-23 00:24:21,749 INFO ipc.Server (Server.java:run(475)) - Stopping IPC Server listener on 48122 [junit] 2010-11-23 00:24:21,749 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 3 on 48122: exiting [junit] 2010-11-23 00:24:21,751 INFO mapred.TaskTracker (TaskTracker.java:offerService(1564)) - Interrupted. Closing down. [junit] 2010-11-23 00:24:21,752 INFO util.AsyncDiskService (AsyncDiskService.java:shutdown(111)) - Shutting down all AsyncDiskService threads... [junit] 2010-11-23 00:24:21,752 INFO util.AsyncDiskService (AsyncDiskService.java:awaitTermination(140)) - All AsyncDiskService threads are terminated. [junit] 2010-11-23 00:24:21,752 INFO mapred.JobTracker (JobTracker.java:close(1765)) - Stopping infoServer [junit] 2010-11-23 00:24:21,874 INFO mapred.JobTracker (JobTracker.java:close(1773)) - Stopping interTrackerServer [junit] 2010-11-23 00:24:21,874 INFO ipc.Server (Server.java:stop(1601)) - Stopping server on 40237 [junit] 2010-11-23 00:24:21,874 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 0 on 40237: exiting [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 3 on 40237: exiting [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 4 on 40237: exiting [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 8 on 40237: exiting [junit] 2010-11-23 00:24:21,875 INFO mapred.JobTracker (JobTracker.java:stopExpireTrackersThread(1812)) - Stopping expireTrackers [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 1 on 40237: exiting [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 2 on 40237: exiting [junit] 2010-11-23 00:24:21,876 INFO mapred.EagerTaskInitializationListener (EagerTaskInitializationListener.java:terminate(108)) - Stopping Job Init Manager thread [junit] 2010-11-23 00:24:21,876 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 6 on 40237: exiting [junit] 2010-11-23 00:24:21,875 INFO mapred.JobTracker (JobTracker.java:offerService(1760)) - Stopped interTrackerServer [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(675)) - Stopping IPC Server Responder [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(475)) - Stopping IPC Server listener on 40237 [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 9 on 40237: exiting [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 7 on 40237: exiting [junit] 2010-11-23 00:24:21,875 INFO ipc.Server (Server.java:run(1444)) - IPC Server handler 5 on 40237: exiting [junit] 2010-11-23 00:24:21,876 INFO mapred.EagerTaskInitializationListener (EagerTaskInitializationListener.java:run(61)) - JobInitManagerThread interrupted. [junit] 2010-11-23 00:24:21,877 INFO mapred.EagerTaskInitializationListener (EagerTaskInitializationListener.java:run(65)) - Shutting down thread pool [junit] 2010-11-23 00:24:21,878 INFO mapred.JobTracker (JobTracker.java:close(1783)) - Stopping expireLaunchingTasks [junit] 2010-11-23 00:24:21,878 INFO jobhistory.JobHistory (JobHistory.java:shutDown(195)) - Interrupting History Cleaner [junit] 2010-11-23 00:24:21,878 INFO jobhistory.JobHistory (JobHistory.java:run(544)) - History Cleaner thread exiting [junit] 2010-11-23 00:24:21,879 INFO mapred.JobTracker (JobTracker.java:close(1806)) - stopped all jobtracker services [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 48.27 sec [junit] Running org.apache.hadoop.mapreduce.lib.input.TestFileInputFormat [junit] 2010-11-23 00:24:22,924 WARN conf.Configuration (Configuration.java:set(582)) - fs.default.name is deprecated. Instead, use fs.defaultFS [junit] 2010-11-23 00:24:23,126 WARN conf.Configuration (Configuration.java:set(582)) - fs.default.name is deprecated. Instead, use fs.defaultFS [junit] defaultfs.getUri() = s3://abc:xyz@hostname [junit] original = file:/foo [junit] results = [file:/foo] [junit] original = file:/bar [junit] results = [file:/bar] [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.996 sec [junit] Running org.apache.hadoop.mapreduce.lib.output.TestFileOutputCommitter [junit] 2010-11-23 00:24:24,596 INFO output.FileOutputCommitter (FileOutputCommitter.java:commitTask(173)) - Saved output of task 'attempt_200707121733_0001_m_000000_0' to [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.502 sec checkfailure: clover.check: clover.setup: [clover-setup] Clover Version 3.0.2, built on April 13 2010 (build-790) [clover-setup] Loaded from: /homes/hudson/tools/clover/latest/lib/clover.jar [clover-setup] Clover: Open Source License registered to Apache. [clover-setup] Clover is enabled with initstring ' clover.info: clover: generate-clover-reports: [mkdir] Created dir: [clover-report] Clover Version 3.0.2, built on April 13 2010 (build-790) [clover-report] Loaded from: /homes/hudson/tools/clover/latest/lib/clover.jar [clover-report] Clover: Open Source License registered to Apache. [clover-report] Loading coverage database from: ' [clover-report] Writing HTML report to ' [clover-report] Done. Processed 54 packages in 12337ms (228ms per package). [clover-report] Clover Version 3.0.2, built on April 13 2010 (build-790) [clover-report] Loaded from: /homes/hudson/tools/clover/latest/lib/clover.jar [clover-report] Clover: Open Source License registered to Apache. [clover-report] Loading coverage database from: ' [clover-report] Writing report to ' BUILD SUCCESSFUL Total time: 26 minutes 18 seconds [FINDBUGS] Collecting findbugs analysis files... Publishing Javadoc ERROR: No javadoc found in : '**/*' doesn't match anything: '**' exists but not '**/*' Archiving artifacts Recording test results Recording fingerprints Publishing Clover coverage report... Publishing Clover HTML report... Publishing Clover XML report... Publishing Clover coverage results...