You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@ignite.apache.org by "Pavel Tupitsyn (JIRA)" <ji...@apache.org> on 2017/11/22 09:49:00 UTC

[jira] [Created] (IGNITE-6986) .NET: Some exceptions can't be serialized

Pavel Tupitsyn created IGNITE-6986:
--------------------------------------

             Summary: .NET: Some exceptions can't be serialized
                 Key: IGNITE-6986
                 URL: https://issues.apache.org/jira/browse/IGNITE-6986
             Project: Ignite
          Issue Type: Bug
          Components: platforms
    Affects Versions: 2.3
            Reporter: Pavel Tupitsyn
             Fix For: 2.4


{{System.Exception}} may include some data that is not handled properly by Ignite.

For example, below is an error caused by calling {{GetCache}} from compute job for a cache that does not exist.

Client-side error:
{code}
System.AggregateException - One or more errors occurred.
Apache.Ignite.Core.Common.IgniteException - Remote job threw user exception (override or implement IComputeTask.result(..) method if you would like to have automatic failover for this exception).
Apache.Ignite.Core.Common.IgniteException - Compute job has failed on remote node, examine InnerException for details.
Apache.Ignite.Core.Common.IgniteException - Call completed with error, but error serialization failed [errType=ArgumentException, serializationErrMsg=Field type mismatch detected [fieldName=WatsonBuckets, expectedType=103, actualType=12]]
Apache.Ignite.Core.Common.JavaException - class org.apache.ignite.IgniteException: Call completed with error, but error serialization failed [errType=ArgumentException, serializationErrMsg=Field type mismatch detected [fieldName=WatsonBuckets, expectedType=103, actualType=12]]
    at org.apache.ignite.internal.util.IgniteUtils.convertException(IgniteUtils.java:966)
    at org.apache.ignite.internal.processors.platform.compute.PlatformAbstractJob.execute(PlatformAbstractJob.java:83)
    at org.apache.ignite.internal.processors.job.GridJobWorker$2.call(GridJobWorker.java:566)
    at org.apache.ignite.internal.util.IgniteUtils.wrapThreadLoader(IgniteUtils.java:6629)
    at org.apache.ignite.internal.processors.job.GridJobWorker.execute0(GridJobWorker.java:560)
    at org.apache.ignite.internal.processors.job.GridJobWorker.body(GridJobWorker.java:489)
    at org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java:110)
    at org.apache.ignite.internal.processors.job.GridJobProcessor.processJobExecuteRequest(GridJobProcessor.java:1181)
    at org.apache.ignite.internal.processors.job.GridJobProcessor$JobExecutionListener.onMessage(GridJobProcessor.java:1908)
    at org.apache.ignite.internal.managers.communication.GridIoManager.invokeListener(GridIoManager.java:1556)
    at org.apache.ignite.internal.managers.communication.GridIoManager.processRegularMessage0(GridIoManager.java:1184)
    at org.apache.ignite.internal.managers.communication.GridIoManager.access$4200(GridIoManager.java:126)
    at org.apache.ignite.internal.managers.communication.GridIoManager$9.run(GridIoManager.java:1097)
    at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
    at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
    at java.lang.Thread.run(Thread.java:748)
Caused by: class org.apache.ignite.IgniteCheckedException: Call completed with error, but error serialization failed [errType=ArgumentException, serializationErrMsg=Field type mismatch detected [fieldName=WatsonBuckets, expectedType=103, actualType=12]]
    at org.apache.ignite.internal.processors.platform.utils.PlatformUtils.readInvocationResult(PlatformUtils.java:834)
    at org.apache.ignite.internal.processors.platform.compute.PlatformFullJob.execute0(PlatformFullJob.java:134)
    at org.apache.ignite.internal.processors.platform.compute.PlatformAbstractJob.execute(PlatformAbstractJob.java:80)
    ... 14 more (edited)
{code}

Server-side error:
{code}
{code}



--
This message was sent by Atlassian JIRA
(v6.4.14#64029)