Uploaded image for project: 'Hadoop Common'
  1. Hadoop Common
  2. HADOOP-3309

Unit test fails on Windows: org.apache.hadoop.mapred.TestMiniMRDFSSort.unknown

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Major
    • Resolution: Fixed
    • 0.18.0
    • 0.18.0
    • None
    • None
    • windows

    • Reviewed

    Description

      Unit test fails on Windows: org.apache.hadoop.mapred.TestMiniMRDFSSort.unknown

      Recent changes:

      1. HADOOP-3061. Writable types for doubles and bytes.
      2. HADOOP-3300. Fix locking of explicit locks in NetworkTopology.
      3. HADOOP-2910. Throttle IPC Clients during bursts of requests or server slowdown. Clients retry connection for up to 15 minutes when socket connection times out.
      4. HADOOP-3285. Fix input split locality when the splits align to fsblocks.
      5. HADOOP-3127. Deleting files in trash should really remove them.
      6. HADOOP-3268. file:// URLs issue in TestUrlStreamHandler under Windows.
      7. HADOOP-1979. Speed up fsck by adding a buffered stream.

      Failed due to timeout
      junit.framework.AssertionFailedError: Timeout occurred

      Output from the console before it timed out:
      [junit] 2008-04-24 13:24:09,556 INFO util.Container (Container.java:stop(156)) - Stopped org.mortbay.jetty.servlet.WebApplicationHandler@4ac216
      [junit] 2008-04-24 13:24:09,696 INFO util.Container (Container.java:stop(156)) - Stopped WebApplicationContext[/,/]
      [junit] 2008-04-24 13:24:09,852 INFO util.Container (Container.java:stop(156)) - Stopped HttpContext[/logs,/logs]
      [junit] 2008-04-24 13:24:10,009 INFO util.Container (Container.java:stop(156)) - Stopped HttpContext[/static,/static]
      [junit] 2008-04-24 13:24:10,009 INFO util.Container (Container.java:stop(156)) - Stopped org.mortbay.jetty.Server@1b5340c
      [junit] 2008-04-24 13:24:10,009 INFO fs.FSNamesystem (FSEditLog.java:printStatistics(849)) - Number of transactions: 310 Total time for transactions(ms): 62 Number of syncs: 254 SyncTimes(ms): 23395 20970
      [junit] 2008-04-24 13:24:10,071 ERROR fs.FSNamesystem (FSNamesystem.java:run(1963)) - java.lang.InterruptedException
      [junit] at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.reportInterruptAfterWait(AbstractQueuedSynchronizer.java:1741)
      [junit] at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:1774)
      [junit] at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:359)
      [junit] at org.apache.hadoop.dfs.FSNamesystem$ResolutionMonitor.run(FSNamesystem.java:1940)
      [junit] at java.lang.Thread.run(Thread.java:595)

      [junit] 2008-04-24 13:24:10,321 INFO ipc.Server (Server.java:stop(1001)) - Stopping server on 3903
      [junit] 2008-04-24 13:24:10,321 INFO ipc.Server (Server.java:run(336)) - Stopping IPC Server listener on 3903
      [junit] 2008-04-24 13:24:10,321 INFO ipc.Server (Server.java:run(506)) - Stopping IPC Server Responder
      [junit] 2008-04-24 13:24:10,321 INFO mapred.MiniMRCluster (MiniMRCluster.java:waitUntilIdle(231)) - Waiting for task tracker tracker_buildsystem:localhost/127.0.0.1:3943 to be idle.
      [junit] 2008-04-24 13:24:10,321 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 0 on 3903: exiting
      [junit] 2008-04-24 13:24:10,321 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 1 on 3903: exiting
      [junit] 2008-04-24 13:24:10,321 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 2 on 3903: exiting
      [junit] 2008-04-24 13:24:10,337 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 9 on 3903: exiting
      [junit] 2008-04-24 13:24:10,337 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 3 on 3903: exiting
      [junit] 2008-04-24 13:24:10,337 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 4 on 3903: exiting
      [junit] 2008-04-24 13:24:10,337 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 5 on 3903: exiting
      [junit] 2008-04-24 13:24:10,337 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 8 on 3903: exiting
      [junit] 2008-04-24 13:24:10,337 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 6 on 3903: exiting
      [junit] 2008-04-24 13:24:10,337 INFO ipc.Server (Server.java:run(927)) - IPC Server handler 7 on 3903: exiting
      [junit] 2008-04-24 13:24:11,321 INFO mapred.MiniMRCluster (MiniMRCluster.java:waitUntilIdle(231)) - Waiting for task tracker tracker_buildsystem:localhost/127.0.0.1:3943 to be idle.
      [junit] 2008-04-24 13:24:12,321 INFO mapred.MiniMRCluster (MiniMRCluster.java:waitUntilIdle(231)) - Waiting for task tracker tracker_buildsystem:localhost/127.0.0.1:3943 to be idle.

      Attachments

        1. HADOOP-3309-1.patch
          0.7 kB
          Lohit Vijaya Renu
        2. HADOOP-3309.patch
          0.6 kB
          Lohit Vijaya Renu

        Activity

          People

            lohit Lohit Vijaya Renu
            mukundm Mukund Madhugiri
            Votes:
            0 Vote for this issue
            Watchers:
            0 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: