You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@ignite.apache.org by "Roger Fischer (CW)" <rf...@Brocade.com> on 2017/07/06 17:47:27 UTC

Unable to connect from Windows Java client to Linux server cluster (ignite 2.0.0)

Hello,

I am unable to make a connection from a client on Windows to an Ignite server cluster running on 3 Linux machines. I have checked firewall settings on both.

I am running a 3-node cluster of Ignite (2.0.0) on Centos 7. The nodes are connected to the same Ethernet switch. The cluster is established properly and everything works fine. I can connect (using my client) when it is running on any of the 3 linux machines.

I reduced the cluster to two nodes, and run the client on the third node. Again the client connects successfully.

There is no problem as long as I stay on the linux boxes.

I have tried 3 Windows PCs, with quite different configurations. None of them can connect to the Ignite cluster on the Linux machines.

PC1 runs Win7 Home, and is connected to the same Ethernet switch as the linux machines.

PC2 is a corporate laptop running Win7 Enterprise, connected over WiFi. I configured the firewall to allow in and outbound connections on 47100-47199 and 47500-47599.

PC3 is another corporate laptop running Win10 Enterprise, also connected over WiFi. I verified that I can connect to port 47100 and 47500 on the linux boxes using Test-NetConnection.

Here is a snipped from the config file I use for the client. It is the same as the one used for the server (except for the client mode).

    <bean id="grid.cfg" class="org.apache.ignite.configuration.IgniteConfiguration">

        <property name="clientMode" value="true"/>

        <property name="discoverySpi">
            <bean class="org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi">
                <property name="ipFinder">
                    <bean class="org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder">
                        <property name="addresses">
                            <list>
                                <value>192.168.1.221</value>
                                <value>192.168.1.231</value>
                            </list>
                        </property>
                    </bean>
                </property>
           </bean>
        </property>

        <property name="cacheConfiguration">
            <list>

When starting the client (Java), the server log shows a client connected, but then disconnecting again.

[10:14:23] Topology snapshot [ver=11, servers=2, clients=1, CPUs=8, heap=3.8GB]
[10:14:49] Topology snapshot [ver=12, servers=2, clients=0, CPUs=4, heap=2.0GB]

The error I get when running the client:

$ java -Xms512m -Xmx2048m -jar target/igniteclient-1.0-SNAPSHOT.jar  config/config-client-nodes-2-3.xml
[10:14:21]    __________  ________________
[10:14:21]   /  _/ ___/ |/ /  _/_  __/ __/
[10:14:21]  _/ // (7 7    // /  / / / _/
[10:14:21] /___/\___/_/|_/___/ /_/ /___/
[10:14:21]
[10:14:21] ver. 2.0.0#20170430-sha1:d4eef3c6
[10:14:21] 2017 Copyright(C) Apache Software Foundation
[10:14:21]
[10:14:21] Ignite documentation: http://ignite.apache.org
[10:14:21]
[10:14:21] Quiet mode.
[10:14:21]   ^-- Logging to file 'C:\Utils\apache-ignite-fabric-1.8.0-bin\work\log\ignite-2aefb227.0.log'
[10:14:21]   ^-- To see **FULL** console log here add -DIGNITE_QUIET=false or "-v" to ignite.{sh|bat}
[10:14:21]
[10:14:21] OS: Windows 7 6.1 amd64
[10:14:21] VM information: Java(TM) SE Runtime Environment 1.8.0_101-b13 Oracle Corporation Java HotSpot(TM) 64-Bit Server VM 25.101-b13
[10:14:21] Configured plugins:
[10:14:21]   ^-- None
[10:14:21]
[10:14:21] Message queue limit is set to 0 which may lead to potential OOMEs when running cache operations in FULL_ASYNC or PRIMARY_SYNC modes due to message queues growth on sender and receiver sides.
[10:14:21] Security status [authentication=off, tls/ssl=off]
[10:14:22] REST protocols do not start on client node. To start the protocols on client node set '-DIGNITE_REST_START_ON_CLIENT=true' system property.
[10:14:49,257][SEVERE][exchange-worker-#24%null%][GridDhtPartitionsExchangeFuture] Failed to reinitialize local partitions (preloading will be stopped): GridDhtPartitionExchangeId [topVer=AffinityTopologyVersion [topVer=11, minorTopVer=0], nodeId=2aefb227, evt=NODE_JOINED]
class org.apache.ignite.IgniteCheckedException: Failed to send message (node may have left the grid or TCP connection cannot be established due to firewall issues) [node=TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false], topic=TOPIC_CACHE, msg=GridDhtPartitionsSingleMessage [parts={-2100569601=GridDhtPartitionMap [moving=0, size=0], 689859866=GridDhtPartitionMap [moving=0, size=0], -399170495=GridDhtPartitionMap [moving=0, size=0]}, partCntrs={-2100569601={}, 689859866={}, -399170495={}}, ex=null, client=true, compress=true, super=GridDhtPartitionsAbstractMessage [exchId=GridDhtPartitionExchangeId [topVer=AffinityTopologyVersion [topVer=11, minorTopVer=0], nodeId=2aefb227, evt=NODE_JOINED], lastVer=GridCacheVersion [topVer=0, order=1499361262057, nodeOrder=0], flags=1, super=GridCacheMessage [msgId=7, depInfo=null, err=null, skipPrepare=false, cacheId=0, cacheId=0]]], policy=2]
        at org.apache.ignite.internal.managers.communication.GridIoManager.send(GridIoManager.java:1334)
        at org.apache.ignite.internal.managers.communication.GridIoManager.sendToGridTopic(GridIoManager.java:1398)
        at org.apache.ignite.internal.processors.cache.GridCacheIoManager.send(GridCacheIoManager.java:946)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.sendLocalPartitions(GridDhtPartitionsExchangeFuture.java:1094)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.clientOnlyExchange(GridDhtPartitionsExchangeFuture.java:793)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.init(GridDhtPartitionsExchangeFuture.java:581)
        at org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager$ExchangeWorker.body(GridCachePartitionExchangeManager.java:1806)
        at org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:110)
        at java.lang.Thread.run(Unknown Source)
