You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@ignite.apache.org by Anthony <ha...@gmail.com> on 2020/04/03 00:39:46 UTC

Error and Question about communication between java node and c++ node

Hello,

I am trying to make java node and c++ node communicate with each other. I
have successfully done it between two c++ node (which is straight forward).

However, when I tried to do a put in java and a get in c++, I got some
errors. Could anyone have a look? Thanks.

Also, examples of the communication would be helpful!

I first created a node and cache in Java:
Ignite ignite = Ignition.start();
IgniteCache<Integer, String> caches = ignite.getOrCreateCache("myCache");

And in C++:
  IgniteConfiguration cfg;
  Ignite grid = Ignition::Start(cfg);
   // Get cache instance.
   Cache<int, std::string> caches = grid.GetCache<int,
std::string>("myCache");

Then I got the following error messages on java side:

[2020-04-02 16:10:27,131][ERROR][main][IgniteKernal] Failed to start
manager: GridManagerAdapter [enabled=true,
name=o.a.i.i.managers.discovery.GridDiscoveryManager]
class org.apache.ignite.IgniteCheckedException: Failed to start SPI:
TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
marsh=JdkMarshaller
[clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@fd9ebde],
reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
skipAddrsRandomization=false]
at
org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
at
org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)

Re: Error and Question about communication between java node and c++ node

Posted by Anthony <ha...@gmail.com>.
It works, thank you so much for your help!

On Fri, Apr 3, 2020 at 8:42 AM Ilya Kasnacheev <il...@gmail.com>
wrote:

