You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@ignite.apache.org by Jeff Jiao <je...@gmail.com> on 2017/09/27 07:03:44 UTC

(.NET) localPort and localPortRange question

Hi Ignite,

I want to start up a .NET Ignite client to connect to my existing Ignite
servers. for the firewall, I opened 47500-47509 and 47100-47109 both way
between servers and clients
in my .NET Ignite client log below, I have 2 questions:

1. do i need to worry about the DEBUG log like this: GridTimeoutProcessor -
Timeout has occurred: CancelableTask, it has a lot of this in the log...

2. i already set localPort 47500 and localPortRange 10 explicitly in my
client code, but from the log, the localPort still be random:Connection
failed [sock=Socket[addr=/ServerIP2,port=47500,localport=58071], is this the
same localPort that i set??


2017-09-27 13:58:56,944 [37] DEBUG
org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi - Balancing data
[min0=0, minIdx=0, max0=-1, maxIdx=-1]
2017-09-27 13:58:57,146 [36] DEBUG
org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor - Timeout
has occurred: CancelableTask
[id=25b5ae1ce51-42011cdc-d370-4d8f-9a5d-b48aa99a4976, endTime=1506491937142,
period=10000, cancel=false,
task=org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing$11@683293a1]
2017-09-27 13:58:57,152 [43] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Balancing
data [min0=0, minIdx=0, max0=-1, maxIdx=-1]
2017-09-27 13:58:58,147 [36] DEBUG
org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor - Timeout
has occurred: CancelableTask
[id=35b5ae1ce51-42011cdc-d370-4d8f-9a5d-b48aa99a4976, endTime=1506491938146,
period=3000, cancel=false,
task=org.apache.ignite.internal.processors.query.GridQueryProcessor$2@4d68f571]
2017-09-27 13:58:58,385 [36] DEBUG
org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor - Timeout
has occurred: CancelableTask
[id=45b5ae1ce51-42011cdc-d370-4d8f-9a5d-b48aa99a4976, endTime=1506491938376,
period=3000, cancel=false, task=MetricsUpdater [prevGcTime=1,
prevCpuTime=3410,
super=org.apache.ignite.internal.managers.discovery.GridDiscoveryManager$MetricsUpdater@270ea0d3]]
2017-09-27 13:59:01,155 [36] DEBUG
org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor - Timeout
has occurred: CancelableTask
[id=35b5ae1ce51-42011cdc-d370-4d8f-9a5d-b48aa99a4976, endTime=1506491941147,
period=3000, cancel=false,
task=org.apache.ignite.internal.processors.query.GridQueryProcessor$2@4d68f571]
2017-09-27 13:59:01,385 [36] DEBUG
org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor - Timeout
has occurred: CancelableTask
[id=45b5ae1ce51-42011cdc-d370-4d8f-9a5d-b48aa99a4976, endTime=1506491941377,
period=3000, cancel=false, task=MetricsUpdater [prevGcTime=1,
prevCpuTime=3424,
super=org.apache.ignite.internal.managers.discovery.GridDiscoveryManager$MetricsUpdater@270ea0d3]]
2017-09-27 13:59:02,945 [37] DEBUG
org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi - Balancing data
[min0=0, minIdx=0, max0=-1, maxIdx=-1]
2017-09-27 13:59:03,153 [43] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Balancing
data [min0=0, minIdx=0, max0=-1, maxIdx=-1]
2017-09-27 13:59:04,155 [36] DEBUG
org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor - Timeout
has occurred: CancelableTask
[id=35b5ae1ce51-42011cdc-d370-4d8f-9a5d-b48aa99a4976, endTime=1506491944147,
period=3000, cancel=false,
task=org.apache.ignite.internal.processors.query.GridQueryProcessor$2@4d68f571]
2017-09-27 13:59:04,387 [36] DEBUG
org.apache.ignite.internal.processors.timeout.GridTimeoutProcessor - Timeout
has occurred: CancelableTask
[id=45b5ae1ce51-42011cdc-d370-4d8f-9a5d-b48aa99a4976, endTime=1506491944377,
period=3000, cancel=false, task=MetricsUpdater [prevGcTime=1,
prevCpuTime=3424,
super=org.apache.ignite.internal.managers.discovery.GridDiscoveryManager$MetricsUpdater@270ea0d3]]
2017-09-27 13:59:04,999 [50] ERROR
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Failed to read message
[sock=Socket[addr=/ServerIP2,port=47500,localport=58071],
locNodeId=82ad2f29-0cf7-4b43-b003-bb6a93b3103d,
rmtNodeId=d37b7619-c38e-49db-aa95-ec5736d48154]
2017-09-27 13:59:05,000 [49] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Connection closed,
will try to restore connection.
2017-09-27 13:59:05,001 [50] ERROR
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Connection failed
[sock=Socket[addr=/ServerIP2,port=47500,localport=58071],
locNodeId=82ad2f29-0cf7-4b43-b003-bb6a93b3103d]
2017-09-27 13:59:05,002 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Started reconnect
process [join=true, timeout=55000]
2017-09-27 13:59:05,002 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Resolved addresses
from IP finder: [/ServerIP1:47500, /ServerIP2:47500, /ServerIP3:47500]
2017-09-27 13:59:05,002 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Send join request
[addr=/ServerIP1:47500, reconnect=true,
locNodeId=82ad2f29-0cf7-4b43-b003-bb6a93b3103d]
2017-09-27 13:59:05,008 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Message has been sent
to address [msg=TcpDiscoveryClientReconnectMessage
[routerNodeId=02c0b5f3-d77d-4a5d-ad51-bffd0c42b2e9, lastMsgId=null,
super=TcpDiscoveryAbstractMessage [sndNodeId=null,
id=c5b5ae1ce51-82ad2f29-0cf7-4b43-b003-bb6a93b3103d, verifierNodeId=null,
topVer=0, pendingIdx=0, failedNodes=null, isClient=true]],
addr=/ServerIP1:47500, rmtNodeId=02c0b5f3-d77d-4a5d-ad51-bffd0c42b2e9]
2017-09-27 13:59:05,009 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Received response to
join request [addr=/ServerIP1:47500, res=1]
2017-09-27 13:59:05,012 [51] ERROR
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Reconnect error
[join=true, timeout=55000]
2017-09-27 13:59:05,012 [51] WARN
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Failed to reconnect to
cluster (will retry): class o.a.i.IgniteCheckedException: Failed to
deserialize object with given class loader:
sun.misc.Launcher$AppClassLoader@18b4aac2
2017-09-27 13:59:05,012 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Resolved addresses
from IP finder: [/ServerIP1:47500, /ServerIP3:47500, /ServerIP2:47500]
2017-09-27 13:59:05,012 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Send join request
[addr=/ServerIP1:47500, reconnect=true,
locNodeId=82ad2f29-0cf7-4b43-b003-bb6a93b3103d]
2017-09-27 13:59:05,016 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Message has been sent
to address [msg=TcpDiscoveryClientReconnectMessage
[routerNodeId=02c0b5f3-d77d-4a5d-ad51-bffd0c42b2e9, lastMsgId=null,
super=TcpDiscoveryAbstractMessage [sndNodeId=null,
id=16b5ae1ce51-82ad2f29-0cf7-4b43-b003-bb6a93b3103d, verifierNodeId=null,
topVer=0, pendingIdx=0, failedNodes=null, isClient=true]],
addr=/ServerIP1:47500, rmtNodeId=02c0b5f3-d77d-4a5d-ad51-bffd0c42b2e9]
2017-09-27 13:59:05,016 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Received response to
join request [addr=/ServerIP1:47500, res=1]
2017-09-27 13:59:05,017 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Received reconnect
response [success=false, msg=TcpDiscoveryClientReconnectMessage
[routerNodeId=02c0b5f3-d77d-4a5d-ad51-bffd0c42b2e9, lastMsgId=null,
super=TcpDiscoveryAbstractMessage [sndNodeId=null,
id=16b5ae1ce51-82ad2f29-0cf7-4b43-b003-bb6a93b3103d,
verifierNodeId=02c0b5f3-d77d-4a5d-ad51-bffd0c42b2e9, topVer=0, pendingIdx=0,
failedNodes=null, isClient=true]]]
2017-09-27 13:59:05,017 [51] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Grid runnable finished
normally: tcp-client-disco-reconnector-#5%null%
2017-09-27 13:59:05,018 [1] ERROR org.apache.ignite.internal.IgniteKernal -
Failed to start manager: GridManagerAdapter [enabled=true,
name=o.a.i.i.managers.discovery.GridDiscoveryManager]
2017-09-27 13:59:05,018 [1] ERROR org.apache.ignite.internal.IgniteKernal -
Got exception while starting (will rollback startup routine).
2017-09-27 13:59:05,018 [1] DEBUG org.apache.ignite.internal.IgniteKernal -
Notifying lifecycle beans.
2017-09-27 13:59:05,022 [48] DEBUG
org.apache.ignite.internal.processors.datastreamer.DataStreamProcessor -
Caught interrupted exception: java.lang.InterruptedException
2017-09-27 13:59:05,022 [48] DEBUG
org.apache.ignite.internal.processors.datastreamer.DataStreamProcessor -
Grid runnable finished due to interruption without cancellation:
grid-data-loader-flusher
2017-09-27 13:59:05,022 [1] DEBUG
org.apache.ignite.internal.processors.datastreamer.DataStreamProcessor -
Stopped data streamer processor.
2017-09-27 13:59:05,022 [1] DEBUG
org.apache.ignite.internal.processors.rest.GridRestProcessor - REST
processor stopped.
2017-09-27 13:59:05,022 [1] DEBUG
org.apache.ignite.internal.managers.communication.GridIoManager - Removed
message listener [topic=TOPIC_JOB_SIBLINGS,
lsnr=org.apache.ignite.internal.processors.task.GridTaskProcessor$JobSiblingsMessageListener@6a4f1a55]
2017-09-27 13:59:05,023 [1] DEBUG
org.apache.ignite.internal.managers.communication.GridIoManager - Removed
message listener [topic=TOPIC_TASK_CANCEL,
lsnr=org.apache.ignite.internal.processors.task.GridTaskProcessor$TaskCancelMessageListener@7bbc8656]
2017-09-27 13:59:05,023 [1] DEBUG
org.apache.ignite.internal.processors.task.GridTaskProcessor - Finished
executing task processor onKernalStop() callback.
2017-09-27 13:59:05,023 [1] DEBUG
org.apache.ignite.internal.managers.communication.GridIoManager - Removed
message listener [topic=TOPIC_JOB,
lsnr=org.apache.ignite.internal.processors.job.GridJobProcessor$JobExecutionListener@6933b6c6]
2017-09-27 13:59:05,023 [1] DEBUG
org.apache.ignite.internal.managers.communication.GridIoManager - Removed
message listener [topic=TOPIC_JOB_CANCEL,
lsnr=org.apache.ignite.internal.processors.job.GridJobProcessor$JobCancelListener@7d3e8655]
2017-09-27 13:59:05,023 [1] DEBUG
org.apache.ignite.internal.processors.job.GridJobProcessor - Finished
executing job processor onKernalStop() callback.
2017-09-27 13:59:05,023 [1] DEBUG
org.apache.ignite.internal.processors.service.GridServiceProcessor - Stopped
service processor.
2017-09-27 13:59:05,023 [43] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
all listening sockets.
2017-09-27 13:59:05,023 [43] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
NIO selector.
2017-09-27 13:59:05,024 [43] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Grid
runnable finished due to interruption without cancellation: nio-acceptor
2017-09-27 13:59:05,026 [1] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Cancelling
grid runnable: ByteBufferNioClientWorker
[readBuf=java.nio.HeapByteBuffer[pos=0 lim=8192 cap=8192],
super=AbstractNioClientWorker [idx=0, bytesRcvd=0, bytesSent=0,
bytesRcvd0=0, bytesSent0=0, select=true, super=GridWorker
[name=grid-nio-worker-sql-listener-0, igniteInstanceName=null,
finished=false, hashCode=2113604623, interrupted=false,
runner=grid-nio-worker-sql-listener-0-#22%null%]]]
2017-09-27 13:59:05,026 [44] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
all connected client sockets.
2017-09-27 13:59:05,026 [1] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Cancelling
grid runnable: ByteBufferNioClientWorker
[readBuf=java.nio.HeapByteBuffer[pos=0 lim=8192 cap=8192],
super=AbstractNioClientWorker [idx=1, bytesRcvd=0, bytesSent=0,
bytesRcvd0=0, bytesSent0=0, select=true, super=GridWorker
[name=grid-nio-worker-sql-listener-1, igniteInstanceName=null,
finished=false, hashCode=616674002, interrupted=false,
runner=grid-nio-worker-sql-listener-1-#23%null%]]]
2017-09-27 13:59:05,026 [44] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
NIO selector.
2017-09-27 13:59:05,026 [45] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
all connected client sockets.
2017-09-27 13:59:05,027 [45] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
NIO selector.
2017-09-27 13:59:05,027 [1] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Cancelling
grid runnable: ByteBufferNioClientWorker
[readBuf=java.nio.HeapByteBuffer[pos=0 lim=8192 cap=8192],
super=AbstractNioClientWorker [idx=2, bytesRcvd=0, bytesSent=0,
bytesRcvd0=0, bytesSent0=0, select=true, super=GridWorker
[name=grid-nio-worker-sql-listener-2, igniteInstanceName=null,
finished=false, hashCode=2109839984, interrupted=false,
runner=grid-nio-worker-sql-listener-2-#24%null%]]]
2017-09-27 13:59:05,027 [44] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Grid
runnable finished due to cancellation: grid-nio-worker-sql-listener-0
2017-09-27 13:59:05,027 [47] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
all connected client sockets.
2017-09-27 13:59:05,027 [45] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Grid
runnable finished due to cancellation: grid-nio-worker-sql-listener-1
2017-09-27 13:59:05,027 [1] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Cancelling
grid runnable: ByteBufferNioClientWorker
[readBuf=java.nio.HeapByteBuffer[pos=0 lim=8192 cap=8192],
super=AbstractNioClientWorker [idx=3, bytesRcvd=0, bytesSent=0,
bytesRcvd0=0, bytesSent0=0, select=true, super=GridWorker
[name=grid-nio-worker-sql-listener-3, igniteInstanceName=null,
finished=false, hashCode=1351478315, interrupted=false,
runner=grid-nio-worker-sql-listener-3-#25%null%]]]
2017-09-27 13:59:05,027 [47] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
NIO selector.
2017-09-27 13:59:05,027 [46] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
all connected client sockets.
2017-09-27 13:59:05,027 [46] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Closing
NIO selector.
2017-09-27 13:59:05,027 [1] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Joining
grid runnable: ByteBufferNioClientWorker
[readBuf=java.nio.HeapByteBuffer[pos=0 lim=8192 cap=8192],
super=AbstractNioClientWorker [idx=0, bytesRcvd=0, bytesSent=0,
bytesRcvd0=0, bytesSent0=0, select=false, super=GridWorker
[name=grid-nio-worker-sql-listener-0, igniteInstanceName=null,
finished=true, hashCode=2113604623, interrupted=unknown, runner=null]]]
2017-09-27 13:59:05,027 [47] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Grid
runnable finished due to cancellation: grid-nio-worker-sql-listener-2
2017-09-27 13:59:05,027 [1] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Joining
grid runnable: ByteBufferNioClientWorker
[readBuf=java.nio.HeapByteBuffer[pos=0 lim=8192 cap=8192],
super=AbstractNioClientWorker [idx=1, bytesRcvd=0, bytesSent=0,
bytesRcvd0=0, bytesSent0=0, select=false, super=GridWorker
[name=grid-nio-worker-sql-listener-1, igniteInstanceName=null,
finished=true, hashCode=616674002, interrupted=unknown, runner=null]]]
2017-09-27 13:59:05,027 [46] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Grid
runnable finished due to cancellation: grid-nio-worker-sql-listener-3
2017-09-27 13:59:05,027 [1] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Joining
grid runnable: ByteBufferNioClientWorker
[readBuf=java.nio.HeapByteBuffer[pos=0 lim=8192 cap=8192],
super=AbstractNioClientWorker [idx=2, bytesRcvd=0, bytesSent=0,
bytesRcvd0=0, bytesSent0=0, select=false, super=GridWorker
[name=grid-nio-worker-sql-listener-2, igniteInstanceName=null,
finished=true, hashCode=2109839984, interrupted=unknown, runner=null]]]
2017-09-27 13:59:05,027 [1] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - Joining
grid runnable: ByteBufferNioClientWorker
[readBuf=java.nio.HeapByteBuffer[pos=0 lim=8192 cap=8192],
super=AbstractNioClientWorker [idx=3, bytesRcvd=0, bytesSent=0,
bytesRcvd0=0, bytesSent0=0, select=false, super=GridWorker
[name=grid-nio-worker-sql-listener-3, igniteInstanceName=null,
finished=true, hashCode=1351478315, interrupted=unknown, runner=null]]]
2017-09-27 13:59:05,027 [1] DEBUG
org.apache.ignite.internal.processors.odbc.SqlListenerProcessor - SQL
connector processor stopped.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager
- Cancelling grid runnable: GridWorker [name=partition-exchanger,
igniteInstanceName=null, finished=false, hashCode=508512860,
interrupted=unknown, runner=null]
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager
- Before joining on exchange worker: GridWorker [name=partition-exchanger,
igniteInstanceName=null, finished=false, hashCode=508512860,
interrupted=unknown, runner=null]
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager
- Joining grid runnable: GridWorker [name=partition-exchanger,
igniteInstanceName=null, finished=false, hashCode=508512860,
interrupted=unknown, runner=null]
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.GridCachePartitionExchangeManager
- Cache manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.GridCacheSharedTtlCleanupManager
- Cache manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.managers.communication.GridIoManager - Removed
message listener [topic=TOPIC_CACHE,
lsnr=org.apache.ignite.internal.processors.cache.GridCacheIoManager$1@37313c65]
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.GridCacheIoManager - Cache
manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.CacheAffinitySharedManager -
Cache manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.GridCacheDeploymentManager -
Cache manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.jta.CacheNoopJtaManager - Cache
manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.persistence.snapshot.IgniteCacheSnapshotManager
- Cache manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.persistence.IgniteCacheDatabaseSharedManager
- Cache manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.managers.communication.GridIoManager - Removed
message listener [topic=TOPIC_TX,
lsnr=org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager$DeadlockDetectionListener@465232e9]
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.transactions.IgniteTxManager -
Cache manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.version.GridCacheVersionManager
- Cache manager received onKernalStop() callback.
2017-09-27 13:59:05,028 [1] DEBUG
org.apache.ignite.internal.processors.cache.GridCacheMvccManager - Cache
manager received onKernalStop() callback.
2017-09-27 13:59:05,029 [1] DEBUG
org.apache.ignite.internal.managers.deployment.GridDeploymentPerVersionStore
- Unregistered deployment discovery listener:
org.apache.ignite.internal.managers.deployment.GridDeploymentPerVersionStore$1@6a192cfe
2017-09-27 13:59:05,029 [1] DEBUG
org.apache.ignite.internal.managers.deployment.GridDeploymentPerLoaderStore
- Unregistered deployment discovery listener:
org.apache.ignite.internal.managers.deployment.GridDeploymentPerLoaderStore$1@2f7298b
2017-09-27 13:59:05,029 [1] DEBUG
org.apache.ignite.internal.managers.communication.GridIoManager - Removed
message listener [topic=TOPIC_EVENT,
lsnr=org.apache.ignite.internal.managers.eventstorage.GridEventStorageManager$RequestListener@1df8da7a]
2017-09-27 13:59:05,029 [1] DEBUG
org.apache.ignite.internal.processors.closure.GridClosureProcessor - Stopped
closure processor.
2017-09-27 13:59:05,029 [1] DEBUG org.apache.ignite.internal.IgniteKernal -
Grid is stopping.
2017-09-27 13:59:05,029 [1] DEBUG
org.apache.ignite.internal.managers.discovery.GridDiscoveryManager -
Cancelling grid runnable: DiscoveryWorker [discoCache=null,
nodeSegFired=false]
2017-09-27 13:59:05,029 [1] DEBUG
org.apache.ignite.internal.managers.discovery.GridDiscoveryManager - Joining
grid runnable: DiscoveryWorker [discoCache=null, nodeSegFired=false]
2017-09-27 13:59:05,030 [1] DEBUG
org.apache.ignite.internal.managers.discovery.GridDiscoveryManager -
Stopping SPI: TcpDiscoverySpi [addrRslvr=null, sockTimeout=604800000,
ackTimeout=30000, marsh=JdkMarshaller [], reconCnt=10, maxAckTimeout=100000,
forceSrvMode=false, clientReconnectDisabled=false]
2017-09-27 13:59:05,030 [1] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Unregistered SPI
MBean: org.apache:clsLdr=18b4aac2,group=SPIs,name=TcpDiscoverySpi
2017-09-27 13:59:05,030 [50] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Caught interrupted
exception: java.lang.InterruptedException
2017-09-27 13:59:05,030 [49] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Caught interrupted
exception: java.lang.InterruptedException
2017-09-27 13:59:05,030 [52] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Caught interrupted
exception: java.lang.InterruptedException
2017-09-27 13:59:05,030 [52] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Grid runnable finished
due to interruption without cancellation:
tcp-client-disco-sock-writer-#2%null%
2017-09-27 13:59:05,030 [50] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Grid runnable finished
due to interruption without cancellation:
tcp-client-disco-sock-reader-#3%null%
2017-09-27 13:59:05,030 [49] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - Grid runnable finished
due to interruption without cancellation:
tcp-client-disco-msg-worker-#4%null%
2017-09-27 13:59:05,031 [1] DEBUG
org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi - SPI stopped ok.
2017-09-27 13:59:05,031 [1] DEBUG
org.apache.ignite.internal.managers.discovery.GridDiscoveryManager - SPI
module stopped OK: org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi



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

Re: (.NET) localPort and localPortRange question

Posted by Alexey Kukushkin <ku...@gmail.com>.
Hi Jeff,

This output "Socket[addr=/ServerIP2,port=47500,localport=58071]" indicates
your server is correctly bound to port 47500 you configured. You have to
open only port 47500 and subsequent ports in your range in your firewall.
Do not worry about localport=58071 in that output. Sockets are
bi-directional: you configure the "server" port (47500) the clients would
connect to and the other end of the communication uses a random ephemeral
port assigned by TCP stack. Firewalls know about the ephemeral ports range
and never block it.

I see timeouts come from GridQueryProcessor. What timeout do you use in
your SqlQuery? Did you try increasing it?