Caused by: class org.apache.ignite.spi.IgniteSpiException: Failed to send message to remote node: TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false]
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage0(TcpCommunicationSpi.java:2483)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage(TcpCommunicationSpi.java:2419)
        at org.apache.ignite.internal.managers.communication.GridIoManager.send(GridIoManager.java:1329)
        ... 8 more
Caused by: class org.apache.ignite.IgniteCheckedException: java.lang.NullPointerException
        at org.apache.ignite.internal.util.IgniteUtils.cast(IgniteUtils.java:7242)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.resolve(GridFutureAdapter.java:258)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.get0(GridFutureAdapter.java:170)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.get(GridFutureAdapter.java:139)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.reserveClient(TcpCommunicationSpi.java:2630)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage0(TcpCommunicationSpi.java:2455)
        ... 10 more
Caused by: java.util.concurrent.ExecutionException: java.lang.NullPointerException
        at java.util.concurrent.FutureTask.report(Unknown Source)
        at java.util.concurrent.FutureTask.get(Unknown Source)
        at org.apache.ignite.internal.util.IgniteUtils.filterReachable(IgniteUtils.java:1895)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.createTcpClient(TcpCommunicationSpi.java:2891)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.createNioClient(TcpCommunicationSpi.java:2702)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.reserveClient(TcpCommunicationSpi.java:2594)
        ... 11 more
Caused by: java.lang.NullPointerException
        at org.apache.ignite.internal.util.IgniteUtils.reachable(IgniteUtils.java:2102)
        at org.apache.ignite.internal.util.IgniteUtils$18.run(IgniteUtils.java:1884)
        at java.util.concurrent.Executors$RunnableAdapter.call(Unknown Source)
        at java.util.concurrent.FutureTask.run(Unknown Source)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(Unknown Source)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(Unknown Source)
        ... 1 more
