You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@giraph.apache.org by Jyoti Yadav <ra...@gmail.com> on 2014/01/12 18:29:29 UTC

Error: Out of memory error..

Hi..

I faced some error at runtime....

Error running child
java.lang.IllegalStateException: run: Caught an unrecoverable exception
waitFor: ExecutionException occurred while waiting for
org.apache.giraph.utils.ProgressableUtils$FutureWaitable@1a1d638
    at org.apache.giraph.graph.GraphMapper.run(GraphMapper.java:101)
    at org.apache.hadoop.mapred.MapTask.runNewMapper(MapTask.java:763)
    at org.apache.hadoop.mapred.MapTask.run(MapTask.java:369)
    at org.apache.hadoop.mapred.Child$4.run(Child.java:259)
    at java.security.AccessController.doPrivileged(Native Method)
    at javax.security.auth.Subject.doAs(Subject.java:415)
    at
org.apache.hadoop.security.UserGroupInformation.doAs(UserGroupInformation.java:1059)
    at org.apache.hadoop.mapred.Child.main(Child.java:253)
Caused by: java.lang.IllegalStateException: waitFor: ExecutionException
occurred while waiting for
org.apache.giraph.utils.ProgressableUtils$FutureWaitable@1a1d638
    at
org.apache.giraph.utils.ProgressableUtils.waitFor(ProgressableUtils.java:181)
    at
org.apache.giraph.utils.ProgressableUtils.waitForever(ProgressableUtils.java:139)
    at
org.apache.giraph.utils.ProgressableUtils.waitForever(ProgressableUtils.java:124)
    at
org.apache.giraph.utils.ProgressableUtils.getFutureResult(ProgressableUtils.java:87)
    at
org.apache.giraph.utils.ProgressableUtils.getResultsWithNCallables(ProgressableUtils.java:221)
    at
org.apache.giraph.worker.BspServiceWorker.loadInputSplits(BspServiceWorker.java:283)
    at
org.apache.giraph.worker.BspServiceWorker.loadVertices(BspServiceWorker.java:327)
    at
org.apache.giraph.worker.BspServiceWorker.setup(BspServiceWorker.java:508)
    at
org.apache.giraph.graph.GraphTaskManager.execute(GraphTaskManager.java:246)
    at org.apache.giraph.graph.GraphMapper.run(GraphMapper.java:91)
    ... 7 more
Caused by: java.util.concurrent.ExecutionException:
*java.lang.OutOfMemoryError:
Java heap space*
    at java.util.concurrent.FutureTask$Sync.innerGet(FutureTask.java:262)
    at java.util.concurrent.FutureTask.get(FutureTask.java:119)
    at
org.apache.giraph.utils.ProgressableUtils$FutureWaitable.waitFor(ProgressableUtils.java:300)
    at
org.apache.giraph.utils.ProgressableUtils.waitFor(ProgressableUtils.java:173)
    ... 16 more
Caused by: java.lang.OutOfMemoryError: Java heap space
    at
org.apache.giraph.edge.ByteArrayEdges.readFields(ByteArrayEdges.java:177)
    at
org.apache.giraph.utils.WritableUtils.reinitializeVertexFromDataInput(WritableUtils.java:524)
    at org.apache.giraph.utils.VertexIterator.next(VertexIterator.java:98)
    at
org.apache.giraph.partition.BasicPartition.addPartitionVertices(BasicPartition.java:99)
    at
org.apache.giraph.comm.requests.SendWorkerVerticesRequest.doRequest(SendWorkerVerticesRequest.java:110)
    at
org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor.doRequest(NettyWorkerClientRequestProcessor.java:482)
    at
org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor.flush(NettyWorkerClientRequestProcessor.java:428)
    at
org.apache.giraph.worker.InputSplitsCallable.call(InputSplitsCallable.java:241)
    at
org.apache.giraph.worker.InputSplitsCallable.call(InputSplitsCallable.java:60)
    at
org.apache.giraph.utils.LogStacktraceCallable.call(LogStacktraceCallable.java:51)
    at java.util.concurrent.FutureTask$Sync.innerRun(FutureTask.java:334)
    at java.util.concurrent.FutureTask.run(FutureTask.java:166)
    at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
    at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
    at java.lang.Thread.run(Thread.java:724)


Any ideas to fix it???
Thanks
Jyoti..