You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@ignite.apache.org by jcalahor <jc...@yahoo.com> on 2018/10/25 19:13:20 UTC

cotinuousquery -> Requesting mapping from grid failed for [ platformId=1, typeId=1173251103]

H,

i'm getting exception on the server nodes when a new City record is added .
The c# code is below:

namespace ignite_test
{
    class Program
    {
  

        class CityEventListener : ICacheEntryEventListener<int, City>

        {

            public void OnEvent(IEnumerable<ICacheEntryEvent&lt;int, City>>
evts)

            {

                foreach (var evt in evts)

                    Console.WriteLine(evt.Value);

            }

        }



        static void Main(string[] args)
        {
            Ignition.ClientMode = true;
            using (var ignite =
Ignition.Start(@"C:\apache_ignite\examples\config\example-ignite.xml"))
            {
                var persons = ignite.GetCache<int, City>("City");

                var localListener = new CityEventListener();
                var qry = new ContinuousQuery<int, City>(localListener);
                {
                    qry.Filter = new RemoteFilter();
                }
                //var query = new SqlQuery("City", "select * from City where
id = 1");
                var queryHandle = persons.QueryContinuous(qry);
                //foreach (var entry in queryHandle.GetInitialQueryCursor())
                  ///  Console.WriteLine("key={0}, val={1}", entry.Key,
entry.Value);
                Console.ReadLine();
            }


        }
    }
}




namespace ignite_shared
{
    public class City
    {
        public City(int id, string name)

        {
            Name = name;
            Id = id;
        }

        [QuerySqlField]
        public int Id { get; set; }
        [QuerySqlField]
        public string Name { get; set; }
    }

}

namespace ignite_shared
{
    public class RemoteFilter : ICacheEntryEventFilter<int, City>
    {
        public bool Evaluate(ICacheEntryEvent<int, City> evt)
        {
            return true;
            //return (evt.Value.Id == 1);
        }
    }
}



One i start the server node, i go into SQlLine and execute the following
command:
CREATE TABLE City (id int PRIMARY KEY, name VARCHAR) WITH
"template=replicated, CACHE_NAME=City, VALUE_TYPE=ignite_shared.City";

then
insert into City (id, name) values (1, 'Lima');


then I start the C# application with no issues, and then i do this on
sqlline:
insert into City (id, name) values (2, 'Quito');


Result (on server node):

[14:07:26,499][SEVERE][sys-#55][] Failure in Java callback
class org.apache.ignite.IgniteException: Platform
error:Apache.Ignite.Core.Binar
y.BinaryObjectException: Requesting mapping from grid failed for
[platformId=1,
typeId=1173251103] ---> Apache.Ignite.Core.Common.JavaException: class
org.apach
e.ignite.binary.BinaryObjectException: Requesting mapping from grid failed
for [
platformId=1, typeId=1173251103]
        at
org.apache.ignite.internal.processors.platform.binary.PlatformBinaryP
rocessor.processInStreamOutStream(PlatformBinaryProcessor.java:126)
        at
org.apache.ignite.internal.processors.platform.PlatformTargetProxyImp
l.inStreamOutStream(PlatformTargetProxyImpl.java:136)
        at
org.apache.ignite.internal.processors.platform.callback.PlatformCallb
ackUtils.inLongOutLong(Native Method)
        at
org.apache.ignite.internal.processors.platform.callback.PlatformCallb
ackGateway.continuousQueryListenerApply(PlatformCallbackGateway.java:377)
        at
org.apache.ignite.internal.processors.platform.utils.PlatformUtils.ap
plyContinuousQueryEvents(PlatformUtils.java:556)
        at
org.apache.ignite.internal.processors.platform.cache.query.PlatformCo
ntinuousQueryImpl.onUpdated(PlatformContinuousQueryImpl.java:200)
        at
org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
tinuousQueryHandler.notifyLocalListener(CacheContinuousQueryHandler.java:942)
        at
org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
tinuousQueryHandler.notifyCallback0(CacheContinuousQueryHandler.java:786)
        at
org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
tinuousQueryHandler.notifyCallback(CacheContinuousQueryHandler.java:727)
        at
org.apache.ignite.internal.processors.continuous.GridContinuousProces
sor.processNotification(GridContinuousProcessor.java:1618)
        at
org.apache.ignite.internal.processors.continuous.GridContinuousProces
sor.access$1800(GridContinuousProcessor.java:108)
        at
org.apache.ignite.internal.processors.continuous.GridContinuousProces
sor$8.onMessage(GridContinuousProcessor.java:1003)
        at
org.apache.ignite.internal.managers.communication.GridIoManager.invok
eListener(GridIoManager.java:1556)
        at
org.apache.ignite.internal.managers.communication.GridIoManager.acces
s$4100(GridIoManager.java:125)
        at
org.apache.ignite.internal.managers.communication.GridIoManager$GridC
ommunicationMessageSet.unwind(GridIoManager.java:2752)
        at
org.apache.ignite.internal.managers.communication.GridIoManager.unwin
dMessageSet(GridIoManager.java:1516)
        at
org.apache.ignite.internal.managers.communication.GridIoManager.acces
s$4400(GridIoManager.java:125)
        at
org.apache.ignite.internal.managers.communication.GridIoManager$10.ru
n(GridIoManager.java:1485)
        at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.
java:1142)
        at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor
.java:617)
        at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.ClassNotFoundException: Requesting mapping from grid
failed
 for [platformId=1, typeId=1173251103]
        at
org.apache.ignite.internal.MarshallerContextImpl.getClassName(Marshal
lerContextImpl.java:385)
        at
org.apache.ignite.internal.processors.platform.binary.PlatformBinaryP
rocessor.processInStreamOutStream(PlatformBinaryProcessor.java:121)
        ... 20 more

   at Apache.Ignite.Core.Impl.Unmanaged.Jni.Env.ExceptionCheck()
   at
Apache.Ignite.Core.Impl.Unmanaged.UnmanagedUtils.TargetInStreamOutStream(G
lobalRef target, Int32 opType, Int64 inMemPtr, Int64 outMemPtr)
   at Apache.Ignite.Core.Impl.PlatformJniTarget.InStreamOutStream[TR](Int32
type
, Action`1 writeAction, Func`2 readAction)
   --- End of inner exception stack trace ---
   at Apache.Ignite.Core.Impl.PlatformJniTarget.InStreamOutStream[TR](Int32
type
, Action`1 writeAction, Func`2 readAction)
   at Apache.Ignite.Core.Impl.Binary.BinaryProcessor.GetTypeName(Int32 id)
   at Apache.Ignite.Core.Impl.Binary.Marshaller.GetDescriptor(Boolean
userType,
Int32 typeId, Boolean requiresType, String typeName, Type knownType)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.ReadFullObject[T](Int32
pos, T
ype typeOverride)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.TryDeserialize[T](T& res,
Type
 typeOverride)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.Deserialize[T](Type
typeOverri
de)
   at
Apache.Ignite.Core.Impl.Binary.BinaryReader.ReadBinaryObject[T](Boolean do
Detach)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.TryDeserialize[T](T& res,
Type
 typeOverride)
   at
Apache.Ignite.Core.Impl.Cache.Query.Continuous.ContinuousQueryUtils.ReadEv
ent0[TK,TV](BinaryReader reader)
   at
Apache.Ignite.Core.Impl.Cache.Query.Continuous.ContinuousQueryUtils.ReadEv
ents[TK,TV](IBinaryStream stream, Marshaller marsh, Boolean keepBinary)
   at
