You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@ignite.apache.org by Saifullah Zahid <sa...@gmail.com> on 2017/02/22 07:44:01 UTC

java.lang.OutOfMemoryError: Java heap space

Hi,

Following is my Metrics for local node but getting out of memory exception
(details below).

Metrics for local node (to disable set 'metricsLogFrequency' to 0)
    ^-- Node [id=80a92be0, name=null, uptime=00:01:00:001]
    ^-- H/N/C [hosts=1, nodes=1, CPUs=8]
    ^-- CPU [cur=13.4%, avg=14.68%, GC=0%]
    ^--* Heap [used=3431MB, free=58.11%, comm=8192MB]*
    ^--* Non heap [used=47MB, free=-1%, comm=49MB] <======= Don't what this
mean?*
    ^-- Public thread pool [active=0, idle=0, qSize=0]
    ^-- System thread pool [active=0, idle=0, qSize=0]
    ^-- Outbound messages queue [size=0]
[12:26:45,026][INFO][exchange-worker-#28%null%][GridCacheProcessor] Started
cache [name=dcache, mode=PARTITIONED]
[12:26:45,041][INFO][exchange-worker-#28%null%][GridCachePartitionExchangeManager]
Skipping rebalancing (nothing scheduled) [top=AffinityTopologyVersion
[topVer=1, minorTopVer=15], evt=DISCOVERY_CUSTOM_EVT,
node=80a92be0-c845-4a05-bc65-ce7bd3a595b5]
*[12:26:54,914][WARNING][main][GridQueryProcessor] Neither key nor value
have property "ID" (is cache indexing configured correctly?) <==== [Key]
attribute is defined on ID*
[12:27:13,795][SEVERE][main][GridJobWorker] Failed to execute job due to
unexpected runtime exception
[jobId=d3ce5b46a51-80a92be0-c845-4a05-bc65-ce7bd3a595b5,
ses=GridJobSessionImpl [ses=GridTaskSessionImpl
[taskName=o.a.i.i.processors.cache.GridCacheAdapter$LoadCacheJobV2,
dep=LocalDeployment [super=GridDeployment [ts=1487748329540,
depMode=SHARED, clsLdr=sun.misc.Launcher$AppClassLoader@c387f44,
clsLdrId=52be5b46a51-80a92be0-c845-4a05-bc65-ce7bd3a595b5, userVer=0,
loc=true, sampleClsName=java.lang.String, pendingUndeploy=false,
undeployed=false, usage=0]],
taskClsName=o.a.i.i.processors.cache.GridCacheAdapter$LoadCacheJobV2,
sesId=c3ce5b46a51-80a92be0-c845-4a05-bc65-ce7bd3a595b5,
startTime=1487748405041, endTime=9223372036854775807,
taskNodeId=80a92be0-c845-4a05-bc65-ce7bd3a595b5,
clsLdr=sun.misc.Launcher$AppClassLoader@c387f44, closed=false, cpSpi=null,
failSpi=null, loadSpi=null, usage=1, fullSup=false, internal=true,
subjId=80a92be0-c845-4a05-bc65-ce7bd3a595b5, mapFut=IgniteFuture
[orig=GridFutureAdapter [resFlag=0, res=null, startTime=1487748405041,
endTime=0, ignoreInterrupts=false, state=INIT]]],
jobId=d3ce5b46a51-80a92be0-c845-4a05-bc65-ce7bd3a595b5]]
java.lang.OutOfMemoryError: Java heap space
at org.jsr166.ConcurrentHashMap8.initTable(ConcurrentHashMap8.java:2011)
at
org.jsr166.ConcurrentHashMap8.internalPutIfAbsent(ConcurrentHashMap8.java:1427)
at org.jsr166.ConcurrentHashMap8.putIfAbsent(ConcurrentHashMap8.java:2725)
at
org.apache.ignite.internal.processors.cache.GridCacheConcurrentMapImpl.putEntryIfObsoleteOrAbsent(GridCacheConcurrentMapImpl.java:134)
at
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtLocalPartition.putEntryIfObsoleteOrAbsent(GridDhtLocalPartition.java:280)
at
org.apache.ignite.internal.processors.cache.distributed.dht.GridCachePartitionedConcurrentMap.putEntryIfObsoleteOrAbsent(GridCachePartitionedConcurrentMap.java:89)
at
org.apache.ignite.internal.processors.cache.GridCacheAdapter.entry0(GridCacheAdapter.java:971)
at
org.apache.ignite.internal.processors.cache.GridCacheAdapter.entryEx(GridCacheAdapter.java:939)
at
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter.entryEx(GridDhtCacheAdapter.java:404)
at
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter.loadEntry(GridDhtCacheAdapter.java:547)
at
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter.access$300(GridDhtCacheAdapter.java:94)
at
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter$4.apply(GridDhtCacheAdapter.java:501)
at
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter$4.apply(GridDhtCacheAdapter.java:497)
at
org.apache.ignite.internal.processors.cache.store.GridCacheStoreManagerAdapter$3.apply(GridCacheStoreManagerAdapter.java:528)
at
org.apache.ignite.internal.processors.platform.dotnet.PlatformDotNetCacheStore$6.applyx(PlatformDotNetCacheStore.java:231)
at
org.apache.ignite.internal.processors.platform.dotnet.PlatformDotNetCacheStore$6.applyx(PlatformDotNetCacheStore.java:226)
at
org.apache.ignite.internal.util.lang.IgniteInClosureX.apply(IgniteInClosureX.java:38)
at
org.apache.ignite.internal.processors.platform.dotnet.PlatformDotNetCacheStore.doInvoke(PlatformDotNetCacheStore.java:438)
at
org.apache.ignite.internal.processors.platform.dotnet.PlatformDotNetCacheStore.loadCache(PlatformDotNetCacheStore.java:219)
at
org.apache.ignite.internal.processors.cache.store.GridCacheStoreManagerAdapter.loadCache(GridCacheStoreManagerAdapter.java:512)
at
org.apache.ignite.internal.processors.cache.distributed.dht.GridDhtCacheAdapter.localLoadCache(GridDhtCacheAdapter.java:497)
at
org.apache.ignite.internal.processors.cache.GridCacheProxyImpl.localLoadCache(GridCacheProxyImpl.java:228)
at
org.apache.ignite.internal.processors.cache.GridCacheAdapter$LoadCacheJob.localExecute(GridCacheAdapter.java:5753)
at
org.apache.ignite.internal.processors.cache.GridCacheAdapter$LoadCacheJobV2.localExecute(GridCacheAdapter.java:5802)
at
org.apache.ignite.internal.processors.cache.GridCacheAdapter$TopologyVersionAwareJob.execute(GridCacheAdapter.java:6473)
at
org.apache.ignite.compute.ComputeJobAdapter.call(ComputeJobAdapter.java:132)
at
org.apache.ignite.internal.processors.closure.GridClosureProcessor$C2V2.execute(GridClosureProcessor.java:2037)
at
org.apache.ignite.internal.processors.job.GridJobWorker$2.call(GridJobWorker.java:556)
at
org.apache.ignite.internal.util.IgniteUtils.wrapThreadLoader(IgniteUtils.java:6564)
at
org.apache.ignite.internal.processors.job.GridJobWorker.execute0(GridJobWorker.java:550)
at
org.apache.ignite.internal.processors.job.GridJobWorker.body(GridJobWorker.java:479)
at
org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:110)

Thanks,
Saif

Re: java.lang.OutOfMemoryError: Java heap space

Posted by vkulichenko <va...@gmail.com>.
Saif,

Out of memory means that you're out of heap memory. Note that there is at
least half a minute between latest metrics print out and the failure, so
it's very possible. Take a heap dump and check what is consuming memory. You
can also try to simple increase heap size.

-Val



--
View this message in context: http://apache-ignite-users.70518.x6.nabble.com/java-lang-OutOfMemoryError-Java-heap-space-tp10788p10820.html
Sent from the Apache Ignite Users mailing list archive at Nabble.com.