[10:14:49,262][SEVERE][main][IgniteKernal] Got exception while starting (will rollback startup routine).
class org.apache.ignite.IgniteCheckedException: Failed to send message (node may have left the grid or TCP connection cannot be established due to firewall issues) [node=TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false], topic=TOPIC_CACHE, msg=GridDhtPartitionsSingleMessage [parts={-2100569601=GridDhtPartitionMap [moving=0, size=0], 689859866=GridDhtPartitionMap [moving=0, size=0], -399170495=GridDhtPartitionMap [moving=0, size=0]}, partCntrs={-2100569601={}, 689859866={}, -399170495={}}, ex=null, client=true, compress=true, super=GridDhtPartitionsAbstractMessage [exchId=GridDhtPartitionExchangeId [topVer=AffinityTopologyVersion [topVer=11, minorTopVer=0], nodeId=2aefb227, evt=NODE_JOINED], lastVer=GridCacheVersion [topVer=0, order=1499361262057, nodeOrder=0], flags=1, super=GridCacheMessage [msgId=7, depInfo=null, err=null, skipPrepare=false, cacheId=0, cacheId=0]]], policy=2]
        at org.apache.ignite.internal.managers.communication.GridIoManager.send(GridIoManager.java:1334)
        at org.apache.ignite.internal.managers.communication.GridIoManager.sendToGridTopic(GridIoManager.java:1398)
        at org.apache.ignite.internal.processors.cache.GridCacheIoManager.send(GridCacheIoManager.java:946)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.sendLocalPartitions(GridDhtPartitionsExchangeFuture.java:1094)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.clientOnlyExchange(GridDhtPartitionsExchangeFuture.java:793)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.init(GridDhtPartitionsExchangeFuture.java:581)
        at org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager$ExchangeWorker.body(GridCachePartitionExchangeManager.java:1806)
        at org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:110)
        at java.lang.Thread.run(Unknown Source)
Caused by: class org.apache.ignite.spi.IgniteSpiException: Failed to send message to remote node: TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false]
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage0(TcpCommunicationSpi.java:2483)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage(TcpCommunicationSpi.java:2419)
        at org.apache.ignite.internal.managers.communication.GridIoManager.send(GridIoManager.java:1329)
        ... 8 more
Caused by: class org.apache.ignite.IgniteCheckedException: java.lang.NullPointerException
        at org.apache.ignite.internal.util.IgniteUtils.cast(IgniteUtils.java:7242)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.resolve(GridFutureAdapter.java:258)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.get0(GridFutureAdapter.java:170)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.get(GridFutureAdapter.java:139)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.reserveClient(TcpCommunicationSpi.java:2630)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage0(TcpCommunicationSpi.java:2455)
        ... 10 more
Caused by: java.util.concurrent.ExecutionException: java.lang.NullPointerException
        at java.util.concurrent.FutureTask.report(Unknown Source)
        at java.util.concurrent.FutureTask.get(Unknown Source)
        at org.apache.ignite.internal.util.IgniteUtils.filterReachable(IgniteUtils.java:1895)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.createTcpClient(TcpCommunicationSpi.java:2891)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.createNioClient(TcpCommunicationSpi.java:2702)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.reserveClient(TcpCommunicationSpi.java:2594)
        ... 11 more
Caused by: java.lang.NullPointerException
        at org.apache.ignite.internal.util.IgniteUtils.reachable(IgniteUtils.java:2102)
        at org.apache.ignite.internal.util.IgniteUtils$18.run(IgniteUtils.java:1884)
        at java.util.concurrent.Executors$RunnableAdapter.call(Unknown Source)
        at java.util.concurrent.FutureTask.run(Unknown Source)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(Unknown Source)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(Unknown Source)
        ... 1 more
[10:14:49,267][SEVERE][exchange-worker-#24%null%][GridCachePartitionExchangeManager] Failed to wait for completion of partition map exchange (preloading will not start): GridDhtPartitionsExchangeFuture [dummy=false, forcePreload=false, reassign=false, discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=2aefb227-5651-445e-8ac9-a5c3acbcdb27, addrs=[0:0:0:0:0:0:0:1, 10.252.193.172, 127.0.0.1, 192.168.1.78, 192.168.56.1, 192.168.99.1, 2001:569:7386:8b00:2c39:92b9:66a9:5dab, 2001:569:7386:8b00:699a:9bba:8918:2683, 2620:100:0:d00:3071:ac47:ae56:eee2, 2620:100:0:d00:d451:26d7:fd1:202c], sockAddrs=[5JJ2GV1.corp.brocade.com/10.252.193.172:0, /0:0:0:0:0:0:0:1:0, /127.0.0.1:0, /2620:100:0:d00:d451:26d7:fd1:202c:0, /2001:569:7386:8b00:2c39:92b9:66a9:5dab:0, /192.168.1.78:0, /192.168.56.1:0, /192.168.99.1:0, /2001:569:7386:8b00:699a:9bba:8918:2683:0, /2620:100:0:d00:3071:ac47:ae56:eee2:0], discPort=0, order=11, intOrder=0, lastExchangeTime=1499361262832, loc=true, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=true], topVer=11, nodeId8=2aefb227, msg=null, type=NODE_JOINED, tstamp=1499361267432], crd=TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false], exchId=GridDhtPartitionExchangeId [topVer=AffinityTopologyVersion [topVer=11, minorTopVer=0], nodeId=2aefb227, evt=NODE_JOINED], added=false, initFut=GridFutureAdapter [ignoreInterrupts=false, state=DONE, res=false, hash=420444188], init=false, lastVer=null, partReleaseFut=null, affChangeMsg=null, skipPreload=true, clientOnlyExchange=true, initTs=1499361267727, centralizedAff=false, changeGlobalStateE=null, exchangeOnChangeGlobalState=false, forcedRebFut=null, evtLatch=0, remaining=[82bfab22-511d-4d90-9d9e-d83748db63d6, 8abb0a7d-ae0e-4750-be9c-b00abbe03e64], srvNodes=[TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false], TcpDiscoveryNode [id=82bfab22-511d-4d90-9d9e-d83748db63d6, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.231, 192.168.122.1, 2001:569:7386:8b00:1912:1b72:761a:8343%enp2s0], sockAddrs=[node-1w7jr9qjyqppbfimluoenv0hv.ipv6.telus.net/2001:569:7386:8b00:1912:1b72:761a:8343:47500, 2001:569:7386:8b00:1912:1b72:761a:8343%enp2s0:47500, /192.168.1.231:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500], discPort=47500, order=2, intOrder=2, lastExchangeTime=1499361263972, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false]], super=GridFutureAdapter [ignoreInterrupts=false, state=DONE, res=class o.a.i.IgniteCheckedException: Failed to send message (node may have left the grid or TCP connection cannot be established due to firewall issues) [node=TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false], topic=TOPIC_CACHE, msg=GridDhtPartitionsSingleMessage [parts={-2100569601=GridDhtPartitionMap [moving=0, size=0], 689859866=GridDhtPartitionMap [moving=0, size=0], -399170495=GridDhtPartitionMap [moving=0, size=0]}, partCntrs={-2100569601={}, 689859866={}, -399170495={}}, ex=null, client=true, compress=true, super=GridDhtPartitionsAbstractMessage [exchId=GridDhtPartitionExchangeId [topVer=AffinityTopologyVersion [topVer=11, minorTopVer=0], nodeId=2aefb227, evt=NODE_JOINED], lastVer=GridCacheVersion [topVer=0, order=1499361262057, nodeOrder=0], flags=1, super=GridCacheMessage [msgId=7, depInfo=null, err=null, skipPrepare=false, cacheId=0, cacheId=0]]], policy=2], hash=1766278665]]
class org.apache.ignite.IgniteCheckedException: Failed to send message (node may have left the grid or TCP connection cannot be established due to firewall issues) [node=TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false], topic=TOPIC_CACHE, msg=GridDhtPartitionsSingleMessage [parts={-2100569601=GridDhtPartitionMap [moving=0, size=0], 689859866=GridDhtPartitionMap [moving=0, size=0], -399170495=GridDhtPartitionMap [moving=0, size=0]}, partCntrs={-2100569601={}, 689859866={}, -399170495={}}, ex=null, client=true, compress=true, super=GridDhtPartitionsAbstractMessage [exchId=GridDhtPartitionExchangeId [topVer=AffinityTopologyVersion [topVer=11, minorTopVer=0], nodeId=2aefb227, evt=NODE_JOINED], lastVer=GridCacheVersion [topVer=0, order=1499361262057, nodeOrder=0], flags=1, super=GridCacheMessage [msgId=7, depInfo=null, err=null, skipPrepare=false, cacheId=0, cacheId=0]]], policy=2]
        at org.apache.ignite.internal.managers.communication.GridIoManager.send(GridIoManager.java:1334)
        at org.apache.ignite.internal.managers.communication.GridIoManager.sendToGridTopic(GridIoManager.java:1398)
        at org.apache.ignite.internal.processors.cache.GridCacheIoManager.send(GridCacheIoManager.java:946)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.sendLocalPartitions(GridDhtPartitionsExchangeFuture.java:1094)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.clientOnlyExchange(GridDhtPartitionsExchangeFuture.java:793)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.init(GridDhtPartitionsExchangeFuture.java:581)
        at org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager$ExchangeWorker.body(GridCachePartitionExchangeManager.java:1806)
        at org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:110)
        at java.lang.Thread.run(Unknown Source)
Caused by: class org.apache.ignite.spi.IgniteSpiException: Failed to send message to remote node: TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false]
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage0(TcpCommunicationSpi.java:2483)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage(TcpCommunicationSpi.java:2419)
        at org.apache.ignite.internal.managers.communication.GridIoManager.send(GridIoManager.java:1329)
        ... 8 more
Caused by: class org.apache.ignite.IgniteCheckedException: java.lang.NullPointerException
        at org.apache.ignite.internal.util.IgniteUtils.cast(IgniteUtils.java:7242)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.resolve(GridFutureAdapter.java:258)
       at org.apache.ignite.internal.util.future.GridFutureAdapter.get0(GridFutureAdapter.java:170)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.get(GridFutureAdapter.java:139)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.reserveClient(TcpCommunicationSpi.java:2630)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage0(TcpCommunicationSpi.java:2455)
        ... 10 more
Caused by: java.util.concurrent.ExecutionException: java.lang.NullPointerException
        at java.util.concurrent.FutureTask.report(Unknown Source)
        at java.util.concurrent.FutureTask.get(Unknown Source)
        at org.apache.ignite.internal.util.IgniteUtils.filterReachable(IgniteUtils.java:1895)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.createTcpClient(TcpCommunicationSpi.java:2891)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.createNioClient(TcpCommunicationSpi.java:2702)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.reserveClient(TcpCommunicationSpi.java:2594)
        ... 11 more
Caused by: java.lang.NullPointerException
        at org.apache.ignite.internal.util.IgniteUtils.reachable(IgniteUtils.java:2102)
        at org.apache.ignite.internal.util.IgniteUtils$18.run(IgniteUtils.java:1884)
        at java.util.concurrent.Executors$RunnableAdapter.call(Unknown Source)
        at java.util.concurrent.FutureTask.run(Unknown Source)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(Unknown Source)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(Unknown Source)
        ... 1 more
[10:14:49] Ignite node stopped OK [uptime=00:00:29:555]
ERROR: failed to connect; exception: Failed to send message to remote node: TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false]
... class org.apache.ignite.spi.IgniteSpiException: Failed to send message to remote node: TcpDiscoveryNode [id=8abb0a7d-ae0e-4750-be9c-b00abbe03e64, addrs=[0:0:0:0:0:0:0:1%lo, 127.0.0.1, 192.168.1.221, 192.168.122.1, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0], sockAddrs=[/192.168.1.221:47500, /192.168.122.1:47500, /0:0:0:0:0:0:0:1%lo:47500, /127.0.0.1:47500, node-1w7jr9qjyqppcanu92l72r5qe.ipv6.telus.net/2001:569:7386:8b00:51f5:da65:665a:e3c6:47500, 2001:569:7386:8b00:51f5:da65:665a:e3c6%enp2s0:47500], discPort=47500, order=1, intOrder=1, lastExchangeTime=1499361263272, loc=false, ver=2.0.0#20170430-sha1:d4eef3c6, isClient=false]
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage0(TcpCommunicationSpi.java:2483)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage(TcpCommunicationSpi.java:2419)
        at org.apache.ignite.internal.managers.communication.GridIoManager.send(GridIoManager.java:1329)
        at org.apache.ignite.internal.managers.communication.GridIoManager.sendToGridTopic(GridIoManager.java:1398)
        at org.apache.ignite.internal.processors.cache.GridCacheIoManager.send(GridCacheIoManager.java:946)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.sendLocalPartitions(GridDhtPartitionsExchangeFuture.java:1094)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.clientOnlyExchange(GridDhtPartitionsExchangeFuture.java:793)
        at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.init(GridDhtPartitionsExchangeFuture.java:581)
        at org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager$ExchangeWorker.body(GridCachePartitionExchangeManager.java:1806)
        at org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:110)
        at java.lang.Thread.run(Unknown Source)
Caused by: class org.apache.ignite.IgniteCheckedException: java.lang.NullPointerException
        at org.apache.ignite.internal.util.IgniteUtils.cast(IgniteUtils.java:7242)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.resolve(GridFutureAdapter.java:258)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.get0(GridFutureAdapter.java:170)
        at org.apache.ignite.internal.util.future.GridFutureAdapter.get(GridFutureAdapter.java:139)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.reserveClient(TcpCommunicationSpi.java:2630)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.sendMessage0(TcpCommunicationSpi.java:2455)
        ... 10 more
Caused by: java.util.concurrent.ExecutionException: java.lang.NullPointerException
        at java.util.concurrent.FutureTask.report(Unknown Source)
        at java.util.concurrent.FutureTask.get(Unknown Source)
        at org.apache.ignite.internal.util.IgniteUtils.filterReachable(IgniteUtils.java:1895)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.createTcpClient(TcpCommunicationSpi.java:2891)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.createNioClient(TcpCommunicationSpi.java:2702)
        at org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.reserveClient(TcpCommunicationSpi.java:2594)
        ... 11 more
Caused by: java.lang.NullPointerException
        at org.apache.ignite.internal.util.IgniteUtils.reachable(IgniteUtils.java:2102)
        at org.apache.ignite.internal.util.IgniteUtils$18.run(IgniteUtils.java:1884)
        at java.util.concurrent.Executors$RunnableAdapter.call(Unknown Source)
        at java.util.concurrent.FutureTask.run(Unknown Source)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(Unknown Source)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(Unknown Source)
        ... 1 more


Any help is greatly appreciated.

Roger


RE: Unable to connect from Windows Java client to Linux server cluster (ignite 2.0.0)

Posted by "Roger Fischer (CW)" <rf...@Brocade.com>.
Thanks, Val.

Running the servers with the property set resolved my problem.

I see that this is already anticipated in the ignite.sh script. I only had to uncomment the line with this property.

Roger


-----Original Message-----
From: vkulichenko [mailto:valentin.kulichenko@gmail.com] 
Sent: Thursday, July 06, 2017 2:53 PM
To: user@ignite.apache.org
Subject: Re: Unable to connect from Windows Java client to Linux server cluster (ignite 2.0.0)

Hi Roger,

This is a known issue: https://urldefense.proofpoint.com/v2/url?u=https-3A__issues.apache.org_jira_browse_IGNITE-2D5189&d=DwICAg&c=IL_XqQWOjubgfqINi2jTzg&r=1esZO0r0bYS90lcsaLA6N4AFxuNo6lzauhETGwdJQoQ&m=zrWGK7PfNr8lHLPVvqtrgWoTZ4aXZ1RfaTzoNWdnrOY&s=S99xvOqo1iLdlOVR2ynj-5GzFQMoVcUdrqdqFLw4IUw&e= 

Try to set java.net.preferIPv4Stack=true system property.

-Val



--
View this message in context: https://urldefense.proofpoint.com/v2/url?u=http-3A__apache-2Dignite-2Dusers.70518.x6.nabble.com_Unable-2Dto-2Dconnect-2Dfrom-2DWindows-2DJava-2Dclient-2Dto-2DLinux-2Dserver-2Dcluster-2Dignite-2D2-2D0-2D0-2Dtp14410p14421.html&d=DwICAg&c=IL_XqQWOjubgfqINi2jTzg&r=1esZO0r0bYS90lcsaLA6N4AFxuNo6lzauhETGwdJQoQ&m=zrWGK7PfNr8lHLPVvqtrgWoTZ4aXZ1RfaTzoNWdnrOY&s=a8JLoBf3757j9EcXXvzQi2SsY6QkLBuSDtF0XrSSitE&e= 
Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: Unable to connect from Windows Java client to Linux server cluster (ignite 2.0.0)

Posted by vkulichenko <va...@gmail.com>.
Hi Roger,

This is a known issue: https://issues.apache.org/jira/browse/IGNITE-5189

Try to set java.net.preferIPv4Stack=true system property.

-Val



--
View this message in context: http://apache-ignite-users.70518.x6.nabble.com/Unable-to-connect-from-Windows-Java-client-to-Linux-server-cluster-ignite-2-0-0-tp14410p14421.html
Sent from the Apache Ignite Users mailing list archive at Nabble.com.