Apache.Ignite.Core.Impl.Cache.Query.Continuous.ContinuousQueryHandleImpl`2
.Apply(IBinaryStream stream)
   at
Apache.Ignite.Core.Impl.Unmanaged.UnmanagedCallbacks.ContinuousQueryListen
erApply(Int64 memPtr)
   at
Apache.Ignite.Core.Impl.Unmanaged.UnmanagedCallbacks.InLongOutLong(Int32 t
ype, Int64 val)
        at
org.apache.ignite.internal.processors.platform.PlatformProcessorImpl.
loggerLog(PlatformProcessorImpl.java:400)
        at
org.apache.ignite.internal.processors.platform.PlatformProcessorImpl.
processInStreamOutLong(PlatformProcessorImpl.java:456)
        at
org.apache.ignite.internal.processors.platform.PlatformProcessorImpl.
processInStreamOutLong(PlatformProcessorImpl.java:503)
        at
org.apache.ignite.internal.processors.platform.PlatformTargetProxyImp
l.inStreamOutLong(PlatformTargetProxyImpl.java:67)
        at
org.apache.ignite.internal.processors.platform.callback.PlatformCallb
ackUtils.inLongOutLong(Native Method)
        at
org.apache.ignite.internal.processors.platform.callback.PlatformCallb
ackGateway.continuousQueryListenerApply(PlatformCallbackGateway.java:377)
        at
org.apache.ignite.internal.processors.platform.utils.PlatformUtils.ap
plyContinuousQueryEvents(PlatformUtils.java:556)
        at
org.apache.ignite.internal.processors.platform.cache.query.PlatformCo
ntinuousQueryImpl.onUpdated(PlatformContinuousQueryImpl.java:200)
        at
org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
tinuousQueryHandler.notifyLocalListener(CacheContinuousQueryHandler.java:942)
        at
org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
tinuousQueryHandler.notifyCallback0(CacheContinuousQueryHandler.java:786)
        at
org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
tinuousQueryHandler.notifyCallback(CacheContinuousQueryHandler.java:727)
        at
org.apache.ignite.internal.processors.continuous.GridContinuousProces
sor.processNotification(GridContinuousProcessor.java:1618)
        at
org.apache.ignite.internal.processors.continuous.GridContinuousProces
sor.access$1800(GridContinuousProcessor.java:108)
        at
org.apache.ignite.internal.processors.continuous.GridContinuousProces
sor$8.onMessage(GridContinuousProcessor.java:1003)
        at
org.apache.ignite.internal.managers.communication.GridIoManager.invok
eListener(GridIoManager.java:1556)
        at
org.apache.ignite.internal.managers.communication.GridIoManager.acces
s$4100(GridIoManager.java:125)
        at
org.apache.ignite.internal.managers.communication.GridIoManager$GridC
ommunicationMessageSet.unwind(GridIoManager.java:2752)
        at
org.apache.ignite.internal.managers.communication.GridIoManager.unwin
dMessageSet(GridIoManager.java:1516)
        at
org.apache.ignite.internal.managers.communication.GridIoManager.acces
s$4400(GridIoManager.java:125)
        at
org.apache.ignite.internal.managers.communication.GridIoManager$10.ru
n(GridIoManager.java:1485)
        at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.
java:1142)
        at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor
.java:617)
        at java.lang.Thread.run(Thread.java:745)







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

Re: cotinuousquery -> Requesting mapping from grid failed for [ platformId=1, typeId=1173251103]

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

Should be OK. Can you prepare a small reproducer of this problem, upload it
to github?

Regards,
-- 
Ilya Kasnacheev


пн, 29 окт. 2018 г. в 16:57, jcalahor <jc...@yahoo.com>:

> i forgot to mention that my starting params is:
> Apache.Ignite.exe
>
> -Assembly=C:\apache_ignite\_net\ignite_shared\ignite_shared\bin\Debug\ignite_shared.dll
>
>
>
>
>
> --
> Sent from: http://apache-ignite-users.70518.x6.nabble.com/
>

Re: cotinuousquery -> Requesting mapping from grid failed for [ platformId=1, typeId=1173251103]

Posted by jcalahor <jc...@yahoo.com>.
?




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

Re: cotinuousquery -> Requesting mapping from grid failed for [ platformId=1, typeId=1173251103]

Posted by jcalahor <jc...@yahoo.com>.
i forgot to mention that my starting params is:
Apache.Ignite.exe
-Assembly=C:\apache_ignite\_net\ignite_shared\ignite_shared\bin\Debug\ignite_shared.dll





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

Re: cotinuousquery -> Requesting mapping from grid failed for [ platformId=1, typeId=1173251103]

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

This usually indicates that assembly with specified type is not loaded on a
node. When using Apache.Ignite.exe, make
sure to load assemblies with -assembly parameter. Alternatively, set
IgniteConfiguration.PeerAssemblyLoadingEnabled to true.

Should be pretty explanatory, shouldn't it?

To use remote C# filters, you need to:
- Start all Ignite nodes as .Net nodes (Apache.Ignite.exe or custom project)
- Include .dlls with filters code on all nodes OR enable
PeerAssemblyLoading.

Regards,
-- 
Ilya Kasnacheev


пт, 26 окт. 2018 г. в 18:10, jcalahor <jc...@yahoo.com>:

> i made the config changes, and now the filter was is not found, the filter
> was working earlier.
>
> C:\apache_ignite\platforms\dotnet\bin>Apache.Ignite.exe
> -Assembly=C:\apache_igni
> te\_net\ignite_shared\ignite_shared\bin\Debug\ignite_shared.dll
> Oct 26, 2018 10:02:49 AM
> org.springframework.beans.factory.xml.XmlBeanDefinition
> Reader loadBeanDefinitions
> INFO: Loading XML bean definitions from URL
> [file:/C:/apache_ignite/examples/con
> fig/example-ignite.xml]
> Oct 26, 2018 10:02:49 AM
> org.springframework.beans.factory.xml.XmlBeanDefinition
> Reader loadBeanDefinitions
> INFO: Loading XML bean definitions from URL
> [file:/C:/apache_ignite/examples/con
> fig/example-default.xml]
> Oct 26, 2018 10:02:49 AM
> org.springframework.context.support.AbstractApplication
> Context prepareRefresh
> INFO: Refreshing
> org.springframework.context.support.GenericApplicationContext@1
> 8ef96: startup date [Fri Oct 26 10:02:49 CDT 2018]; root of context
> hierarchy
> [10:02:50]    __________  ________________
> [10:02:50]   /  _/ ___/ |/ /  _/_  __/ __/
> [10:02:50]  _/ // (7 7    // /  / / / _/
> [10:02:50] /___/\___/_/|_/___/ /_/ /___/
> [10:02:50]
> [10:02:50] ver. 2.6.0#20180710-sha1:669feacc
> [10:02:50] 2018 Copyright(C) Apache Software Foundation
> [10:02:50]
> [10:02:50] Ignite documentation: http://ignite.apache.org
> [10:02:50]
> [10:02:50] Quiet mode.
> [10:02:50]   ^-- Logging to file
> 'C:\apache_ignite\work\log\ignite-117c9354.0.lo
> g'
> [10:02:50]   ^-- Logging by 'JavaLogger [quiet=true, config=null]'
> [10:02:50]   ^-- To see **FULL** console log here add -DIGNITE_QUIET=false
> or "-
> v" to ignite.{sh|bat}
> [10:02:50]
> [10:02:50] OS: Windows 7 6.1 amd64
> [10:02:50] VM information: Java(TM) SE Runtime Environment 1.8.0_101-b13
> Oracle
> Corporation Java HotSpot(TM) 64-Bit Server VM 25.101-b13
> [10:02:50] Initial heap size is 384MB (should be no less than 512MB, use
> -Xms512
> m -Xmx512m).
> [10:02:50] Configured plugins:
> [10:02:50]   ^-- None
> [10:02:50]
> [10:02:50] Configured failure handler: [hnd=StopNodeOrHaltFailureHandler
> [trySto
> p=false, timeout=0]]
> [10:02:50] Message queue limit is set to 0 which may lead to potential
> OOMEs
> whe
> n running cache operations in FULL_ASYNC or PRIMARY_SYNC modes due to
> message qu
> eues growth on sender and receiver sides.
> [10:02:50] Security status [authentication=off, tls/ssl=off]
> [10:03:16] Nodes started on local machine require more than 20% 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=20952MB,
> available=2
> 4573MB]
> [10:03:16] Performance suggestions for grid  (fix if possible)
> [10:03:16] To disable, set -DIGNITE_PERFORMANCE_SUGGESTIONS_DISABLED=true
> [10:03:16]   ^-- Disable grid events (remove 'includeEventTypes' from
> configurat
> ion)
> [10:03:16]   ^-- Enable G1 Garbage Collector (add '-XX:+UseG1GC' to JVM
> options)
>
> [10:03:16]   ^-- Specify JVM heap max size (add '-Xmx<size>[g|G|m|M|k|K]'
> to
> JVM
>  options)
> [10:03:16]   ^-- Set max direct memory size if getting 'OOME: Direct buffer
> memo
> ry' (add '-XX:MaxDirectMemorySize=<size>[g|G|m|M|k|K]' to JVM options)
> [10:03:16]   ^-- Disable processing of calls to System.gc() (add
> '-XX:+DisableEx
> plicitGC' to JVM options)
> [10:03:16] Refer to this page for more performance suggestions:
> https://apacheig
> nite.readme.io/docs/jvm-and-system-tuning
> [10:03:16]
> [10:03:16] To start Console Management & Monitoring run
> ignitevisorcmd.{sh|bat}
> [10:03:16]
> [10:03:16] Ignite node started OK (id=117c9354)
> [10:03:16] Topology snapshot [ver=2, servers=2, clients=0, CPUs=12,
> offheap=9.6G
> B, heap=11.0GB]
> [10:03:16]   ^-- Node [id=117C9354-D951-4AF0-9AA8-C3A4D68E3E0F,
> clusterState=ACT
> IVE]
> [10:03:16] Data Regions Configured:
> [10:03:16]   ^-- default [initSize=256.0 MiB, maxSize=4.8 GiB,
> persistenceEnable
> d=false]
> [10:03:56] Topology snapshot [ver=3, servers=2, clients=1, CPUs=12,
> offheap=9.6G
> B, heap=16.0GB]
> [10:03:56]   ^-- Node [id=117C9354-D951-4AF0-9AA8-C3A4D68E3E0F,
> clusterState=ACT
> IVE]
> [10:03:56] Data Regions Configured:
> [10:03:56]   ^-- default [initSize=256.0 MiB, maxSize=4.8 GiB,
> persistenceEnable
> d=false]
> [10:04:20,994][SEVERE][client-connector-#72][] Failure in Java callback
> class org.apache.ignite.IgniteException: Platform
> error:Apache.Ignite.Core.Binar
> y.BinaryObjectException: No matching type found for object
> [typeId=1939983858, t
> ypeName=ignite_shared.RemoteFilter]. This usually indicates that assembly
> with s
> pecified type is not loaded on a node. When using Apache.Ignite.exe, make
> sure t
> o load assemblies with -assembly parameter. Alternatively, set
> IgniteConfigurati
> on.PeerAssemblyLoadingEnabled to true.
>    at Apache.Ignite.Core.Impl.Binary.BinaryReader.ReadFullObject[T](Int32
> pos, T
> ype typeOverride)
>    at Apache.Ignite.Core.Impl.Binary.BinaryReader.TryDeserialize[T](T& res,
> Type
>  typeOverride)
>    at Apache.Ignite.Core.Impl.Binary.BinaryReader.Deserialize[T](Type
> typeOverri
> de)
>    at
> Apache.Ignite.Core.Impl.Cache.Query.Continuous.ContinuousQueryFilterHolder
> ..ctor(IBinaryRawReader reader)
>    at
> Apache.Ignite.Core.Impl.Binary.Marshaller.<AddSystemTypes>b__d(BinaryReade
> r r)
>    at
> Apache.Ignite.Core.Impl.Binary.BinarySystemTypeSerializer`1.ReadBinary[T1]
> (BinaryReader reader, IBinaryTypeDescriptor desc, Int32 pos, Type
> typeOverride)
>    at Apache.Ignite.Core.Impl.Binary.BinaryReader.ReadFullObject[T](Int32
> pos, T
> ype typeOverride)
>    at Apache.Ignite.Core.Impl.Binary.BinaryReader.TryDeserialize[T](T& res,
> Type
>  typeOverride)
>    at Apache.Ignite.Core.Impl.Binary.BinaryReader.Deserialize[T](Type
> typeOverri
> de)
>    at
> Apache.Ignite.Core.Impl.Binary.BinaryReader.ReadBinaryObject[T](Boolean do
> Detach)
>    at Apache.Ignite.Core.Impl.Binary.BinaryReader.TryDeserialize[T](T& res,
> Type
>  typeOverride)
>    at Apache.Ignite.Core.Impl.Binary.BinaryReader.Deserialize[T](Type
> typeOverri
> de)
>    at
> Apache.Ignite.Core.Impl.Unmanaged.UnmanagedCallbacks.ContinuousQueryFilter
> Create(Int64 memPtr)
>    at
> Apache.Ignite.Core.Impl.Unmanaged.UnmanagedCallbacks.InLongOutLong(Int32 t
> ype, Int64 val)
>         at
> org.apache.ignite.internal.processors.platform.PlatformProcessorImpl.
> loggerLog(PlatformProcessorImpl.java:400)
>         at
> org.apache.ignite.internal.processors.platform.PlatformProcessorImpl.
> processInStreamOutLong(PlatformProcessorImpl.java:456)
>         at
> org.apache.ignite.internal.processors.platform.PlatformProcessorImpl.
> processInStreamOutLong(PlatformProcessorImpl.java:503)
>         at
> org.apache.ignite.internal.processors.platform.PlatformTargetProxyImp
> l.inStreamOutLong(PlatformTargetProxyImpl.java:67)
>         at
> org.apache.ignite.internal.processors.platform.callback.PlatformCallb
> ackUtils.inLongOutLong(Native Method)
>         at
> org.apache.ignite.internal.processors.platform.callback.PlatformCallb
> ackGateway.continuousQueryFilterCreate(PlatformCallbackGateway.java:394)
>         at
> org.apache.ignite.internal.processors.platform.cache.query.PlatformCo
>
> ntinuousQueryRemoteFilter.deploy(PlatformContinuousQueryRemoteFilter.java:124)
>         at
> org.apache.ignite.internal.processors.platform.cache.query.PlatformCo
>
> ntinuousQueryRemoteFilter.evaluate(PlatformContinuousQueryRemoteFilter.java:84)
>         at
> org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
> tinuousQueryHandler.filter(CacheContinuousQueryHandler.java:833)
>         at
> org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
> tinuousQueryHandler$2.onEntryUpdated(CacheContinuousQueryHandler.java:422)
>         at
> org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
> tinuousQueryManager.onEntryUpdated(CacheContinuousQueryManager.java:376)
>         at
> org.apache.ignite.internal.processors.cache.GridCacheMapEntry.innerUp
> date(GridCacheMapEntry.java:1931)
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
> idDhtAtomicCache.updateSingle(GridDhtAtomicCache.java:2421)
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
> idDhtAtomicCache.update(GridDhtAtomicCache.java:1883)
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
> idDhtAtomicCache.updateAllAsyncInternal0(GridDhtAtomicCache.java:1736)
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
> idDhtAtomicCache.updateAllAsyncInternal(GridDhtAtomicCache.java:1628)
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
>
> idNearAtomicAbstractUpdateFuture.sendSingleRequest(GridNearAtomicAbstractUpdateF
> uture.java:299)
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
>
> idNearAtomicSingleUpdateFuture.map(GridNearAtomicSingleUpdateFuture.java:483)
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
>
> idNearAtomicSingleUpdateFuture.mapOnTopology(GridNearAtomicSingleUpdateFuture.ja
> va:443)
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
>
> idNearAtomicAbstractUpdateFuture.map(GridNearAtomicAbstractUpdateFuture.java:248
> )
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
> idDhtAtomicCache.update0(GridDhtAtomicCache.java:1117)
>         at
> org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
> idDhtAtomicCache.put0(GridDhtAtomicCache.java:606)
>         at
> org.apache.ignite.internal.processors.cache.GridCacheAdapter.put(Grid
> CacheAdapter.java:2372)
>         at
> org.apache.ignite.internal.processors.cache.GridCacheAdapter.putIfAbs
> ent(GridCacheAdapter.java:2755)
>         at
> org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
> .doInsert(DmlStatementsProcessor.java:800)
>         at
> org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
> .processDmlSelectResult(DmlStatementsProcessor.java:581)
>         at
> org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
> .executeUpdateStatement(DmlStatementsProcessor.java:539)
>         at
> org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
> .updateSqlFields(DmlStatementsProcessor.java:171)
>         at
> org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
> .updateSqlFieldsDistributed(DmlStatementsProcessor.java:345)
>         at
> org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing.doRun
> Prepared(IgniteH2Indexing.java:1706)
>         at
> org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing.query
> SqlFields(IgniteH2Indexing.java:1671)
>         at
> org.apache.ignite.internal.processors.query.GridQueryProcessor$4.appl
> yx(GridQueryProcessor.java:2035)
>         at
> org.apache.ignite.internal.processors.query.GridQueryProcessor$4.appl
> yx(GridQueryProcessor.java:2030)
>         at
> org.apache.ignite.internal.util.lang.IgniteOutClosureX.apply(IgniteOu
> tClosureX.java:36)
>         at
> org.apache.ignite.internal.processors.query.GridQueryProcessor.execut
> eQuery(GridQueryProcessor.java:2578)
>         at
> org.apache.ignite.internal.processors.query.GridQueryProcessor.queryS
> qlFields(GridQueryProcessor.java:2044)
>         at
> org.apache.ignite.internal.processors.odbc.jdbc.JdbcRequestHandler.ex
> ecuteQuery(JdbcRequestHandler.java:456)
>         at
> org.apache.ignite.internal.processors.odbc.jdbc.JdbcRequestHandler.ha
> ndle(JdbcRequestHandler.java:203)
>         at
> org.apache.ignite.internal.processors.odbc.ClientListenerNioListener.
> onMessage(ClientListenerNioListener.java:160)
>         at
> org.apache.ignite.internal.processors.odbc.ClientListenerNioListener.
> onMessage(ClientListenerNioListener.java:44)
>         at
> org.apache.ignite.internal.util.nio.GridNioFilterChain$TailFilter.onM
> essageReceived(GridNioFilterChain.java:279)
>         at
> org.apache.ignite.internal.util.nio.GridNioFilterAdapter.proceedMessa
> geReceived(GridNioFilterAdapter.java:109)
>         at
> org.apache.ignite.internal.util.nio.GridNioAsyncNotifyFilter$3.body(G
> ridNioAsyncNotifyFilter.java:97)
>         at
> org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java
> :110)
>         at
> org.apache.ignite.internal.util.worker.GridWorkerPool$1.run(GridWorke
> rPool.java:70)
>         at
> java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.
> java:1142)
>         at
> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor
> .java:617)
>         at java.lang.Thread.run(Thread.java:745)
> [10:04:21,036][SEVERE][client-connector-#72][query] CacheEntryEventFilter
> failed
> : javax.cache.event.CacheEntryListenerException: Failed to deploy the
> filter.
>
>
>
>
> --
> Sent from: http://apache-ignite-users.70518.x6.nabble.com/
>

Re: cotinuousquery -> Requesting mapping from grid failed for [ platformId=1, typeId=1173251103]

Posted by jcalahor <jc...@yahoo.com>.
i made the config changes, and now the filter was is not found, the filter
was working earlier.

C:\apache_ignite\platforms\dotnet\bin>Apache.Ignite.exe
-Assembly=C:\apache_igni
te\_net\ignite_shared\ignite_shared\bin\Debug\ignite_shared.dll
Oct 26, 2018 10:02:49 AM
org.springframework.beans.factory.xml.XmlBeanDefinition
Reader loadBeanDefinitions
INFO: Loading XML bean definitions from URL
[file:/C:/apache_ignite/examples/con
fig/example-ignite.xml]
Oct 26, 2018 10:02:49 AM
org.springframework.beans.factory.xml.XmlBeanDefinition
Reader loadBeanDefinitions
INFO: Loading XML bean definitions from URL
[file:/C:/apache_ignite/examples/con
fig/example-default.xml]
Oct 26, 2018 10:02:49 AM
org.springframework.context.support.AbstractApplication
Context prepareRefresh
INFO: Refreshing
org.springframework.context.support.GenericApplicationContext@1
8ef96: startup date [Fri Oct 26 10:02:49 CDT 2018]; root of context
hierarchy
[10:02:50]    __________  ________________
[10:02:50]   /  _/ ___/ |/ /  _/_  __/ __/
[10:02:50]  _/ // (7 7    // /  / / / _/
[10:02:50] /___/\___/_/|_/___/ /_/ /___/
[10:02:50]
[10:02:50] ver. 2.6.0#20180710-sha1:669feacc
[10:02:50] 2018 Copyright(C) Apache Software Foundation
[10:02:50]
[10:02:50] Ignite documentation: http://ignite.apache.org
[10:02:50]
[10:02:50] Quiet mode.
[10:02:50]   ^-- Logging to file
'C:\apache_ignite\work\log\ignite-117c9354.0.lo
g'
[10:02:50]   ^-- Logging by 'JavaLogger [quiet=true, config=null]'
[10:02:50]   ^-- To see **FULL** console log here add -DIGNITE_QUIET=false
or "-
v" to ignite.{sh|bat}
[10:02:50]
[10:02:50] OS: Windows 7 6.1 amd64
[10:02:50] VM information: Java(TM) SE Runtime Environment 1.8.0_101-b13
Oracle
Corporation Java HotSpot(TM) 64-Bit Server VM 25.101-b13
[10:02:50] Initial heap size is 384MB (should be no less than 512MB, use
-Xms512
m -Xmx512m).
[10:02:50] Configured plugins:
[10:02:50]   ^-- None
[10:02:50]
[10:02:50] Configured failure handler: [hnd=StopNodeOrHaltFailureHandler
[trySto
p=false, timeout=0]]
[10:02:50] Message queue limit is set to 0 which may lead to potential OOMEs
whe
n running cache operations in FULL_ASYNC or PRIMARY_SYNC modes due to
message qu
eues growth on sender and receiver sides.
[10:02:50] Security status [authentication=off, tls/ssl=off]
[10:03:16] Nodes started on local machine require more than 20% 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=20952MB,
available=2
4573MB]
[10:03:16] Performance suggestions for grid  (fix if possible)
[10:03:16] To disable, set -DIGNITE_PERFORMANCE_SUGGESTIONS_DISABLED=true
[10:03:16]   ^-- Disable grid events (remove 'includeEventTypes' from
configurat
ion)
[10:03:16]   ^-- Enable G1 Garbage Collector (add '-XX:+UseG1GC' to JVM
options)

