yp19910928 opened a new issue, #12621: URL: https://github.com/apache/ignite/issues/12621
We are seeing an error during Ignite server startup. Environment: **Apache Ignite 2.17.0 Cache service running in Docker container Single server node persistenceEnabled = false Client: .NET Thin Client** During startup, the server logs the following error: **class org.apache.ignite.IgniteException: Failed to execute affinity operation on cache groups Caused by: class org.apache.ignite.IgniteCheckedException: Failed to find completed exchange future to fetch affinity.** The error happens while the node is still starting, before cluster initialization is fully completed. This looks related to IGNITE-10878, which also reports: ``` "Failed to find completed exchange future" error occurs in test with round cluster restart ``` ignite log: ``` [2025-12-30 06:03:52] [WARNING][org.apache.ignite.internal.util.typedef.G] Ignite work directory is not provided, automatically resolved to: /opt/ignite/apache-ignite/work [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] >>> __________ ________________ >>> / _/ ___/ |/ / _/_ __/ __/ >>> _/ // (7 7 // / / / / _/ >>> /___/\___/_/|_/___/ /_/ /___/ >>> >>> ver. 2.17.0#20250209-sha1:d53d4540 >>> 2025 Copyright(C) Apache Software Foundation >>> >>> Ignite documentation: https://ignite.apache.org [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] Config URL: file:/opt/ignite/apache-ignite/config/default-config.xml [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] IgniteConfiguration [igniteInstanceName=null, pubPoolSize=8, svcPoolSize=8, callbackPoolSize=8, stripedPoolSize=8, sysPoolSize=8, mgmtPoolSize=4, dataStreamerPoolSize=8, utilityCachePoolSize=8, utilityCacheKeepAliveTime=60000, p2pPoolSize=2, qryPoolSize=8, buildIdxPoolSize=1, igniteHome=/opt/ignite/apache-ignite, igniteWorkDir=/opt/ignite/apache-ignite/work, mbeanSrv=com.sun.jmx.mbeanserver.JmxMBeanServer@2a448449, nodeId=e8a2d1ab-e371-4853-8a99-9decef8a41b0, marsh=null, marshLocJobs=false, p2pEnabled=false, netTimeout=5000, netCompressionLevel=1, sndRetryDelay=1000, sndRetryCnt=3, metricsHistSize=10000, metricsUpdateFreq=2000, metricsExpTime=9223372036854775807, discoSpi=TcpDiscoverySpi [addrRslvr=null, addressFilter=null, sockTimeout=3000, ackTimeout=0, marsh=null, reconCnt=10, reconDelay=2000, maxAckTimeout=600000, soLinger=0, forceSrvMode=false, clientReconnectDisabled=false, internalLsnr=null, skipAddrsRand omization=false], segPlc=USE_FAILURE_HANDLER, segResolveAttempts=2, waitForSegOnStart=true, allResolversPassReq=true, segChkFreq=10000, commSpi=TcpCommunicationSpi [connectGate=org.apache.ignite.spi.communication.tcp.internal.ConnectGateway@58dea0a5, ctxInitLatch=java.util.concurrent.CountDownLatch@2a2bb0eb[Count = 1], stopping=false, clientPool=null, nioSrvWrapper=null, stateProvider=null], evtSpi=org.apache.ignite.spi.eventstorage.NoopEventStorageSpi@3c291aad, colSpi=NoopCollisionSpi [], deploySpi=LocalDeploymentSpi [], indexingSpi=org.apache.ignite.spi.indexing.noop.NoopIndexingSpi@436390f4, addrRslvr=null, encryptionSpi=org.apache.ignite.spi.encryption.noop.NoopEncryptionSpi@4d157787, tracingSpi=org.apache.ignite.spi.tracing.NoopTracingSpi@68ed96ca, clientMode=false, rebalanceThreadPoolSize=1, rebalanceTimeout=10000, rebalanceBatchesPrefetchCnt=3, rebalanceThrottle=0, rebalanceBatchSize=524288, txCfg=TransactionConfiguration [txSerEnabled=false, dfltIsolation=REPEATABLE_READ, df ltConcurrency=PESSIMISTIC, dfltTxTimeout=0, txTimeoutOnPartitionMapExchange=0, pessimisticTxLogSize=0, pessimisticTxLogLinger=10000, tmLookupClsName=null, txManagerFactory=null, useJtaSync=false, txAwareQueriesEnabled=false], cacheSanityCheckEnabled=true, discoStartupDelay=60000, deployMode=SHARED, p2pMissedCacheSize=100, locHost=null, timeSrvPortBase=31100, timeSrvPortRange=100, failureDetectionTimeout=60000, sysWorkerBlockedTimeout=10000, clientFailureDetectionTimeout=5000, metricsLogFreq=60000, connectorCfg=ConnectorConfiguration [jettyPath=/config/jetty.xml, host=null, port=11211, noDelay=true, directBuf=false, sndBufSize=32768, rcvBufSize=32768, idleQryCurTimeout=600000, idleQryCurCheckFreq=60000, sndQueueLimit=0, selectorCnt=2, idleTimeout=7000, sslEnabled=false, sslClientAuth=false, sslFactory=null, portRange=100, threadPoolSize=8, msgInterceptor=null], odbcCfg=null, warmupClos=null, atomicCfg=AtomicConfiguration [seqReserveSize=1000, cacheMode=PARTITIONED, backups=1, aff=nul l, grpName=null], classLdr=null, sslCtxFactory=null, platformCfg=null, binaryCfg=BinaryConfiguration [idMapper=null, nameMapper=BinaryBaseNameMapper [isSimpleName=false], serializer=null, compactFooter=true], memCfg=null, pstCfg=null, dsCfg=DataStorageConfiguration [pageSize=0, concLvl=0, sysDataRegConf=org.apache.ignite.configuration.SystemDataRegionConfiguration@28a2a3e7, dfltDataRegConf=DataRegionConfiguration [name=Default_Region, maxSize=3221225472, initSize=268435456, swapPath=null, pageEvictionMode=DISABLED, pageReplacementMode=CLOCK, evictionThreshold=0.9, emptyPagesPoolSize=100, metricsEnabled=false, metricsSubIntervalCount=5, metricsRateTimeInterval=60000, persistenceEnabled=false, checkpointPageBufSize=805306368, lazyMemoryAllocation=true, warmUpCfg=null, memoryAllocator=null, cdcEnabled=false], dataRegions=null, storagePath=/data/local/db, checkpointFreq=180000, lockWaitTime=10000, checkpointThreads=4, checkpointWriteOrder=SEQUENTIAL, walHistSize=20, maxWalArchiveSize=10 73741824, walSegments=10, walSegmentSize=67108864, walPath=/data/local/db/wal, walArchivePath=/data/local/db/wal/archive, cdcWalPath=db/wal/cdc, cdcWalDirMaxSize=0, 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@610db97e, metricsSubIntervalCnt=5, metricsRateTimeInterval=60000, walAutoArchiveAfterInactivity=-1, walForceArchiveTimeout=-1, writeThrottlingEnabled=true, walCompactionEnabled=false, walCompactionLevel=1, checkpointReadLockTimeout=null, walPageCompression=DISABLED, walPageCompressionLevel=null, dfltWarmUpCfg=null, encCfg=org.apache.ignite.configuration.EncryptionConfiguration@3fabf088, defragmentationThreadPoolSize=4, minWalArchiveSize=-1, memoryAllocator=null], snapshotPath=snapshots, snapshotThreadPoolSize=4, activeOnStart=true, activeOnStartPropSetFlag=fa lse, autoActivation=true, autoActivationPropSetFlag=false, clusterStateOnStart=null, sqlConnCfg=null, cliConnCfg=ClientConnectorConfiguration [host=null, port=10800, portRange=100, sockSndBufSize=0, sockRcvBufSize=0, tcpNoDelay=true, maxOpenCursorsPerConn=128, threadPoolSize=8, selectorCnt=4, idleTimeout=0, handshakeTimeout=10000, jdbcEnabled=true, odbcEnabled=true, thinCliEnabled=true, sslEnabled=false, useIgniteSslCtxFactory=true, sslClientAuth=false, sslCtxFactory=null, thinCliCfg=ThinClientConfiguration [maxActiveTxPerConn=100, maxActiveComputeTasksPerConn=0, sendServerExcStackTraceToClient=false], sesOutboundMsgQueueLimit=0], authEnabled=false, failureHnd=StopNodeFailureHandler [super=AbstractFailureHandler [ignoredFailureTypes=UnmodifiableSet [SYSTEM_WORKER_BLOCKED, SYSTEM_CRITICAL_OPERATION_TIMEOUT]]], commFailureRslvr=null, sqlCfg=SqlConfiguration [longQryWarnTimeout=3000, dfltQryTimeout=0, sqlQryHistSize=1000, validationEnabled=false], asyncContinuationExecutor=null] [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] OS: Linux 4.19.132-5.ph3-esx amd64 [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] OS user: root [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] PID: 302 [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] Language runtime: Java Platform API Specification ver. 11 [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] VM information: OpenJDK Runtime Environment 11.0.26+4 Eclipse Adoptium OpenJDK 64-Bit Server VM 11.0.26+4 [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] VM total memory: 3.5GB [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] Remote Management [restart: off, REST: on, JMX (remote: off)] [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] Logger: JavaLogger [quiet=true, config=/opt/ignite/apache-ignite/config/java.util.logging.properties] [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] IGNITE_HOME=/opt/ignite/apache-ignite [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.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, --add-opens=jdk.management/com.sun.management.internal=ALL-UNNAMED, --add-opens=java.base/jdk.internal.access=ALL-UNNAMED, --illegal-access=permit, -Xms1024m, -Xmx3584m, -XX:+HeapDumpOnOutOfMemoryError, -DIGNITE_QUIET=true, -Duser.timezone=UTC, -Djava.net.preferIPv4Stack=true, -XX:+AlwaysPreTouch, -XX:+UseG1GC, -XX:+ScavengeBeforeFullGC, -XX:+DisableExplicitGC, -DIGNITE_ALLOW_DML_INSIDE_TRANSACTION=true, -DIGNITE_HOME=/opt/ignite/apache-ignite] [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] System cache's DataRegion size is configured to 40 MB. Use DataStorageConfiguration.systemRegionInitialSize property to change the setting. [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] Configured caches [in 'sysMemPlc' dataRegion: ['ignite-sys-cache']] [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.IgniteKernal] 3-rd party licenses can be found at: /opt/ignite/apache-ignite/libs/licenses [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.processors.plugin.IgnitePluginProcessor] Configured plugins: [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.processors.plugin.IgnitePluginProcessor] ^-- None [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.processors.plugin.IgnitePluginProcessor] [2025-12-30 06:03:52] [INFO][org.apache.ignite.internal.processors.failure.FailureProcessor] Configured failure handler: [hnd=StopNodeFailureHandler [super=AbstractFailureHandler [ignoredFailureTypes=UnmodifiableSet [SYSTEM_WORKER_BLOCKED, SYSTEM_CRITICAL_OPERATION_TIMEOUT]]]] [2025-12-30 06:03:52] [INFO][org.apache.ignite.spi.communication.tcp.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] [2025-12-30 06:03:52] [WARNING][org.apache.ignite.spi.communication.tcp.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. [2025-12-30 06:03:53] [WARNING][org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi] Failure detection timeout will be ignored (one of SPI parameters has been set explicitly) [2025-12-30 06:03:53] [INFO][org.apache.ignite.internal.managers.collision.GridCollisionManager] Collision resolution is disabled (all jobs will be activated upon arrival). [2025-12-30 06:03:53] [WARNING][org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi] Failure detection timeout will be ignored (one of SPI parameters has been set explicitly) [2025-12-30 06:03:53] [INFO][org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi] Successfully bound to TCP port [port=47500, localHost=0.0.0.0/0.0.0.0, locNodeId=e8a2d1ab-e371-4853-8a99-9decef8a41b0] [2025-12-30 06:03:53] [INFO][org.apache.ignite.internal.processors.cache.GridLocalConfigManager] Resolved page store work directory: /data/local/db/10_13_10_2_127_0_0_1_47500 [2025-12-30 06:03:53] [INFO][org.apache.ignite.internal.processors.cache.persistence.IgniteCacheDatabaseSharedManager] The DataStorageConfiguration.pageSize property has been set to: 4096 bytes [2025-12-30 06:03:53] [INFO][org.apache.ignite.internal.processors.cache.persistence.IgniteCacheDatabaseSharedManager] Configured data regions initialized successfully [total=3] [2025-12-30 06:03:53] [WARNING][org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing] Serialization of Java objects in H2 was enabled. [2025-12-30 06:03:53] [INFO][org.apache.ignite.internal.processors.odbc.ClientListenerProcessor] Client connector processor has started on TCP port 10800 [2025-12-30 06:03:53] [INFO][org.apache.ignite.internal.processors.rest.protocols.tcp.GridTcpRestProtocol] Command protocol successfully started [name=TCP binary, host=0.0.0.0/0.0.0.0, port=11211] [2025-12-30 06:03:54] [WARNING][org.apache.ignite.internal.processors.odbc.ClientListenerNioListener] Error during handshake [rmtAddr=/10.13.10.1:42604, type=thin, ver=1.7.0, msg=Node in recovery mode.] [2025-12-30 06:03:54] [INFO][org.apache.ignite.internal.processors.rest.protocols.http.jetty.GridJettyRestProtocol] Command protocol successfully started [name=Jetty REST, host=/0.0.0.0, port=8080] [2025-12-30 06:03:54] [WARNING][org.apache.ignite.internal.IgniteKernal] System property will override environment variable with the same name: IGNITE_QUIET [2025-12-30 06:03:54] [INFO][org.apache.ignite.internal.IgniteKernal] Non-loopback local IPs: 10.13.10.2 [2025-12-30 06:03:54] [INFO][org.apache.ignite.internal.IgniteKernal] Enabled local MACs: 02420A0D0A02 [2025-12-30 06:03:54] [INFO][org.apache.ignite.internal.processors.cluster.ClusterProcessor] Cluster ID and tag has been read from metastorage: null [2025-12-30 06:03:54] [INFO][org.apache.ignite.internal.cluster.IgniteClusterImpl] Shutdown policy was updated [oldVal=null, newVal=null] [2025-12-30 06:03:54] [WARNING][org.apache.ignite.internal.processors.odbc.ClientListenerNioListener] Error during handshake [rmtAddr=/10.13.10.1:42638, type=thin, ver=1.7.0, msg=Node in recovery mode.] [2025-12-30 06:03:54] [INFO][org.apache.ignite.internal.processors.cluster.GridClusterStateProcessor] Received activate cluster request with BaselineTopology[id=0] initiator node ID: e8a2d1ab-e371-4853-8a99-9decef8a41b0 [2025-12-30 06:03:54] [INFO][org.apache.ignite.internal.processors.cluster.GridClusterStateProcessor] Started state transition: activate cluster [2025-12-30 06:03:54] [INFO][org.apache.ignite.internal.processors.cluster.GridClusterStateProcessor] Received state change finish message: ACTIVE [2025-12-30 06:03:54] [INFO][org.apache.ignite.internal.processors.cluster.GridClusterStateProcessor] Cluster state was changed from ACTIVE to ACTIVE [2025-12-30 06:03:54] [WARNING][org.apache.ignite.internal.IgniteKernal] Nodes started on local machine require more than 80% of physical RAM what can lead to significant slowdown due to swapping (please decrease JVM heap size, data region size or checkpoint buffer size) [required=6756MB, available=6144MB] [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cluster.ClusterProcessor] Writing cluster ID and tag to metastorage on ready for write ClusterIdAndTag [id=daaab175-0f7e-4dee-a8d4-34268bf8cfeb, tag=sweet_lewin] [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.cluster.DistributedBaselineConfiguration] Baseline parameter 'baselineAutoAdjustEnabled' was changed from 'null' to 'true' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cluster.ClusterProcessor] Cluster tag will be set to new value: sweet_lewin, previous value was: null [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.cluster.DistributedBaselineConfiguration] Baseline parameter 'baselineAutoAdjustTimeout' was changed from 'null' to '0' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager] Transactions parameter 'longOperationsDumpTimeout' was changed from 'null' to '60000' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager] Transactions parameter 'longTransactionTimeDumpThreshold' was changed from 'null' to '0' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager] Transactions parameter 'transactionTimeDumpSamplesCoefficient' was changed from 'null' to '0.0' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager] Transactions parameter 'longTransactionTimeDumpSamplesPerSecondLimit' was changed from 'null' to '5' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager] Transactions parameter 'collisionsDumpInterval' was changed from 'null' to '1000' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager] Transactions parameter 'txOwnerDumpRequestsAllowed' was changed from 'null' to 'true' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteSnapshotManager] The snapshot transfer rate is not limited. [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing] SQL parameter 'sql.defaultQueryTimeout' was changed from 'null' to '0' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing] SQL parameter 'sql.disabledFunctions' was changed from 'null' to '[FILE_WRITE, CANCEL_SESSION, MEMORY_USED, CSVREAD, LINK_SCHEMA, MEMORY_FREE, FILE_READ, CSVWRITE, SESSION_ID, LOCK_MODE]' [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.exchange.time] Started exchange init [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], crd=true, evt=NODE_JOINED, evtNode=e8a2d1ab-e371-4853-8a99-9decef8a41b0, customEvt=null, allowMerge=false, exchangeFreeSwitch=false] [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.persistence.IgniteCacheDatabaseSharedManager] Data Regions Started: 3 [2025-12-30 06:03:55] [INFO][org.apache.ignite.cache.msg] Components activation performed in 74 ms. [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.GridCacheProcessor] Started cache [name=ignite-sys-cache, id=-2100569601, dataRegionName=sysMemPlc, mode=REPLICATED, atomicity=TRANSACTIONAL, backups=2147483647] [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.GridCacheProcessor] Starting caches on local join performed in 162 ms. [2025-12-30 06:03:55] [SEVERE][org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture] Failed to reinitialize local partitions (rebalancing will be stopped): GridDhtPartitionExchangeId [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], discoEvt=DiscoveryEvent [evtNode=TcpDiscoveryNode [id=e8a2d1ab-e371-4853-8a99-9decef8a41b0, consistentId=10.13.10.2,127.0.0.1:47500, addrs=ArrayList [10.13.10.2, 127.0.0.1], sockAddrs=HashSet [/127.0.0.1:47500, /10.13.10.2:47500], discPort=47500, order=1, intOrder=1, loc=true, ver=2.17.0#20250209-sha1:d53d4540, isClient=false], topVer=1, msgTemplate=null, span=o.a.i.i.processors.tracing.NoopSpan@65cff5e6, nodeId8=e8a2d1ab, msg=null, type=NODE_JOINED, tstamp=1767074634955], nodeId=e8a2d1ab, evt=NODE_JOINED] class org.apache.ignite.IgniteException: Failed to execute affinity operation on cache groups at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.forAllRegisteredCacheGroups(CacheAffinitySharedManager.java:1296) at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.initCoordinatorCaches(CacheAffinitySharedManager.java:1960) at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.initCoordinatorCaches(GridDhtPartitionsExchangeFuture.java:865) at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.init(GridDhtPartitionsExchangeFuture.java:1011) at org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager$ExchangeWorker.body0(GridCachePartitionExchangeManager.java:3321) at org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager$ExchangeWorker.body(GridCachePartitionExchangeManager.java:3155) at org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:125) at java.base/java.lang.Thread.run(Unknown Source) Caused by: class org.apache.ignite.IgniteCheckedException: Failed to find completed exchange future to fetch affinity. at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager$17.applyx(CacheAffinitySharedManager.java:2007) at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager$17.applyx(CacheAffinitySharedManager.java:1960) at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.lambda$forAllRegisteredCacheGroups$e0a6939d$1(CacheAffinitySharedManager.java:1290) at org.apache.ignite.internal.util.IgniteUtils.doInParallel(IgniteUtils.java:11613) at org.apache.ignite.internal.util.IgniteUtils.doInParallel(IgniteUtils.java:11515) at org.apache.ignite.internal.util.IgniteUtils.doInParallel(IgniteUtils.java:11495) at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.forAllRegisteredCacheGroups(CacheAffinitySharedManager.java:1289) ... 7 more [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture] Finish exchange future [startVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], resVer=null, err=class org.apache.ignite.IgniteException: Failed to execute affinity operation on cache groups, rebalanced=false, wasRebalanced=false] [2025-12-30 06:03:55] [SEVERE][org.apache.ignite.internal.IgniteKernal] Got exception while starting (will rollback startup routine). class org.apache.ignite.IgniteCheckedException: Failed to execute affinity operation on cache groups at org.apache.ignite.internal.util.IgniteUtils.cast(IgniteUtils.java:7984) at org.apache.ignite.internal.util.future.GridFutureAdapter.resolve(GridFutureAdapter.java:263) at org.apache.ignite.internal.util.future.GridFutureAdapter.get0(GridFutureAdapter.java:237) at org.apache.ignite.internal.util.future.GridFutureAdapter.get(GridFutureAdapter.java:163) at org.apache.ignite.internal.util.future.GridFutureAdapter.get(GridFutureAdapter.java:155) at org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager.onKernalStart(GridCachePartitionExchangeManager.java:898) at org.apache.ignite.internal.processors.cache.GridCacheProcessor.onKernalStart(GridCacheProcessor.java:688) at org.apache.ignite.internal.IgniteKernal.start(IgniteKernal.java:1248) at org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start0(IgnitionEx.java:1720) at org.apache.ignite.internal.IgnitionEx$IgniteNamedInstance.start(IgnitionEx.java:1642) at org.apache.ignite.internal.IgnitionEx.start0(IgnitionEx.java:1084) at org.apache.ignite.internal.IgnitionEx.startConfigurations(IgnitionEx.java:978) at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:884) at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:803) at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:673) at org.apache.ignite.internal.IgnitionEx.start(IgnitionEx.java:642) at org.apache.ignite.Ignition.start(Ignition.java:325) at org.apache.ignite.startup.cmdline.CommandLineStartup.main(CommandLineStartup.java:365) Caused by: class org.apache.ignite.IgniteException: Failed to execute affinity operation on cache groups at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.forAllRegisteredCacheGroups(CacheAffinitySharedManager.java:1296) at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.initCoordinatorCaches(CacheAffinitySharedManager.java:1960) at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.initCoordinatorCaches(GridDhtPartitionsExchangeFuture.java:865) at org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture.init(GridDhtPartitionsExchangeFuture.java:1011) at org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager$ExchangeWorker.body0(GridCachePartitionExchangeManager.java:3321) at org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager$ExchangeWorker.body(GridCachePartitionExchangeManager.java:3155) at org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:125) at java.base/java.lang.Thread.run(Unknown Source) Caused by: class org.apache.ignite.IgniteCheckedException: Failed to find completed exchange future to fetch affinity. at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager$17.applyx(CacheAffinitySharedManager.java:2007) at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager$17.applyx(CacheAffinitySharedManager.java:1960) at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.lambda$forAllRegisteredCacheGroups$e0a6939d$1(CacheAffinitySharedManager.java:1290) at org.apache.ignite.internal.util.IgniteUtils.doInParallel(IgniteUtils.java:11613) at org.apache.ignite.internal.util.IgniteUtils.doInParallel(IgniteUtils.java:11515) at org.apache.ignite.internal.util.IgniteUtils.doInParallel(IgniteUtils.java:11495) at org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager.forAllRegisteredCacheGroups(CacheAffinitySharedManager.java:1289) ... 7 more [2025-12-30 06:03:55] [INFO][org.apache.ignite.internal.processors.rest.protocols.tcp.GridTcpRestProtocol] Command protocol successfully stopped: TCP binary [2025-12-30 06:03:56] [INFO][org.apache.ignite.internal.processors.cache.distributed.dht.preloader.GridDhtPartitionsExchangeFuture] Completed partition exchange [localNode=e8a2d1ab-e371-4853-8a99-9decef8a41b0, exchange=GridDhtPartitionsExchangeFuture [topVer=AffinityTopologyVersion [topVer=1, minorTopVer=0], evt=NODE_JOINED, evtNode=TcpDiscoveryNode [id=e8a2d1ab-e371-4853-8a99-9decef8a41b0, consistentId=10.13.10.2,127.0.0.1:47500, addrs=ArrayList [10.13.10.2, 127.0.0.1], sockAddrs=HashSet [/127.0.0.1:47500, /10.13.10.2:47500], discPort=47500, order=1, intOrder=1, loc=true, ver=2.17.0#20250209-sha1:d53d4540, isClient=false], rebalanced=false, done=true, newCrdFut=null], topVer=null] ``` log attachment: [ignite-e8a2d1ab.0.log](https://github.com/user-attachments/files/24447539/ignite-e8a2d1ab.0.log) -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. To unsubscribe, e-mail: [email protected] For queries about this service, please contact Infrastructure at: [email protected]
