Uploaded image for project: 'Hama'
  1. Hama
  2. HAMA-705

run the pagerank example , got the wrong result

    XMLWordPrintableJSON

Details

    • Question
    • Status: Resolved
    • Major
    • Resolution: Not A Problem
    • 0.6.0
    • 0.6.0
    • examples
    • Ubuntu 12.04 32bit
      JDK 1.6.33
      hadoop 1.0.4

    Description

      I'v installed the hama-0.6.0 with pseudo distributed mode.
      but when i run the pagerank example several times with the command line :
      hama jar hama-examples-0.6.0.jar pagerank /tmp/input/input.txt /tmp/output

      the input.txt is:
      stackoverflow.com\tyahoo.com
      facebook.com\ttwitter.com\tgoogle.com\tnasa.gov
      yahoo.com\tnasa.gov\tstackoverflow.com
      twitter.com\tgoogle.com\tfacebook.com
      nasa.gov\tyahoo.com\tstackoverflow.com
      youtube.com\tgoogle.com\tyahoo.com

      but i'v got the wrong result with every verticle's value is the same:
      stackoverflow.com\tyahoo.com 0.16539487340086836
      facebook.com\ttwitter.com\tgoogle.com\tnasa.gov 0.16539487340086836
      yahoo.com\tnasa.gov\tstackoverflow.com 0.16539487340086836
      twitter.com\tgoogle.com\tfacebook.com 0.16539487340086836
      nasa.gov\tyahoo.com\tstackoverflow.com 0.16539487340086836
      youtube.com\tgoogle.com\tyahoo.com 0.16539487340086836

      my tasklog is attempt_201212311309_0008_000000_0.log:
      12/12/31 13:37:08 INFO sync.ZKSyncClient: Initializing ZK Sync Client
      12/12/31 13:37:08 INFO sync.ZooKeeperSyncClientImpl: Start connecting to Zookeeper! At lee- OptiPlex-790/10.0.0.2:61001
      12/12/31 13:37:08 ERROR sync.ZooKeeperSyncClientImpl: org.apache.zookeeper.KeeperException$NoNodeException: KeeperErrorCode = NoNode for /bsp/job_201212311309_0008/peers
      12/12/31 13:37:08 INFO ipc.Server: Starting SocketReader
      12/12/31 13:37:08 INFO ipc.Server: IPC Server Responder: starting
      12/12/31 13:37:08 INFO ipc.Server: IPC Server listener on 61001: starting
      12/12/31 13:37:08 INFO message.HadoopMessageManagerImpl: BSPPeer address:lee-OptiPlex-790 port:61001
      12/12/31 13:37:08 INFO ipc.Server: IPC Server handler 0 on 61001: starting
      12/12/31 13:37:12 INFO ipc.Server: Stopping server on 61001
      12/12/31 13:37:12 INFO ipc.Server: Stopping IPC Server listener on 61001
      12/12/31 13:37:12 INFO ipc.Server: IPC Server handler 0 on 61001: exiting
      12/12/31 13:37:12 INFO metrics.RpcInstrumentation: shut down
      12/12/31 13:37:12 INFO ipc.Server: Stopping IPC Server Responder
      12/12/31 13:37:12 ERROR bsp.BSPTask: Shutting down ping service.

      hama-hadoop-bspmaster-lee-OptiPlex-790.log:
      2012-12-31 13:37:07,908 INFO org.apache.hama.bsp.JobInProgress: Job is initialized.
      2012-12-31 13:37:13,626 INFO org.apache.hama.bsp.JobInProgress: Job successfully done.

      hama-hadoop-groom-lee-OptiPlex-790.log:
      2012-12-31 13:37:07,981 INFO org.apache.hama.bsp.GroomServer: Task 'attempt_201212311309_0008_000000_0' has started.
      2012-12-31 13:37:12,812 INFO org.apache.hama.bsp.GroomServer: Task attempt_201212311309_0008_000000_0 is done.

      hama-hadoop-zookeeper-lee-OptiPlex-790.log:
      2012-12-31 13:09:45,415 ERROR org.apache.zookeeper.server.quorum.QuorumPeerConfig: Invalid configuration, only one server specified (ignoring)

      i don't know if there is something wrong with the zookeeper, but i follow the installion guide and set the hama-site.xml:
      <configuration>
      <property>
      <name>bsp.master.address</name>
      <value>lee-OptiPlex-790:40000</value>
      <description>The address of the bsp master server. Either the
      literal string "local" or a host:port for distributed mode
      </description>
      </property>

      <property>
      <name>fs.default.name</name>
      <value>hdfs://lee-OptiPlex-790:9000</value>
      <description>
      The name of the default file system. Either the literal string
      "local" or a host:port for HDFS.
      </description>
      </property>
      <property>
      <name>hama.zookeeper.quorum</name>
      <value>lee-OptiPlex-790</value>
      <description></description>
      </property>

      </configuration>

      so , help me! thanks

      Attachments

        Activity

          People

            Unassigned Unassigned
            gding ding.lee
            Votes:
            0 Vote for this issue
            Watchers:
            2 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved:

              Time Tracking

                Estimated:
                Original Estimate - 3h
                3h
                Remaining:
                Remaining Estimate - 3h
                3h
                Logged:
                Time Spent - Not Specified
                Not Specified