> Hello!
>
> Local node's binary configuration is not equal to remote node's binary
> configuration [locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
> rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> locBinaryCfg={globIdMapper=org.apache.ignite.binary.BinaryBasicIdMapper,
> compactFooter=false, globSerializer=null}, rmtBinaryCfg=null]
>
> As explained in the docs, C++ nodes require compactFooter to be false, so
> it is necessary to include  matching BinaryConfiguration in your Java
> node's IgniteConfiguration. Tune it until the error goes away.
> Please check
> https://apacheignite-cpp.readme.io/docs/cross-platform-interoperability
>
> Regards,
> --
> Ilya Kasnacheev
>
>
> пт, 3 апр. 2020 г. в 17:24, Anthony <ha...@gmail.com>:
>
>> Attached is the log file from C++Side:
>> [07:20:41,216][WARNING][main][G] Ignite work directory is not provided,
>> automatically resolved to:
>> C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work
>> [07:20:41,344][INFO][main][IgniteKernal%myGrid]
>>
>> >>>    __________  ________________
>> >>>   /  _/ ___/ |/ /  _/_  __/ __/
>> >>>  _/ // (7 7    // /  / / / _/
>> >>> /___/\___/_/|_/___/ /_/ /___/
>> >>>
>> >>> ver. 2.8.0#20200226-sha1:341b01df
>> >>> 2020 Copyright(C) Apache Software Foundation
>> >>>
>> >>> Ignite documentation: http://ignite.apache.org
>>
>> [07:20:41,353][INFO][main][IgniteKernal%myGrid] Config URL: n/a
>> [07:20:41,367][INFO][main][IgniteKernal%myGrid] IgniteConfiguration
>> [igniteInstanceName=myGrid, pubPoolSize=8, svcPoolSize=8,
>> callbackPoolSize=8, stripedPoolSize=8, sysPoolSize=8, mgmtPoolSize=4,
>> igfsPoolSize=8, dataStreamerPoolSize=8, utilityCachePoolSize=8,
>> utilityCacheKeepAliveTime=60000, p2pPoolSize=2, qryPoolSize=8,
>> sqlQryHistSize=1000, dfltQryTimeout=0,
>> igniteHome=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin,
>> igniteWorkDir=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work,
>> mbeanSrv=com.sun.jmx.mbeanserver.JmxMBeanServer@5f0fd5a0,
>> nodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af, marsh=BinaryMarshaller [],
>> marshLocJobs=false, daemon=false, p2pEnabled=true, netTimeout=5000,
>> netCompressionLevel=1, 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, soLinger=5, forceSrvMode=false,
>> clientReconnectDisabled=false, internalLsnr=null,
>> skipAddrsRandomization=false], segPlc=STOP, segResolveAttempts=2,
>> waitForSegOnStart=true, allResolversPassReq=true, segChkFreq=10000,
>> commSpi=TcpCommunicationSpi [connectGate=null,
>> connPlc=org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi$FirstConnectionPolicy@604f2bd2,
>> chConnPlc=null, 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@1d3ac898[Count = 1],
>> stopping=false, metricsLsnr=null],
>> evtSpi=org.apache.ignite.spi.eventstorage.NoopEventStorageSpi@1b73be9f,
>> colSpi=NoopCollisionSpi [], deploySpi=LocalDeploymentSpi [],
>> indexingSpi=org.apache.ignite.spi.indexing.noop.NoopIndexingSpi@366ac49b,
>> addrRslvr=null,
>> encryptionSpi=org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi@6ad59d92,
>> clientMode=false, rebalanceThreadPoolSize=4, rebalanceTimeout=10000,
>> rebalanceBatchesPrefetchCnt=3, rebalanceThrottle=0,
>> rebalanceBatchSize=524288, txCfg=TransactionConfiguration
>> [txSerEnabled=false, dfltIsolation=REPEATABLE_READ,
>> dfltConcurrency=PESSIMISTIC, dfltTxTimeout=0,
>> txTimeoutOnPartitionMapExchange=0, deadlockTimeout=10000,
>> 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=PlatformConfiguration [], binaryCfg=BinaryConfiguration
>> [idMapper=BinaryBaseIdMapper [isLowerCase=true],
>> nameMapper=BinaryBaseNameMapper [isSimpleName=true], serializer=null,
>> compactFooter=false], memCfg=null, pstCfg=null,
>> dsCfg=DataStorageConfiguration [sysRegionInitSize=41943040,
>> sysRegionMaxSize=104857600, pageSize=0, concLvl=0,
>> dfltDataRegConf=DataRegionConfiguration [name=default, maxSize=3390213324,
>> initSize=268435456, swapPath=null, pageEvictionMode=DISABLED,
>> evictionThreshold=0.9, emptyPagesPoolSize=100, metricsEnabled=false,
>> metricsSubIntervalCount=5, metricsRateTimeInterval=60000,
>> persistenceEnabled=false, checkpointPageBufSize=0,
>> lazyMemoryAllocation=true], dataRegions=null, storagePath=null,
>> checkpointFreq=180000, lockWaitTime=10000, checkpointThreads=4,
>> checkpointWriteOrder=SEQUENTIAL, walHistSize=20,
>> maxWalArchiveSize=1073741824, walSegments=10, walSegmentSize=67108864,
>> walPath=db/wal, walArchivePath=db/wal/archive, metricsEnabled=false,
>> walMode=LOG_ONLY, walTlbSize=131072, walBuffSize=0, walFlushFreq=2000,
>> walFsyncDelay=1000, walRecordIterBuffSize=67108864,
>> alwaysWriteFullPages=false,
>> fileIOFactory=org.apache.ignite.internal.processors.cache.persistence.file.AsyncFileIOFactory@6d23017e,
>> metricsSubIntervalCnt=5, metricsRateTimeInterval=60000,
>> walAutoArchiveAfterInactivity=-1, writeThrottlingEnabled=false,
>> walCompactionEnabled=false, walCompactionLevel=1,
>> checkpointReadLockTimeout=null, walPageCompression=DISABLED,
>> walPageCompressionLevel=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,
>> handshakeTimeout=10000, jdbcEnabled=true, odbcEnabled=true,
>> thinCliEnabled=true, sslEnabled=false, useIgniteSslCtxFactory=true,
>> sslClientAuth=false, sslCtxFactory=null, thinCliCfg=ThinClientConfiguration
>> [maxActiveTxPerConn=100]], mvccVacuumThreadCnt=2, mvccVacuumFreq=5000,
>> authEnabled=false, failureHnd=null, commFailureRslvr=null]
>> [07:20:41,367][INFO][main][IgniteKernal%myGrid] Daemon mode: off
>> [07:20:41,367][INFO][main][IgniteKernal%myGrid] OS: Windows 10 10.0 amd64
>> [07:20:41,368][INFO][main][IgniteKernal%myGrid] OS user: harte
>> [07:20:41,376][INFO][main][IgniteKernal%myGrid] PID: 37704
>> [07:20:41,378][INFO][main][IgniteKernal%myGrid] Language runtime: Java
>> Platform API Specification ver. 13
>> [07:20:41,378][INFO][main][IgniteKernal%myGrid] VM information: Java(TM)
>> SE Runtime Environment 13.0.2+8 Oracle Corporation Java HotSpot(TM) 64-Bit
>> Server VM 13.0.2+8
>> [07:20:41,378][INFO][main][IgniteKernal%myGrid] VM total memory: 1.0GB
>> [07:20:41,379][INFO][main][IgniteKernal%myGrid] Remote Management
>> [restart: off, REST: on, JMX (remote: off)]
>> [07:20:41,379][INFO][main][IgniteKernal%myGrid] Logger: JavaLogger
>> [quiet=true, config=null]
>> [07:20:41,379][INFO][main][IgniteKernal%myGrid]
>> IGNITE_HOME=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin
>> [07:20:41,379][INFO][main][IgniteKernal%myGrid] VM arguments:
>> [-DIGNITE_HOME=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin,
>> -Xms512m, -Xmx1024m, -Dfile.encoding=UTF-8,
>> --add-exports=java.base/jdk.internal.misc=ALL-UNNAMED,
>> --add-exports=java.base/sun.nio.ch=ALL-UNNAMED,
>> --add-exports=java.management/com.sun.jmx.mbeanserver=ALL-UNNAMED,
>> --add-exports=jdk.internal.jvmstat/sun.jvmstat.monitor=ALL-UNNAMED,
>> --add-exports=java.base/sun.reflect.generics.reflectiveObjects=ALL-UNNAMED,
>> --illegal-access=permit]
>> [07:20:41,379][INFO][main][IgniteKernal%myGrid] System cache's DataRegion
>> size is configured to 40 MB. Use
>> DataStorageConfiguration.systemRegionInitialSize property to change the
>> setting.
>> [07:20:41,379][INFO][main][IgniteKernal%myGrid] Configured caches [in
>> 'sysMemPlc' dataRegion: ['ignite-sys-cache']]
>> [07:20:41,379][WARNING][main][IgniteKernal%myGrid] Peer class loading is
>> enabled (disable it in production for performance and deployment
>> consistency reasons)
>> [07:20:41,379][WARNING][main][IgniteKernal%myGrid] Please set system
>> property '-Djava.net.preferIPv4Stack=true' to avoid possible problems in
>> mixed environments.
>> [07:20:41,381][WARNING][pub-#19%myGrid%][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.
>> [07:20:41,386][INFO][main][IgniteKernal%myGrid] 3-rd party licenses can
>> be found at:
>> C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\libs\licenses
>> [07:20:41,447][INFO][main][IgnitePluginProcessor] Configured plugins:
>> [07:20:41,449][INFO][main][IgnitePluginProcessor]   ^-- None
>> [07:20:41,449][INFO][main][IgnitePluginProcessor]
>> [07:20:41,452][INFO][main][FailureProcessor] Configured failure handler:
>> [hnd=StopNodeOrHaltFailureHandler [tryStop=false, timeout=0,
>> super=AbstractFailureHandler [ignoredFailureTypes=UnmodifiableSet
>> [SYSTEM_WORKER_BLOCKED, SYSTEM_CRITICAL_OPERATION_TIMEOUT]]]]
>> [07:20:41,641][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]
>> [07:20:41,737][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.
>> [07:20:41,749][WARNING][main][NoopCheckpointSpi] Checkpoints are disabled
>> (to enable configure any GridCheckpointSpi implementation)
>> [07:20:41,764][WARNING][main][GridCollisionManager] Collision resolution
>> is disabled (all jobs will be activated upon arrival).
>> [07:20:41,767][INFO][main][IgniteKernal%myGrid] Security status
>> [authentication=off, tls/ssl=off]
>> [07:20:41,959][INFO][main][TcpDiscoverySpi] Successfully bound to TCP
>> port [port=47501, localHost=0.0.0.0/0.0.0.0,
>> locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af]
>> [07:20:41,984][WARNING][main][IgniteCacheDatabaseSharedManager]
>> DataRegionConfiguration.maxWalArchiveSize instead
>> DataRegionConfiguration.walHistorySize would be used for removing old
>> archive wal files
>> [07:20:41,992][INFO][main][IgniteCacheDatabaseSharedManager] Configured
>> data regions initialized successfully [total=3]
>> [07:20:42,006][INFO][main][PartitionsEvictManager] Evict partition
>> permits=2
>> [07:20:42,054][WARNING][main][IgniteH2Indexing] Serialization of Java
>> objects in H2 was enabled.
>> [07:20:42,221][INFO][main][ClientListenerProcessor] Client connector
>> processor has started on TCP port 10801
>> [07:20:42,281][INFO][main][GridTcpRestProtocol] Command protocol
>> successfully started [name=TCP binary, host=0.0.0.0/0.0.0.0, port=11212]
>> [07:20:42,311][WARNING][main][PlatformProcessorImpl] Binary configuration
>> is automatically initiated, note that binary name mapper is set to
>> BinaryBaseNameMapper [isSimpleName=true] and binary ID mapper is set to
>> BinaryBaseIdMapper [isLowerCase=true] (other nodes must have the same
>> binary name and ID mapper types).
>> [07:20:42,713][INFO][main][IgniteKernal%myGrid] Non-loopback local IPs:
>> 192.168.0.2, 2600:8801:3600:3820:98c8:6653:241f:8982,
>> 2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0,
>> fe80:0:0:0:682b:8974:4c86:a81b%wlan0, fe80:0:0:0:75b1:a90f:8fd6:31f9%wlan1,
>> fe80:0:0:0:a0b7:294a:aa3a:41c1%eth3, fe80:0:0:0:e8d2:2fe9:d844:de7e%eth5,
>> fe80:0:0:0:ecb2:ebd5:7bfc:ecd0%wlan2
>> [07:20:42,713][INFO][main][IgniteKernal%myGrid] Enabled local MACs:
>> 287FCFBB82D0, 287FCFBB82D1, 287FCFBB82D4, 2A7FCFBB82D0, E8D8D1443071
>> [07:20:42,736][INFO][main][TcpDiscoverySpi] Connection check threshold is
>> calculated: 10000
>> [07:20:47,186][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
>> TCP discovery accepted incoming connection
>> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982, rmtPort=62659]
>> [07:20:47,192][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
>> TCP discovery spawning a new thread for connection
>> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982, rmtPort=62659]
>> [07:20:47,192][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
>> Started serving remote node connection
>> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659]
>> [07:20:47,194][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
>> Received ping request from the remote node
>> [rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659]
>> [07:20:47,195][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
>> Finished writing ping response
>> [rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659]
>> [07:20:47,195][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
>> Finished serving remote node connection
>> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659
>> [07:20:47,203][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
>> TCP discovery accepted incoming connection [rmtAddr=/0:0:0:0:0:0:0:1,
>> rmtPort=62660]
>> [07:20:47,203][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
>> TCP discovery spawning a new thread for connection
>> [rmtAddr=/0:0:0:0:0:0:0:1, rmtPort=62660]
>> [07:20:47,204][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
>> Started serving remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62660,
>> rmtPort=62660]
>> [07:20:47,205][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
>> Received ping request from the remote node
>> [rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> rmtAddr=/0:0:0:0:0:0:0:1:62660, rmtPort=62660]
>> [07:20:47,205][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
>> Finished writing ping response
>> [rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> rmtAddr=/0:0:0:0:0:0:0:1:62660, rmtPort=62660]
>> [07:20:47,205][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
>> Finished serving remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62660,
>> rmtPort=62660
>> [07:20:47,207][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
>> TCP discovery accepted incoming connection [rmtAddr=/0:0:0:0:0:0:0:1,
>> rmtPort=62661]
>> [07:20:47,208][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
>> TCP discovery spawning a new thread for connection
>> [rmtAddr=/0:0:0:0:0:0:0:1, rmtPort=62661]
>> [07:20:47,208][INFO][tcp-disco-sock-reader-[]-#12%myGrid%][TcpDiscoverySpi]
>> Started serving remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62661,
>> rmtPort=62661]
>> [07:20:47,210][INFO][tcp-disco-sock-reader-[db4efc6e
>> 0:0:0:0:0:0:0:1:62661]-#12%myGrid%][TcpDiscoverySpi] Initialized connection
>> with remote server node [nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> rmtAddr=/0:0:0:0:0:0:0:1:62661]
>> [07:20:47,213][SEVERE][main][IgniteKernal%myGrid] Failed to start
>> manager: GridManagerAdapter [enabled=true,
>> name=o.a.i.i.managers.discovery.GridDiscoveryManager]
>> class org.apache.ignite.IgniteCheckedException: Failed to start SPI:
>> TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
>> marsh=JdkMarshaller
>> [clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@72825400],
>> reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
>> forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
>> skipAddrsRandomization=false]
>> at
>> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
>> at
>> org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
>> at
>> org.apache.ignite.internal.IgniteKernal.startManager(IgniteKernal.java:1960)
>> at org.apache.ignite.internal.IgniteKernal.start(IgniteKernal.java:1276)
>> at
>> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start0(IgnitionEx.java:2038)
>> at
>> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start(IgnitionEx.java:1703)
>> at org.apache.ignite.internal.IgnitionEx.start0(IgnitionEx.java:1117)
>> at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:615)
>> at
>> org.apache.ignite.internal.processors.platform.PlatformAbstractBootstrap.start(PlatformAbstractBootstrap.java:43)
>> at
>> org.apache.ignite.internal.processors.platform.PlatformIgnition.start(PlatformIgnition.java:74)
>> Caused by: class org.apache.ignite.spi.IgniteSpiException: Local node's
>> binary configuration is not equal to remote node's binary configuration
>> [locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
>> rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> locBinaryCfg={globIdMapper=org.apache.ignite.binary.BinaryBasicIdMapper,
>> compactFooter=false, globSerializer=null}, rmtBinaryCfg=null]
>> at
>> org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.checkFailedError(TcpDiscoverySpi.java:1997)
>> at
>> org.apache.ignite.spi.discovery.tcp.ServerImpl.joinTopology(ServerImpl.java:1116)
>> at
>> org.apache.ignite.spi.discovery.tcp.ServerImpl.spiStart(ServerImpl.java:427)
>> at
>> org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.spiStart(TcpDiscoverySpi.java:2099)
>> at
>> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:297)
>> ... 9 more
>> [07:20:47,214][INFO][tcp-disco-sock-reader-[db4efc6e
>> 0:0:0:0:0:0:0:1:62661]-#12%myGrid%][TcpDiscoverySpi] Finished serving
>> remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62661, rmtPort=62661
>> [07:20:47,214][SEVERE][main][IgniteKernal%myGrid] Got exception while
>> starting (will rollback startup routine).
>> class org.apache.ignite.IgniteCheckedException: Failed to start manager:
>> GridManagerAdapter [enabled=true,
>> name=org.apache.ignite.internal.managers.discovery.GridDiscoveryManager]
>> at
>> org.apache.ignite.internal.IgniteKernal.startManager(IgniteKernal.java:1965)
>> at org.apache.ignite.internal.IgniteKernal.start(IgniteKernal.java:1276)
>> at
>> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start0(IgnitionEx.java:2038)
>> at
>> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start(IgnitionEx.java:1703)
>> at org.apache.ignite.internal.IgnitionEx.start0(IgnitionEx.java:1117)
>> at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:615)
>> at
>> org.apache.ignite.internal.processors.platform.PlatformAbstractBootstrap.start(PlatformAbstractBootstrap.java:43)
>> at
>> org.apache.ignite.internal.processors.platform.PlatformIgnition.start(PlatformIgnition.java:74)
>> Caused by: class org.apache.ignite.IgniteCheckedException: Failed to
>> start SPI: TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000,
>> ackTimeout=5000, marsh=JdkMarshaller
>> [clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@72825400],
>> reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
>> forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
>> skipAddrsRandomization=false]
>> at
>> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
>> at
>> org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
>> at
>> org.apache.ignite.internal.IgniteKernal.startManager(IgniteKernal.java:1960)
>> ... 7 more
>> Caused by: class org.apache.ignite.spi.IgniteSpiException: Local node's
>> binary configuration is not equal to remote node's binary configuration
>> [locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
>> rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> locBinaryCfg={globIdMapper=org.apache.ignite.binary.BinaryBasicIdMapper,
>> compactFooter=false, globSerializer=null}, rmtBinaryCfg=null]
>> at
>> org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.checkFailedError(TcpDiscoverySpi.java:1997)
>> at
>> org.apache.ignite.spi.discovery.tcp.ServerImpl.joinTopology(ServerImpl.java:1116)
>> at
>> org.apache.ignite.spi.discovery.tcp.ServerImpl.spiStart(ServerImpl.java:427)
>> at
>> org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.spiStart(TcpDiscoverySpi.java:2099)
>> at
>> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:297)
>> ... 9 more
>> [07:20:47,228][INFO][main][GridTcpRestProtocol] Command protocol
>> successfully stopped: TCP binary
>> [07:20:52,235][INFO][main][TcpDiscoverySpi] No verification for local
>> node leave has been received from coordinator (will stop node anyway).
>> [07:20:52,245][INFO][main][IgniteKernal%myGrid]
>>
>> >>>
>> +---------------------------------------------------------------------------------+
>> >>> Ignite ver.
>> 2.8.0#20200226-sha1:341b01dfd8abf2d9b01d468ad1bb26dfe84ac4f6 stopped OK
>> >>>
>> +---------------------------------------------------------------------------------+
>> >>> Ignite instance name: myGrid
>> >>> Grid uptime: 00:00:11.528
>>
>>
>>
>> And Java Side:
>> [2020-04-03 07:20:16,818][WARN ][main][G] Ignite work directory is not
>> provided, automatically resolved to:
>> C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work
>> [2020-04-03 07:20:16,993][INFO ][main][IgniteKernal]
>>
>> >>>    __________  ________________
>> >>>   /  _/ ___/ |/ /  _/_  __/ __/
>> >>>  _/ // (7 7    // /  / / / _/
>> >>> /___/\___/_/|_/___/ /_/ /___/
>> >>>
>> >>> ver. 2.8.0#20200226-sha1:341b01df
>> >>> 2020 Copyright(C) Apache Software Foundation
>> >>>
>> >>> Ignite documentation: http://ignite.apache.org
>>
>> [2020-04-03 07:20:17,002][INFO ][main][IgniteKernal] Config URL:
>> file:/C:/Users/harte/Desktop/work/apache-ignite-2.8.0-bin-try/apache-ignite-2.8.0-bin/examples/config/example-ignite.xml
>> [2020-04-03 07:20:17,021][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,
>> sqlQryHistSize=1000, dfltQryTimeout=0,
>> igniteHome=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin,
>> igniteWorkDir=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work,
>> mbeanSrv=com.sun.jmx.mbeanserver.JmxMBeanServer@7d9e8ef7,
>> nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448, marsh=BinaryMarshaller [],
>> marshLocJobs=false, daemon=false, p2pEnabled=true, netTimeout=5000,
>> netCompressionLevel=1, 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, soLinger=5, forceSrvMode=false,
>> clientReconnectDisabled=false, internalLsnr=null,
>> skipAddrsRandomization=false], segPlc=STOP, segResolveAttempts=2,
>> waitForSegOnStart=true, allResolversPassReq=true, segChkFreq=10000,
>> commSpi=TcpCommunicationSpi [connectGate=null,
>> connPlc=org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi$FirstConnectionPolicy@4b7e96a,
>> chConnPlc=null, 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@6475472c[Count = 1],
>> stopping=false, metricsLsnr=null],
>> evtSpi=org.apache.ignite.spi.eventstorage.NoopEventStorageSpi@3f07b12c,
>> colSpi=NoopCollisionSpi [], deploySpi=LocalDeploymentSpi [],
>> indexingSpi=org.apache.ignite.spi.indexing.noop.NoopIndexingSpi@784b990c,
>> addrRslvr=null,
>> encryptionSpi=org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi@3d3ba765,
>> clientMode=false, rebalanceThreadPoolSize=4, rebalanceTimeout=10000,
>> rebalanceBatchesPrefetchCnt=3, rebalanceThrottle=0,
>> rebalanceBatchSize=524288, txCfg=TransactionConfiguration
>> [txSerEnabled=false, dfltIsolation=REPEATABLE_READ,
>> dfltConcurrency=PESSIMISTIC, dfltTxTimeout=0,
>> txTimeoutOnPartitionMapExchange=0, deadlockTimeout=10000,
>> 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=DataStorageConfiguration [sysRegionInitSize=41943040,
>> sysRegionMaxSize=104857600, pageSize=0, concLvl=0,
>> dfltDataRegConf=DataRegionConfiguration [name=default, maxSize=3390213324,
>> initSize=268435456, swapPath=null, pageEvictionMode=DISABLED,
>> evictionThreshold=0.9, emptyPagesPoolSize=100, metricsEnabled=false,
>> metricsSubIntervalCount=5, metricsRateTimeInterval=60000,
>> persistenceEnabled=false, checkpointPageBufSize=0,
>> lazyMemoryAllocation=true], dataRegions=null, storagePath=null,
>> checkpointFreq=180000, lockWaitTime=10000, checkpointThreads=4,
>> checkpointWriteOrder=SEQUENTIAL, walHistSize=20,
>> maxWalArchiveSize=1073741824, walSegments=10, walSegmentSize=67108864,
>> walPath=db/wal, walArchivePath=db/wal/archive, metricsEnabled=false,
>> walMode=LOG_ONLY, walTlbSize=131072, walBuffSize=0, walFlushFreq=2000,
>> walFsyncDelay=1000, walRecordIterBuffSize=67108864,
>> alwaysWriteFullPages=false,
>> fileIOFactory=org.apache.ignite.internal.processors.cache.persistence.file.AsyncFileIOFactory@758a34ce,
>> metricsSubIntervalCnt=5, metricsRateTimeInterval=60000,
>> walAutoArchiveAfterInactivity=-1, writeThrottlingEnabled=false,
>> walCompactionEnabled=false, walCompactionLevel=1,
>> checkpointReadLockTimeout=null, walPageCompression=DISABLED,
>> walPageCompressionLevel=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,
>> handshakeTimeout=10000, jdbcEnabled=true, odbcEnabled=true,
>> thinCliEnabled=true, sslEnabled=false, useIgniteSslCtxFactory=true,
>> sslClientAuth=false, sslCtxFactory=null, thinCliCfg=ThinClientConfiguration
>> [maxActiveTxPerConn=100]], mvccVacuumThreadCnt=2, mvccVacuumFreq=5000,
>> authEnabled=false, failureHnd=null, commFailureRslvr=null]
>> [2020-04-03 07:20:17,021][INFO ][main][IgniteKernal] Daemon mode: off
>> [2020-04-03 07:20:17,021][INFO ][main][IgniteKernal] OS: Windows 10 10.0
>> amd64
>> [2020-04-03 07:20:17,021][INFO ][main][IgniteKernal] OS user: harte
>> [2020-04-03 07:20:17,032][INFO ][main][IgniteKernal] PID: 38064
>> [2020-04-03 07:20:17,033][INFO ][main][IgniteKernal] Language runtime:
>> Java Platform API Specification ver. 13
>> [2020-04-03 07:20:17,033][INFO ][main][IgniteKernal] VM information:
>> Java(TM) SE Runtime Environment 13.0.2+8 Oracle Corporation Java
>> HotSpot(TM) 64-Bit Server VM 13.0.2+8
>> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] VM total memory:
>> 3.9GB
>> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] Remote Management
>> [restart: off, REST: on, JMX (remote: off)]
>> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] Logger: Log4JLogger
>> [quiet=true,
>> config=/C:/Users/harte/Desktop/work/apache-ignite-2.8.0-bin-try/apache-ignite-2.8.0-bin/config/ignite-log4j.xml]
>> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal]
>> IGNITE_HOME=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin
>> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] VM arguments:
>> [--add-exports=java.base/jdk.internal.misc=ALL-UNNAMED,
>> --add-exports=java.base/sun.nio.ch=ALL-UNNAMED,
>> --add-exports=java.management/com.sun.jmx.mbeanserver=ALL-UNNAMED,
>> --add-exports=jdk.internal.jvmstat/sun.jvmstat.monitor=ALL-UNNAMED,
>> --add-exports=java.base/sun.reflect.generics.reflectiveObjects=ALL-UNNAMED,
>> --illegal-access=permit,
>> -Djava.library.path=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\examples\src\main\java\org\apache\ignite\examples\datagrid,
>> -javaagent:C:\Program Files\JetBrains\IntelliJ IDEA Community Edition
>> 2019.3.2\lib\idea_rt.jar=62570:C:\Program Files\JetBrains\IntelliJ IDEA
>> Community Edition 2019.3.2\bin, -Dfile.encoding=UTF-8]
>> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] System cache's
>> DataRegion size is configured to 40 MB. Use
>> DataStorageConfiguration.systemRegionInitialSize property to change the
>> setting.
>> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] Configured caches
>> [in 'sysMemPlc' dataRegion: ['ignite-sys-cache']]
>> [2020-04-03 07:20:17,034][WARN ][main][IgniteKernal] Peer class loading
>> is enabled (disable it in production for performance and deployment
>> consistency reasons)
>> [2020-04-03 07:20:17,035][WARN ][main][IgniteKernal] Please set system
>> property '-Djava.net.preferIPv4Stack=true' to avoid possible problems in
>> mixed environments.
>> [2020-04-03 07:20:17,038][INFO ][main][IgniteKernal] 3-rd party licenses
>> can be found at:
>> C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\libs\licenses
>> [2020-04-03 07:20:17,038][WARN ][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.
>> [2020-04-03 07:20:17,044][WARN ][pub-#22][GridDiagnostic] Initial heap
>> size is 254MB (should be no less than 512MB, use -Xms512m -Xmx512m).
>> [2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor] Configured
>> plugins:
>> [2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor]   ^--
>> ml-inference-plugin 1.0.0
>> [2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor]   ^-- null
>> [2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor]
>> [2020-04-03 07:20:17,135][INFO ][main][FailureProcessor] Configured
>> failure handler: [hnd=StopNodeOrHaltFailureHandler [tryStop=false,
>> timeout=0, super=AbstractFailureHandler
>> [ignoredFailureTypes=UnmodifiableSet [SYSTEM_WORKER_BLOCKED,
>> SYSTEM_CRITICAL_OPERATION_TIMEOUT]]]]
>> [2020-04-03 07:20:17,350][INFO ][main][TcpCommunicationSpi] Successfully
>> bound communication NIO server to TCP port [port=47100, locHost=
>> 0.0.0.0/0.0.0.0, selectorsCnt=4, selectorSpins=0, pairedConn=false]
>> [2020-04-03 07:20:17,441][WARN ][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.
>> [2020-04-03 07:20:17,452][WARN ][main][NoopCheckpointSpi] Checkpoints are
>> disabled (to enable configure any GridCheckpointSpi implementation)
>> [2020-04-03 07:20:17,467][WARN ][main][GridCollisionManager] Collision
>> resolution is disabled (all jobs will be activated upon arrival).
>> [2020-04-03 07:20:17,469][INFO ][main][IgniteKernal] Security status
>> [authentication=off, tls/ssl=off]
>> [2020-04-03 07:20:17,637][INFO ][main][TcpDiscoverySpi] Successfully
>> bound to TCP port [port=47500, localHost=0.0.0.0/0.0.0.0,
>> locNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448]
>> [2020-04-03 07:20:17,662][WARN ][main][IgniteCacheDatabaseSharedManager]
>> DataRegionConfiguration.maxWalArchiveSize instead
>> DataRegionConfiguration.walHistorySize would be used for removing old
>> archive wal files
>> [2020-04-03 07:20:17,672][INFO ][main][IgniteCacheDatabaseSharedManager]
>> Configured data regions initialized successfully [total=3]
>> [2020-04-03 07:20:17,686][INFO ][main][PartitionsEvictManager] Evict
>> partition permits=2
>> [2020-04-03 07:20:17,731][WARN ][main][IgniteH2Indexing] Serialization of
>> Java objects in H2 was enabled.
>> [2020-04-03 07:20:17,877][INFO ][main][ClientListenerProcessor] Client
>> connector processor has started on TCP port 10800
>> [2020-04-03 07:20:17,917][INFO ][main][GridTcpRestProtocol] Command
>> protocol successfully started [name=TCP binary, host=0.0.0.0/0.0.0.0,
>> port=11211]
>> [2020-04-03 07:20:18,207][INFO ][main][IgniteKernal] Non-loopback local
>> IPs: 192.168.0.2, 2600:8801:3600:3820:98c8:6653:241f:8982,
>> 2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0,
>> fe80:0:0:0:682b:8974:4c86:a81b%wlan0, fe80:0:0:0:75b1:a90f:8fd6:31f9%wlan1,
>> fe80:0:0:0:a0b7:294a:aa3a:41c1%eth3, fe80:0:0:0:e8d2:2fe9:d844:de7e%eth5,
>> fe80:0:0:0:ecb2:ebd5:7bfc:ecd0%wlan2
>> [2020-04-03 07:20:18,207][INFO ][main][IgniteKernal] Enabled local MACs:
>> 287FCFBB82D0, 287FCFBB82D1, 287FCFBB82D4, 2A7FCFBB82D0, E8D8D1443071
>> [2020-04-03 07:20:18,223][INFO ][main][TcpDiscoverySpi] Connection check
>> threshold is calculated: 10000
>> [2020-04-03 07:20:38,531][INFO
>> ][disco-notifier-worker-#41][GridClusterStateProcessor] Received activate
>> request with BaselineTopology[id=0]
>> [2020-04-03 07:20:38,531][INFO
>> ][disco-notifier-worker-#41][GridClusterStateProcessor] Started state
>> transition: true
>> [2020-04-03 07:20:38,532][INFO
>> ][disco-notifier-worker-#41][GridClusterStateProcessor] Received state
>> change finish message: true
>> [2020-04-03 07:20:38,533][INFO
>> ][disco-notifier-worker-#41][MvccProcessorImpl] Assigned mvcc coordinator
>> [crd=MvccCoordinator [topVer=AffinityTopologyVersion [topVer=1,
>> minorTopVer=0], nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> ver=1585923638519, local=true, initialized=false]]
>> [2020-04-03 07:20:38,563][INFO
>> ][disco-notifier-worker-#41][DistributedBaselineConfiguration] Baseline
>> parameter 'baselineAutoAdjustEnabled' was changed from 'null' to 'true'
>> [2020-04-03 07:20:38,566][INFO
>> ][disco-notifier-worker-#41][DistributedBaselineConfiguration] Baseline
>> parameter 'baselineAutoAdjustTimeout' was changed from 'null' to '0'
>> [2020-04-03 07:20:38,587][INFO ][exchange-worker-#43][time] Started
>> exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
>> crd=true, evt=NODE_JOINED, evtNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> customEvt=null, allowMerge=false, exchangeFreeSwitch=false]
>> [2020-04-03 07:20:38,603][INFO
>> ][exchange-worker-#43][IgniteCacheDatabaseSharedManager] Configured data
>> regions started successfully [total=3]
>> [2020-04-03 07:20:38,604][INFO ][exchange-worker-#43][msg] Components
>> activation performed in 17 ms.
>> [2020-04-03 07:20:38,729][INFO ][exchange-worker-#43][GridCacheProcessor]
>> Started cache [name=ignite-sys-cache, id=-2100569601,
>> dataRegionName=sysMemPlc, mode=REPLICATED, atomicity=TRANSACTIONAL,
>> backups=2147483647, mvcc=false]
>> [2020-04-03 07:20:38,730][INFO ][exchange-worker-#43][GridCacheProcessor]
>> Starting caches on local join performed in 127 ms.
>> [2020-04-03 07:20:38,740][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Skipped waiting for
>> partitions release future (local node is joining)
>> [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0]]
>> [2020-04-03 07:20:38,790][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture]
>> finishExchangeOnCoordinator [topVer=AffinityTopologyVersion [topVer=1,
>> minorTopVer=0], resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0]]
>> [2020-04-03 07:20:38,803][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finish exchange
>> future [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
>> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], err=null,
>> rebalanced=true, wasRebalanced=false]
>> [2020-04-03 07:20:38,815][INFO ][exchange-worker-#43][GridCacheProcessor]
>> Finish proxy initialization, cacheName=ignite-sys-cache,
>> localNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448
>> [2020-04-03 07:20:38,816][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Completed partition
>> exchange [localNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> exchange=GridDhtPartitionsExchangeFuture [topVer=AffinityTopologyVersion
>> [topVer=1, minorTopVer=0], evt=NODE_JOINED, evtNode=TcpDiscoveryNode
>> [id=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> consistentId=0:0:0:0:0:0:0:1,127.0.0.1,192.168.0.2,2600:8801:3600:3820:98c8:6653:241f:8982,2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500,
>> addrs=ArrayList [0:0:0:0:0:0:0:1, 127.0.0.1, 192.168.0.2,
>> 2600:8801:3600:3820:98c8:6653:241f:8982,
>> 2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0], sockAddrs=HashSet
>> [/2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500, /0:0:0:0:0:0:0:1:47500, /
>> 127.0.0.1:47500, /2600:8801:3600:3820:98c8:6653:241f:8982:47500,
>> LAPTOP-MUM8SQ8C/192.168.0.2:47500], discPort=47500, order=1, intOrder=1,
>> lastExchangeTime=1585923618219, loc=true, ver=2.8.0#20200226-sha1:341b01df,
>> isClient=false], done=true, newCrdFut=null], topVer=AffinityTopologyVersion
>> [topVer=1, minorTopVer=0]]
>> [2020-04-03 07:20:38,816][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange timings
>> [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
>> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], stage="Waiting in
>> exchange queue" (42 ms), stage="Exchange parameters initialization" (1 ms),
>> stage="Components activation" (16 ms), stage="Determine exchange type" (135
>> ms), stage="Preloading notification" (0 ms), stage="WAL history
>> reservation" (0 ms), stage="After states restored callback" (49 ms),
>> stage="Waiting for all single messages" (0 ms), stage="Affinity
>> recalculation (crd)" (0 ms), stage="Collect update counters and create
>> affinity messages" (0 ms), stage="Validate partitions states" (2 ms),
>> stage="Assign partitions states" (0 ms), stage="Apply update counters" (0
>> ms), stage="Full message preparing" (8 ms), stage="Full message sending" (0
>> ms), stage="State finish message sending" (0 ms), stage="Exchange done" (12
>> ms), stage="Total time" (265 ms)]
>> [2020-04-03 07:20:38,816][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange longest
>> local stages [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
>> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
>> stage="Coordinator affinity cache init [grp=ignite-sys-cache]" (129 ms)
>> (parent=Determine exchange type), stage="First node affinity initialization
>> (node join) [grp=ignite-sys-cache]" (4 ms) (parent=Determine exchange type)]
>> [2020-04-03 07:20:38,817][INFO ][exchange-worker-#43][time] Finished
>> exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
>> crd=true]
>> [2020-04-03 07:20:38,819][INFO
>> ][exchange-worker-#43][GridCachePartitionExchangeManager] Skipping
>> rebalancing (nothing scheduled) [top=AffinityTopologyVersion [topVer=1,
>> minorTopVer=0], force=false, evt=NODE_JOINED,
>> node=db4efc6e-44c7-46ce-b7c0-154e387c0448]
>> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal] Performance
>> suggestions for grid  (fix if possible)
>> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal] To disable, set
>> -DIGNITE_PERFORMANCE_SUGGESTIONS_DISABLED=true
>> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Disable grid
>> events (remove 'includeEventTypes' from configuration)
>> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Switch to the
>> most recent 1.8 JVM version
>> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Specify JVM
>> heap max size (add '-Xmx<size>[g|G|m|M|k|K]' to JVM options)
>> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Set max direct
>> memory size if getting 'OOME: Direct buffer memory' (add
>> '-XX:MaxDirectMemorySize=<size>[g|G|m|M|k|K]' to JVM options)
>> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Disable
>> processing of calls to System.gc() (add '-XX:+DisableExplicitGC' to JVM
>> options)
>> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal] Refer to this page
>> for more performance suggestions:
>> https://apacheignite.readme.io/docs/jvm-and-system-tuning
>> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]
>> [2020-04-03 07:20:38,868][INFO ][main][IgniteKernal] To start Console
>> Management & Monitoring run ignitevisorcmd.{sh|bat}
>> [2020-04-03 07:20:38,870][INFO ][main][IgniteKernal] Data Regions
>> Configured:
>> [2020-04-03 07:20:38,870][INFO ][main][IgniteKernal]   ^-- default
>> [initSize=256.0 MiB, maxSize=3.2 GiB, persistence=false,
>> lazyMemoryAllocation=true]
>> [2020-04-03 07:20:38,871][INFO ][main][IgniteKernal]
>>
>> >>>
>> +----------------------------------------------------------------------+
>> >>> Ignite ver.
>> 2.8.0#20200226-sha1:341b01dfd8abf2d9b01d468ad1bb26dfe84ac4f6
>> >>>
>> +----------------------------------------------------------------------+
>> >>> OS name: Windows 10 10.0 amd64
>> >>> CPU(s): 8
>> >>> Heap: 3.9GB
>> >>> VM name: 38064@LAPTOP-MUM8SQ8C
>> >>> Local node [ID=DB4EFC6E-44C7-46CE-B7C0-154E387C0448, order=1,
>> clientMode=false]
>> >>> Local node addresses: [LAPTOP-MUM8SQ8C/0:0:0:0:0:0:0:1,
>> LAPTOP-MUM8SQ8C/127.0.0.1, LAPTOP-MUM8SQ8C/192.168.0.2,
>> /2600:8801:3600:3820:98c8:6653:241f:8982,
>> /2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0]
>> >>> Local ports: TCP:10800 TCP:11211 TCP:47100 UDP:47400 TCP:47500
>>
>> [2020-04-03 07:20:38,874][INFO ][main][GridDiscoveryManager] Topology
>> snapshot [ver=1, locNode=db4efc6e, servers=1, clients=0, state=ACTIVE,
>> CPUs=8, offheap=3.2GB, heap=3.9GB]
>> [2020-04-03 07:20:38,874][INFO ][main][GridDiscoveryManager]   ^--
>> Baseline [id=0, size=1, online=1, offline=0]
>> [2020-04-03 07:20:38,874][INFO ][main][G] Node started :
>> [stage="Configure system pool" (66 ms),stage="Start managers" (502
>> ms),stage="Configure binary metadata" (40 ms),stage="Start processors" (416
>> ms),stage="Start 'ml-inference-plugin' plugin" (0 ms),stage="Init
>> metastore" (271 ms),stage="Finish recovery" (0 ms),stage="Join topology"
>> (20318 ms),stage="Await transition" (17 ms),stage="Await exchange" (323
>> ms),stage="Total time" (21953 ms)]
>> [2020-04-03 07:20:38,889][INFO ][exchange-worker-#43][time] Started
>> exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
>> crd=true, evt=DISCOVERY_CUSTOM_EVT,
>> evtNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> customEvt=DynamicCacheChangeBatch
>> [id=e9de9604171-03f8bb55-f219-4232-903a-6af839413db6, reqs=ArrayList
>> [DynamicCacheChangeRequest [cacheName=myCache, hasCfg=true,
>> nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448, clientStartOnly=false,
>> stop=false, destroy=false, disabledAfterStartfalse]],
>> exchangeActions=ExchangeActions [startCaches=[myCache], stopCaches=null,
>> startGrps=[myCache], stopGrps=[], resetParts=null,
>> stateChangeRequest=null], startCaches=false], allowMerge=false,
>> exchangeFreeSwitch=false]
>> [2020-04-03 07:20:38,915][INFO ][exchange-worker-#43][GridCacheProcessor]
>> Started cache [name=myCache, id=1482644790, dataRegionName=default,
>> mode=PARTITIONED, atomicity=ATOMIC, backups=0, mvcc=false]
>> [2020-04-03 07:20:38,928][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finished waiting
>> for partition release future [topVer=AffinityTopologyVersion [topVer=1,
>> minorTopVer=1], waitTime=0ms, futInfo=NA, mode=DISTRIBUTED]
>> [2020-04-03 07:20:38,930][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finished waiting
>> for partitions release latch: ServerLatch [permits=0, pendingAcks=HashSet
>> [], super=CompletableLatch [id=CompletableLatchUid [id=exchange,
>> topVer=AffinityTopologyVersion [topVer=1, minorTopVer=1]]]]
>> [2020-04-03 07:20:38,930][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finished waiting
>> for partition release future [topVer=AffinityTopologyVersion [topVer=1,
>> minorTopVer=1], waitTime=0ms, futInfo=NA, mode=LOCAL]
>> [2020-04-03 07:20:38,987][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture]
>> finishExchangeOnCoordinator [topVer=AffinityTopologyVersion [topVer=1,
>> minorTopVer=1], resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1]]
>> [2020-04-03 07:20:39,004][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finish exchange
>> future [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
>> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1], err=null,
>> rebalanced=true, wasRebalanced=true]
>> [2020-04-03 07:20:39,008][INFO ][exchange-worker-#43][GridCacheProcessor]
>> Finish proxy initialization, cacheName=myCache,
>> localNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448
>> [2020-04-03 07:20:39,009][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Completed partition
>> exchange [localNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> exchange=GridDhtPartitionsExchangeFuture [topVer=AffinityTopologyVersion
>> [topVer=1, minorTopVer=1], evt=DISCOVERY_CUSTOM_EVT,
>> evtNode=TcpDiscoveryNode [id=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> consistentId=0:0:0:0:0:0:0:1,127.0.0.1,192.168.0.2,2600:8801:3600:3820:98c8:6653:241f:8982,2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500,
>> addrs=ArrayList [0:0:0:0:0:0:0:1, 127.0.0.1, 192.168.0.2,
>> 2600:8801:3600:3820:98c8:6653:241f:8982,
>> 2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0], sockAddrs=HashSet
>> [/2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500, /0:0:0:0:0:0:0:1:47500, /
>> 127.0.0.1:47500, /2600:8801:3600:3820:98c8:6653:241f:8982:47500,
>> LAPTOP-MUM8SQ8C/192.168.0.2:47500], discPort=47500, order=1, intOrder=1,
>> lastExchangeTime=1585923618219, loc=true, ver=2.8.0#20200226-sha1:341b01df,
>> isClient=false], done=true, newCrdFut=null], topVer=AffinityTopologyVersion
>> [topVer=1, minorTopVer=1]]
>> [2020-04-03 07:20:39,009][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange timings
>> [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
>> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1], stage="Waiting in
>> exchange queue" (0 ms), stage="Exchange parameters initialization" (1 ms),
>> stage="Update caches registry" (1 ms), stage="Start caches" (25 ms),
>> stage="Affinity initialization on cache group start" (6 ms),
>> stage="Determine exchange type" (0 ms), stage="Preloading notification" (0
>> ms), stage="WAL history reservation" (0 ms), stage="Wait partitions
>> release" (4 ms), stage="Wait partitions release latch" (1 ms), stage="Wait
>> partitions release" (0 ms), stage="After states restored callback" (50 ms),
>> stage="Waiting for all single messages" (6 ms), stage="Affinity
>> recalculation (crd)" (0 ms), stage="Collect update counters and create
>> affinity messages" (0 ms), stage="Validate partitions states" (1 ms),
>> stage="Assign partitions states" (0 ms), stage="Apply update counters" (2
>> ms), stage="Full message preparing" (10 ms), stage="Full message sending"
>> (0 ms), stage="Exchange done" (5 ms), stage="Total time" (112 ms)]
>> [2020-04-03 07:20:39,009][INFO
>> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange longest
>> local stages [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
>> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1], stage="Affinity
>> initialization on cache group start [grp=myCache]" (6 ms) (parent=Affinity
>> initialization on cache group start)]
>> [2020-04-03 07:20:39,010][INFO ][exchange-worker-#43][time] Finished
>> exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
>> crd=true]
>> [2020-04-03 07:20:39,014][INFO
>> ][exchange-worker-#43][GridCachePartitionExchangeManager] Skipping
>> rebalancing (nothing scheduled) [top=AffinityTopologyVersion [topVer=1,
>> minorTopVer=1], force=false, evt=DISCOVERY_CUSTOM_EVT,
>> node=db4efc6e-44c7-46ce-b7c0-154e387c0448]
>> [2020-04-03 07:20:47,163][INFO
>> ][tcp-disco-srvr-[:47500]-#3][TcpDiscoverySpi] TCP discovery accepted
>> incoming connection [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982,
>> rmtPort=62658]
>> [2020-04-03 07:20:47,167][INFO
>> ][tcp-disco-srvr-[:47500]-#3][TcpDiscoverySpi] TCP discovery spawning a new
>> thread for connection [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982,
>> rmtPort=62658]
>> [2020-04-03 07:20:47,168][INFO
>> ][tcp-disco-sock-reader-[]-#11][TcpDiscoverySpi] Started serving remote
>> node connection [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62658,
>> rmtPort=62658]
>> [2020-04-03 07:20:47,172][INFO ][tcp-disco-sock-reader-[155424bd
>> 2600:8801:3600:3820:98c8:6653:241f:8982:62658]-#11][TcpDiscoverySpi]
>> Initialized connection with remote server node
>> [nodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
>> rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62658]
>> [2020-04-03 07:20:47,196][INFO ][tcp-disco-sock-reader-[155424bd
>> 2600:8801:3600:3820:98c8:6653:241f:8982:62658]-#11][TcpDiscoverySpi]
>> Finished serving remote node connection
>> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62658, rmtPort=62658
>> [2020-04-03 07:20:47,201][INFO
>> ][tcp-disco-msg-worker-[crd]-#2][GridEncryptionManager] Joining node
>> doesn't have encryption data [node=155424bd-1c8e-48a2-83ff-26aa6cf9e7af]
>> [2020-04-03 07:20:47,206][WARN ][disco-pool-#55][TcpDiscoverySpi] Local
>> node's binary configuration is not equal to remote node's binary
>> configuration [locNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
>> rmtNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af, locBinaryCfg=null,
>> rmtBinaryCfg={globIdMapper=o.a.i.binary.BinaryBasicIdMapper,
>> compactFooter=false, globSerializer=null}]
>> [2020-04-03 07:20:48,554][INFO
>> ][ignite-update-notifier-timer][GridUpdateNotifier] Your version is up to
>> date.
>> [2020-04-03 07:21:38,869][INFO ][grid-timeout-worker-#23][IgniteKernal]
>> Metrics for local node (to disable set 'metricsLogFrequency' to 0)
>>     ^-- Node [id=db4efc6e, uptime=00:01:00.003]
>>     ^-- H/N/C [hosts=1, nodes=1, CPUs=8]
>>     ^-- CPU [cur=-100%, avg=-95.83%, GC=0%]
>>     ^-- PageMemory [pages=2252]
>>     ^-- Heap [used=43MB, free=98.92%, comm=87MB]
>>     ^-- Off-heap [used=8MB, free=99.74%, comm=336MB]
>>     ^--   sysMemPlc region [used=0MB, free=99.21%, comm=40MB]
>>     ^--   default region [used=8MB, free=99.75%, comm=256MB]
>>     ^--   TxLog region [used=0MB, free=100%, comm=40MB]
>>     ^-- Outbound messages queue [size=0]
>>     ^-- Public thread pool [active=0, idle=0, qSize=0]
>>     ^-- System thread pool [active=0, idle=8, qSize=0]
>> [2020-04-03 07:21:38,870][INFO ][grid-timeout-worker-#23][IgniteKernal]
>> FreeList [name=default##FreeList, buckets=256, dataPages=1, reusePages=0]
>> [2020-04-03 07:22:38,880][INFO ][grid-timeout-worker-#23][IgniteKernal]
>> Metrics for local node (to disable set 'metricsLogFrequency' to 0)
>>     ^-- Node [id=db4efc6e, uptime=00:02:00.022]
>>     ^-- H/N/C [hosts=1, nodes=1, CPUs=8]
>>     ^-- CPU [cur=-100%, avg=-97.87%, GC=0%]
>>     ^-- PageMemory [pages=2252]
>>     ^-- Heap [used=46MB, free=98.85%, comm=87MB]
>>     ^-- Off-heap [used=8MB, free=99.74%, comm=336MB]
>>     ^--   sysMemPlc region [used=0MB, free=99.21%, comm=40MB]
>>     ^--   default region [used=8MB, free=99.75%, comm=256MB]
>>     ^--   TxLog region [used=0MB, free=100%, comm=40MB]
>>     ^-- Outbound messages queue [size=0]
>>     ^-- Public thread pool [active=0, idle=0, qSize=0]
>>     ^-- System thread pool [active=0, idle=6, qSize=0]
>> [2020-04-03 07:22:38,880][INFO ][grid-timeout-worker-#23][IgniteKernal]
>> FreeList [name=default##FreeList, buckets=256, dataPages=1, reusePages=0]
>>
>> On Thu, Apr 2, 2020 at 5:59 PM Evgenii Zhuravlev <
>> e.zhuravlev.wk@gmail.com> wrote:
>>
>>> Hi,
>>>
>>> Can you share full log files?
>>>
>>> Evgenii
>>>
>>> чт, 2 апр. 2020 г. в 17:40, Anthony <ha...@gmail.com>:
>>>
>>>> Hello,
>>>>
>>>> I am trying to make java node and c++ node communicate with each other.
>>>> I have successfully done it between two c++ node (which is straight
>>>> forward).
>>>>
>>>> However, when I tried to do a put in java and a get in c++, I got some
>>>> errors. Could anyone have a look? Thanks.
>>>>
>>>> Also, examples of the communication would be helpful!
>>>>
>>>> I first created a node and cache in Java:
>>>> Ignite ignite = Ignition.start();
>>>> IgniteCache<Integer, String> caches =
>>>> ignite.getOrCreateCache("myCache");
>>>>
>>>> And in C++:
>>>>   IgniteConfiguration cfg;
>>>>   Ignite grid = Ignition::Start(cfg);
>>>>    // Get cache instance.
>>>>    Cache<int, std::string> caches = grid.GetCache<int,
>>>> std::string>("myCache");
>>>>
>>>> Then I got the following error messages on java side:
>>>>
>>>> [2020-04-02 16:10:27,131][ERROR][main][IgniteKernal] Failed to start
>>>> manager: GridManagerAdapter [enabled=true,
>>>> name=o.a.i.i.managers.discovery.GridDiscoveryManager]
>>>> class org.apache.ignite.IgniteCheckedException: Failed to start SPI:
>>>> TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
>>>> marsh=JdkMarshaller
>>>> [clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@fd9ebde],
>>>> reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
>>>> forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
>>>> skipAddrsRandomization=false]
>>>> at
>>>> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
>>>> at
>>>> org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
>>>>
>>>>

Re: Error and Question about communication between java node and c++ node

Posted by Ilya Kasnacheev <il...@gmail.com>.
Hello!

Local node's binary configuration is not equal to remote node's binary
configuration [locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
locBinaryCfg={globIdMapper=org.apache.ignite.binary.BinaryBasicIdMapper,
compactFooter=false, globSerializer=null}, rmtBinaryCfg=null]

As explained in the docs, C++ nodes require compactFooter to be false, so
it is necessary to include  matching BinaryConfiguration in your Java
node's IgniteConfiguration. Tune it until the error goes away.
Please check
https://apacheignite-cpp.readme.io/docs/cross-platform-interoperability

Regards,
-- 
Ilya Kasnacheev


пт, 3 апр. 2020 г. в 17:24, Anthony <ha...@gmail.com>:

> Attached is the log file from C++Side:
> [07:20:41,216][WARNING][main][G] Ignite work directory is not provided,
> automatically resolved to:
> C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work
> [07:20:41,344][INFO][main][IgniteKernal%myGrid]
>
> >>>    __________  ________________
> >>>   /  _/ ___/ |/ /  _/_  __/ __/
> >>>  _/ // (7 7    // /  / / / _/
> >>> /___/\___/_/|_/___/ /_/ /___/
> >>>
> >>> ver. 2.8.0#20200226-sha1:341b01df
> >>> 2020 Copyright(C) Apache Software Foundation
> >>>
> >>> Ignite documentation: http://ignite.apache.org
>
> [07:20:41,353][INFO][main][IgniteKernal%myGrid] Config URL: n/a
> [07:20:41,367][INFO][main][IgniteKernal%myGrid] IgniteConfiguration
> [igniteInstanceName=myGrid, pubPoolSize=8, svcPoolSize=8,
> callbackPoolSize=8, stripedPoolSize=8, sysPoolSize=8, mgmtPoolSize=4,
> igfsPoolSize=8, dataStreamerPoolSize=8, utilityCachePoolSize=8,
> utilityCacheKeepAliveTime=60000, p2pPoolSize=2, qryPoolSize=8,
> sqlQryHistSize=1000, dfltQryTimeout=0,
> igniteHome=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin,
> igniteWorkDir=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work,
> mbeanSrv=com.sun.jmx.mbeanserver.JmxMBeanServer@5f0fd5a0,
> nodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af, marsh=BinaryMarshaller [],
> marshLocJobs=false, daemon=false, p2pEnabled=true, netTimeout=5000,
> netCompressionLevel=1, 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, soLinger=5, forceSrvMode=false,
> clientReconnectDisabled=false, internalLsnr=null,
> skipAddrsRandomization=false], segPlc=STOP, segResolveAttempts=2,
> waitForSegOnStart=true, allResolversPassReq=true, segChkFreq=10000,
> commSpi=TcpCommunicationSpi [connectGate=null,
> connPlc=org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi$FirstConnectionPolicy@604f2bd2,
> chConnPlc=null, 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@1d3ac898[Count = 1],
> stopping=false, metricsLsnr=null],
> evtSpi=org.apache.ignite.spi.eventstorage.NoopEventStorageSpi@1b73be9f,
> colSpi=NoopCollisionSpi [], deploySpi=LocalDeploymentSpi [],
> indexingSpi=org.apache.ignite.spi.indexing.noop.NoopIndexingSpi@366ac49b,
> addrRslvr=null,
> encryptionSpi=org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi@6ad59d92,
> clientMode=false, rebalanceThreadPoolSize=4, rebalanceTimeout=10000,
> rebalanceBatchesPrefetchCnt=3, rebalanceThrottle=0,
> rebalanceBatchSize=524288, txCfg=TransactionConfiguration
> [txSerEnabled=false, dfltIsolation=REPEATABLE_READ,
> dfltConcurrency=PESSIMISTIC, dfltTxTimeout=0,
> txTimeoutOnPartitionMapExchange=0, deadlockTimeout=10000,
> 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=PlatformConfiguration [], binaryCfg=BinaryConfiguration
> [idMapper=BinaryBaseIdMapper [isLowerCase=true],
> nameMapper=BinaryBaseNameMapper [isSimpleName=true], serializer=null,
> compactFooter=false], memCfg=null, pstCfg=null,
> dsCfg=DataStorageConfiguration [sysRegionInitSize=41943040,
> sysRegionMaxSize=104857600, pageSize=0, concLvl=0,
> dfltDataRegConf=DataRegionConfiguration [name=default, maxSize=3390213324,
> initSize=268435456, swapPath=null, pageEvictionMode=DISABLED,
> evictionThreshold=0.9, emptyPagesPoolSize=100, metricsEnabled=false,
> metricsSubIntervalCount=5, metricsRateTimeInterval=60000,
> persistenceEnabled=false, checkpointPageBufSize=0,
> lazyMemoryAllocation=true], dataRegions=null, storagePath=null,
> checkpointFreq=180000, lockWaitTime=10000, checkpointThreads=4,
> checkpointWriteOrder=SEQUENTIAL, walHistSize=20,
> maxWalArchiveSize=1073741824, walSegments=10, walSegmentSize=67108864,
> walPath=db/wal, walArchivePath=db/wal/archive, metricsEnabled=false,
> walMode=LOG_ONLY, walTlbSize=131072, walBuffSize=0, walFlushFreq=2000,
> walFsyncDelay=1000, walRecordIterBuffSize=67108864,
> alwaysWriteFullPages=false,
> fileIOFactory=org.apache.ignite.internal.processors.cache.persistence.file.AsyncFileIOFactory@6d23017e,
> metricsSubIntervalCnt=5, metricsRateTimeInterval=60000,
> walAutoArchiveAfterInactivity=-1, writeThrottlingEnabled=false,
> walCompactionEnabled=false, walCompactionLevel=1,
> checkpointReadLockTimeout=null, walPageCompression=DISABLED,
> walPageCompressionLevel=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,
> handshakeTimeout=10000, jdbcEnabled=true, odbcEnabled=true,
> thinCliEnabled=true, sslEnabled=false, useIgniteSslCtxFactory=true,
> sslClientAuth=false, sslCtxFactory=null, thinCliCfg=ThinClientConfiguration
> [maxActiveTxPerConn=100]], mvccVacuumThreadCnt=2, mvccVacuumFreq=5000,
> authEnabled=false, failureHnd=null, commFailureRslvr=null]
> [07:20:41,367][INFO][main][IgniteKernal%myGrid] Daemon mode: off
> [07:20:41,367][INFO][main][IgniteKernal%myGrid] OS: Windows 10 10.0 amd64
> [07:20:41,368][INFO][main][IgniteKernal%myGrid] OS user: harte
> [07:20:41,376][INFO][main][IgniteKernal%myGrid] PID: 37704
> [07:20:41,378][INFO][main][IgniteKernal%myGrid] Language runtime: Java
> Platform API Specification ver. 13
> [07:20:41,378][INFO][main][IgniteKernal%myGrid] VM information: Java(TM)
> SE Runtime Environment 13.0.2+8 Oracle Corporation Java HotSpot(TM) 64-Bit
> Server VM 13.0.2+8
> [07:20:41,378][INFO][main][IgniteKernal%myGrid] VM total memory: 1.0GB
> [07:20:41,379][INFO][main][IgniteKernal%myGrid] Remote Management
> [restart: off, REST: on, JMX (remote: off)]
> [07:20:41,379][INFO][main][IgniteKernal%myGrid] Logger: JavaLogger
> [quiet=true, config=null]
> [07:20:41,379][INFO][main][IgniteKernal%myGrid]
> IGNITE_HOME=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin
> [07:20:41,379][INFO][main][IgniteKernal%myGrid] VM arguments:
> [-DIGNITE_HOME=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin,
> -Xms512m, -Xmx1024m, -Dfile.encoding=UTF-8,
> --add-exports=java.base/jdk.internal.misc=ALL-UNNAMED,
> --add-exports=java.base/sun.nio.ch=ALL-UNNAMED,
> --add-exports=java.management/com.sun.jmx.mbeanserver=ALL-UNNAMED,
> --add-exports=jdk.internal.jvmstat/sun.jvmstat.monitor=ALL-UNNAMED,
> --add-exports=java.base/sun.reflect.generics.reflectiveObjects=ALL-UNNAMED,
> --illegal-access=permit]
> [07:20:41,379][INFO][main][IgniteKernal%myGrid] System cache's DataRegion
> size is configured to 40 MB. Use
> DataStorageConfiguration.systemRegionInitialSize property to change the
> setting.
> [07:20:41,379][INFO][main][IgniteKernal%myGrid] Configured caches [in
> 'sysMemPlc' dataRegion: ['ignite-sys-cache']]
> [07:20:41,379][WARNING][main][IgniteKernal%myGrid] Peer class loading is
> enabled (disable it in production for performance and deployment
> consistency reasons)
> [07:20:41,379][WARNING][main][IgniteKernal%myGrid] Please set system
> property '-Djava.net.preferIPv4Stack=true' to avoid possible problems in
> mixed environments.
> [07:20:41,381][WARNING][pub-#19%myGrid%][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.
> [07:20:41,386][INFO][main][IgniteKernal%myGrid] 3-rd party licenses can be
> found at:
> C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\libs\licenses
> [07:20:41,447][INFO][main][IgnitePluginProcessor] Configured plugins:
> [07:20:41,449][INFO][main][IgnitePluginProcessor]   ^-- None
> [07:20:41,449][INFO][main][IgnitePluginProcessor]
> [07:20:41,452][INFO][main][FailureProcessor] Configured failure handler:
> [hnd=StopNodeOrHaltFailureHandler [tryStop=false, timeout=0,
> super=AbstractFailureHandler [ignoredFailureTypes=UnmodifiableSet
> [SYSTEM_WORKER_BLOCKED, SYSTEM_CRITICAL_OPERATION_TIMEOUT]]]]
> [07:20:41,641][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]
> [07:20:41,737][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.
> [07:20:41,749][WARNING][main][NoopCheckpointSpi] Checkpoints are disabled
> (to enable configure any GridCheckpointSpi implementation)
> [07:20:41,764][WARNING][main][GridCollisionManager] Collision resolution
> is disabled (all jobs will be activated upon arrival).
> [07:20:41,767][INFO][main][IgniteKernal%myGrid] Security status
> [authentication=off, tls/ssl=off]
> [07:20:41,959][INFO][main][TcpDiscoverySpi] Successfully bound to TCP port
> [port=47501, localHost=0.0.0.0/0.0.0.0,
> locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af]
> [07:20:41,984][WARNING][main][IgniteCacheDatabaseSharedManager]
> DataRegionConfiguration.maxWalArchiveSize instead
> DataRegionConfiguration.walHistorySize would be used for removing old
> archive wal files
> [07:20:41,992][INFO][main][IgniteCacheDatabaseSharedManager] Configured
> data regions initialized successfully [total=3]
> [07:20:42,006][INFO][main][PartitionsEvictManager] Evict partition
> permits=2
> [07:20:42,054][WARNING][main][IgniteH2Indexing] Serialization of Java
> objects in H2 was enabled.
> [07:20:42,221][INFO][main][ClientListenerProcessor] Client connector
> processor has started on TCP port 10801
> [07:20:42,281][INFO][main][GridTcpRestProtocol] Command protocol
> successfully started [name=TCP binary, host=0.0.0.0/0.0.0.0, port=11212]
> [07:20:42,311][WARNING][main][PlatformProcessorImpl] Binary configuration
> is automatically initiated, note that binary name mapper is set to
> BinaryBaseNameMapper [isSimpleName=true] and binary ID mapper is set to
> BinaryBaseIdMapper [isLowerCase=true] (other nodes must have the same
> binary name and ID mapper types).
> [07:20:42,713][INFO][main][IgniteKernal%myGrid] Non-loopback local IPs:
> 192.168.0.2, 2600:8801:3600:3820:98c8:6653:241f:8982,
> 2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0,
> fe80:0:0:0:682b:8974:4c86:a81b%wlan0, fe80:0:0:0:75b1:a90f:8fd6:31f9%wlan1,
> fe80:0:0:0:a0b7:294a:aa3a:41c1%eth3, fe80:0:0:0:e8d2:2fe9:d844:de7e%eth5,
> fe80:0:0:0:ecb2:ebd5:7bfc:ecd0%wlan2
> [07:20:42,713][INFO][main][IgniteKernal%myGrid] Enabled local MACs:
> 287FCFBB82D0, 287FCFBB82D1, 287FCFBB82D4, 2A7FCFBB82D0, E8D8D1443071
> [07:20:42,736][INFO][main][TcpDiscoverySpi] Connection check threshold is
> calculated: 10000
> [07:20:47,186][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
> TCP discovery accepted incoming connection
> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982, rmtPort=62659]
> [07:20:47,192][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
> TCP discovery spawning a new thread for connection
> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982, rmtPort=62659]
> [07:20:47,192][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
> Started serving remote node connection
> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659]
> [07:20:47,194][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
> Received ping request from the remote node
> [rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659]
> [07:20:47,195][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
> Finished writing ping response
> [rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659]
> [07:20:47,195][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
> Finished serving remote node connection
> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659
> [07:20:47,203][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
> TCP discovery accepted incoming connection [rmtAddr=/0:0:0:0:0:0:0:1,
> rmtPort=62660]
> [07:20:47,203][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
> TCP discovery spawning a new thread for connection
> [rmtAddr=/0:0:0:0:0:0:0:1, rmtPort=62660]
> [07:20:47,204][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
> Started serving remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62660,
> rmtPort=62660]
> [07:20:47,205][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
> Received ping request from the remote node
> [rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> rmtAddr=/0:0:0:0:0:0:0:1:62660, rmtPort=62660]
> [07:20:47,205][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
> Finished writing ping response
> [rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> rmtAddr=/0:0:0:0:0:0:0:1:62660, rmtPort=62660]
> [07:20:47,205][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
> Finished serving remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62660,
> rmtPort=62660
> [07:20:47,207][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
> TCP discovery accepted incoming connection [rmtAddr=/0:0:0:0:0:0:0:1,
> rmtPort=62661]
> [07:20:47,208][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
> TCP discovery spawning a new thread for connection
> [rmtAddr=/0:0:0:0:0:0:0:1, rmtPort=62661]
> [07:20:47,208][INFO][tcp-disco-sock-reader-[]-#12%myGrid%][TcpDiscoverySpi]
> Started serving remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62661,
> rmtPort=62661]
> [07:20:47,210][INFO][tcp-disco-sock-reader-[db4efc6e
> 0:0:0:0:0:0:0:1:62661]-#12%myGrid%][TcpDiscoverySpi] Initialized connection
> with remote server node [nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> rmtAddr=/0:0:0:0:0:0:0:1:62661]
> [07:20:47,213][SEVERE][main][IgniteKernal%myGrid] Failed to start manager:
> GridManagerAdapter [enabled=true,
> name=o.a.i.i.managers.discovery.GridDiscoveryManager]
> class org.apache.ignite.IgniteCheckedException: Failed to start SPI:
> TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
> marsh=JdkMarshaller
> [clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@72825400],
> reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
> forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
> skipAddrsRandomization=false]
> at
> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
> at
> org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
> at
> org.apache.ignite.internal.IgniteKernal.startManager(IgniteKernal.java:1960)
> at org.apache.ignite.internal.IgniteKernal.start(IgniteKernal.java:1276)
> at
> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start0(IgnitionEx.java:2038)
> at
> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start(IgnitionEx.java:1703)
> at org.apache.ignite.internal.IgnitionEx.start0(IgnitionEx.java:1117)
> at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:615)
> at
> org.apache.ignite.internal.processors.platform.PlatformAbstractBootstrap.start(PlatformAbstractBootstrap.java:43)
> at
> org.apache.ignite.internal.processors.platform.PlatformIgnition.start(PlatformIgnition.java:74)
> Caused by: class org.apache.ignite.spi.IgniteSpiException: Local node's
> binary configuration is not equal to remote node's binary configuration
> [locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
> rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> locBinaryCfg={globIdMapper=org.apache.ignite.binary.BinaryBasicIdMapper,
> compactFooter=false, globSerializer=null}, rmtBinaryCfg=null]
> at
> org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.checkFailedError(TcpDiscoverySpi.java:1997)
> at
> org.apache.ignite.spi.discovery.tcp.ServerImpl.joinTopology(ServerImpl.java:1116)
> at
> org.apache.ignite.spi.discovery.tcp.ServerImpl.spiStart(ServerImpl.java:427)
> at
> org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.spiStart(TcpDiscoverySpi.java:2099)
> at
> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:297)
> ... 9 more
> [07:20:47,214][INFO][tcp-disco-sock-reader-[db4efc6e
> 0:0:0:0:0:0:0:1:62661]-#12%myGrid%][TcpDiscoverySpi] Finished serving
> remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62661, rmtPort=62661
> [07:20:47,214][SEVERE][main][IgniteKernal%myGrid] Got exception while
> starting (will rollback startup routine).
> class org.apache.ignite.IgniteCheckedException: Failed to start manager:
> GridManagerAdapter [enabled=true,
> name=org.apache.ignite.internal.managers.discovery.GridDiscoveryManager]
> at
> org.apache.ignite.internal.IgniteKernal.startManager(IgniteKernal.java:1965)
> at org.apache.ignite.internal.IgniteKernal.start(IgniteKernal.java:1276)
> at
> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start0(IgnitionEx.java:2038)
> at
> org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start(IgnitionEx.java:1703)
> at org.apache.ignite.internal.IgnitionEx.start0(IgnitionEx.java:1117)
> at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:615)
> at
> org.apache.ignite.internal.processors.platform.PlatformAbstractBootstrap.start(PlatformAbstractBootstrap.java:43)
> at
> org.apache.ignite.internal.processors.platform.PlatformIgnition.start(PlatformIgnition.java:74)
> Caused by: class org.apache.ignite.IgniteCheckedException: Failed to start
> SPI: TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
> marsh=JdkMarshaller
> [clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@72825400],
> reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
> forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
> skipAddrsRandomization=false]
> at
> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
> at
> org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
> at
> org.apache.ignite.internal.IgniteKernal.startManager(IgniteKernal.java:1960)
> ... 7 more
> Caused by: class org.apache.ignite.spi.IgniteSpiException: Local node's
> binary configuration is not equal to remote node's binary configuration
> [locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
> rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> locBinaryCfg={globIdMapper=org.apache.ignite.binary.BinaryBasicIdMapper,
> compactFooter=false, globSerializer=null}, rmtBinaryCfg=null]
> at
> org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.checkFailedError(TcpDiscoverySpi.java:1997)
> at
> org.apache.ignite.spi.discovery.tcp.ServerImpl.joinTopology(ServerImpl.java:1116)
> at
> org.apache.ignite.spi.discovery.tcp.ServerImpl.spiStart(ServerImpl.java:427)
> at
> org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.spiStart(TcpDiscoverySpi.java:2099)
> at
> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:297)
> ... 9 more
> [07:20:47,228][INFO][main][GridTcpRestProtocol] Command protocol
> successfully stopped: TCP binary
> [07:20:52,235][INFO][main][TcpDiscoverySpi] No verification for local node
> leave has been received from coordinator (will stop node anyway).
> [07:20:52,245][INFO][main][IgniteKernal%myGrid]
>
> >>>
> +---------------------------------------------------------------------------------+
> >>> Ignite ver.
> 2.8.0#20200226-sha1:341b01dfd8abf2d9b01d468ad1bb26dfe84ac4f6 stopped OK
> >>>
> +---------------------------------------------------------------------------------+
> >>> Ignite instance name: myGrid
> >>> Grid uptime: 00:00:11.528
>
>
>
> And Java Side:
> [2020-04-03 07:20:16,818][WARN ][main][G] Ignite work directory is not
> provided, automatically resolved to:
> C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work
> [2020-04-03 07:20:16,993][INFO ][main][IgniteKernal]
>
> >>>    __________  ________________
> >>>   /  _/ ___/ |/ /  _/_  __/ __/
> >>>  _/ // (7 7    // /  / / / _/
> >>> /___/\___/_/|_/___/ /_/ /___/
> >>>
> >>> ver. 2.8.0#20200226-sha1:341b01df
> >>> 2020 Copyright(C) Apache Software Foundation
> >>>
> >>> Ignite documentation: http://ignite.apache.org
>
> [2020-04-03 07:20:17,002][INFO ][main][IgniteKernal] Config URL:
> file:/C:/Users/harte/Desktop/work/apache-ignite-2.8.0-bin-try/apache-ignite-2.8.0-bin/examples/config/example-ignite.xml
> [2020-04-03 07:20:17,021][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,
> sqlQryHistSize=1000, dfltQryTimeout=0,
> igniteHome=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin,
> igniteWorkDir=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work,
> mbeanSrv=com.sun.jmx.mbeanserver.JmxMBeanServer@7d9e8ef7,
> nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448, marsh=BinaryMarshaller [],
> marshLocJobs=false, daemon=false, p2pEnabled=true, netTimeout=5000,
> netCompressionLevel=1, 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, soLinger=5, forceSrvMode=false,
> clientReconnectDisabled=false, internalLsnr=null,
> skipAddrsRandomization=false], segPlc=STOP, segResolveAttempts=2,
> waitForSegOnStart=true, allResolversPassReq=true, segChkFreq=10000,
> commSpi=TcpCommunicationSpi [connectGate=null,
> connPlc=org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi$FirstConnectionPolicy@4b7e96a,
> chConnPlc=null, 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@6475472c[Count = 1],
> stopping=false, metricsLsnr=null],
> evtSpi=org.apache.ignite.spi.eventstorage.NoopEventStorageSpi@3f07b12c,
> colSpi=NoopCollisionSpi [], deploySpi=LocalDeploymentSpi [],
> indexingSpi=org.apache.ignite.spi.indexing.noop.NoopIndexingSpi@784b990c,
> addrRslvr=null,
> encryptionSpi=org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi@3d3ba765,
> clientMode=false, rebalanceThreadPoolSize=4, rebalanceTimeout=10000,
> rebalanceBatchesPrefetchCnt=3, rebalanceThrottle=0,
> rebalanceBatchSize=524288, txCfg=TransactionConfiguration
> [txSerEnabled=false, dfltIsolation=REPEATABLE_READ,
> dfltConcurrency=PESSIMISTIC, dfltTxTimeout=0,
> txTimeoutOnPartitionMapExchange=0, deadlockTimeout=10000,
> 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=DataStorageConfiguration [sysRegionInitSize=41943040,
> sysRegionMaxSize=104857600, pageSize=0, concLvl=0,
> dfltDataRegConf=DataRegionConfiguration [name=default, maxSize=3390213324,
> initSize=268435456, swapPath=null, pageEvictionMode=DISABLED,
> evictionThreshold=0.9, emptyPagesPoolSize=100, metricsEnabled=false,
> metricsSubIntervalCount=5, metricsRateTimeInterval=60000,
> persistenceEnabled=false, checkpointPageBufSize=0,
> lazyMemoryAllocation=true], dataRegions=null, storagePath=null,
> checkpointFreq=180000, lockWaitTime=10000, checkpointThreads=4,
> checkpointWriteOrder=SEQUENTIAL, walHistSize=20,
> maxWalArchiveSize=1073741824, walSegments=10, walSegmentSize=67108864,
> walPath=db/wal, walArchivePath=db/wal/archive, metricsEnabled=false,
> walMode=LOG_ONLY, walTlbSize=131072, walBuffSize=0, walFlushFreq=2000,
> walFsyncDelay=1000, walRecordIterBuffSize=67108864,
> alwaysWriteFullPages=false,
> fileIOFactory=org.apache.ignite.internal.processors.cache.persistence.file.AsyncFileIOFactory@758a34ce,
> metricsSubIntervalCnt=5, metricsRateTimeInterval=60000,
> walAutoArchiveAfterInactivity=-1, writeThrottlingEnabled=false,
> walCompactionEnabled=false, walCompactionLevel=1,
> checkpointReadLockTimeout=null, walPageCompression=DISABLED,
> walPageCompressionLevel=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,
> handshakeTimeout=10000, jdbcEnabled=true, odbcEnabled=true,
> thinCliEnabled=true, sslEnabled=false, useIgniteSslCtxFactory=true,
> sslClientAuth=false, sslCtxFactory=null, thinCliCfg=ThinClientConfiguration
> [maxActiveTxPerConn=100]], mvccVacuumThreadCnt=2, mvccVacuumFreq=5000,
> authEnabled=false, failureHnd=null, commFailureRslvr=null]
> [2020-04-03 07:20:17,021][INFO ][main][IgniteKernal] Daemon mode: off
> [2020-04-03 07:20:17,021][INFO ][main][IgniteKernal] OS: Windows 10 10.0
> amd64
> [2020-04-03 07:20:17,021][INFO ][main][IgniteKernal] OS user: harte
> [2020-04-03 07:20:17,032][INFO ][main][IgniteKernal] PID: 38064
> [2020-04-03 07:20:17,033][INFO ][main][IgniteKernal] Language runtime:
> Java Platform API Specification ver. 13
> [2020-04-03 07:20:17,033][INFO ][main][IgniteKernal] VM information:
> Java(TM) SE Runtime Environment 13.0.2+8 Oracle Corporation Java
> HotSpot(TM) 64-Bit Server VM 13.0.2+8
> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] VM total memory: 3.9GB
> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] Remote Management
> [restart: off, REST: on, JMX (remote: off)]
> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] Logger: Log4JLogger
> [quiet=true,
> config=/C:/Users/harte/Desktop/work/apache-ignite-2.8.0-bin-try/apache-ignite-2.8.0-bin/config/ignite-log4j.xml]
> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal]
> IGNITE_HOME=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin
> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] VM arguments:
> [--add-exports=java.base/jdk.internal.misc=ALL-UNNAMED,
> --add-exports=java.base/sun.nio.ch=ALL-UNNAMED,
> --add-exports=java.management/com.sun.jmx.mbeanserver=ALL-UNNAMED,
> --add-exports=jdk.internal.jvmstat/sun.jvmstat.monitor=ALL-UNNAMED,
> --add-exports=java.base/sun.reflect.generics.reflectiveObjects=ALL-UNNAMED,
> --illegal-access=permit,
> -Djava.library.path=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\examples\src\main\java\org\apache\ignite\examples\datagrid,
> -javaagent:C:\Program Files\JetBrains\IntelliJ IDEA Community Edition
> 2019.3.2\lib\idea_rt.jar=62570:C:\Program Files\JetBrains\IntelliJ IDEA
> Community Edition 2019.3.2\bin, -Dfile.encoding=UTF-8]
> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] System cache's
> DataRegion size is configured to 40 MB. Use
> DataStorageConfiguration.systemRegionInitialSize property to change the
> setting.
> [2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] Configured caches [in
> 'sysMemPlc' dataRegion: ['ignite-sys-cache']]
> [2020-04-03 07:20:17,034][WARN ][main][IgniteKernal] Peer class loading is
> enabled (disable it in production for performance and deployment
> consistency reasons)
> [2020-04-03 07:20:17,035][WARN ][main][IgniteKernal] Please set system
> property '-Djava.net.preferIPv4Stack=true' to avoid possible problems in
> mixed environments.
> [2020-04-03 07:20:17,038][INFO ][main][IgniteKernal] 3-rd party licenses
> can be found at:
> C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\libs\licenses
> [2020-04-03 07:20:17,038][WARN ][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.
> [2020-04-03 07:20:17,044][WARN ][pub-#22][GridDiagnostic] Initial heap
> size is 254MB (should be no less than 512MB, use -Xms512m -Xmx512m).
> [2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor] Configured
> plugins:
> [2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor]   ^--
> ml-inference-plugin 1.0.0
> [2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor]   ^-- null
> [2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor]
> [2020-04-03 07:20:17,135][INFO ][main][FailureProcessor] Configured
> failure handler: [hnd=StopNodeOrHaltFailureHandler [tryStop=false,
> timeout=0, super=AbstractFailureHandler
> [ignoredFailureTypes=UnmodifiableSet [SYSTEM_WORKER_BLOCKED,
> SYSTEM_CRITICAL_OPERATION_TIMEOUT]]]]
> [2020-04-03 07:20:17,350][INFO ][main][TcpCommunicationSpi] Successfully
> bound communication NIO server to TCP port [port=47100, locHost=
> 0.0.0.0/0.0.0.0, selectorsCnt=4, selectorSpins=0, pairedConn=false]
> [2020-04-03 07:20:17,441][WARN ][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.
> [2020-04-03 07:20:17,452][WARN ][main][NoopCheckpointSpi] Checkpoints are
> disabled (to enable configure any GridCheckpointSpi implementation)
> [2020-04-03 07:20:17,467][WARN ][main][GridCollisionManager] Collision
> resolution is disabled (all jobs will be activated upon arrival).
> [2020-04-03 07:20:17,469][INFO ][main][IgniteKernal] Security status
> [authentication=off, tls/ssl=off]
> [2020-04-03 07:20:17,637][INFO ][main][TcpDiscoverySpi] Successfully bound
> to TCP port [port=47500, localHost=0.0.0.0/0.0.0.0,
> locNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448]
> [2020-04-03 07:20:17,662][WARN ][main][IgniteCacheDatabaseSharedManager]
> DataRegionConfiguration.maxWalArchiveSize instead
> DataRegionConfiguration.walHistorySize would be used for removing old
> archive wal files
> [2020-04-03 07:20:17,672][INFO ][main][IgniteCacheDatabaseSharedManager]
> Configured data regions initialized successfully [total=3]
> [2020-04-03 07:20:17,686][INFO ][main][PartitionsEvictManager] Evict
> partition permits=2
> [2020-04-03 07:20:17,731][WARN ][main][IgniteH2Indexing] Serialization of
> Java objects in H2 was enabled.
> [2020-04-03 07:20:17,877][INFO ][main][ClientListenerProcessor] Client
> connector processor has started on TCP port 10800
> [2020-04-03 07:20:17,917][INFO ][main][GridTcpRestProtocol] Command
> protocol successfully started [name=TCP binary, host=0.0.0.0/0.0.0.0,
> port=11211]
> [2020-04-03 07:20:18,207][INFO ][main][IgniteKernal] Non-loopback local
> IPs: 192.168.0.2, 2600:8801:3600:3820:98c8:6653:241f:8982,
> 2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0,
> fe80:0:0:0:682b:8974:4c86:a81b%wlan0, fe80:0:0:0:75b1:a90f:8fd6:31f9%wlan1,
> fe80:0:0:0:a0b7:294a:aa3a:41c1%eth3, fe80:0:0:0:e8d2:2fe9:d844:de7e%eth5,
> fe80:0:0:0:ecb2:ebd5:7bfc:ecd0%wlan2
> [2020-04-03 07:20:18,207][INFO ][main][IgniteKernal] Enabled local MACs:
> 287FCFBB82D0, 287FCFBB82D1, 287FCFBB82D4, 2A7FCFBB82D0, E8D8D1443071
> [2020-04-03 07:20:18,223][INFO ][main][TcpDiscoverySpi] Connection check
> threshold is calculated: 10000
> [2020-04-03 07:20:38,531][INFO
> ][disco-notifier-worker-#41][GridClusterStateProcessor] Received activate
> request with BaselineTopology[id=0]
> [2020-04-03 07:20:38,531][INFO
> ][disco-notifier-worker-#41][GridClusterStateProcessor] Started state
> transition: true
> [2020-04-03 07:20:38,532][INFO
> ][disco-notifier-worker-#41][GridClusterStateProcessor] Received state
> change finish message: true
> [2020-04-03 07:20:38,533][INFO
> ][disco-notifier-worker-#41][MvccProcessorImpl] Assigned mvcc coordinator
> [crd=MvccCoordinator [topVer=AffinityTopologyVersion [topVer=1,
> minorTopVer=0], nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> ver=1585923638519, local=true, initialized=false]]
> [2020-04-03 07:20:38,563][INFO
> ][disco-notifier-worker-#41][DistributedBaselineConfiguration] Baseline
> parameter 'baselineAutoAdjustEnabled' was changed from 'null' to 'true'
> [2020-04-03 07:20:38,566][INFO
> ][disco-notifier-worker-#41][DistributedBaselineConfiguration] Baseline
> parameter 'baselineAutoAdjustTimeout' was changed from 'null' to '0'
> [2020-04-03 07:20:38,587][INFO ][exchange-worker-#43][time] Started
> exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
> crd=true, evt=NODE_JOINED, evtNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> customEvt=null, allowMerge=false, exchangeFreeSwitch=false]
> [2020-04-03 07:20:38,603][INFO
> ][exchange-worker-#43][IgniteCacheDatabaseSharedManager] Configured data
> regions started successfully [total=3]
> [2020-04-03 07:20:38,604][INFO ][exchange-worker-#43][msg] Components
> activation performed in 17 ms.
> [2020-04-03 07:20:38,729][INFO ][exchange-worker-#43][GridCacheProcessor]
> Started cache [name=ignite-sys-cache, id=-2100569601,
> dataRegionName=sysMemPlc, mode=REPLICATED, atomicity=TRANSACTIONAL,
> backups=2147483647, mvcc=false]
> [2020-04-03 07:20:38,730][INFO ][exchange-worker-#43][GridCacheProcessor]
> Starting caches on local join performed in 127 ms.
> [2020-04-03 07:20:38,740][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Skipped waiting for
> partitions release future (local node is joining)
> [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0]]
> [2020-04-03 07:20:38,790][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture]
> finishExchangeOnCoordinator [topVer=AffinityTopologyVersion [topVer=1,
> minorTopVer=0], resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0]]
> [2020-04-03 07:20:38,803][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finish exchange
> future [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], err=null,
> rebalanced=true, wasRebalanced=false]
> [2020-04-03 07:20:38,815][INFO ][exchange-worker-#43][GridCacheProcessor]
> Finish proxy initialization, cacheName=ignite-sys-cache,
> localNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448
> [2020-04-03 07:20:38,816][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Completed partition
> exchange [localNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> exchange=GridDhtPartitionsExchangeFuture [topVer=AffinityTopologyVersion
> [topVer=1, minorTopVer=0], evt=NODE_JOINED, evtNode=TcpDiscoveryNode
> [id=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> consistentId=0:0:0:0:0:0:0:1,127.0.0.1,192.168.0.2,2600:8801:3600:3820:98c8:6653:241f:8982,2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500,
> addrs=ArrayList [0:0:0:0:0:0:0:1, 127.0.0.1, 192.168.0.2,
> 2600:8801:3600:3820:98c8:6653:241f:8982,
> 2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0], sockAddrs=HashSet
> [/2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500, /0:0:0:0:0:0:0:1:47500, /
> 127.0.0.1:47500, /2600:8801:3600:3820:98c8:6653:241f:8982:47500,
> LAPTOP-MUM8SQ8C/192.168.0.2:47500], discPort=47500, order=1, intOrder=1,
> lastExchangeTime=1585923618219, loc=true, ver=2.8.0#20200226-sha1:341b01df,
> isClient=false], done=true, newCrdFut=null], topVer=AffinityTopologyVersion
> [topVer=1, minorTopVer=0]]
> [2020-04-03 07:20:38,816][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange timings
> [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], stage="Waiting in
> exchange queue" (42 ms), stage="Exchange parameters initialization" (1 ms),
> stage="Components activation" (16 ms), stage="Determine exchange type" (135
> ms), stage="Preloading notification" (0 ms), stage="WAL history
> reservation" (0 ms), stage="After states restored callback" (49 ms),
> stage="Waiting for all single messages" (0 ms), stage="Affinity
> recalculation (crd)" (0 ms), stage="Collect update counters and create
> affinity messages" (0 ms), stage="Validate partitions states" (2 ms),
> stage="Assign partitions states" (0 ms), stage="Apply update counters" (0
> ms), stage="Full message preparing" (8 ms), stage="Full message sending" (0
> ms), stage="State finish message sending" (0 ms), stage="Exchange done" (12
> ms), stage="Total time" (265 ms)]
> [2020-04-03 07:20:38,816][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange longest
> local stages [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
> stage="Coordinator affinity cache init [grp=ignite-sys-cache]" (129 ms)
> (parent=Determine exchange type), stage="First node affinity initialization
> (node join) [grp=ignite-sys-cache]" (4 ms) (parent=Determine exchange type)]
> [2020-04-03 07:20:38,817][INFO ][exchange-worker-#43][time] Finished
> exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
> crd=true]
> [2020-04-03 07:20:38,819][INFO
> ][exchange-worker-#43][GridCachePartitionExchangeManager] Skipping
> rebalancing (nothing scheduled) [top=AffinityTopologyVersion [topVer=1,
> minorTopVer=0], force=false, evt=NODE_JOINED,
> node=db4efc6e-44c7-46ce-b7c0-154e387c0448]
> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal] Performance
> suggestions for grid  (fix if possible)
> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal] To disable, set
> -DIGNITE_PERFORMANCE_SUGGESTIONS_DISABLED=true
> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Disable grid
> events (remove 'includeEventTypes' from configuration)
> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Switch to the
> most recent 1.8 JVM version
> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Specify JVM
> heap max size (add '-Xmx<size>[g|G|m|M|k|K]' to JVM options)
> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Set max direct
> memory size if getting 'OOME: Direct buffer memory' (add
> '-XX:MaxDirectMemorySize=<size>[g|G|m|M|k|K]' to JVM options)
> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Disable
> processing of calls to System.gc() (add '-XX:+DisableExplicitGC' to JVM
> options)
> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal] Refer to this page
> for more performance suggestions:
> https://apacheignite.readme.io/docs/jvm-and-system-tuning
> [2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]
> [2020-04-03 07:20:38,868][INFO ][main][IgniteKernal] To start Console
> Management & Monitoring run ignitevisorcmd.{sh|bat}
> [2020-04-03 07:20:38,870][INFO ][main][IgniteKernal] Data Regions
> Configured:
> [2020-04-03 07:20:38,870][INFO ][main][IgniteKernal]   ^-- default
> [initSize=256.0 MiB, maxSize=3.2 GiB, persistence=false,
> lazyMemoryAllocation=true]
> [2020-04-03 07:20:38,871][INFO ][main][IgniteKernal]
>
> >>>
> +----------------------------------------------------------------------+
> >>> Ignite ver.
> 2.8.0#20200226-sha1:341b01dfd8abf2d9b01d468ad1bb26dfe84ac4f6
> >>>
> +----------------------------------------------------------------------+
> >>> OS name: Windows 10 10.0 amd64
> >>> CPU(s): 8
> >>> Heap: 3.9GB
> >>> VM name: 38064@LAPTOP-MUM8SQ8C
> >>> Local node [ID=DB4EFC6E-44C7-46CE-B7C0-154E387C0448, order=1,
> clientMode=false]
> >>> Local node addresses: [LAPTOP-MUM8SQ8C/0:0:0:0:0:0:0:1,
> LAPTOP-MUM8SQ8C/127.0.0.1, LAPTOP-MUM8SQ8C/192.168.0.2,
> /2600:8801:3600:3820:98c8:6653:241f:8982,
> /2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0]
> >>> Local ports: TCP:10800 TCP:11211 TCP:47100 UDP:47400 TCP:47500
>
> [2020-04-03 07:20:38,874][INFO ][main][GridDiscoveryManager] Topology
> snapshot [ver=1, locNode=db4efc6e, servers=1, clients=0, state=ACTIVE,
> CPUs=8, offheap=3.2GB, heap=3.9GB]
> [2020-04-03 07:20:38,874][INFO ][main][GridDiscoveryManager]   ^--
> Baseline [id=0, size=1, online=1, offline=0]
> [2020-04-03 07:20:38,874][INFO ][main][G] Node started : [stage="Configure
> system pool" (66 ms),stage="Start managers" (502 ms),stage="Configure
> binary metadata" (40 ms),stage="Start processors" (416 ms),stage="Start
> 'ml-inference-plugin' plugin" (0 ms),stage="Init metastore" (271
> ms),stage="Finish recovery" (0 ms),stage="Join topology" (20318
> ms),stage="Await transition" (17 ms),stage="Await exchange" (323
> ms),stage="Total time" (21953 ms)]
> [2020-04-03 07:20:38,889][INFO ][exchange-worker-#43][time] Started
> exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
> crd=true, evt=DISCOVERY_CUSTOM_EVT,
> evtNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> customEvt=DynamicCacheChangeBatch
> [id=e9de9604171-03f8bb55-f219-4232-903a-6af839413db6, reqs=ArrayList
> [DynamicCacheChangeRequest [cacheName=myCache, hasCfg=true,
> nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448, clientStartOnly=false,
> stop=false, destroy=false, disabledAfterStartfalse]],
> exchangeActions=ExchangeActions [startCaches=[myCache], stopCaches=null,
> startGrps=[myCache], stopGrps=[], resetParts=null,
> stateChangeRequest=null], startCaches=false], allowMerge=false,
> exchangeFreeSwitch=false]
> [2020-04-03 07:20:38,915][INFO ][exchange-worker-#43][GridCacheProcessor]
> Started cache [name=myCache, id=1482644790, dataRegionName=default,
> mode=PARTITIONED, atomicity=ATOMIC, backups=0, mvcc=false]
> [2020-04-03 07:20:38,928][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finished waiting
> for partition release future [topVer=AffinityTopologyVersion [topVer=1,
> minorTopVer=1], waitTime=0ms, futInfo=NA, mode=DISTRIBUTED]
> [2020-04-03 07:20:38,930][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finished waiting
> for partitions release latch: ServerLatch [permits=0, pendingAcks=HashSet
> [], super=CompletableLatch [id=CompletableLatchUid [id=exchange,
> topVer=AffinityTopologyVersion [topVer=1, minorTopVer=1]]]]
> [2020-04-03 07:20:38,930][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finished waiting
> for partition release future [topVer=AffinityTopologyVersion [topVer=1,
> minorTopVer=1], waitTime=0ms, futInfo=NA, mode=LOCAL]
> [2020-04-03 07:20:38,987][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture]
> finishExchangeOnCoordinator [topVer=AffinityTopologyVersion [topVer=1,
> minorTopVer=1], resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1]]
> [2020-04-03 07:20:39,004][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finish exchange
> future [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1], err=null,
> rebalanced=true, wasRebalanced=true]
> [2020-04-03 07:20:39,008][INFO ][exchange-worker-#43][GridCacheProcessor]
> Finish proxy initialization, cacheName=myCache,
> localNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448
> [2020-04-03 07:20:39,009][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Completed partition
> exchange [localNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> exchange=GridDhtPartitionsExchangeFuture [topVer=AffinityTopologyVersion
> [topVer=1, minorTopVer=1], evt=DISCOVERY_CUSTOM_EVT,
> evtNode=TcpDiscoveryNode [id=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> consistentId=0:0:0:0:0:0:0:1,127.0.0.1,192.168.0.2,2600:8801:3600:3820:98c8:6653:241f:8982,2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500,
> addrs=ArrayList [0:0:0:0:0:0:0:1, 127.0.0.1, 192.168.0.2,
> 2600:8801:3600:3820:98c8:6653:241f:8982,
> 2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0], sockAddrs=HashSet
> [/2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500, /0:0:0:0:0:0:0:1:47500, /
> 127.0.0.1:47500, /2600:8801:3600:3820:98c8:6653:241f:8982:47500,
> LAPTOP-MUM8SQ8C/192.168.0.2:47500], discPort=47500, order=1, intOrder=1,
> lastExchangeTime=1585923618219, loc=true, ver=2.8.0#20200226-sha1:341b01df,
> isClient=false], done=true, newCrdFut=null], topVer=AffinityTopologyVersion
> [topVer=1, minorTopVer=1]]
> [2020-04-03 07:20:39,009][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange timings
> [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1], stage="Waiting in
> exchange queue" (0 ms), stage="Exchange parameters initialization" (1 ms),
> stage="Update caches registry" (1 ms), stage="Start caches" (25 ms),
> stage="Affinity initialization on cache group start" (6 ms),
> stage="Determine exchange type" (0 ms), stage="Preloading notification" (0
> ms), stage="WAL history reservation" (0 ms), stage="Wait partitions
> release" (4 ms), stage="Wait partitions release latch" (1 ms), stage="Wait
> partitions release" (0 ms), stage="After states restored callback" (50 ms),
> stage="Waiting for all single messages" (6 ms), stage="Affinity
> recalculation (crd)" (0 ms), stage="Collect update counters and create
> affinity messages" (0 ms), stage="Validate partitions states" (1 ms),
> stage="Assign partitions states" (0 ms), stage="Apply update counters" (2
> ms), stage="Full message preparing" (10 ms), stage="Full message sending"
> (0 ms), stage="Exchange done" (5 ms), stage="Total time" (112 ms)]
> [2020-04-03 07:20:39,009][INFO
> ][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange longest
> local stages [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
> resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1], stage="Affinity
> initialization on cache group start [grp=myCache]" (6 ms) (parent=Affinity
> initialization on cache group start)]
> [2020-04-03 07:20:39,010][INFO ][exchange-worker-#43][time] Finished
> exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
> crd=true]
> [2020-04-03 07:20:39,014][INFO
> ][exchange-worker-#43][GridCachePartitionExchangeManager] Skipping
> rebalancing (nothing scheduled) [top=AffinityTopologyVersion [topVer=1,
> minorTopVer=1], force=false, evt=DISCOVERY_CUSTOM_EVT,
> node=db4efc6e-44c7-46ce-b7c0-154e387c0448]
> [2020-04-03 07:20:47,163][INFO
> ][tcp-disco-srvr-[:47500]-#3][TcpDiscoverySpi] TCP discovery accepted
> incoming connection [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982,
> rmtPort=62658]
> [2020-04-03 07:20:47,167][INFO
> ][tcp-disco-srvr-[:47500]-#3][TcpDiscoverySpi] TCP discovery spawning a new
> thread for connection [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982,
> rmtPort=62658]
> [2020-04-03 07:20:47,168][INFO
> ][tcp-disco-sock-reader-[]-#11][TcpDiscoverySpi] Started serving remote
> node connection [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62658,
> rmtPort=62658]
> [2020-04-03 07:20:47,172][INFO ][tcp-disco-sock-reader-[155424bd
> 2600:8801:3600:3820:98c8:6653:241f:8982:62658]-#11][TcpDiscoverySpi]
> Initialized connection with remote server node
> [nodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
> rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62658]
> [2020-04-03 07:20:47,196][INFO ][tcp-disco-sock-reader-[155424bd
> 2600:8801:3600:3820:98c8:6653:241f:8982:62658]-#11][TcpDiscoverySpi]
> Finished serving remote node connection
> [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62658, rmtPort=62658
> [2020-04-03 07:20:47,201][INFO
> ][tcp-disco-msg-worker-[crd]-#2][GridEncryptionManager] Joining node
> doesn't have encryption data [node=155424bd-1c8e-48a2-83ff-26aa6cf9e7af]
> [2020-04-03 07:20:47,206][WARN ][disco-pool-#55][TcpDiscoverySpi] Local
> node's binary configuration is not equal to remote node's binary
> configuration [locNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
> rmtNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af, locBinaryCfg=null,
> rmtBinaryCfg={globIdMapper=o.a.i.binary.BinaryBasicIdMapper,
> compactFooter=false, globSerializer=null}]
> [2020-04-03 07:20:48,554][INFO
> ][ignite-update-notifier-timer][GridUpdateNotifier] Your version is up to
> date.
> [2020-04-03 07:21:38,869][INFO ][grid-timeout-worker-#23][IgniteKernal]
> Metrics for local node (to disable set 'metricsLogFrequency' to 0)
>     ^-- Node [id=db4efc6e, uptime=00:01:00.003]
>     ^-- H/N/C [hosts=1, nodes=1, CPUs=8]
>     ^-- CPU [cur=-100%, avg=-95.83%, GC=0%]
>     ^-- PageMemory [pages=2252]
>     ^-- Heap [used=43MB, free=98.92%, comm=87MB]
>     ^-- Off-heap [used=8MB, free=99.74%, comm=336MB]
>     ^--   sysMemPlc region [used=0MB, free=99.21%, comm=40MB]
>     ^--   default region [used=8MB, free=99.75%, comm=256MB]
>     ^--   TxLog region [used=0MB, free=100%, comm=40MB]
>     ^-- Outbound messages queue [size=0]
>     ^-- Public thread pool [active=0, idle=0, qSize=0]
>     ^-- System thread pool [active=0, idle=8, qSize=0]
> [2020-04-03 07:21:38,870][INFO ][grid-timeout-worker-#23][IgniteKernal]
> FreeList [name=default##FreeList, buckets=256, dataPages=1, reusePages=0]
> [2020-04-03 07:22:38,880][INFO ][grid-timeout-worker-#23][IgniteKernal]
> Metrics for local node (to disable set 'metricsLogFrequency' to 0)
>     ^-- Node [id=db4efc6e, uptime=00:02:00.022]
>     ^-- H/N/C [hosts=1, nodes=1, CPUs=8]
>     ^-- CPU [cur=-100%, avg=-97.87%, GC=0%]
>     ^-- PageMemory [pages=2252]
>     ^-- Heap [used=46MB, free=98.85%, comm=87MB]
>     ^-- Off-heap [used=8MB, free=99.74%, comm=336MB]
>     ^--   sysMemPlc region [used=0MB, free=99.21%, comm=40MB]
>     ^--   default region [used=8MB, free=99.75%, comm=256MB]
>     ^--   TxLog region [used=0MB, free=100%, comm=40MB]
>     ^-- Outbound messages queue [size=0]
>     ^-- Public thread pool [active=0, idle=0, qSize=0]
>     ^-- System thread pool [active=0, idle=6, qSize=0]
> [2020-04-03 07:22:38,880][INFO ][grid-timeout-worker-#23][IgniteKernal]
> FreeList [name=default##FreeList, buckets=256, dataPages=1, reusePages=0]
>
> On Thu, Apr 2, 2020 at 5:59 PM Evgenii Zhuravlev <e....@gmail.com>
> wrote:
>
>> Hi,
>>
>> Can you share full log files?
>>
>> Evgenii
>>
>> чт, 2 апр. 2020 г. в 17:40, Anthony <ha...@gmail.com>:
>>
>>> Hello,
>>>
>>> I am trying to make java node and c++ node communicate with each other.
>>> I have successfully done it between two c++ node (which is straight
>>> forward).
>>>
>>> However, when I tried to do a put in java and a get in c++, I got some
>>> errors. Could anyone have a look? Thanks.
>>>
>>> Also, examples of the communication would be helpful!
>>>
>>> I first created a node and cache in Java:
>>> Ignite ignite = Ignition.start();
>>> IgniteCache<Integer, String> caches = ignite.getOrCreateCache("myCache");
>>>
>>> And in C++:
>>>   IgniteConfiguration cfg;
>>>   Ignite grid = Ignition::Start(cfg);
>>>    // Get cache instance.
>>>    Cache<int, std::string> caches = grid.GetCache<int,
>>> std::string>("myCache");
>>>
>>> Then I got the following error messages on java side:
>>>
>>> [2020-04-02 16:10:27,131][ERROR][main][IgniteKernal] Failed to start
>>> manager: GridManagerAdapter [enabled=true,
>>> name=o.a.i.i.managers.discovery.GridDiscoveryManager]
>>> class org.apache.ignite.IgniteCheckedException: Failed to start SPI:
>>> TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
>>> marsh=JdkMarshaller
>>> [clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@fd9ebde],
>>> reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
>>> forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
>>> skipAddrsRandomization=false]
>>> at
>>> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
>>> at
>>> org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
>>>
>>>

Re: Error and Question about communication between java node and c++ node

Posted by Anthony <ha...@gmail.com>.
Attached is the log file from C++Side:
[07:20:41,216][WARNING][main][G] Ignite work directory is not provided,
automatically resolved to:
C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work
[07:20:41,344][INFO][main][IgniteKernal%myGrid]

>>>    __________  ________________
>>>   /  _/ ___/ |/ /  _/_  __/ __/
>>>  _/ // (7 7    // /  / / / _/
>>> /___/\___/_/|_/___/ /_/ /___/
>>>
>>> ver. 2.8.0#20200226-sha1:341b01df
>>> 2020 Copyright(C) Apache Software Foundation
>>>
>>> Ignite documentation: http://ignite.apache.org

[07:20:41,353][INFO][main][IgniteKernal%myGrid] Config URL: n/a
[07:20:41,367][INFO][main][IgniteKernal%myGrid] IgniteConfiguration
[igniteInstanceName=myGrid, pubPoolSize=8, svcPoolSize=8,
callbackPoolSize=8, stripedPoolSize=8, sysPoolSize=8, mgmtPoolSize=4,
igfsPoolSize=8, dataStreamerPoolSize=8, utilityCachePoolSize=8,
utilityCacheKeepAliveTime=60000, p2pPoolSize=2, qryPoolSize=8,
sqlQryHistSize=1000, dfltQryTimeout=0,
igniteHome=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin,
igniteWorkDir=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work,
mbeanSrv=com.sun.jmx.mbeanserver.JmxMBeanServer@5f0fd5a0,
nodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af, marsh=BinaryMarshaller [],
marshLocJobs=false, daemon=false, p2pEnabled=true, netTimeout=5000,
netCompressionLevel=1, 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, soLinger=5, forceSrvMode=false,
clientReconnectDisabled=false, internalLsnr=null,
skipAddrsRandomization=false], segPlc=STOP, segResolveAttempts=2,
waitForSegOnStart=true, allResolversPassReq=true, segChkFreq=10000,
commSpi=TcpCommunicationSpi [connectGate=null,
connPlc=org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi$FirstConnectionPolicy@604f2bd2,
chConnPlc=null, 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@1d3ac898[Count = 1],
stopping=false, metricsLsnr=null],
evtSpi=org.apache.ignite.spi.eventstorage.NoopEventStorageSpi@1b73be9f,
colSpi=NoopCollisionSpi [], deploySpi=LocalDeploymentSpi [],
indexingSpi=org.apache.ignite.spi.indexing.noop.NoopIndexingSpi@366ac49b,
addrRslvr=null,
encryptionSpi=org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi@6ad59d92,
clientMode=false, rebalanceThreadPoolSize=4, rebalanceTimeout=10000,
rebalanceBatchesPrefetchCnt=3, rebalanceThrottle=0,
rebalanceBatchSize=524288, txCfg=TransactionConfiguration
[txSerEnabled=false, dfltIsolation=REPEATABLE_READ,
dfltConcurrency=PESSIMISTIC, dfltTxTimeout=0,
txTimeoutOnPartitionMapExchange=0, deadlockTimeout=10000,
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=PlatformConfiguration [], binaryCfg=BinaryConfiguration
[idMapper=BinaryBaseIdMapper [isLowerCase=true],
nameMapper=BinaryBaseNameMapper [isSimpleName=true], serializer=null,
compactFooter=false], memCfg=null, pstCfg=null,
dsCfg=DataStorageConfiguration [sysRegionInitSize=41943040,
sysRegionMaxSize=104857600, pageSize=0, concLvl=0,
dfltDataRegConf=DataRegionConfiguration [name=default, maxSize=3390213324,
initSize=268435456, swapPath=null, pageEvictionMode=DISABLED,
evictionThreshold=0.9, emptyPagesPoolSize=100, metricsEnabled=false,
metricsSubIntervalCount=5, metricsRateTimeInterval=60000,
persistenceEnabled=false, checkpointPageBufSize=0,
lazyMemoryAllocation=true], dataRegions=null, storagePath=null,
checkpointFreq=180000, lockWaitTime=10000, checkpointThreads=4,
checkpointWriteOrder=SEQUENTIAL, walHistSize=20,
maxWalArchiveSize=1073741824, walSegments=10, walSegmentSize=67108864,
walPath=db/wal, walArchivePath=db/wal/archive, metricsEnabled=false,
walMode=LOG_ONLY, walTlbSize=131072, walBuffSize=0, walFlushFreq=2000,
walFsyncDelay=1000, walRecordIterBuffSize=67108864,
alwaysWriteFullPages=false,
fileIOFactory=org.apache.ignite.internal.processors.cache.persistence.file.AsyncFileIOFactory@6d23017e,
metricsSubIntervalCnt=5, metricsRateTimeInterval=60000,
walAutoArchiveAfterInactivity=-1, writeThrottlingEnabled=false,
walCompactionEnabled=false, walCompactionLevel=1,
checkpointReadLockTimeout=null, walPageCompression=DISABLED,
walPageCompressionLevel=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,
handshakeTimeout=10000, jdbcEnabled=true, odbcEnabled=true,
thinCliEnabled=true, sslEnabled=false, useIgniteSslCtxFactory=true,
sslClientAuth=false, sslCtxFactory=null, thinCliCfg=ThinClientConfiguration
[maxActiveTxPerConn=100]], mvccVacuumThreadCnt=2, mvccVacuumFreq=5000,
authEnabled=false, failureHnd=null, commFailureRslvr=null]
[07:20:41,367][INFO][main][IgniteKernal%myGrid] Daemon mode: off
[07:20:41,367][INFO][main][IgniteKernal%myGrid] OS: Windows 10 10.0 amd64
[07:20:41,368][INFO][main][IgniteKernal%myGrid] OS user: harte
[07:20:41,376][INFO][main][IgniteKernal%myGrid] PID: 37704
[07:20:41,378][INFO][main][IgniteKernal%myGrid] Language runtime: Java
Platform API Specification ver. 13
[07:20:41,378][INFO][main][IgniteKernal%myGrid] VM information: Java(TM) SE
Runtime Environment 13.0.2+8 Oracle Corporation Java HotSpot(TM) 64-Bit
Server VM 13.0.2+8
[07:20:41,378][INFO][main][IgniteKernal%myGrid] VM total memory: 1.0GB
[07:20:41,379][INFO][main][IgniteKernal%myGrid] Remote Management [restart:
off, REST: on, JMX (remote: off)]
[07:20:41,379][INFO][main][IgniteKernal%myGrid] Logger: JavaLogger
[quiet=true, config=null]
[07:20:41,379][INFO][main][IgniteKernal%myGrid]
IGNITE_HOME=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin
[07:20:41,379][INFO][main][IgniteKernal%myGrid] VM arguments:
[-DIGNITE_HOME=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin,
-Xms512m, -Xmx1024m, -Dfile.encoding=UTF-8,
--add-exports=java.base/jdk.internal.misc=ALL-UNNAMED,
--add-exports=java.base/sun.nio.ch=ALL-UNNAMED,
--add-exports=java.management/com.sun.jmx.mbeanserver=ALL-UNNAMED,
--add-exports=jdk.internal.jvmstat/sun.jvmstat.monitor=ALL-UNNAMED,
--add-exports=java.base/sun.reflect.generics.reflectiveObjects=ALL-UNNAMED,
--illegal-access=permit]
[07:20:41,379][INFO][main][IgniteKernal%myGrid] System cache's DataRegion
size is configured to 40 MB. Use
DataStorageConfiguration.systemRegionInitialSize property to change the
setting.
[07:20:41,379][INFO][main][IgniteKernal%myGrid] Configured caches [in
'sysMemPlc' dataRegion: ['ignite-sys-cache']]
[07:20:41,379][WARNING][main][IgniteKernal%myGrid] Peer class loading is
enabled (disable it in production for performance and deployment
consistency reasons)
[07:20:41,379][WARNING][main][IgniteKernal%myGrid] Please set system
property '-Djava.net.preferIPv4Stack=true' to avoid possible problems in
mixed environments.
[07:20:41,381][WARNING][pub-#19%myGrid%][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.
[07:20:41,386][INFO][main][IgniteKernal%myGrid] 3-rd party licenses can be
found at:
C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\libs\licenses
[07:20:41,447][INFO][main][IgnitePluginProcessor] Configured plugins:
[07:20:41,449][INFO][main][IgnitePluginProcessor]   ^-- None
[07:20:41,449][INFO][main][IgnitePluginProcessor]
[07:20:41,452][INFO][main][FailureProcessor] Configured failure handler:
[hnd=StopNodeOrHaltFailureHandler [tryStop=false, timeout=0,
super=AbstractFailureHandler [ignoredFailureTypes=UnmodifiableSet
[SYSTEM_WORKER_BLOCKED, SYSTEM_CRITICAL_OPERATION_TIMEOUT]]]]
[07:20:41,641][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]
[07:20:41,737][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.
[07:20:41,749][WARNING][main][NoopCheckpointSpi] Checkpoints are disabled
(to enable configure any GridCheckpointSpi implementation)
[07:20:41,764][WARNING][main][GridCollisionManager] Collision resolution is
disabled (all jobs will be activated upon arrival).
[07:20:41,767][INFO][main][IgniteKernal%myGrid] Security status
[authentication=off, tls/ssl=off]
[07:20:41,959][INFO][main][TcpDiscoverySpi] Successfully bound to TCP port
[port=47501, localHost=0.0.0.0/0.0.0.0,
locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af]
[07:20:41,984][WARNING][main][IgniteCacheDatabaseSharedManager]
DataRegionConfiguration.maxWalArchiveSize instead
DataRegionConfiguration.walHistorySize would be used for removing old
archive wal files
[07:20:41,992][INFO][main][IgniteCacheDatabaseSharedManager] Configured
data regions initialized successfully [total=3]
[07:20:42,006][INFO][main][PartitionsEvictManager] Evict partition permits=2
[07:20:42,054][WARNING][main][IgniteH2Indexing] Serialization of Java
objects in H2 was enabled.
[07:20:42,221][INFO][main][ClientListenerProcessor] Client connector
processor has started on TCP port 10801
[07:20:42,281][INFO][main][GridTcpRestProtocol] Command protocol
successfully started [name=TCP binary, host=0.0.0.0/0.0.0.0, port=11212]
[07:20:42,311][WARNING][main][PlatformProcessorImpl] Binary configuration
is automatically initiated, note that binary name mapper is set to
BinaryBaseNameMapper [isSimpleName=true] and binary ID mapper is set to
BinaryBaseIdMapper [isLowerCase=true] (other nodes must have the same
binary name and ID mapper types).
[07:20:42,713][INFO][main][IgniteKernal%myGrid] Non-loopback local IPs:
192.168.0.2, 2600:8801:3600:3820:98c8:6653:241f:8982,
2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0,
fe80:0:0:0:682b:8974:4c86:a81b%wlan0, fe80:0:0:0:75b1:a90f:8fd6:31f9%wlan1,
fe80:0:0:0:a0b7:294a:aa3a:41c1%eth3, fe80:0:0:0:e8d2:2fe9:d844:de7e%eth5,
fe80:0:0:0:ecb2:ebd5:7bfc:ecd0%wlan2
[07:20:42,713][INFO][main][IgniteKernal%myGrid] Enabled local MACs:
287FCFBB82D0, 287FCFBB82D1, 287FCFBB82D4, 2A7FCFBB82D0, E8D8D1443071
[07:20:42,736][INFO][main][TcpDiscoverySpi] Connection check threshold is
calculated: 10000
[07:20:47,186][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
TCP discovery accepted incoming connection
[rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982, rmtPort=62659]
[07:20:47,192][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
TCP discovery spawning a new thread for connection
[rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982, rmtPort=62659]
[07:20:47,192][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
Started serving remote node connection
[rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659]
[07:20:47,194][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
Received ping request from the remote node
[rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659]
[07:20:47,195][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
Finished writing ping response
[rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659]
[07:20:47,195][INFO][tcp-disco-sock-reader-[]-#10%myGrid%][TcpDiscoverySpi]
Finished serving remote node connection
[rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62659, rmtPort=62659
[07:20:47,203][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
TCP discovery accepted incoming connection [rmtAddr=/0:0:0:0:0:0:0:1,
rmtPort=62660]
[07:20:47,203][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
TCP discovery spawning a new thread for connection
[rmtAddr=/0:0:0:0:0:0:0:1, rmtPort=62660]
[07:20:47,204][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
Started serving remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62660,
rmtPort=62660]
[07:20:47,205][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
Received ping request from the remote node
[rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
rmtAddr=/0:0:0:0:0:0:0:1:62660, rmtPort=62660]
[07:20:47,205][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
Finished writing ping response
[rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
rmtAddr=/0:0:0:0:0:0:0:1:62660, rmtPort=62660]
[07:20:47,205][INFO][tcp-disco-sock-reader-[]-#11%myGrid%][TcpDiscoverySpi]
Finished serving remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62660,
rmtPort=62660
[07:20:47,207][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
TCP discovery accepted incoming connection [rmtAddr=/0:0:0:0:0:0:0:1,
rmtPort=62661]
[07:20:47,208][INFO][tcp-disco-srvr-[:47501]-#3%myGrid%][TcpDiscoverySpi]
TCP discovery spawning a new thread for connection
[rmtAddr=/0:0:0:0:0:0:0:1, rmtPort=62661]
[07:20:47,208][INFO][tcp-disco-sock-reader-[]-#12%myGrid%][TcpDiscoverySpi]
Started serving remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62661,
rmtPort=62661]
[07:20:47,210][INFO][tcp-disco-sock-reader-[db4efc6e
0:0:0:0:0:0:0:1:62661]-#12%myGrid%][TcpDiscoverySpi] Initialized connection
with remote server node [nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
rmtAddr=/0:0:0:0:0:0:0:1:62661]
[07:20:47,213][SEVERE][main][IgniteKernal%myGrid] Failed to start manager:
GridManagerAdapter [enabled=true,
name=o.a.i.i.managers.discovery.GridDiscoveryManager]
class org.apache.ignite.IgniteCheckedException: Failed to start SPI:
TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
marsh=JdkMarshaller
[clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@72825400],
reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
skipAddrsRandomization=false]
at
org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
at
org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
at
org.apache.ignite.internal.IgniteKernal.startManager(IgniteKernal.java:1960)
at org.apache.ignite.internal.IgniteKernal.start(IgniteKernal.java:1276)
at
org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start0(IgnitionEx.java:2038)
at
org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start(IgnitionEx.java:1703)
at org.apache.ignite.internal.IgnitionEx.start0(IgnitionEx.java:1117)
at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:615)
at
org.apache.ignite.internal.processors.platform.PlatformAbstractBootstrap.start(PlatformAbstractBootstrap.java:43)
at
org.apache.ignite.internal.processors.platform.PlatformIgnition.start(PlatformIgnition.java:74)
Caused by: class org.apache.ignite.spi.IgniteSpiException: Local node's
binary configuration is not equal to remote node's binary configuration
[locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
locBinaryCfg={globIdMapper=org.apache.ignite.binary.BinaryBasicIdMapper,
compactFooter=false, globSerializer=null}, rmtBinaryCfg=null]
at
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.checkFailedError(TcpDiscoverySpi.java:1997)
at
org.apache.ignite.spi.discovery.tcp.ServerImpl.joinTopology(ServerImpl.java:1116)
at
org.apache.ignite.spi.discovery.tcp.ServerImpl.spiStart(ServerImpl.java:427)
at
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.spiStart(TcpDiscoverySpi.java:2099)
at
org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:297)
... 9 more
[07:20:47,214][INFO][tcp-disco-sock-reader-[db4efc6e
0:0:0:0:0:0:0:1:62661]-#12%myGrid%][TcpDiscoverySpi] Finished serving
remote node connection [rmtAddr=/0:0:0:0:0:0:0:1:62661, rmtPort=62661
[07:20:47,214][SEVERE][main][IgniteKernal%myGrid] Got exception while
starting (will rollback startup routine).
class org.apache.ignite.IgniteCheckedException: Failed to start manager:
GridManagerAdapter [enabled=true,
name=org.apache.ignite.internal.managers.discovery.GridDiscoveryManager]
at
org.apache.ignite.internal.IgniteKernal.startManager(IgniteKernal.java:1965)
at org.apache.ignite.internal.IgniteKernal.start(IgniteKernal.java:1276)
at
org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start0(IgnitionEx.java:2038)
at
org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start(IgnitionEx.java:1703)
at org.apache.ignite.internal.IgnitionEx.start0(IgnitionEx.java:1117)
at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:615)
at
org.apache.ignite.internal.processors.platform.PlatformAbstractBootstrap.start(PlatformAbstractBootstrap.java:43)
at
org.apache.ignite.internal.processors.platform.PlatformIgnition.start(PlatformIgnition.java:74)
Caused by: class org.apache.ignite.IgniteCheckedException: Failed to start
SPI: TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
marsh=JdkMarshaller
[clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@72825400],
reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
skipAddrsRandomization=false]
at
org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
at
org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
at
org.apache.ignite.internal.IgniteKernal.startManager(IgniteKernal.java:1960)
... 7 more
Caused by: class org.apache.ignite.spi.IgniteSpiException: Local node's
binary configuration is not equal to remote node's binary configuration
[locNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
rmtNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
locBinaryCfg={globIdMapper=org.apache.ignite.binary.BinaryBasicIdMapper,
compactFooter=false, globSerializer=null}, rmtBinaryCfg=null]
at
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.checkFailedError(TcpDiscoverySpi.java:1997)
at
org.apache.ignite.spi.discovery.tcp.ServerImpl.joinTopology(ServerImpl.java:1116)
at
org.apache.ignite.spi.discovery.tcp.ServerImpl.spiStart(ServerImpl.java:427)
at
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi.spiStart(TcpDiscoverySpi.java:2099)
at
org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:297)
... 9 more
[07:20:47,228][INFO][main][GridTcpRestProtocol] Command protocol
successfully stopped: TCP binary
[07:20:52,235][INFO][main][TcpDiscoverySpi] No verification for local node
leave has been received from coordinator (will stop node anyway).
[07:20:52,245][INFO][main][IgniteKernal%myGrid]

>>>
+---------------------------------------------------------------------------------+
>>> Ignite ver.
2.8.0#20200226-sha1:341b01dfd8abf2d9b01d468ad1bb26dfe84ac4f6 stopped OK
>>>
+---------------------------------------------------------------------------------+
>>> Ignite instance name: myGrid
>>> Grid uptime: 00:00:11.528



And Java Side:
[2020-04-03 07:20:16,818][WARN ][main][G] Ignite work directory is not
provided, automatically resolved to:
C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work
[2020-04-03 07:20:16,993][INFO ][main][IgniteKernal]

>>>    __________  ________________
>>>   /  _/ ___/ |/ /  _/_  __/ __/
>>>  _/ // (7 7    // /  / / / _/
>>> /___/\___/_/|_/___/ /_/ /___/
>>>
>>> ver. 2.8.0#20200226-sha1:341b01df
>>> 2020 Copyright(C) Apache Software Foundation
>>>
>>> Ignite documentation: http://ignite.apache.org

[2020-04-03 07:20:17,002][INFO ][main][IgniteKernal] Config URL:
file:/C:/Users/harte/Desktop/work/apache-ignite-2.8.0-bin-try/apache-ignite-2.8.0-bin/examples/config/example-ignite.xml
[2020-04-03 07:20:17,021][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,
sqlQryHistSize=1000, dfltQryTimeout=0,
igniteHome=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin,
igniteWorkDir=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\work,
mbeanSrv=com.sun.jmx.mbeanserver.JmxMBeanServer@7d9e8ef7,
nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448, marsh=BinaryMarshaller [],
marshLocJobs=false, daemon=false, p2pEnabled=true, netTimeout=5000,
netCompressionLevel=1, 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, soLinger=5, forceSrvMode=false,
clientReconnectDisabled=false, internalLsnr=null,
skipAddrsRandomization=false], segPlc=STOP, segResolveAttempts=2,
waitForSegOnStart=true, allResolversPassReq=true, segChkFreq=10000,
commSpi=TcpCommunicationSpi [connectGate=null,
connPlc=org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi$FirstConnectionPolicy@4b7e96a,
chConnPlc=null, 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@6475472c[Count = 1],
stopping=false, metricsLsnr=null],
evtSpi=org.apache.ignite.spi.eventstorage.NoopEventStorageSpi@3f07b12c,
colSpi=NoopCollisionSpi [], deploySpi=LocalDeploymentSpi [],
indexingSpi=org.apache.ignite.spi.indexing.noop.NoopIndexingSpi@784b990c,
addrRslvr=null,
encryptionSpi=org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi@3d3ba765,
clientMode=false, rebalanceThreadPoolSize=4, rebalanceTimeout=10000,
rebalanceBatchesPrefetchCnt=3, rebalanceThrottle=0,
rebalanceBatchSize=524288, txCfg=TransactionConfiguration
[txSerEnabled=false, dfltIsolation=REPEATABLE_READ,
dfltConcurrency=PESSIMISTIC, dfltTxTimeout=0,
txTimeoutOnPartitionMapExchange=0, deadlockTimeout=10000,
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=DataStorageConfiguration [sysRegionInitSize=41943040,
sysRegionMaxSize=104857600, pageSize=0, concLvl=0,
dfltDataRegConf=DataRegionConfiguration [name=default, maxSize=3390213324,
initSize=268435456, swapPath=null, pageEvictionMode=DISABLED,
evictionThreshold=0.9, emptyPagesPoolSize=100, metricsEnabled=false,
metricsSubIntervalCount=5, metricsRateTimeInterval=60000,
persistenceEnabled=false, checkpointPageBufSize=0,
lazyMemoryAllocation=true], dataRegions=null, storagePath=null,
checkpointFreq=180000, lockWaitTime=10000, checkpointThreads=4,
checkpointWriteOrder=SEQUENTIAL, walHistSize=20,
maxWalArchiveSize=1073741824, walSegments=10, walSegmentSize=67108864,
walPath=db/wal, walArchivePath=db/wal/archive, metricsEnabled=false,
walMode=LOG_ONLY, walTlbSize=131072, walBuffSize=0, walFlushFreq=2000,
walFsyncDelay=1000, walRecordIterBuffSize=67108864,
alwaysWriteFullPages=false,
fileIOFactory=org.apache.ignite.internal.processors.cache.persistence.file.AsyncFileIOFactory@758a34ce,
metricsSubIntervalCnt=5, metricsRateTimeInterval=60000,
walAutoArchiveAfterInactivity=-1, writeThrottlingEnabled=false,
walCompactionEnabled=false, walCompactionLevel=1,
checkpointReadLockTimeout=null, walPageCompression=DISABLED,
walPageCompressionLevel=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,
handshakeTimeout=10000, jdbcEnabled=true, odbcEnabled=true,
thinCliEnabled=true, sslEnabled=false, useIgniteSslCtxFactory=true,
sslClientAuth=false, sslCtxFactory=null, thinCliCfg=ThinClientConfiguration
[maxActiveTxPerConn=100]], mvccVacuumThreadCnt=2, mvccVacuumFreq=5000,
authEnabled=false, failureHnd=null, commFailureRslvr=null]
[2020-04-03 07:20:17,021][INFO ][main][IgniteKernal] Daemon mode: off
[2020-04-03 07:20:17,021][INFO ][main][IgniteKernal] OS: Windows 10 10.0
amd64
[2020-04-03 07:20:17,021][INFO ][main][IgniteKernal] OS user: harte
[2020-04-03 07:20:17,032][INFO ][main][IgniteKernal] PID: 38064
[2020-04-03 07:20:17,033][INFO ][main][IgniteKernal] Language runtime: Java
Platform API Specification ver. 13
[2020-04-03 07:20:17,033][INFO ][main][IgniteKernal] VM information:
Java(TM) SE Runtime Environment 13.0.2+8 Oracle Corporation Java
HotSpot(TM) 64-Bit Server VM 13.0.2+8
[2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] VM total memory: 3.9GB
[2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] Remote Management
[restart: off, REST: on, JMX (remote: off)]
[2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] Logger: Log4JLogger
[quiet=true,
config=/C:/Users/harte/Desktop/work/apache-ignite-2.8.0-bin-try/apache-ignite-2.8.0-bin/config/ignite-log4j.xml]
[2020-04-03 07:20:17,034][INFO ][main][IgniteKernal]
IGNITE_HOME=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin
[2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] VM arguments:
[--add-exports=java.base/jdk.internal.misc=ALL-UNNAMED,
--add-exports=java.base/sun.nio.ch=ALL-UNNAMED,
--add-exports=java.management/com.sun.jmx.mbeanserver=ALL-UNNAMED,
--add-exports=jdk.internal.jvmstat/sun.jvmstat.monitor=ALL-UNNAMED,
--add-exports=java.base/sun.reflect.generics.reflectiveObjects=ALL-UNNAMED,
--illegal-access=permit,
-Djava.library.path=C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\examples\src\main\java\org\apache\ignite\examples\datagrid,
-javaagent:C:\Program Files\JetBrains\IntelliJ IDEA Community Edition
2019.3.2\lib\idea_rt.jar=62570:C:\Program Files\JetBrains\IntelliJ IDEA
Community Edition 2019.3.2\bin, -Dfile.encoding=UTF-8]
[2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] System cache's
DataRegion size is configured to 40 MB. Use
DataStorageConfiguration.systemRegionInitialSize property to change the
setting.
[2020-04-03 07:20:17,034][INFO ][main][IgniteKernal] Configured caches [in
'sysMemPlc' dataRegion: ['ignite-sys-cache']]
[2020-04-03 07:20:17,034][WARN ][main][IgniteKernal] Peer class loading is
enabled (disable it in production for performance and deployment
consistency reasons)
[2020-04-03 07:20:17,035][WARN ][main][IgniteKernal] Please set system
property '-Djava.net.preferIPv4Stack=true' to avoid possible problems in
mixed environments.
[2020-04-03 07:20:17,038][INFO ][main][IgniteKernal] 3-rd party licenses
can be found at:
C:\Users\harte\Desktop\work\apache-ignite-2.8.0-bin-try\apache-ignite-2.8.0-bin\libs\licenses
[2020-04-03 07:20:17,038][WARN ][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.
[2020-04-03 07:20:17,044][WARN ][pub-#22][GridDiagnostic] Initial heap size
is 254MB (should be no less than 512MB, use -Xms512m -Xmx512m).
[2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor] Configured
plugins:
[2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor]   ^--
ml-inference-plugin 1.0.0
[2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor]   ^-- null
[2020-04-03 07:20:17,133][INFO ][main][IgnitePluginProcessor]
[2020-04-03 07:20:17,135][INFO ][main][FailureProcessor] Configured failure
handler: [hnd=StopNodeOrHaltFailureHandler [tryStop=false, timeout=0,
super=AbstractFailureHandler [ignoredFailureTypes=UnmodifiableSet
[SYSTEM_WORKER_BLOCKED, SYSTEM_CRITICAL_OPERATION_TIMEOUT]]]]
[2020-04-03 07:20:17,350][INFO ][main][TcpCommunicationSpi] Successfully
bound communication NIO server to TCP port [port=47100, locHost=
0.0.0.0/0.0.0.0, selectorsCnt=4, selectorSpins=0, pairedConn=false]
[2020-04-03 07:20:17,441][WARN ][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.
[2020-04-03 07:20:17,452][WARN ][main][NoopCheckpointSpi] Checkpoints are
disabled (to enable configure any GridCheckpointSpi implementation)
[2020-04-03 07:20:17,467][WARN ][main][GridCollisionManager] Collision
resolution is disabled (all jobs will be activated upon arrival).
[2020-04-03 07:20:17,469][INFO ][main][IgniteKernal] Security status
[authentication=off, tls/ssl=off]
[2020-04-03 07:20:17,637][INFO ][main][TcpDiscoverySpi] Successfully bound
to TCP port [port=47500, localHost=0.0.0.0/0.0.0.0,
locNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448]
[2020-04-03 07:20:17,662][WARN ][main][IgniteCacheDatabaseSharedManager]
DataRegionConfiguration.maxWalArchiveSize instead
DataRegionConfiguration.walHistorySize would be used for removing old
archive wal files
[2020-04-03 07:20:17,672][INFO ][main][IgniteCacheDatabaseSharedManager]
Configured data regions initialized successfully [total=3]
[2020-04-03 07:20:17,686][INFO ][main][PartitionsEvictManager] Evict
partition permits=2
[2020-04-03 07:20:17,731][WARN ][main][IgniteH2Indexing] Serialization of
Java objects in H2 was enabled.
[2020-04-03 07:20:17,877][INFO ][main][ClientListenerProcessor] Client
connector processor has started on TCP port 10800
[2020-04-03 07:20:17,917][INFO ][main][GridTcpRestProtocol] Command
protocol successfully started [name=TCP binary, host=0.0.0.0/0.0.0.0,
port=11211]
[2020-04-03 07:20:18,207][INFO ][main][IgniteKernal] Non-loopback local
IPs: 192.168.0.2, 2600:8801:3600:3820:98c8:6653:241f:8982,
2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0,
fe80:0:0:0:682b:8974:4c86:a81b%wlan0, fe80:0:0:0:75b1:a90f:8fd6:31f9%wlan1,
fe80:0:0:0:a0b7:294a:aa3a:41c1%eth3, fe80:0:0:0:e8d2:2fe9:d844:de7e%eth5,
fe80:0:0:0:ecb2:ebd5:7bfc:ecd0%wlan2
[2020-04-03 07:20:18,207][INFO ][main][IgniteKernal] Enabled local MACs:
287FCFBB82D0, 287FCFBB82D1, 287FCFBB82D4, 2A7FCFBB82D0, E8D8D1443071
[2020-04-03 07:20:18,223][INFO ][main][TcpDiscoverySpi] Connection check
threshold is calculated: 10000
[2020-04-03 07:20:38,531][INFO
][disco-notifier-worker-#41][GridClusterStateProcessor] Received activate
request with BaselineTopology[id=0]
[2020-04-03 07:20:38,531][INFO
][disco-notifier-worker-#41][GridClusterStateProcessor] Started state
transition: true
[2020-04-03 07:20:38,532][INFO
][disco-notifier-worker-#41][GridClusterStateProcessor] Received state
change finish message: true
[2020-04-03 07:20:38,533][INFO
][disco-notifier-worker-#41][MvccProcessorImpl] Assigned mvcc coordinator
[crd=MvccCoordinator [topVer=AffinityTopologyVersion [topVer=1,
minorTopVer=0], nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
ver=1585923638519, local=true, initialized=false]]
[2020-04-03 07:20:38,563][INFO
][disco-notifier-worker-#41][DistributedBaselineConfiguration] Baseline
parameter 'baselineAutoAdjustEnabled' was changed from 'null' to 'true'
[2020-04-03 07:20:38,566][INFO
][disco-notifier-worker-#41][DistributedBaselineConfiguration] Baseline
parameter 'baselineAutoAdjustTimeout' was changed from 'null' to '0'
[2020-04-03 07:20:38,587][INFO ][exchange-worker-#43][time] Started
exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
crd=true, evt=NODE_JOINED, evtNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
customEvt=null, allowMerge=false, exchangeFreeSwitch=false]
[2020-04-03 07:20:38,603][INFO
][exchange-worker-#43][IgniteCacheDatabaseSharedManager] Configured data
regions started successfully [total=3]
[2020-04-03 07:20:38,604][INFO ][exchange-worker-#43][msg] Components
activation performed in 17 ms.
[2020-04-03 07:20:38,729][INFO ][exchange-worker-#43][GridCacheProcessor]
Started cache [name=ignite-sys-cache, id=-2100569601,
dataRegionName=sysMemPlc, mode=REPLICATED, atomicity=TRANSACTIONAL,
backups=2147483647, mvcc=false]
[2020-04-03 07:20:38,730][INFO ][exchange-worker-#43][GridCacheProcessor]
Starting caches on local join performed in 127 ms.
[2020-04-03 07:20:38,740][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Skipped waiting for
partitions release future (local node is joining)
[topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0]]
[2020-04-03 07:20:38,790][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture]
finishExchangeOnCoordinator [topVer=AffinityTopologyVersion [topVer=1,
minorTopVer=0], resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0]]
[2020-04-03 07:20:38,803][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finish exchange
future [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], err=null,
rebalanced=true, wasRebalanced=false]
[2020-04-03 07:20:38,815][INFO ][exchange-worker-#43][GridCacheProcessor]
Finish proxy initialization, cacheName=ignite-sys-cache,
localNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448
[2020-04-03 07:20:38,816][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Completed partition
exchange [localNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
exchange=GridDhtPartitionsExchangeFuture [topVer=AffinityTopologyVersion
[topVer=1, minorTopVer=0], evt=NODE_JOINED, evtNode=TcpDiscoveryNode
[id=db4efc6e-44c7-46ce-b7c0-154e387c0448,
consistentId=0:0:0:0:0:0:0:1,127.0.0.1,192.168.0.2,2600:8801:3600:3820:98c8:6653:241f:8982,2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500,
addrs=ArrayList [0:0:0:0:0:0:0:1, 127.0.0.1, 192.168.0.2,
2600:8801:3600:3820:98c8:6653:241f:8982,
2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0], sockAddrs=HashSet
[/2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500, /0:0:0:0:0:0:0:1:47500, /
127.0.0.1:47500, /2600:8801:3600:3820:98c8:6653:241f:8982:47500,
LAPTOP-MUM8SQ8C/192.168.0.2:47500], discPort=47500, order=1, intOrder=1,
lastExchangeTime=1585923618219, loc=true, ver=2.8.0#20200226-sha1:341b01df,
isClient=false], done=true, newCrdFut=null], topVer=AffinityTopologyVersion
[topVer=1, minorTopVer=0]]
[2020-04-03 07:20:38,816][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange timings
[startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], stage="Waiting in
exchange queue" (42 ms), stage="Exchange parameters initialization" (1 ms),
stage="Components activation" (16 ms), stage="Determine exchange type" (135
ms), stage="Preloading notification" (0 ms), stage="WAL history
reservation" (0 ms), stage="After states restored callback" (49 ms),
stage="Waiting for all single messages" (0 ms), stage="Affinity
recalculation (crd)" (0 ms), stage="Collect update counters and create
affinity messages" (0 ms), stage="Validate partitions states" (2 ms),
stage="Assign partitions states" (0 ms), stage="Apply update counters" (0
ms), stage="Full message preparing" (8 ms), stage="Full message sending" (0
ms), stage="State finish message sending" (0 ms), stage="Exchange done" (12
ms), stage="Total time" (265 ms)]
[2020-04-03 07:20:38,816][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange longest
local stages [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
resVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
stage="Coordinator affinity cache init [grp=ignite-sys-cache]" (129 ms)
(parent=Determine exchange type), stage="First node affinity initialization
(node join) [grp=ignite-sys-cache]" (4 ms) (parent=Determine exchange type)]
[2020-04-03 07:20:38,817][INFO ][exchange-worker-#43][time] Finished
exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0],
crd=true]
[2020-04-03 07:20:38,819][INFO
][exchange-worker-#43][GridCachePartitionExchangeManager] Skipping
rebalancing (nothing scheduled) [top=AffinityTopologyVersion [topVer=1,
minorTopVer=0], force=false, evt=NODE_JOINED,
node=db4efc6e-44c7-46ce-b7c0-154e387c0448]
[2020-04-03 07:20:38,867][INFO ][main][IgniteKernal] Performance
suggestions for grid  (fix if possible)
[2020-04-03 07:20:38,867][INFO ][main][IgniteKernal] To disable, set
-DIGNITE_PERFORMANCE_SUGGESTIONS_DISABLED=true
[2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Disable grid
events (remove 'includeEventTypes' from configuration)
[2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Switch to the
most recent 1.8 JVM version
[2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Specify JVM heap
max size (add '-Xmx<size>[g|G|m|M|k|K]' to JVM options)
[2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Set max direct
memory size if getting 'OOME: Direct buffer memory' (add
'-XX:MaxDirectMemorySize=<size>[g|G|m|M|k|K]' to JVM options)
[2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]   ^-- Disable
processing of calls to System.gc() (add '-XX:+DisableExplicitGC' to JVM
options)
[2020-04-03 07:20:38,867][INFO ][main][IgniteKernal] Refer to this page for
more performance suggestions:
https://apacheignite.readme.io/docs/jvm-and-system-tuning
[2020-04-03 07:20:38,867][INFO ][main][IgniteKernal]
[2020-04-03 07:20:38,868][INFO ][main][IgniteKernal] To start Console
Management & Monitoring run ignitevisorcmd.{sh|bat}
[2020-04-03 07:20:38,870][INFO ][main][IgniteKernal] Data Regions
Configured:
[2020-04-03 07:20:38,870][INFO ][main][IgniteKernal]   ^-- default
[initSize=256.0 MiB, maxSize=3.2 GiB, persistence=false,
lazyMemoryAllocation=true]
[2020-04-03 07:20:38,871][INFO ][main][IgniteKernal]

>>> +----------------------------------------------------------------------+
>>> Ignite ver. 2.8.0#20200226-sha1:341b01dfd8abf2d9b01d468ad1bb26dfe84ac4f6
>>> +----------------------------------------------------------------------+
>>> OS name: Windows 10 10.0 amd64
>>> CPU(s): 8
>>> Heap: 3.9GB
>>> VM name: 38064@LAPTOP-MUM8SQ8C
>>> Local node [ID=DB4EFC6E-44C7-46CE-B7C0-154E387C0448, order=1,
clientMode=false]
>>> Local node addresses: [LAPTOP-MUM8SQ8C/0:0:0:0:0:0:0:1, LAPTOP-MUM8SQ8C/
127.0.0.1, LAPTOP-MUM8SQ8C/192.168.0.2,
/2600:8801:3600:3820:98c8:6653:241f:8982,
/2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0]
>>> Local ports: TCP:10800 TCP:11211 TCP:47100 UDP:47400 TCP:47500

[2020-04-03 07:20:38,874][INFO ][main][GridDiscoveryManager] Topology
snapshot [ver=1, locNode=db4efc6e, servers=1, clients=0, state=ACTIVE,
CPUs=8, offheap=3.2GB, heap=3.9GB]
[2020-04-03 07:20:38,874][INFO ][main][GridDiscoveryManager]   ^-- Baseline
[id=0, size=1, online=1, offline=0]
[2020-04-03 07:20:38,874][INFO ][main][G] Node started : [stage="Configure
system pool" (66 ms),stage="Start managers" (502 ms),stage="Configure
binary metadata" (40 ms),stage="Start processors" (416 ms),stage="Start
'ml-inference-plugin' plugin" (0 ms),stage="Init metastore" (271
ms),stage="Finish recovery" (0 ms),stage="Join topology" (20318
ms),stage="Await transition" (17 ms),stage="Await exchange" (323
ms),stage="Total time" (21953 ms)]
[2020-04-03 07:20:38,889][INFO ][exchange-worker-#43][time] Started
exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
crd=true, evt=DISCOVERY_CUSTOM_EVT,
evtNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
customEvt=DynamicCacheChangeBatch
[id=e9de9604171-03f8bb55-f219-4232-903a-6af839413db6, reqs=ArrayList
[DynamicCacheChangeRequest [cacheName=myCache, hasCfg=true,
nodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448, clientStartOnly=false,
stop=false, destroy=false, disabledAfterStartfalse]],
exchangeActions=ExchangeActions [startCaches=[myCache], stopCaches=null,
startGrps=[myCache], stopGrps=[], resetParts=null,
stateChangeRequest=null], startCaches=false], allowMerge=false,
exchangeFreeSwitch=false]
[2020-04-03 07:20:38,915][INFO ][exchange-worker-#43][GridCacheProcessor]
Started cache [name=myCache, id=1482644790, dataRegionName=default,
mode=PARTITIONED, atomicity=ATOMIC, backups=0, mvcc=false]
[2020-04-03 07:20:38,928][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finished waiting
for partition release future [topVer=AffinityTopologyVersion [topVer=1,
minorTopVer=1], waitTime=0ms, futInfo=NA, mode=DISTRIBUTED]
[2020-04-03 07:20:38,930][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finished waiting
for partitions release latch: ServerLatch [permits=0, pendingAcks=HashSet
[], super=CompletableLatch [id=CompletableLatchUid [id=exchange,
topVer=AffinityTopologyVersion [topVer=1, minorTopVer=1]]]]
[2020-04-03 07:20:38,930][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finished waiting
for partition release future [topVer=AffinityTopologyVersion [topVer=1,
minorTopVer=1], waitTime=0ms, futInfo=NA, mode=LOCAL]
[2020-04-03 07:20:38,987][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture]
finishExchangeOnCoordinator [topVer=AffinityTopologyVersion [topVer=1,
minorTopVer=1], resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1]]
[2020-04-03 07:20:39,004][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Finish exchange
future [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1], err=null,
rebalanced=true, wasRebalanced=true]
[2020-04-03 07:20:39,008][INFO ][exchange-worker-#43][GridCacheProcessor]
Finish proxy initialization, cacheName=myCache,
localNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448
[2020-04-03 07:20:39,009][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Completed partition
exchange [localNode=db4efc6e-44c7-46ce-b7c0-154e387c0448,
exchange=GridDhtPartitionsExchangeFuture [topVer=AffinityTopologyVersion
[topVer=1, minorTopVer=1], evt=DISCOVERY_CUSTOM_EVT,
evtNode=TcpDiscoveryNode [id=db4efc6e-44c7-46ce-b7c0-154e387c0448,
consistentId=0:0:0:0:0:0:0:1,127.0.0.1,192.168.0.2,2600:8801:3600:3820:98c8:6653:241f:8982,2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500,
addrs=ArrayList [0:0:0:0:0:0:0:1, 127.0.0.1, 192.168.0.2,
2600:8801:3600:3820:98c8:6653:241f:8982,
2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0], sockAddrs=HashSet
[/2600:8801:3600:3820:ecb2:ebd5:7bfc:ecd0:47500, /0:0:0:0:0:0:0:1:47500, /
127.0.0.1:47500, /2600:8801:3600:3820:98c8:6653:241f:8982:47500,
LAPTOP-MUM8SQ8C/192.168.0.2:47500], discPort=47500, order=1, intOrder=1,
lastExchangeTime=1585923618219, loc=true, ver=2.8.0#20200226-sha1:341b01df,
isClient=false], done=true, newCrdFut=null], topVer=AffinityTopologyVersion
[topVer=1, minorTopVer=1]]
[2020-04-03 07:20:39,009][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange timings
[startVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1], stage="Waiting in
exchange queue" (0 ms), stage="Exchange parameters initialization" (1 ms),
stage="Update caches registry" (1 ms), stage="Start caches" (25 ms),
stage="Affinity initialization on cache group start" (6 ms),
stage="Determine exchange type" (0 ms), stage="Preloading notification" (0
ms), stage="WAL history reservation" (0 ms), stage="Wait partitions
release" (4 ms), stage="Wait partitions release latch" (1 ms), stage="Wait
partitions release" (0 ms), stage="After states restored callback" (50 ms),
stage="Waiting for all single messages" (6 ms), stage="Affinity
recalculation (crd)" (0 ms), stage="Collect update counters and create
affinity messages" (0 ms), stage="Validate partitions states" (1 ms),
stage="Assign partitions states" (0 ms), stage="Apply update counters" (2
ms), stage="Full message preparing" (10 ms), stage="Full message sending"
(0 ms), stage="Exchange done" (5 ms), stage="Total time" (112 ms)]
[2020-04-03 07:20:39,009][INFO
][exchange-worker-#43][GridDhtPartitionsExchangeFuture] Exchange longest
local stages [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
resVer=AffinityTopologyVersion [topVer=1, minorTopVer=1], stage="Affinity
initialization on cache group start [grp=myCache]" (6 ms) (parent=Affinity
initialization on cache group start)]
[2020-04-03 07:20:39,010][INFO ][exchange-worker-#43][time] Finished
exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=1],
crd=true]
[2020-04-03 07:20:39,014][INFO
][exchange-worker-#43][GridCachePartitionExchangeManager] Skipping
rebalancing (nothing scheduled) [top=AffinityTopologyVersion [topVer=1,
minorTopVer=1], force=false, evt=DISCOVERY_CUSTOM_EVT,
node=db4efc6e-44c7-46ce-b7c0-154e387c0448]
[2020-04-03 07:20:47,163][INFO
][tcp-disco-srvr-[:47500]-#3][TcpDiscoverySpi] TCP discovery accepted
incoming connection [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982,
rmtPort=62658]
[2020-04-03 07:20:47,167][INFO
][tcp-disco-srvr-[:47500]-#3][TcpDiscoverySpi] TCP discovery spawning a new
thread for connection [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982,
rmtPort=62658]
[2020-04-03 07:20:47,168][INFO
][tcp-disco-sock-reader-[]-#11][TcpDiscoverySpi] Started serving remote
node connection [rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62658,
rmtPort=62658]
[2020-04-03 07:20:47,172][INFO ][tcp-disco-sock-reader-[155424bd
2600:8801:3600:3820:98c8:6653:241f:8982:62658]-#11][TcpDiscoverySpi]
Initialized connection with remote server node
[nodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af,
rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62658]
[2020-04-03 07:20:47,196][INFO ][tcp-disco-sock-reader-[155424bd
2600:8801:3600:3820:98c8:6653:241f:8982:62658]-#11][TcpDiscoverySpi]
Finished serving remote node connection
[rmtAddr=/2600:8801:3600:3820:98c8:6653:241f:8982:62658, rmtPort=62658
[2020-04-03 07:20:47,201][INFO
][tcp-disco-msg-worker-[crd]-#2][GridEncryptionManager] Joining node
doesn't have encryption data [node=155424bd-1c8e-48a2-83ff-26aa6cf9e7af]
[2020-04-03 07:20:47,206][WARN ][disco-pool-#55][TcpDiscoverySpi] Local
node's binary configuration is not equal to remote node's binary
configuration [locNodeId=db4efc6e-44c7-46ce-b7c0-154e387c0448,
rmtNodeId=155424bd-1c8e-48a2-83ff-26aa6cf9e7af, locBinaryCfg=null,
rmtBinaryCfg={globIdMapper=o.a.i.binary.BinaryBasicIdMapper,
compactFooter=false, globSerializer=null}]
[2020-04-03 07:20:48,554][INFO
][ignite-update-notifier-timer][GridUpdateNotifier] Your version is up to
date.
[2020-04-03 07:21:38,869][INFO ][grid-timeout-worker-#23][IgniteKernal]
Metrics for local node (to disable set 'metricsLogFrequency' to 0)
    ^-- Node [id=db4efc6e, uptime=00:01:00.003]
    ^-- H/N/C [hosts=1, nodes=1, CPUs=8]
    ^-- CPU [cur=-100%, avg=-95.83%, GC=0%]
    ^-- PageMemory [pages=2252]
    ^-- Heap [used=43MB, free=98.92%, comm=87MB]
    ^-- Off-heap [used=8MB, free=99.74%, comm=336MB]
    ^--   sysMemPlc region [used=0MB, free=99.21%, comm=40MB]
    ^--   default region [used=8MB, free=99.75%, comm=256MB]
    ^--   TxLog region [used=0MB, free=100%, comm=40MB]
    ^-- Outbound messages queue [size=0]
    ^-- Public thread pool [active=0, idle=0, qSize=0]
    ^-- System thread pool [active=0, idle=8, qSize=0]
[2020-04-03 07:21:38,870][INFO ][grid-timeout-worker-#23][IgniteKernal]
FreeList [name=default##FreeList, buckets=256, dataPages=1, reusePages=0]
[2020-04-03 07:22:38,880][INFO ][grid-timeout-worker-#23][IgniteKernal]
Metrics for local node (to disable set 'metricsLogFrequency' to 0)
    ^-- Node [id=db4efc6e, uptime=00:02:00.022]
    ^-- H/N/C [hosts=1, nodes=1, CPUs=8]
    ^-- CPU [cur=-100%, avg=-97.87%, GC=0%]
    ^-- PageMemory [pages=2252]
    ^-- Heap [used=46MB, free=98.85%, comm=87MB]
    ^-- Off-heap [used=8MB, free=99.74%, comm=336MB]
    ^--   sysMemPlc region [used=0MB, free=99.21%, comm=40MB]
    ^--   default region [used=8MB, free=99.75%, comm=256MB]
    ^--   TxLog region [used=0MB, free=100%, comm=40MB]
    ^-- Outbound messages queue [size=0]
    ^-- Public thread pool [active=0, idle=0, qSize=0]
    ^-- System thread pool [active=0, idle=6, qSize=0]
[2020-04-03 07:22:38,880][INFO ][grid-timeout-worker-#23][IgniteKernal]
FreeList [name=default##FreeList, buckets=256, dataPages=1, reusePages=0]

On Thu, Apr 2, 2020 at 5:59 PM Evgenii Zhuravlev <e....@gmail.com>
wrote:

> Hi,
>
> Can you share full log files?
>
> Evgenii
>
> чт, 2 апр. 2020 г. в 17:40, Anthony <ha...@gmail.com>:
>
>> Hello,
>>
>> I am trying to make java node and c++ node communicate with each other. I
>> have successfully done it between two c++ node (which is straight forward).
>>
>> However, when I tried to do a put in java and a get in c++, I got some
>> errors. Could anyone have a look? Thanks.
>>
>> Also, examples of the communication would be helpful!
>>
>> I first created a node and cache in Java:
>> Ignite ignite = Ignition.start();
>> IgniteCache<Integer, String> caches = ignite.getOrCreateCache("myCache");
>>
>> And in C++:
>>   IgniteConfiguration cfg;
>>   Ignite grid = Ignition::Start(cfg);
>>    // Get cache instance.
>>    Cache<int, std::string> caches = grid.GetCache<int,
>> std::string>("myCache");
>>
>> Then I got the following error messages on java side:
>>
>> [2020-04-02 16:10:27,131][ERROR][main][IgniteKernal] Failed to start
>> manager: GridManagerAdapter [enabled=true,
>> name=o.a.i.i.managers.discovery.GridDiscoveryManager]
>> class org.apache.ignite.IgniteCheckedException: Failed to start SPI:
>> TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
>> marsh=JdkMarshaller
>> [clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@fd9ebde],
>> reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
>> forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
>> skipAddrsRandomization=false]
>> at
>> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
>> at
>> org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
>>
>>

Re: Error and Question about communication between java node and c++ node

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

Can you share full log files?

Evgenii

чт, 2 апр. 2020 г. в 17:40, Anthony <ha...@gmail.com>:

> Hello,
>
> I am trying to make java node and c++ node communicate with each other. I
> have successfully done it between two c++ node (which is straight forward).
>
> However, when I tried to do a put in java and a get in c++, I got some
> errors. Could anyone have a look? Thanks.
>
> Also, examples of the communication would be helpful!
>
> I first created a node and cache in Java:
> Ignite ignite = Ignition.start();
> IgniteCache<Integer, String> caches = ignite.getOrCreateCache("myCache");
>
> And in C++:
>   IgniteConfiguration cfg;
>   Ignite grid = Ignition::Start(cfg);
>    // Get cache instance.
>    Cache<int, std::string> caches = grid.GetCache<int,
> std::string>("myCache");
>
> Then I got the following error messages on java side:
>
> [2020-04-02 16:10:27,131][ERROR][main][IgniteKernal] Failed to start
> manager: GridManagerAdapter [enabled=true,
> name=o.a.i.i.managers.discovery.GridDiscoveryManager]
> class org.apache.ignite.IgniteCheckedException: Failed to start SPI:
> TcpDiscoverySpi [addrRslvr=null, sockTimeout=5000, ackTimeout=5000,
> marsh=JdkMarshaller
> [clsFilter=org.apache.ignite.marshaller.MarshallerUtils$1@fd9ebde],
> reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=5,
> forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null,
> skipAddrsRandomization=false]
> at
> org.apache.ignite.internal.managers.GridManagerAdapter.startSpi(GridManagerAdapter.java:300)
> at
> org.apache.ignite.internal.managers.discovery.GridDiscoveryManager.start(GridDiscoveryManager.java:943)
>
>