You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@ignite.apache.org by "Sergey Kozlov (JIRA)" <ji...@apache.org> on 2015/02/16 10:42:12 UTC

[jira] [Updated] (IGNITE-234) Unable to start two nodes with same configs

     [ https://issues.apache.org/jira/browse/IGNITE-234?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Sergey Kozlov updated IGNITE-234:
---------------------------------
    Summary: Unable to start two nodes with same configs  (was: Don't start two nodes with same configs)

> Unable to start two nodes with same configs
> -------------------------------------------
>
>                 Key: IGNITE-234
>                 URL: https://issues.apache.org/jira/browse/IGNITE-234
>             Project: Ignite
>          Issue Type: Bug
>          Components: general
>    Affects Versions: sprint-1
>         Environment: OS X ver 10.8.5
> Java 1.7.0_67
> IDEA 14.0.2
>            Reporter: Ilya Suntsov
>            Assignee: Ilya Suntsov
>            Priority: Blocker
>             Fix For: sprint-1
>
>         Attachments: IDEA_node.log, IDEA_node.txt, term_node.txt, terminal_node.log
>
>
> 1. Start node with compute config in Terminal
>  2. Start node with compute config  in IDEA
> Result:
> *IDEA's node:*
>  {noformat}
> [11:47:03,567][INFO][main][IgniteKernal] 
> >>>    __________  ________________  
> >>>   /  _/ ___/ |/ /  _/_  __/ __/  
> >>>  _/ // (_ /    // /  / / / _/    
> >>> /___/\___/_/|_/___/ /_/ /___/   
> >>> 
> >>> ver. 1.0.0#19700101-sha1:DEV
> >>> 2015 Copyright(C) Apache Software Foundation
> [11:47:03,568][INFO][main][IgniteKernal] Config URL: file:/Users/gridgain/Downloads/ignite-fabric-1.0-4.0-SNAPSHOT/examples/config/example-compute.xml
> [11:47:03,568][INFO][main][IgniteKernal] Daemon mode: off
> [11:47:03,568][INFO][main][IgniteKernal] OS: Mac OS X 10.8.5 x86_64
> [11:47:03,568][INFO][main][IgniteKernal] OS user: gridgain
> [11:47:03,569][INFO][main][IgniteKernal] Language runtime: Java Platform API Specification ver. 1.7
> [11:47:03,569][INFO][main][IgniteKernal] VM information: Java(TM) SE Runtime Environment 1.7.0_67-b01 Oracle Corporation Java HotSpot(TM) 64-Bit Server VM 24.65-b04
> [11:47:03,570][INFO][main][IgniteKernal] VM total memory: 3.6GB
> [11:47:03,570][INFO][main][IgniteKernal] Remote Management [restart: off, REST: on, JMX (remote: off)]
> [11:47:03,570][INFO][main][IgniteKernal] IGNITE_HOME=/Users/gridgain/Downloads/ignite-fabric-1.0-4.0-SNAPSHOT
> [11:47:03,570][INFO][main][IgniteKernal] VM arguments: [-DIGNITE_QUIET=false, -Didea.launcher.port=7535, -Didea.launcher.bin.path=/Applications/IntelliJ IDEA 14 CE.app/Contents/bin, -Dfile.encoding=UTF-8]
> [11:47:03,571][WARNING][main][IgniteKernal] SMTP is not configured - email notifications are off.
> [11:47:03,571][INFO][main][IgniteKernal] Configured caches ['ignite-sys-cache', 'ignite-atomics-sys-cache']
> [11:47:03,571][WARNING][main][IgniteKernal] Peer class loading is enabled (disable it in production for performance and deployment consistency reasons)
> [11:47:03,576][WARNING][ignite-#7%pub-null%][GridWorker] Initial heap size is 256MB (should be no less than 512MB, use -Xms512m -Xmx512m).
> [11:47:03,582][INFO][main][IgniteKernal] 3-rd party licenses can be found at: /Users/gridgain/Downloads/ignite-fabric-1.0-4.0-SNAPSHOT/libs/licenses
> [11:47:03,588][INFO][main][IgniteKernal] Non-loopback local IPs: 10.0.0.4, fe80:0:0:0:1610:9fff:fedd:4ccf%5
> [11:47:03,588][INFO][main][IgniteKernal] Enabled local MACs: 14109FDD4CCF
> [11:47:03,697][INFO][main][TcpCommunicationSpi] IPC shared memory server endpoint started [port=48101, tokDir=/Users/gridgain/Downloads/ignite-fabric-1.0-4.0-SNAPSHOT/work/ipc/shmem/e5b039ca-b50e-423b-bcca-4c7094ce43e8-926]
> [11:47:03,697][INFO][main][TcpCommunicationSpi] Successfully bound shared memory communication to TCP port [port=48101, locHost=0.0.0.0/0.0.0.0]
> [11:47:03,711][INFO][main][TcpCommunicationSpi] Successfully bound to TCP port [port=47101, locHost=0.0.0.0/0.0.0.0]
> [11:47:33,759][WARNING][main][NoopCheckpointSpi] Checkpoints are disabled (to enable configure any GridCheckpointSpi implementation)
> [11:47:33,790][WARNING][main][GridCollisionManager] Collision resolution is disabled (all jobs will be activated upon arrival).
> [11:47:33,794][WARNING][main][NoopSwapSpaceSpi] Swap space is disabled. To enable use GridFileSwapSpaceSpi.
> [11:47:33,796][WARNING][main][GridIndexingManager] Indexing is disabled (to enable please configure GridIndexingSpi).
> [11:47:33,796][INFO][main][IgniteKernal] Security status [authentication=off, secure-session=off]
> [11:47:34,076][WARNING][main][GridCacheProcessor] Query indexing is disabled (queries will not work) for cache: 'ignite-atomics-sys-cache'. To enable change GridCacheConfiguration.isQueryIndexEnabled() property.
> [11:47:34,126][WARNING][main][GridCacheStoreManager] <ignite-sys-cache> CacheConfiguration.isKeepPortableInStore() configuration property will be ignored because portable mode is not enabled for cache: ignite-sys-cache
> [11:47:34,146][INFO][main][GridCacheProcessor] Started cache [name=ignite-sys-cache, mode=REPLICATED]
> [11:47:34,149][INFO][main][CacheConsistentHashAffinityFunction] Consistent hash configuration [cacheName=ignite-atomics-sys-cache, partitions=10000, excludeNeighbors=false, replicas=128, backupFilter=null, hashIdRslvr=CacheAffinityNodeAddressHashResolver []]
> [11:47:34,195][WARNING][main][GridCacheStoreManager] <ignite-atomics-sys-cache> CacheConfiguration.isKeepPortableInStore() configuration property will be ignored because portable mode is not enabled for cache: ignite-atomics-sys-cache
> [11:47:34,198][INFO][main][GridCacheProcessor] Started cache [name=ignite-atomics-sys-cache, mode=PARTITIONED]
> [11:47:34,240][INFO][main][GridTcpRestProtocol] Command protocol successfully started [name=TCP binary, host=0.0.0.0/0.0.0.0, port=11212]
> [11:47:34,240][WARNING][main][GridRestProcessor] Failed to initialize HTTP REST protocol (consider adding ignite-rest-http module to classpath).
> [11:48:04,290][INFO][main][TcpDiscoverySpi] Successfully bound to TCP port [port=47501, localHost=0.0.0.0/0.0.0.0]
> [11:49:15,366][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:49:24,911][WARNING][main][GridCachePartitionExchangeManager] Failed to wait for initial partition map exchange. Possible reasons are: 
>   ^-- Transactions in deadlock.
>   ^-- Long running transactions (ignore if this is the case).
>   ^-- Unreleased explicit locks.
> [11:49:25,385][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:49:35,389][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:49:44,916][WARNING][main][GridCachePartitionExchangeManager] Still waiting for initial partition map exchange [fut=GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e5b039ca-b50e-423b-bcca-4c7094ce43e8, addrs=[10.0.0.4, 0:0:0:0:0:0:0:1, 127.0.0.1], sockAddrs=[/10.0.0.4:47501, /0:0:0:0:0:0:0:1:47501, /127.0.0.1:47501], discPort=47501, order=2, intOrder=2, loc=true, ver=1.0.0#19700101-sha1:00000000, isClient=false], topVer=2, nodeId8=e5b039ca, msg=null, type=NODE_JOINED, tstamp=1423727344893], rcvdIds=GridConcurrentHashSet [elements=[]], rmtIds=[c2d34374-80dc-42eb-b241-17d0df0577f0], exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], init=true, ready=true, replied=false, cctx=o.a.i.i.processors.cache.GridCacheSharedContext@74fcad2e, added=true, initFut=GridFutureAdapter [res=true, err=null, startTime=1423727344904, endTime=1423727345301, valid=true, syncNotify=true, concurNotify=false, state=DONE], topSnapshot=null, lastVer=null, partReleaseFut=GridCompoundFuture [lsnrCalls=3, finished=true, rdc=null, init=true, res=java.util.concurrent.atomic.AtomicMarkableReference@225b8b2f, err=null, done=true, cancelled=false, err=null, futs=[true, true, true]], oldest=c2d34374-80dc-42eb-b241-17d0df0577f0, oldestOrder=1, evtLatch=0, remaining=[c2d34374-80dc-42eb-b241-17d0df0577f0], super=GridFutureAdapter [res=null, err=null, startTime=1423727344904, endTime=0, valid=true, syncNotify=true, concurNotify=false, state=INIT]]]
> [11:49:45,393][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:49:55,400][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:50:04,918][WARNING][main][GridCachePartitionExchangeManager] Still waiting for initial partition map exchange [fut=GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e5b039ca-b50e-423b-bcca-4c7094ce43e8, addrs=[10.0.0.4, 0:0:0:0:0:0:0:1, 127.0.0.1], sockAddrs=[/10.0.0.4:47501, /0:0:0:0:0:0:0:1:47501, /127.0.0.1:47501], discPort=47501, order=2, intOrder=2, loc=true, ver=1.0.0#19700101-sha1:00000000, isClient=false], topVer=2, nodeId8=e5b039ca, msg=null, type=NODE_JOINED, tstamp=1423727344893], rcvdIds=GridConcurrentHashSet [elements=[]], rmtIds=[c2d34374-80dc-42eb-b241-17d0df0577f0], exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], init=true, ready=true, replied=false, cctx=o.a.i.i.processors.cache.GridCacheSharedContext@74fcad2e, added=true, initFut=GridFutureAdapter [res=true, err=null, startTime=1423727344904, endTime=1423727345301, valid=true, syncNotify=true, concurNotify=false, state=DONE], topSnapshot=null, lastVer=null, partReleaseFut=GridCompoundFuture [lsnrCalls=3, finished=true, rdc=null, init=true, res=java.util.concurrent.atomic.AtomicMarkableReference@225b8b2f, err=null, done=true, cancelled=false, err=null, futs=[true, true, true]], oldest=c2d34374-80dc-42eb-b241-17d0df0577f0, oldestOrder=1, evtLatch=0, remaining=[c2d34374-80dc-42eb-b241-17d0df0577f0], super=GridFutureAdapter [res=null, err=null, startTime=1423727344904, endTime=0, valid=true, syncNotify=true, concurNotify=false, state=INIT]]]
> [11:50:05,411][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:50:15,415][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:50:24,920][WARNING][main][GridCachePartitionExchangeManager] Still waiting for initial partition map exchange [fut=GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e5b039ca-b50e-423b-bcca-4c7094ce43e8, addrs=[10.0.0.4, 0:0:0:0:0:0:0:1, 127.0.0.1], sockAddrs=[/10.0.0.4:47501, /0:0:0:0:0:0:0:1:47501, /127.0.0.1:47501], discPort=47501, order=2, intOrder=2, loc=true, ver=1.0.0#19700101-sha1:00000000, isClient=false], topVer=2, nodeId8=e5b039ca, msg=null, type=NODE_JOINED, tstamp=1423727344893], rcvdIds=GridConcurrentHashSet [elements=[]], rmtIds=[c2d34374-80dc-42eb-b241-17d0df0577f0], exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], init=true, ready=true, replied=false, cctx=o.a.i.i.processors.cache.GridCacheSharedContext@74fcad2e, added=true, initFut=GridFutureAdapter [res=true, err=null, startTime=1423727344904, endTime=1423727345301, valid=true, syncNotify=true, concurNotify=false, state=DONE], topSnapshot=null, lastVer=null, partReleaseFut=GridCompoundFuture [lsnrCalls=3, finished=true, rdc=null, init=true, res=java.util.concurrent.atomic.AtomicMarkableReference@225b8b2f, err=null, done=true, cancelled=false, err=null, futs=[true, true, true]], oldest=c2d34374-80dc-42eb-b241-17d0df0577f0, oldestOrder=1, evtLatch=0, remaining=[c2d34374-80dc-42eb-b241-17d0df0577f0], super=GridFutureAdapter [res=null, err=null, startTime=1423727344904, endTime=0, valid=true, syncNotify=true, concurNotify=false, state=INIT]]]
> [11:50:25,427][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:50:35,430][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:50:44,922][WARNING][main][GridCachePartitionExchangeManager] Still waiting for initial partition map exchange [fut=GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e5b039ca-b50e-423b-bcca-4c7094ce43e8, addrs=[10.0.0.4, 0:0:0:0:0:0:0:1, 127.0.0.1], sockAddrs=[/10.0.0.4:47501, /0:0:0:0:0:0:0:1:47501, /127.0.0.1:47501], discPort=47501, order=2, intOrder=2, loc=true, ver=1.0.0#19700101-sha1:00000000, isClient=false], topVer=2, nodeId8=e5b039ca, msg=null, type=NODE_JOINED, tstamp=1423727344893], rcvdIds=GridConcurrentHashSet [elements=[]], rmtIds=[c2d34374-80dc-42eb-b241-17d0df0577f0], exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], init=true, ready=true, replied=false, cctx=o.a.i.i.processors.cache.GridCacheSharedContext@74fcad2e, added=true, initFut=GridFutureAdapter [res=true, err=null, startTime=1423727344904, endTime=1423727345301, valid=true, syncNotify=true, concurNotify=false, state=DONE], topSnapshot=null, lastVer=null, partReleaseFut=GridCompoundFuture [lsnrCalls=3, finished=true, rdc=null, init=true, res=java.util.concurrent.atomic.AtomicMarkableReference@225b8b2f, err=null, done=true, cancelled=false, err=null, futs=[true, true, true]], oldest=c2d34374-80dc-42eb-b241-17d0df0577f0, oldestOrder=1, evtLatch=0, remaining=[c2d34374-80dc-42eb-b241-17d0df0577f0], super=GridFutureAdapter [res=null, err=null, startTime=1423727344904, endTime=0, valid=true, syncNotify=true, concurNotify=false, state=INIT]]]
> [11:50:45,436][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:50:55,446][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:51:04,924][WARNING][main][GridCachePartitionExchangeManager] Still waiting for initial partition map exchange [fut=GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e5b039ca-b50e-423b-bcca-4c7094ce43e8, addrs=[10.0.0.4, 0:0:0:0:0:0:0:1, 127.0.0.1], sockAddrs=[/10.0.0.4:47501, /0:0:0:0:0:0:0:1:47501, /127.0.0.1:47501], discPort=47501, order=2, intOrder=2, loc=true, ver=1.0.0#19700101-sha1:00000000, isClient=false], topVer=2, nodeId8=e5b039ca, msg=null, type=NODE_JOINED, tstamp=1423727344893], rcvdIds=GridConcurrentHashSet [elements=[]], rmtIds=[c2d34374-80dc-42eb-b241-17d0df0577f0], exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], init=true, ready=true, replied=false, cctx=o.a.i.i.processors.cache.GridCacheSharedContext@74fcad2e, added=true, initFut=GridFutureAdapter [res=true, err=null, startTime=1423727344904, endTime=1423727345301, valid=true, syncNotify=true, concurNotify=false, state=DONE], topSnapshot=null, lastVer=null, partReleaseFut=GridCompoundFuture [lsnrCalls=3, finished=true, rdc=null, init=true, res=java.util.concurrent.atomic.AtomicMarkableReference@225b8b2f, err=null, done=true, cancelled=false, err=null, futs=[true, true, true]], oldest=c2d34374-80dc-42eb-b241-17d0df0577f0, oldestOrder=1, evtLatch=0, remaining=[c2d34374-80dc-42eb-b241-17d0df0577f0], super=GridFutureAdapter [res=null, err=null, startTime=1423727344904, endTime=0, valid=true, syncNotify=true, concurNotify=false, state=INIT]]]
> [11:51:05,452][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:51:15,463][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:51:24,925][WARNING][main][GridCachePartitionExchangeManager] Still waiting for initial partition map exchange [fut=GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e5b039ca-b50e-423b-bcca-4c7094ce43e8, addrs=[10.0.0.4, 0:0:0:0:0:0:0:1, 127.0.0.1], sockAddrs=[/10.0.0.4:47501, /0:0:0:0:0:0:0:1:47501, /127.0.0.1:47501], discPort=47501, order=2, intOrder=2, loc=true, ver=1.0.0#19700101-sha1:00000000, isClient=false], topVer=2, nodeId8=e5b039ca, msg=null, type=NODE_JOINED, tstamp=1423727344893], rcvdIds=GridConcurrentHashSet [elements=[]], rmtIds=[c2d34374-80dc-42eb-b241-17d0df0577f0], exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], init=true, ready=true, replied=false, cctx=o.a.i.i.processors.cache.GridCacheSharedContext@74fcad2e, added=true, initFut=GridFutureAdapter [res=true, err=null, startTime=1423727344904, endTime=1423727345301, valid=true, syncNotify=true, concurNotify=false, state=DONE], topSnapshot=null, lastVer=null, partReleaseFut=GridCompoundFuture [lsnrCalls=3, finished=true, rdc=null, init=true, res=java.util.concurrent.atomic.AtomicMarkableReference@225b8b2f, err=null, done=true, cancelled=false, err=null, futs=[true, true, true]], oldest=c2d34374-80dc-42eb-b241-17d0df0577f0, oldestOrder=1, evtLatch=0, remaining=[c2d34374-80dc-42eb-b241-17d0df0577f0], super=GridFutureAdapter [res=null, err=null, startTime=1423727344904, endTime=0, valid=true, syncNotify=true, concurNotify=false, state=INIT]]]
> [11:51:25,466][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:51:35,470][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:51:44,927][WARNING][main][GridCachePartitionExchangeManager] Still waiting for initial partition map exchange [fut=GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e5b039ca-b50e-423b-bcca-4c7094ce43e8, addrs=[10.0.0.4, 0:0:0:0:0:0:0:1, 127.0.0.1], sockAddrs=[/10.0.0.4:47501, /0:0:0:0:0:0:0:1:47501, /127.0.0.1:47501], discPort=47501, order=2, intOrder=2, loc=true, ver=1.0.0#19700101-sha1:00000000, isClient=false], topVer=2, nodeId8=e5b039ca, msg=null, type=NODE_JOINED, tstamp=1423727344893], rcvdIds=GridConcurrentHashSet [elements=[]], rmtIds=[c2d34374-80dc-42eb-b241-17d0df0577f0], exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], init=true, ready=true, replied=false, cctx=o.a.i.i.processors.cache.GridCacheSharedContext@74fcad2e, added=true, initFut=GridFutureAdapter [res=true, err=null, startTime=1423727344904, endTime=1423727345301, valid=true, syncNotify=true, concurNotify=false, state=DONE], topSnapshot=null, lastVer=null, partReleaseFut=GridCompoundFuture [lsnrCalls=3, finished=true, rdc=null, init=true, res=java.util.concurrent.atomic.AtomicMarkableReference@225b8b2f, err=null, done=true, cancelled=false, err=null, futs=[true, true, true]], oldest=c2d34374-80dc-42eb-b241-17d0df0577f0, oldestOrder=1, evtLatch=0, remaining=[c2d34374-80dc-42eb-b241-17d0df0577f0], super=GridFutureAdapter [res=null, err=null, startTime=1423727344904, endTime=0, valid=true, syncNotify=true, concurNotify=false, state=INIT]]]
> [11:51:45,474][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:51:55,477][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:52:04,929][WARNING][main][GridCachePartitionExchangeManager] Still waiting for initial partition map exchange [fut=GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e5b039ca-b50e-423b-bcca-4c7094ce43e8, addrs=[10.0.0.4, 0:0:0:0:0:0:0:1, 127.0.0.1], sockAddrs=[/10.0.0.4:47501, /0:0:0:0:0:0:0:1:47501, /127.0.0.1:47501], discPort=47501, order=2, intOrder=2, loc=true, ver=1.0.0#19700101-sha1:00000000, isClient=false], topVer=2, nodeId8=e5b039ca, msg=null, type=NODE_JOINED, tstamp=1423727344893], rcvdIds=GridConcurrentHashSet [elements=[]], rmtIds=[c2d34374-80dc-42eb-b241-17d0df0577f0], exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], init=true, ready=true, replied=false, cctx=o.a.i.i.processors.cache.GridCacheSharedContext@74fcad2e, added=true, initFut=GridFutureAdapter [res=true, err=null, startTime=1423727344904, endTime=1423727345301, valid=true, syncNotify=true, concurNotify=false, state=DONE], topSnapshot=null, lastVer=null, partReleaseFut=GridCompoundFuture [lsnrCalls=3, finished=true, rdc=null, init=true, res=java.util.concurrent.atomic.AtomicMarkableReference@225b8b2f, err=null, done=true, cancelled=false, err=null, futs=[true, true, true]], oldest=c2d34374-80dc-42eb-b241-17d0df0577f0, oldestOrder=1, evtLatch=0, remaining=[c2d34374-80dc-42eb-b241-17d0df0577f0], super=GridFutureAdapter [res=null, err=null, startTime=1423727344904, endTime=0, valid=true, syncNotify=true, concurNotify=false, state=INIT]]]
> [11:52:05,491][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:52:15,503][WARNING][grid-timeout-worker-#33%null%][GridDhtPartitionsExchangeFuture] Retrying preload partition exchange due to timeout [done=false, dummy=false, exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], rcvdIds=[], rmtIds=[c2d34374], remaining=[c2d34374], init=true, initFut=true, ready=true, replied=false, added=true, oldest=c2d34374, oldestOrder=1, evtLatch=0, locNodeOrder=2, locNodeId=e5b039ca-b50e-423b-bcca-4c7094ce43e8]
> [11:52:24,931][WARNING][main][GridCachePartitionExchangeManager] Still waiting for initial partition map exchange [fut=GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e5b039ca-b50e-423b-bcca-4c7094ce43e8, addrs=[10.0.0.4, 0:0:0:0:0:0:0:1, 127.0.0.1], sockAddrs=[/10.0.0.4:47501, /0:0:0:0:0:0:0:1:47501, /127.0.0.1:47501], discPort=47501, order=2, intOrder=2, loc=true, ver=1.0.0#19700101-sha1:00000000, isClient=false], topVer=2, nodeId8=e5b039ca, msg=null, type=NODE_JOINED, tstamp=1423727344893], rcvdIds=GridConcurrentHashSet [elements=[]], rmtIds=[c2d34374-80dc-42eb-b241-17d0df0577f0], exchId=GridDhtPartitionExchangeId [topVer=2, nodeId=e5b039ca, evt=NODE_JOINED], init=true, ready=true, replied=false, cctx=o.a.i.i.processors.cache.GridCacheSharedContext@74fcad2e, added=true, initFut=GridFutureAdapter [res=true, err=null, startTime=1423727344904, endTime=1423727345301, valid=true, syncNotify=true, concurNotify=false, state=DONE], topSnapshot=null, lastVer=null, partReleaseFut=GridCompoundFuture [lsnrCalls=3, finished=true, rdc=null, init=true, res=java.util.concurrent.atomic.AtomicMarkableReference@225b8b2f, err=null, done=true, cancelled=false, err=null, futs=[true, true, true]], oldest=c2d34374-80dc-42eb-b241-17d0df0577f0, oldestOrder=1, evtLatch=0, remaining=[c2d34374-80dc-42eb-b241-17d0df0577f0], super=GridFutureAdapter [res=null, err=null, startTime=1423727344904, endTime=0, valid=true, syncNotify=true, concurNotify=false, state=INIT]]]
> {noformat}
> *Node in terminal:* 
> {noformat}
> Using configuration: examples/config/example-compute.xml
> [11:38:17]    __________  ________________ 
> [11:38:17]   /  _/ ___/ |/ /  _/_  __/ __/ 
> [11:38:17]  _/ // (_ /    // /  / / / _/   
> [11:38:17] /___/\___/_/|_/___/ /_/ /___/  
> [11:38:17]  
> [11:38:17] ver. 1.0.0#19700101-sha1:DEV
> [11:38:17] 2015 Copyright(C) Apache Software Foundation
> [11:38:17] 
> [11:38:17] Quiet mode.
> [11:38:17]   ^-- Logging to file '/Users/gridgain/Downloads/ignite-fabric-1.0-4.0-SNAPSHOT/work/log/ignite-c47836ab.0.log'
> [11:38:17]   ^-- To see **FULL** console log here add -DIGNITE_QUIET=false or "-v" to ignite.{sh|bat}
> [11:38:17] 
> [11:38:47] Failed to initialize HTTP REST protocol (consider adding ignite-rest-http module to classpath).
> [11:40:18] Performance suggestions for grid  (fix if possible)
> [11:40:18] To disable, set -DIGNITE_PERFORMANCE_SUGGESTIONS_DISABLED=true
> [11:40:18]   ^-- Disable peer class loading (set 'peerClassLoadingEnabled' to false)
> [11:40:18]   ^-- Disable grid events (remove 'includeEventTypes' from configuration)
> [11:40:18] 
> [11:40:18] If running benchmarks, see http://bit.ly/GridGain-Benchmarking
> [11:40:18] To start Console Management & Monitoring run ignitevisorcmd.{sh|bat}
> [11:40:18] 
> [11:40:18] Ignite node started OK (id=c47836ab)
> [11:40:19] Topology snapshot [ver=1, nodes=1, CPUs=8, heap=1.0GB]
> [11:40:19] Topology snapshot [ver=2, nodes=2, CPUs=8, heap=2.0GB]
> [11:42:27] Topology snapshot [ver=3, nodes=3, CPUs=8, heap=5.6GB]
> [11:42:28,188][SEVERE][ignite-#28%sys-null%][GridCacheIoManager] Failed to process message (note that distributed services do not support peer class loading, if you deploy distributed service you should have all required classes in CLASSPATH on all nodes in topology) [senderId=f7b1e6b0-4233-4291-9d6a-8a70a5e6d6bd, err=Optimized stream class checksum mismatch (is same version of marshalled class present on all nodes?) [expected=0, actual=31829, cls=class o.a.i.i.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyPool$1]]
> [11:42:37,926][SEVERE][ignite-#29%sys-null%][GridCacheIoManager] Failed to process message (note that distributed services do not support peer class loading, if you deploy distributed service you should have all required classes in CLASSPATH on all nodes in topology) [senderId=f7b1e6b0-4233-4291-9d6a-8a70a5e6d6bd, err=Optimized stream class checksum mismatch (is same version of marshalled class present on all nodes?) [expected=0, actual=31829, cls=class o.a.i.i.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyPool$1]]
> [11:42:38,198][SEVERE][ignite-#31%sys-null%][GridCacheIoManager] Failed to process message (note that distributed services do not support peer class loading, if you deploy distributed service you should have all required classes in CLASSPATH on all nodes in topology) [senderId=f7b1e6b0-4233-4291-9d6a-8a70a5e6d6bd, err=Optimized stream class checksum mismatch (is same version of marshalled class present on all nodes?) [expected=0, actual=31829, cls=class o.a.i.i.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyPool$1]]
> [11:42:47,900][SEVERE][ignite-#32%sys-null%][GridCacheIoManager] Failed to process message (note that distributed services do not support peer class loading, if you deploy distributed service you should have all required classes in CLASSPATH on all nodes in topology) [senderId=f7b1e6b0-4233-4291-9d6a-8a70a5e6d6bd, err=Optimized stream class checksum mismatch (is same version of marshalled class present on all nodes?) [expected=0, actual=31829, cls=class o.a.i.i.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyPool$1]]
> [11:42:48,204][SEVERE][ignite-#18%sys-null%][GridCacheIoManager] Failed to process message (note that distributed services do not support peer class loading, if you deploy distributed service you should have all required classes in CLASSPATH on all nodes in topology) [senderId=f7b1e6b0-4233-4291-9d6a-8a70a5e6d6bd, err=Optimized stream class checksum mismatch (is same version of marshalled class present on all nodes?) [expected=0, actual=31829, cls=class o.a.i.i.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyPool$1]]
> [11:42:57,908][SEVERE][ignite-#19%sys-null%][GridCacheIoManager] Failed to process message (note that distributed services do not support peer class loading, if you deploy distributed service you should have all required classes in CLASSPATH on all nodes in topology) [senderId=f7b1e6b0-4233-4291-9d6a-8a70a5e6d6bd, err=Optimized stream class checksum mismatch (is same version of marshalled class present on all nodes?) [expected=0, actual=31829, cls=class o.a.i.i.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyPool$1]]
> [11:42:58,207][SEVERE][ignite-#21%sys-null%][GridCacheIoManager] Failed to process message (note that distributed services do not support peer class loading, if you deploy distributed service you should have all required classes in CLASSPATH on all nodes in topology) [senderId=f7b1e6b0-4233-4291-9d6a-8a70a5e6d6bd, err=Optimized stream class checksum mismatch (is same version of marshalled class present on all nodes?) [expected=0, actual=31829, cls=class o.a.i.i.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyPool$1]]
> [11:43:07,908][SEVERE][ignite-#22%sys-null%][GridCacheIoManager] Failed to process message (note that distributed services do not support peer class loading, if you deploy distributed service you should have all required classes in CLASSPATH on all nodes in topology) [senderId=f7b1e6b0-4233-4291-9d6a-8a70a5e6d6bd, err=Optimized stream class checksum mismatch (is same version of marshalled class present on all nodes?) [expected=0, actual=31829, cls=class o.a.i.i.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyPool$1]]
> [11:43:08,216][SEVERE][ignite-#24%sys-null%][GridCacheIoManager] Failed to process message (note that distributed services do not support peer class loading, if you deploy distributed service you should have all required classes in CLASSPATH on all nodes in topology) [senderId=f7b1e6b0-4233-4291-9d6a-8a70a5e6d6bd, err=Optimized stream class checksum mismatch (is same version of marshalled class present on all nodes?) [expected=0, actual=31829, cls=class o.a.i.i.processors.cache.distributed.dht.preloader.GridDhtPartitionSupplyPool$1]]
> {noformat}
> *Thread dumps and full logs in attachment*



--
This message was sent by Atlassian JIRA
(v6.3.4#6332)