Uploaded image for project: 'Hadoop Map/Reduce'
  1. Hadoop Map/Reduce
  2. MAPREDUCE-3638

Yarn trying to download cacheFile to container but Path is a local file

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Invalid
    • 0.23.0
    • None
    • mrv2
    • None

    Description

      It looks like the AM, which is running on
      host1.com, is trying to access a local file but the file is on host2.com
      (where the command was run).

      ran:
      hadoop --config conf/hadoop/
      jar hadoop-streaming.jar -Dmapreduce.job.acl-view-job=*
      -input Streaming/streaming-610/input.txt -mapper 'xargs cat' -reducer cat -output
      Streaming/streaming-610/Output -cacheFile
      file://Streaming/data/streaming-610//InputFile#testlink
      -jobconf mapred.map.tasks=1 -jobconf mapred.reduce.tasks=1 -jobconf
      mapred.job.name=streamingTest-610 -jobconf mapreduce.job.acl-view-job=*

      failure:

      11/11/10 07:48:06 INFO mapreduce.Job: Job job_1320887371559_0215 failed with state FAILED due to: Application
      application_1320887371559_0215 failed 1 times due to AM Container for appattempt_1320887371559_0215_000001 exited with
      exitCode: -1000 due to: java.io.FileNotFoundException: File
      file:/Streaming/data/streaming-610/InputFile
      does not exist
      at org.apache.hadoop.fs.RawLocalFileSystem.getFileStatus(RawLocalFileSystem.java:431)
      at org.apache.hadoop.fs.FilterFileSystem.getFileStatus(FilterFileSystem.java:315)
      at org.apache.hadoop.yarn.util.FSDownload.copy(FSDownload.java:85)
      at org.apache.hadoop.yarn.util.FSDownload.call(FSDownload.java:152)
      at org.apache.hadoop.yarn.util.FSDownload.call(FSDownload.java:50)
      at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
      at java.util.concurrent.FutureTask.run(FutureTask.java:138)
      at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:441)
      at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:303)
      at java.util.concurrent.FutureTask.run(FutureTask.java:138)
      at java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:886)
      at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:908)
      at java.lang.Thread.run(Thread.java:619)

      Attachments

        Activity

          People

            Unassigned Unassigned
            tgraves Thomas Graves
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: