You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@ignite.apache.org by salmanbhatti81 <sa...@gmail.com> on 2020/04/03 14:42:25 UTC

Unable to connect java client application to dockerize ignite server in windows 10

I have been able to successfully run apache ignite with custom config using
command

docker run -it --net=host -v
"pathToLocalDirectory"/config:/opt/ignite/apache-ignite/config -e
"CONFIG_URI=file:///opt/ignite/apache-ignite/config/default-config.xml"
apacheignite/ignite.

But when i run my java project in intellij i get the message

"IP finder returned empty addresses list. Please check IP finder
configuration and make sure multicast works on your network...".

Note: the java client project works if i run ignite server using windows
batch file. Also i have published 47500 port as well . the result is the
same.



--
Sent from: http://apache-ignite-users.70518.x6.nabble.com/

Re: Unable to connect java client application to dockerize ignite server in windows 10

Posted by Evgenii Zhuravlev <e....@gmail.com>.
You will need to enter docker container and find it there

пт, 3 апр. 2020 г. в 15:23, Evgenii Zhuravlev <e....@gmail.com>:

> Can you share the full log file for server node too? This one is for a
> client.
>
> пт, 3 апр. 2020 г. в 15:06, salmanbhatti81 <sa...@gmail.com>:
>
>> ignite-b5f169b9.log
>> <
>> http://apache-ignite-users.70518.x6.nabble.com/file/t2822/ignite-b5f169b9.log>
>>
>> the log file
>>
>>
>>
>>
>>
>>
>> --
>> Sent from: http://apache-ignite-users.70518.x6.nabble.com/
>>
>

Re: Unable to connect java client application to dockerize ignite server in windows 10

Posted by Evgenii Zhuravlev <e....@gmail.com>.
Can you share the full log file for server node too? This one is for a
client.

пт, 3 апр. 2020 г. в 15:06, salmanbhatti81 <sa...@gmail.com>:

> ignite-b5f169b9.log
> <
> http://apache-ignite-users.70518.x6.nabble.com/file/t2822/ignite-b5f169b9.log>
>
> the log file
>
>
>
>
>
>
> --
> Sent from: http://apache-ignite-users.70518.x6.nabble.com/
>

Re: Unable to connect java client application to dockerize ignite server in windows 10

Posted by salmanbhatti81 <sa...@gmail.com>.
ignite-b5f169b9.log
<http://apache-ignite-users.70518.x6.nabble.com/file/t2822/ignite-b5f169b9.log>   
the log file






--
Sent from: http://apache-ignite-users.70518.x6.nabble.com/

Re: Unable to connect java client application to dockerize ignite server in windows 10

Posted by Evgenii Zhuravlev <e....@gmail.com>.
It's not a full server log, there is a log file placed in a
$IGNITE_HOME/work/log dir, can you attach it too? Alternatively, you can
run server with the same flag as client.

пт, 3 апр. 2020 г. в 14:45, salmanbhatti81 <sa...@gmail.com>:

> the server log
> <http://apache-ignite-users.70518.x6.nabble.com/file/t2822/error1.png>
>
> unable to run client with -DIGNITE_QUIET  =false
> could you please guide how can i run in windows using intellij. this is a
> spring boot app.
>
> below are client logs
> >>> /___/\___/_/|_/___/ /_/ /___/
> >>>
> >>> ver. 2.7.6#20190911-sha1:21f7ca41
> >>> 2019 Copyright(C) Apache Software Foundation
> >>>
> >>> Ignite documentation: http://ignite.apache.org
>
> [02:36:35,321][INFO][main][IgniteKernal] Config URL: n/a
> [02:36:35,335][INFO][main][IgniteKernal] IgniteConfiguration
> [igniteInstanceName=null, pubPoolSize=8, svcPoolSize=8, callbackPoolSize=8,
> stripedPoolSize=8, sysPoolSize=8, mgmtPoolSize=4, igfsPoolSize=8,
> dataStreamerPoolSize=8, utilityCachePoolSize=8,
> utilityCacheKeepAliveTime=60000, p2pPoolSize=2, qryPoolSize=8,
> igniteHome=C:\Users\Salman\Downloads\apache-ignite-2.7.6-bin,
> igniteWorkDir=C:\Users\Salman\Downloads\apache-ignite-2.7.6-bin\work,
> mbeanSrv=com.sun.jmx.mbeanserver.JmxMBeanServer@1f51431,
> nodeId=b5f169b9-f4a3-41b4-8a7d-20776fb7d775, marsh=BinaryMarshaller [],
> marshLocJobs=false, daemon=false, p2pEnabled=true, netTimeout=5000,
> sndRetryDelay=1000, sndRetryCnt=3, metricsHistSize=10000,
> metricsUpdateFreq=2000, metricsExpTime=9223372036854775807,
> discoSpi=TcpDiscoverySpi [addrRslvr=null, sockTimeout=0, ackTimeout=0,
> marsh=null, reconCnt=10, reconDelay=2000, maxAckTimeout=600000,
> forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null],
> segPlc=STOP, segResolveAttempts=2, waitForSegOnStart=true,
> allResolversPassReq=true, segChkFreq=10000, commSpi=TcpCommunicationSpi
> [connectGate=null,
>
> connPlc=org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi$FirstConnectionPolicy@43da41e
> ,
> enableForcibleNodeKill=false, enableTroubleshootingLog=false, locAddr=null,
> locHost=null, locPort=47100, locPortRange=100, shmemPort=-1,
> directBuf=true,
> directSndBuf=false, idleConnTimeout=600000, connTimeout=5000,
> maxConnTimeout=600000, reconCnt=10, sockSndBuf=32768, sockRcvBuf=32768,
> msgQueueLimit=0, slowClientQueueLimit=0, nioSrvr=null, shmemSrv=null,
> usePairedConnections=false, connectionsPerNode=1, tcpNoDelay=true,
> filterReachableAddresses=false, ackSndThreshold=32, unackedMsgsBufSize=0,
> sockWriteTimeout=2000, boundTcpPort=-1, boundTcpShmemPort=-1,
> selectorsCnt=4, selectorSpins=0, addrRslvr=null,
> ctxInitLatch=java.util.concurrent.CountDownLatch@148c7c4b[Count = 1],
> stopping=false],
> evtSpi=org.apache.ignite.spi.eventstorage.NoopEventStorageSpi@2009f9b0,
> colSpi=NoopCollisionSpi [], deploySpi=LocalDeploymentSpi [],
> indexingSpi=org.apache.ignite.spi.indexing.noop.NoopIndexingSpi@3bd3d05e,
> addrRslvr=null,
>
> encryptionSpi=org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi@6aba5d30
> ,
> clientMode=true, rebalanceThreadPoolSize=1, txCfg=TransactionConfiguration
> [txSerEnabled=false, dfltIsolation=REPEATABLE_READ,
> dfltConcurrency=PESSIMISTIC, dfltTxTimeout=0,
> txTimeoutOnPartitionMapExchange=0, pessimisticTxLogSize=0,
> pessimisticTxLogLinger=10000, tmLookupClsName=null, txManagerFactory=null,
> useJtaSync=false], cacheSanityCheckEnabled=true, discoStartupDelay=60000,
> deployMode=SHARED, p2pMissedCacheSize=100, locHost=null,
> timeSrvPortBase=31100, timeSrvPortRange=100, failureDetectionTimeout=10000,
> sysWorkerBlockedTimeout=null, clientFailureDetectionTimeout=30000,
> metricsLogFreq=60000, hadoopCfg=null, connectorCfg=ConnectorConfiguration
> [jettyPath=null, host=null, port=11211, noDelay=true, directBuf=false,
> sndBufSize=32768, rcvBufSize=32768, idleQryCurTimeout=600000,
> idleQryCurCheckFreq=60000, sndQueueLimit=0, selectorCnt=4,
> idleTimeout=7000,
> sslEnabled=false, sslClientAuth=false, sslCtxFactory=null, sslFactory=null,
> portRange=100, threadPoolSize=8, msgInterceptor=null], odbcCfg=null,
> warmupClos=null, atomicCfg=AtomicConfiguration [seqReserveSize=1000,
> cacheMode=PARTITIONED, backups=1, aff=null, grpName=null], classLdr=null,
> sslCtxFactory=null, platformCfg=null, binaryCfg=null, memCfg=null,
> pstCfg=null, dsCfg=null, activeOnStart=true, autoActivation=true,
> longQryWarnTimeout=3000, sqlConnCfg=null,
> cliConnCfg=ClientConnectorConfiguration [host=null, port=10800,
> portRange=100, sockSndBufSize=0, sockRcvBufSize=0, tcpNoDelay=true,
> maxOpenCursorsPerConn=128, threadPoolSize=8, idleTimeout=0,
> jdbcEnabled=true, odbcEnabled=true, thinCliEnabled=true, sslEnabled=false,
> useIgniteSslCtxFactory=true, sslClientAuth=false, sslCtxFactory=null],
> mvccVacuumThreadCnt=2, mvccVacuumFreq=5000, authEnabled=false,
> failureHnd=null, commFailureRslvr=null]
> [02:36:35,337][INFO][main][IgniteKernal] Daemon mode: off
> [02:36:35,337][INFO][main][IgniteKernal] OS: Windows 10 10.0 amd64
> [02:36:35,337][INFO][main][IgniteKernal] OS user: Salman
> [02:36:35,337][INFO][main][IgniteKernal] PID: 6240
> [02:36:35,338][INFO][main][IgniteKernal] Language runtime: Java Platform
> API
> Specification ver. 1.8
> [02:36:35,338][INFO][main][IgniteKernal] VM information: Java(TM) SE
> Runtime
> Environment 1.8.0_241-b07 Oracle Corporation Java HotSpot(TM) 64-Bit Server
> VM 25.241-b07
> [02:36:35,338][INFO][main][IgniteKernal] VM total memory: 3.5GB
> [02:36:35,338][INFO][main][IgniteKernal] Remote Management [restart: off,
> REST: off, JMX (remote: off)]
> [02:36:35,338][INFO][main][IgniteKernal] Logger: JavaLogger [quiet=true,
> config=null]
> [02:36:35,339][INFO][main][IgniteKernal]
> IGNITE_HOME=C:\Users\Salman\Downloads\apache-ignite-2.7.6-bin
> [02:36:35,339][INFO][main][IgniteKernal] VM arguments:
> [-Dfile.encoding=windows-1252, -Duser.country=US, -Duser.language=en,
> -Duser.variant]
> [02:36:35,339][INFO][main][IgniteKernal] Configured caches [in 'sysMemPlc'
> dataRegion: ['ignite-sys-cache'], in 'null' dataRegion: ['QuoteRequest',
> 'CarrierFreightTemplate']]
> [02:36:35,339][WARNING][main][IgniteKernal] Peer class loading is enabled
> (disable it in production for performance and deployment consistency
> reasons)
> [02:36:35,339][WARNING][main][IgniteKernal] Please set system property
> '-Djava.net.preferIPv4Stack=true' to avoid possible problems in mixed
> environments.
> [02:36:35,341][WARNING][pub-#19][GridDiagnostic] This operating system has
> been tested less rigorously: Windows 10 10.0 amd64. Our team will
> appreciate
> the feedback if you experience any problems running ignite in this
> environment.
> [02:36:35,349][INFO][main][IgniteKernal] 3-rd party licenses can be found
> at: C:\Users\Salman\Downloads\apache-ignite-2.7.6-bin\libs\licenses
> [02:36:35,349][WARNING][pub-#22][GridDiagnostic] Initial heap size is 254MB
> (should be no less than 512MB, use -Xms512m -Xmx512m).
> [02:36:35,420][INFO][main][IgnitePluginProcessor] Configured plugins:
> [02:36:35,420][INFO][main][IgnitePluginProcessor]   ^-- None
> [02:36:35,420][INFO][main][IgnitePluginProcessor]
> [02:36:35,423][INFO][main][FailureProcessor] Configured failure handler:
> [hnd=StopNodeOrHaltFailureHandler [tryStop=false, timeout=0,
> super=AbstractFailureHandler [ignoredFailureTypes=[SYSTEM_WORKER_BLOCKED,
> SYSTEM_CRITICAL_OPERATION_TIMEOUT]]]]
> [02:36:35,464][INFO][main][TcpCommunicationSpi] Successfully bound
> communication NIO server to TCP port [port=47101, locHost=0.0.0.0/0.0.0.0,
> selectorsCnt=4, selectorSpins=0, pairedConn=false]
> [02:36:40,604][WARNING][main][TcpCommunicationSpi] 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.
> [02:36:40,637][WARNING][main][NoopCheckpointSpi] Checkpoints are disabled
> (to enable configure any GridCheckpointSpi implementation)
> [02:36:40,660][WARNING][main][GridCollisionManager] Collision resolution is
> disabled (all jobs will be activated upon arrival).
> [02:36:40,664][INFO][main][IgniteKernal] Security status
> [authentication=off, tls/ssl=off]
> [02:36:40,837][INFO][main][PartitionsEvictManager] Evict partition
> permits=2
> [02:36:41,029][INFO][main][ClientListenerProcessor] Client connector
> processor has started on TCP port 10801
> [02:36:41,044][INFO][main][GridRestProcessor] REST protocols do not start
> on
> client node. To start the protocols on client node set
> '-DIGNITE_REST_START_ON_CLIENT=true' system property.
> [02:36:41,952][INFO][main][IgniteKernal] Non-loopback local IPs:
> 192.168.10.3, 192.168.128.1, 192.168.99.193,
> fe80:0:0:0:18e2:4cac:28c5:900c%eth25, fe80:0:0:0:2536:85fb:23a8:e7d1%wlan1,
> fe80:0:0:0:488a:1c5b:3a1c:e25f%eth2, fe80:0:0:0:6d4f:d48d:6dd:3c85%wlan2,
> fe80:0:0:0:a86c:f233:3cec:f766%eth12, fe80:0:0:0:d42f:a05a:393b:3d02%eth3,
> fe80:0:0:0:d95:9e5c:d8d2:12dd%wlan0, fe80:0:0:0:fcba:1ef9:9586:48cd%eth0
> [02:36:41,952][INFO][main][IgniteKernal] Enabled local MACs: 00155DCAB5B1,
> 00155DEB9BAE, 00FF82A88A0A, 588A5A052AB9, BCA8A68088F1, BCA8A68088F2,
> BCA8A68088F5, BEA8A68088F1
> [02:36:59,052][SEVERE][grid-timeout-worker-#23][G] Blocked system-critical
> thread has been detected. This can lead to cluster-wide undefined behaviour
> [threadName=tcp-client-disco-msg-worker, blockedFor=17s]
> [02:36:59,054][WARNING][grid-timeout-worker-#23][G] Thread
> [name="tcp-client-disco-msg-worker-#4", id=66, state=RUNNABLE, blockCnt=1,
> waitCnt=1]
>
> [02:36:59,057][SEVERE][grid-timeout-worker-#23][] Critical system error
> detected. Will be handled accordingly to configured handler
> [hnd=StopNodeOrHaltFailureHandler [tryStop=false, timeout=0,
> super=AbstractFailureHandler [ignoredFailureTypes=[SYSTEM_WORKER_BLOCKED,
> SYSTEM_CRITICAL_OPERATION_TIMEOUT]]], failureCtx=FailureContext
> [type=SYSTEM_WORKER_BLOCKED, err=class o.a.i.IgniteException: GridWorker
> [name=tcp-client-disco-msg-worker, igniteInstanceName=null, finished=false,
> heartbeatTs=1585949801979]]]
> class org.apache.ignite.IgniteException: GridWorker
> [name=tcp-client-disco-msg-worker, igniteInstanceName=null, finished=false,
> heartbeatTs=1585949801979]
>         at
>
> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance$2.apply(IgnitionEx.java:1831)
>         at
>
> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance$2.apply(IgnitionEx.java:1826)
>         at
>
> org.apache.ignite.internal.worker.WorkersRegistry.onIdle(WorkersRegistry.java:233)
>         at
>
> org.apache.ignite.internal.util.worker.GridWorker.onIdle(GridWorker.java:297)
>         at
>
> org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor$TimeoutWorker.body(GridTimeoutProcessor.java:221)
>         at
> org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:120)
>         at java.lang.Thread.run(Thread.java:748)
>
>
>
> --
> Sent from: http://apache-ignite-users.70518.x6.nabble.com/
>

Re: Unable to connect java client application to dockerize ignite server in windows 10

Posted by salmanbhatti81 <sa...@gmail.com>.
the server log
<http://apache-ignite-users.70518.x6.nabble.com/file/t2822/error1.png> 

unable to run client with -DIGNITE_QUIET  =false
could you please guide how can i run in windows using intellij. this is a
spring boot app.

below are client logs 
>>> /___/\___/_/|_/___/ /_/ /___/   
>>> 
>>> ver. 2.7.6#20190911-sha1:21f7ca41
>>> 2019 Copyright(C) Apache Software Foundation
>>> 
>>> Ignite documentation: http://ignite.apache.org

[02:36:35,321][INFO][main][IgniteKernal] Config URL: n/a
[02:36:35,335][INFO][main][IgniteKernal] IgniteConfiguration
[igniteInstanceName=null, pubPoolSize=8, svcPoolSize=8, callbackPoolSize=8,
stripedPoolSize=8, sysPoolSize=8, mgmtPoolSize=4, igfsPoolSize=8,
dataStreamerPoolSize=8, utilityCachePoolSize=8,
utilityCacheKeepAliveTime=60000, p2pPoolSize=2, qryPoolSize=8,
igniteHome=C:\Users\Salman\Downloads\apache-ignite-2.7.6-bin,
igniteWorkDir=C:\Users\Salman\Downloads\apache-ignite-2.7.6-bin\work,
mbeanSrv=com.sun.jmx.mbeanserver.JmxMBeanServer@1f51431,
nodeId=b5f169b9-f4a3-41b4-8a7d-20776fb7d775, marsh=BinaryMarshaller [],
marshLocJobs=false, daemon=false, p2pEnabled=true, netTimeout=5000,
sndRetryDelay=1000, sndRetryCnt=3, metricsHistSize=10000,
metricsUpdateFreq=2000, metricsExpTime=9223372036854775807,
discoSpi=TcpDiscoverySpi [addrRslvr=null, sockTimeout=0, ackTimeout=0,
marsh=null, reconCnt=10, reconDelay=2000, maxAckTimeout=600000,
forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null],
segPlc=STOP, segResolveAttempts=2, waitForSegOnStart=true,
allResolversPassReq=true, segChkFreq=10000, commSpi=TcpCommunicationSpi
[connectGate=null,
connPlc=org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi$FirstConnectionPolicy@43da41e,
enableForcibleNodeKill=false, enableTroubleshootingLog=false, locAddr=null,
locHost=null, locPort=47100, locPortRange=100, shmemPort=-1, directBuf=true,
directSndBuf=false, idleConnTimeout=600000, connTimeout=5000,
maxConnTimeout=600000, reconCnt=10, sockSndBuf=32768, sockRcvBuf=32768,
msgQueueLimit=0, slowClientQueueLimit=0, nioSrvr=null, shmemSrv=null,
usePairedConnections=false, connectionsPerNode=1, tcpNoDelay=true,
filterReachableAddresses=false, ackSndThreshold=32, unackedMsgsBufSize=0,
sockWriteTimeout=2000, boundTcpPort=-1, boundTcpShmemPort=-1,
selectorsCnt=4, selectorSpins=0, addrRslvr=null,
ctxInitLatch=java.util.concurrent.CountDownLatch@148c7c4b[Count = 1],
stopping=false],
evtSpi=org.apache.ignite.spi.eventstorage.NoopEventStorageSpi@2009f9b0,
colSpi=NoopCollisionSpi [], deploySpi=LocalDeploymentSpi [],
indexingSpi=org.apache.ignite.spi.indexing.noop.NoopIndexingSpi@3bd3d05e,
addrRslvr=null,
encryptionSpi=org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi@6aba5d30,
clientMode=true, rebalanceThreadPoolSize=1, txCfg=TransactionConfiguration
[txSerEnabled=false, dfltIsolation=REPEATABLE_READ,
dfltConcurrency=PESSIMISTIC, dfltTxTimeout=0,
txTimeoutOnPartitionMapExchange=0, pessimisticTxLogSize=0,
pessimisticTxLogLinger=10000, tmLookupClsName=null, txManagerFactory=null,
useJtaSync=false], cacheSanityCheckEnabled=true, discoStartupDelay=60000,
deployMode=SHARED, p2pMissedCacheSize=100, locHost=null,
timeSrvPortBase=31100, timeSrvPortRange=100, failureDetectionTimeout=10000,
sysWorkerBlockedTimeout=null, clientFailureDetectionTimeout=30000,
metricsLogFreq=60000, hadoopCfg=null, connectorCfg=ConnectorConfiguration
[jettyPath=null, host=null, port=11211, noDelay=true, directBuf=false,
sndBufSize=32768, rcvBufSize=32768, idleQryCurTimeout=600000,
idleQryCurCheckFreq=60000, sndQueueLimit=0, selectorCnt=4, idleTimeout=7000,
sslEnabled=false, sslClientAuth=false, sslCtxFactory=null, sslFactory=null,
portRange=100, threadPoolSize=8, msgInterceptor=null], odbcCfg=null,
warmupClos=null, atomicCfg=AtomicConfiguration [seqReserveSize=1000,
cacheMode=PARTITIONED, backups=1, aff=null, grpName=null], classLdr=null,
sslCtxFactory=null, platformCfg=null, binaryCfg=null, memCfg=null,
pstCfg=null, dsCfg=null, activeOnStart=true, autoActivation=true,
longQryWarnTimeout=3000, sqlConnCfg=null,
cliConnCfg=ClientConnectorConfiguration [host=null, port=10800,
portRange=100, sockSndBufSize=0, sockRcvBufSize=0, tcpNoDelay=true,
maxOpenCursorsPerConn=128, threadPoolSize=8, idleTimeout=0,
jdbcEnabled=true, odbcEnabled=true, thinCliEnabled=true, sslEnabled=false,
useIgniteSslCtxFactory=true, sslClientAuth=false, sslCtxFactory=null],
mvccVacuumThreadCnt=2, mvccVacuumFreq=5000, authEnabled=false,
failureHnd=null, commFailureRslvr=null]
[02:36:35,337][INFO][main][IgniteKernal] Daemon mode: off
[02:36:35,337][INFO][main][IgniteKernal] OS: Windows 10 10.0 amd64
[02:36:35,337][INFO][main][IgniteKernal] OS user: Salman
[02:36:35,337][INFO][main][IgniteKernal] PID: 6240
[02:36:35,338][INFO][main][IgniteKernal] Language runtime: Java Platform API
Specification ver. 1.8
[02:36:35,338][INFO][main][IgniteKernal] VM information: Java(TM) SE Runtime
Environment 1.8.0_241-b07 Oracle Corporation Java HotSpot(TM) 64-Bit Server
VM 25.241-b07
[02:36:35,338][INFO][main][IgniteKernal] VM total memory: 3.5GB
[02:36:35,338][INFO][main][IgniteKernal] Remote Management [restart: off,
REST: off, JMX (remote: off)]
[02:36:35,338][INFO][main][IgniteKernal] Logger: JavaLogger [quiet=true,
config=null]
[02:36:35,339][INFO][main][IgniteKernal]
IGNITE_HOME=C:\Users\Salman\Downloads\apache-ignite-2.7.6-bin
[02:36:35,339][INFO][main][IgniteKernal] VM arguments:
[-Dfile.encoding=windows-1252, -Duser.country=US, -Duser.language=en,
-Duser.variant]
[02:36:35,339][INFO][main][IgniteKernal] Configured caches [in 'sysMemPlc'
dataRegion: ['ignite-sys-cache'], in 'null' dataRegion: ['QuoteRequest',
'CarrierFreightTemplate']]
[02:36:35,339][WARNING][main][IgniteKernal] Peer class loading is enabled
(disable it in production for performance and deployment consistency
reasons)
[02:36:35,339][WARNING][main][IgniteKernal] Please set system property
'-Djava.net.preferIPv4Stack=true' to avoid possible problems in mixed
environments.
[02:36:35,341][WARNING][pub-#19][GridDiagnostic] This operating system has
been tested less rigorously: Windows 10 10.0 amd64. Our team will appreciate
the feedback if you experience any problems running ignite in this
environment.
[02:36:35,349][INFO][main][IgniteKernal] 3-rd party licenses can be found
at: C:\Users\Salman\Downloads\apache-ignite-2.7.6-bin\libs\licenses
[02:36:35,349][WARNING][pub-#22][GridDiagnostic] Initial heap size is 254MB
(should be no less than 512MB, use -Xms512m -Xmx512m).
[02:36:35,420][INFO][main][IgnitePluginProcessor] Configured plugins:
[02:36:35,420][INFO][main][IgnitePluginProcessor]   ^-- None
[02:36:35,420][INFO][main][IgnitePluginProcessor] 
[02:36:35,423][INFO][main][FailureProcessor] Configured failure handler:
[hnd=StopNodeOrHaltFailureHandler [tryStop=false, timeout=0,
super=AbstractFailureHandler [ignoredFailureTypes=[SYSTEM_WORKER_BLOCKED,
SYSTEM_CRITICAL_OPERATION_TIMEOUT]]]]
[02:36:35,464][INFO][main][TcpCommunicationSpi] Successfully bound
communication NIO server to TCP port [port=47101, locHost=0.0.0.0/0.0.0.0,
selectorsCnt=4, selectorSpins=0, pairedConn=false]
[02:36:40,604][WARNING][main][TcpCommunicationSpi] 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.
[02:36:40,637][WARNING][main][NoopCheckpointSpi] Checkpoints are disabled
(to enable configure any GridCheckpointSpi implementation)
[02:36:40,660][WARNING][main][GridCollisionManager] Collision resolution is
disabled (all jobs will be activated upon arrival).
[02:36:40,664][INFO][main][IgniteKernal] Security status
[authentication=off, tls/ssl=off]
[02:36:40,837][INFO][main][PartitionsEvictManager] Evict partition permits=2
[02:36:41,029][INFO][main][ClientListenerProcessor] Client connector
processor has started on TCP port 10801
[02:36:41,044][INFO][main][GridRestProcessor] REST protocols do not start on
client node. To start the protocols on client node set
'-DIGNITE_REST_START_ON_CLIENT=true' system property.
[02:36:41,952][INFO][main][IgniteKernal] Non-loopback local IPs:
192.168.10.3, 192.168.128.1, 192.168.99.193,
fe80:0:0:0:18e2:4cac:28c5:900c%eth25, fe80:0:0:0:2536:85fb:23a8:e7d1%wlan1,
fe80:0:0:0:488a:1c5b:3a1c:e25f%eth2, fe80:0:0:0:6d4f:d48d:6dd:3c85%wlan2,
fe80:0:0:0:a86c:f233:3cec:f766%eth12, fe80:0:0:0:d42f:a05a:393b:3d02%eth3,
fe80:0:0:0:d95:9e5c:d8d2:12dd%wlan0, fe80:0:0:0:fcba:1ef9:9586:48cd%eth0
[02:36:41,952][INFO][main][IgniteKernal] Enabled local MACs: 00155DCAB5B1,
00155DEB9BAE, 00FF82A88A0A, 588A5A052AB9, BCA8A68088F1, BCA8A68088F2,
BCA8A68088F5, BEA8A68088F1
[02:36:59,052][SEVERE][grid-timeout-worker-#23][G] Blocked system-critical
thread has been detected. This can lead to cluster-wide undefined behaviour
[threadName=tcp-client-disco-msg-worker, blockedFor=17s]
[02:36:59,054][WARNING][grid-timeout-worker-#23][G] Thread
[name="tcp-client-disco-msg-worker-#4", id=66, state=RUNNABLE, blockCnt=1,
waitCnt=1]

[02:36:59,057][SEVERE][grid-timeout-worker-#23][] Critical system error
detected. Will be handled accordingly to configured handler
[hnd=StopNodeOrHaltFailureHandler [tryStop=false, timeout=0,
super=AbstractFailureHandler [ignoredFailureTypes=[SYSTEM_WORKER_BLOCKED,
SYSTEM_CRITICAL_OPERATION_TIMEOUT]]], failureCtx=FailureContext
[type=SYSTEM_WORKER_BLOCKED, err=class o.a.i.IgniteException: GridWorker
[name=tcp-client-disco-msg-worker, igniteInstanceName=null, finished=false,
heartbeatTs=1585949801979]]]
class org.apache.ignite.IgniteException: GridWorker
[name=tcp-client-disco-msg-worker, igniteInstanceName=null, finished=false,
heartbeatTs=1585949801979]
	at
org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance$2.apply(IgnitionEx.java:1831)
	at
org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance$2.apply(IgnitionEx.java:1826)
	at
org.apache.ignite.internal.worker.WorkersRegistry.onIdle(WorkersRegistry.java:233)
	at
org.apache.ignite.internal.util.worker.GridWorker.onIdle(GridWorker.java:297)
	at
org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor$TimeoutWorker.body(GridTimeoutProcessor.java:221)
	at
org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:120)
	at java.lang.Thread.run(Thread.java:748)



--
Sent from: http://apache-ignite-users.70518.x6.nabble.com/

Re: Unable to connect java client application to dockerize ignite server in windows 10

Posted by Evgenii Zhuravlev <e....@gmail.com>.
please run client with -DIGNITE_QUIET=false and share full logs from both
client and server.

thanks,
Evgenii

пт, 3 апр. 2020 г. в 13:29, salmanbhatti81 <sa...@gmail.com>:

> I am configuring client apache ignite in java via bean. I get the following
> error when I run client app as in the image below :
> the error is same if I use xml configuration as per mentioned by you.
>   <http://apache-ignite-users.70518.x6.nabble.com/file/t2822/error.png>
>
> i.e.
> class org.apache.ignite.IgniteException: GridWorker
> [name=tcp-client-disco-msg-worker, igniteInstanceName=null, finished=false,
> heartbeatTs=1585944979993]
> Failed to connect to any address from IP finder
>
> My configuration for multicast in client app:
> TcpDiscoverySpi spi = new TcpDiscoverySpi();
> TcpDiscoveryMulticastIpFinder ipFinder = new
> TcpDiscoveryMulticastIpFinder();
> ipFinder.setAddresses(Arrays.asList("127.0.0.1:47500..47509"));
> spi.setIpFinder(ipFinder);
>
> TcpCommunicationSpi commSpi=new TcpCommunicationSpi();
> IgniteConfiguration config = new IgniteConfiguration();
> config.setDiscoverySpi(spi);
>
> Ignition.getOrStart(config);
>
>
>
> *Note*: The server log doesn't have any effect upon running client
> application.
>
>
> again for reference My docker command:
> docker run -it --net=host -v
>
> C:/Username/Downloads/apache-ignite-2.7.6-bin/config:/opt/ignite/apache-ignite/config
> -e "CONFIG_URI=file:///opt/ignite/apache-ignite/config/default-config.xml"
> -p 10800:10800 -p 47100:47100 -p 47500-47509:47500-47509
> apacheignite/ignite.
>
> Thanks for help in advance.
>
>
>
> --
> Sent from: http://apache-ignite-users.70518.x6.nabble.com/
>

Re: Unable to connect java client application to dockerize ignite server in windows 10

Posted by salmanbhatti81 <sa...@gmail.com>.
I am configuring client apache ignite in java via bean. I get the following
error when I run client app as in the image below :
the error is same if I use xml configuration as per mentioned by you.
  <http://apache-ignite-users.70518.x6.nabble.com/file/t2822/error.png> 

i.e. 
class org.apache.ignite.IgniteException: GridWorker
[name=tcp-client-disco-msg-worker, igniteInstanceName=null, finished=false,
heartbeatTs=1585944979993]
Failed to connect to any address from IP finder 

My configuration for multicast in client app:
TcpDiscoverySpi spi = new TcpDiscoverySpi();
TcpDiscoveryMulticastIpFinder ipFinder = new
TcpDiscoveryMulticastIpFinder();
ipFinder.setAddresses(Arrays.asList("127.0.0.1:47500..47509"));
spi.setIpFinder(ipFinder);

TcpCommunicationSpi commSpi=new TcpCommunicationSpi();
IgniteConfiguration config = new IgniteConfiguration();
config.setDiscoverySpi(spi);

Ignition.getOrStart(config);



*Note*: The server log doesn't have any effect upon running client
application.


again for reference My docker command:  
docker run -it --net=host -v
C:/Username/Downloads/apache-ignite-2.7.6-bin/config:/opt/ignite/apache-ignite/config
-e "CONFIG_URI=file:///opt/ignite/apache-ignite/config/default-config.xml" 
-p 10800:10800 -p 47100:47100 -p 47500-47509:47500-47509 
apacheignite/ignite.

Thanks for help in advance.



--
Sent from: http://apache-ignite-users.70518.x6.nabble.com/

Re: Unable to connect java client application to dockerize ignite server in windows 10

Posted by Evgenii Zhuravlev <e....@gmail.com>.
Hi,

Probably you didn't configure node addresses and multicast can't find this
server node, You can use this configuration on client side:

<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>
                            <!-- In distributed environment, replace
with actual host IP address. -->
                        <value>127.0.0.1:47500..47509</value>
                    </list>
                </property>
            </bean>
        </property>
    </bean>
</property>


If this won't help, it makes sense to check logs from server node itself.


Evgenii


пт, 3 апр. 2020 г. в 07:42, salmanbhatti81 <sa...@gmail.com>:

> I have been able to successfully run apache ignite with custom config using
> command
>
> docker run -it --net=host -v
> "pathToLocalDirectory"/config:/opt/ignite/apache-ignite/config -e
> "CONFIG_URI=file:///opt/ignite/apache-ignite/config/default-config.xml"
> apacheignite/ignite.
>
> But when i run my java project in intellij i get the message
>
> "IP finder returned empty addresses list. Please check IP finder
> configuration and make sure multicast works on your network...".
>
> Note: the java client project works if i run ignite server using windows
> batch file. Also i have published 47500 port as well . the result is the
> same.
>
>
>
> --
> Sent from: http://apache-ignite-users.70518.x6.nabble.com/
>