[10:03:16]   ^-- Specify JVM heap max size (add '-Xmx<size>[g|G|m|M|k|K]' to
JVM
 options)
[10:03:16]   ^-- Set max direct memory size if getting 'OOME: Direct buffer
memo
ry' (add '-XX:MaxDirectMemorySize=<size>[g|G|m|M|k|K]' to JVM options)
[10:03:16]   ^-- Disable processing of calls to System.gc() (add
'-XX:+DisableEx
plicitGC' to JVM options)
[10:03:16] Refer to this page for more performance suggestions:
https://apacheig
nite.readme.io/docs/jvm-and-system-tuning
[10:03:16]
[10:03:16] To start Console Management & Monitoring run
ignitevisorcmd.{sh|bat}
[10:03:16]
[10:03:16] Ignite node started OK (id=117c9354)
[10:03:16] Topology snapshot [ver=2, servers=2, clients=0, CPUs=12,
offheap=9.6G
B, heap=11.0GB]
[10:03:16]   ^-- Node [id=117C9354-D951-4AF0-9AA8-C3A4D68E3E0F,
clusterState=ACT
IVE]
[10:03:16] Data Regions Configured:
[10:03:16]   ^-- default [initSize=256.0 MiB, maxSize=4.8 GiB,
persistenceEnable
d=false]
[10:03:56] Topology snapshot [ver=3, servers=2, clients=1, CPUs=12,
offheap=9.6G
B, heap=16.0GB]
[10:03:56]   ^-- Node [id=117C9354-D951-4AF0-9AA8-C3A4D68E3E0F,
clusterState=ACT
IVE]
[10:03:56] Data Regions Configured:
[10:03:56]   ^-- default [initSize=256.0 MiB, maxSize=4.8 GiB,
persistenceEnable
d=false]
[10:04:20,994][SEVERE][client-connector-#72][] Failure in Java callback
class org.apache.ignite.IgniteException: Platform
error:Apache.Ignite.Core.Binar
y.BinaryObjectException: No matching type found for object
[typeId=1939983858, t
ypeName=ignite_shared.RemoteFilter]. This usually indicates that assembly
with s
pecified type is not loaded on a node. When using Apache.Ignite.exe, make
sure t
o load assemblies with -assembly parameter. Alternatively, set
IgniteConfigurati
on.PeerAssemblyLoadingEnabled to true.
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.ReadFullObject[T](Int32
pos, T
ype typeOverride)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.TryDeserialize[T](T& res,
Type
 typeOverride)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.Deserialize[T](Type
typeOverri
de)
   at
Apache.Ignite.Core.Impl.Cache.Query.Continuous.ContinuousQueryFilterHolder
..ctor(IBinaryRawReader reader)
   at
Apache.Ignite.Core.Impl.Binary.Marshaller.<AddSystemTypes>b__d(BinaryReade
r r)
   at
Apache.Ignite.Core.Impl.Binary.BinarySystemTypeSerializer`1.ReadBinary[T1]
(BinaryReader reader, IBinaryTypeDescriptor desc, Int32 pos, Type
typeOverride)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.ReadFullObject[T](Int32
pos, T
ype typeOverride)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.TryDeserialize[T](T& res,
Type
 typeOverride)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.Deserialize[T](Type
typeOverri
de)
   at
Apache.Ignite.Core.Impl.Binary.BinaryReader.ReadBinaryObject[T](Boolean do
Detach)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.TryDeserialize[T](T& res,
Type
 typeOverride)
   at Apache.Ignite.Core.Impl.Binary.BinaryReader.Deserialize[T](Type
typeOverri
de)
   at
Apache.Ignite.Core.Impl.Unmanaged.UnmanagedCallbacks.ContinuousQueryFilter
Create(Int64 memPtr)
   at
Apache.Ignite.Core.Impl.Unmanaged.UnmanagedCallbacks.InLongOutLong(Int32 t
ype, Int64 val)
        at
org.apache.ignite.internal.processors.platform.PlatformProcessorImpl.
loggerLog(PlatformProcessorImpl.java:400)
        at
org.apache.ignite.internal.processors.platform.PlatformProcessorImpl.
processInStreamOutLong(PlatformProcessorImpl.java:456)
        at
org.apache.ignite.internal.processors.platform.PlatformProcessorImpl.
processInStreamOutLong(PlatformProcessorImpl.java:503)
        at
org.apache.ignite.internal.processors.platform.PlatformTargetProxyImp
l.inStreamOutLong(PlatformTargetProxyImpl.java:67)
        at
org.apache.ignite.internal.processors.platform.callback.PlatformCallb
ackUtils.inLongOutLong(Native Method)
        at
org.apache.ignite.internal.processors.platform.callback.PlatformCallb
ackGateway.continuousQueryFilterCreate(PlatformCallbackGateway.java:394)
        at
org.apache.ignite.internal.processors.platform.cache.query.PlatformCo
ntinuousQueryRemoteFilter.deploy(PlatformContinuousQueryRemoteFilter.java:124)
        at
org.apache.ignite.internal.processors.platform.cache.query.PlatformCo
ntinuousQueryRemoteFilter.evaluate(PlatformContinuousQueryRemoteFilter.java:84)
        at
org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
tinuousQueryHandler.filter(CacheContinuousQueryHandler.java:833)
        at
org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
tinuousQueryHandler$2.onEntryUpdated(CacheContinuousQueryHandler.java:422)
        at
org.apache.ignite.internal.processors.cache.query.continuous.CacheCon
tinuousQueryManager.onEntryUpdated(CacheContinuousQueryManager.java:376)
        at
org.apache.ignite.internal.processors.cache.GridCacheMapEntry.innerUp
date(GridCacheMapEntry.java:1931)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idDhtAtomicCache.updateSingle(GridDhtAtomicCache.java:2421)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idDhtAtomicCache.update(GridDhtAtomicCache.java:1883)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idDhtAtomicCache.updateAllAsyncInternal0(GridDhtAtomicCache.java:1736)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idDhtAtomicCache.updateAllAsyncInternal(GridDhtAtomicCache.java:1628)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idNearAtomicAbstractUpdateFuture.sendSingleRequest(GridNearAtomicAbstractUpdateF
uture.java:299)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idNearAtomicSingleUpdateFuture.map(GridNearAtomicSingleUpdateFuture.java:483)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idNearAtomicSingleUpdateFuture.mapOnTopology(GridNearAtomicSingleUpdateFuture.ja
va:443)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idNearAtomicAbstractUpdateFuture.map(GridNearAtomicAbstractUpdateFuture.java:248
)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idDhtAtomicCache.update0(GridDhtAtomicCache.java:1117)
        at
org.apache.ignite.internal.processors.cache.distributed.dht.atomic.Gr
idDhtAtomicCache.put0(GridDhtAtomicCache.java:606)
        at
org.apache.ignite.internal.processors.cache.GridCacheAdapter.put(Grid
CacheAdapter.java:2372)
        at
org.apache.ignite.internal.processors.cache.GridCacheAdapter.putIfAbs
ent(GridCacheAdapter.java:2755)
        at
org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
.doInsert(DmlStatementsProcessor.java:800)
        at
org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
.processDmlSelectResult(DmlStatementsProcessor.java:581)
        at
org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
.executeUpdateStatement(DmlStatementsProcessor.java:539)
        at
org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
.updateSqlFields(DmlStatementsProcessor.java:171)
        at
org.apache.ignite.internal.processors.query.h2.DmlStatementsProcessor
.updateSqlFieldsDistributed(DmlStatementsProcessor.java:345)
        at
org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing.doRun
Prepared(IgniteH2Indexing.java:1706)
        at
org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing.query
SqlFields(IgniteH2Indexing.java:1671)
        at
org.apache.ignite.internal.processors.query.GridQueryProcessor$4.appl
yx(GridQueryProcessor.java:2035)
        at
org.apache.ignite.internal.processors.query.GridQueryProcessor$4.appl
yx(GridQueryProcessor.java:2030)
        at
org.apache.ignite.internal.util.lang.IgniteOutClosureX.apply(IgniteOu
tClosureX.java:36)
        at
org.apache.ignite.internal.processors.query.GridQueryProcessor.execut
eQuery(GridQueryProcessor.java:2578)
        at
org.apache.ignite.internal.processors.query.GridQueryProcessor.queryS
qlFields(GridQueryProcessor.java:2044)
        at
org.apache.ignite.internal.processors.odbc.jdbc.JdbcRequestHandler.ex
ecuteQuery(JdbcRequestHandler.java:456)
        at
org.apache.ignite.internal.processors.odbc.jdbc.JdbcRequestHandler.ha
ndle(JdbcRequestHandler.java:203)
        at
org.apache.ignite.internal.processors.odbc.ClientListenerNioListener.
onMessage(ClientListenerNioListener.java:160)
        at
org.apache.ignite.internal.processors.odbc.ClientListenerNioListener.
onMessage(ClientListenerNioListener.java:44)
        at
org.apache.ignite.internal.util.nio.GridNioFilterChain$TailFilter.onM
essageReceived(GridNioFilterChain.java:279)
        at
org.apache.ignite.internal.util.nio.GridNioFilterAdapter.proceedMessa
geReceived(GridNioFilterAdapter.java:109)
        at
org.apache.ignite.internal.util.nio.GridNioAsyncNotifyFilter$3.body(G
ridNioAsyncNotifyFilter.java:97)
        at
org.apache.ignite.internal.util.worker.GridWorker.run(GridWorker.java
:110)
        at
org.apache.ignite.internal.util.worker.GridWorkerPool$1.run(GridWorke
rPool.java:70)
        at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.
java:1142)
        at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor
.java:617)
        at java.lang.Thread.run(Thread.java:745)
[10:04:21,036][SEVERE][client-connector-#72][query] CacheEntryEventFilter
failed
: javax.cache.event.CacheEntryListenerException: Failed to deploy the
filter.




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

Re: cotinuousquery -> Requesting mapping from grid failed for [ platformId=1, typeId=1173251103]

Posted by akurbanov <an...@gmail.com>.
Hello,

This issue seems to be raised as you didn't specify binary configuration for
your C# type. Since you create your entity via sqlline (actually it doesn't
matter where do you create it), Ignite knows nothing about C# type mapping
to Java type:
/Caused by: java.lang.ClassNotFoundException: Requesting mapping from grid 
failed 
 for [platformId=1, typeId=1173251103] /

Please follow the links for docs and samples to find out how to make it work
correctly:
1. https://apacheignite-net.readme.io/docs/platform-interoperability
Refer to simple name mapper (which ignores namespace) can be used to avoid
this problem. It should be configured both on .NET and Java sides, allow it
inside your xml configuration or the one that you prefer.

2. https://ptupitsyn.github.io/Ignite-Multi-Platform-Cluster  
Initially written for 1.7, 2.0+ version could be found on github:
https://github.com/ptupitsyn/ignite-multi-platform-demo/tree/ignite-2.0

Regards,
Anton



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