You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@ignite.apache.org by dkarachentsev <dk...@gridgain.com> on 2017/02/20 15:20:06 UTC

Re: java.lang.NoClassDefFoundError: Could not initialize class org.apache.ignite.sink.flink.IgniteSink$SinkContext$Holder

Hi,

Check that file in path igniteCfgFile that you pass to IgniteSink
constructor is available. If class initialization failed
NoClassDefFoundError will be thrown. 

Also verify if IgniteSink$SinkContext$Holder.class is present in
ignite-flink-2.0.jar.

-Dmitry.



--
View this message in context: http://apache-ignite-users.70518.x6.nabble.com/java-lang-NoClassDefFoundError-Could-not-initialize-class-org-apache-ignite-sink-flink-IgniteSink-Sir-tp10703p10733.html
Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: java.lang.NoClassDefFoundError: Could not initialize class org.apache.ignite.sink.flink.IgniteSink$SinkContext$Holder

Posted by vkulichenko <va...@gmail.com>.
kadsank wrote
> Thanks, But can you suggest the name of missing libraries.

I assume you need ignite-flink module with all its dependencies.

-Val



--
View this message in context: http://apache-ignite-users.70518.x6.nabble.com/java-lang-NoClassDefFoundError-Could-not-initialize-class-org-apache-ignite-sink-flink-IgniteSink-Sir-tp10703p10883.html
Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: java.lang.NoClassDefFoundError: Could not initialize class org.apache.ignite.sink.flink.IgniteSink$SinkContext$Holder

Posted by vkulichenko <va...@gmail.com>.



--
View this message in context: http://apache-ignite-users.70518.x6.nabble.com/java-lang-NoClassDefFoundError-Could-not-initialize-class-org-apache-ignite-sink-flink-IgniteSink-Sir-tp10703p10881.html
Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: java.lang.NoClassDefFoundError: Could not initialize class org.apache.ignite.sink.flink.IgniteSink$SinkContext$Holder

Posted by vkulichenko <va...@gmail.com>.
Hi,

Please properly subscribe to the mailing list so that the community can
receive email notifications for your messages. To subscribe, send empty
email to user-subscribe@ignite.apache.org and follow simple instructions in
the reply.


kadsank wrote
> Please try to run the programe on flink cluster because I think the Static
> initialization and serialization of object are causing the problem.
> 
> 
> Error log:
> 
> Cluster configuration: Standalone cluster with JobManager at
> /192.168.140.53:6123
> Using address 192.168.140.53:6123 to connect to JobManager.
> JobManager web interface address http://192.168.140.53:8081
> Starting execution of program
> [10:08:25]    __________  ________________
> [10:08:25]   /  _/ ___/ |/ /  _/_  __/ __/
> [10:08:25]  _/ // (7 7    // /  / / / _/
> [10:08:25] /___/\___/_/|_/___/ /_/ /___/
> [10:08:25]
> [10:08:25] ver. 2.0.0-SNAPSHOT#20170110-sha1:ff0caf81
> [10:08:25] 2016 Copyright(C) Apache Software Foundation
> [10:08:25]
> [10:08:25] Ignite documentation: http://ignite.apache.org
> [10:08:25]
> [10:08:25] Quiet mode.
> [10:08:25]   ^-- Logging to file
> '/opt/apache-ignite-fabric-2.0.0-SNAPSHOT-bin/work/log/ignite-5468b9c1.0.log'
> [10:08:25]   ^-- To see **FULL** console log here add -DIGNITE_QUIET=false
> or "-v" to ignite.{sh|bat}
> [10:08:25]
> [10:08:25] OS: Linux 2.6.32-431.el6.x86_64 amd64
> [10:08:25] VM information: Java(TM) SE Runtime Environment 1.8.0_71-b15
> Oracle Corporation Java HotSpot(TM) 64-Bit Server VM 25.71-b15
> [10:08:25] Configured plugins:
> [10:08:25]   ^-- None
> [10:08:25]
> [10:08:25] 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.
> [10:08:25] Security status [authentication=off, tls/ssl=off]
> [10:08:27] To start Console Management & Monitoring run
> ignitevisorcmd.{sh|bat}
> [10:08:27]
> [10:08:27] Ignite node started OK (id=5468b9c1)
> [10:08:27] Topology snapshot [ver=201, servers=2, clients=0, CPUs=48,
> heap=28.0GB]
> Submitting job with JobID: 2bd79002612254209186cd6aeec8e043. Waiting for
> job completion.
> Connected to JobManager at
> Actor[akka.tcp://flink@192.168.140.53:6123/user/jobmanager#1956747552]
> 02/23/2017 10:08:28     Job execution switched to status RUNNING.
> 02/23/2017 10:08:28     Source: Custom Source -> Flat Map -> Sink:
> Unnamed(1/1) switched to SCHEDULED
> 02/23/2017 10:08:28     Source: Custom Source -> Flat Map -> Sink:
> Unnamed(1/1) switched to DEPLOYING
> 02/23/2017 10:08:28     Source: Custom Source -> Flat Map -> Sink:
> Unnamed(1/1) switched to RUNNING
> 02/23/2017 10:08:28     Source: Custom Source -> Flat Map -> Sink:
> Unnamed(1/1) switched to FAILED
> java.lang.NoClassDefFoundError: Could not initialize class
> org.apache.ignite.sink.flink.IgniteSink$SinkContext$Holder
>         at
> org.apache.ignite.sink.flink.IgniteSink$SinkContext.getStreamer(IgniteSink.java:201)
>         at
> org.apache.ignite.sink.flink.IgniteSink$SinkContext.access$100(IgniteSink.java:175)
>         at
> org.apache.ignite.sink.flink.IgniteSink.invoke(IgniteSink.java:165)
>         at
> org.apache.flink.streaming.api.operators.StreamSink.processElement(StreamSink.java:39)
>         at
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:391)
>         at
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:376)
>         at
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:366)
>         at
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:349)
>         at
> org.apache.flink.streaming.api.operators.TimestampedCollector.collect(TimestampedCollector.java:51)
>         at flink_ignite_sink$Splitter.flatMap(flink_ignite_sink.java:189)
>         at flink_ignite_sink$Splitter.flatMap(flink_ignite_sink.java:1)
>         at
> org.apache.flink.streaming.api.operators.StreamFlatMap.processElement(StreamFlatMap.java:48)
>         at
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:391)
>         at
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:376)
>         at
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:366)
>         at
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:349)
>         at
> org.apache.flink.streaming.api.operators.StreamSource$NonTimestampContext.collect(StreamSource.java:161)
>         at
> org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher.emitRecord(AbstractFetcher.java:225)
>         at
> org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher.run(Kafka09Fetcher.java:253)
>         at java.lang.Thread.run(Thread.java:745)
> 
> 02/23/2017 10:08:28     Job execution switched to status FAILING.
> java.lang.NoClassDefFoundError: Could not initialize class
> org.apache.ignite.sink.flink.IgniteSink$SinkContext$Holder
>         at
> org.apache.ignite.sink.flink.IgniteSink$SinkContext.getStreamer(IgniteSink.java:201)
>         at
> org.apache.ignite.sink.flink.IgniteSink$SinkContext.access$100(IgniteSink.java:175)
>         at
> org.apache.ignite.sink.flink.IgniteSink.invoke(IgniteSink.java:165)
>         at
> org.apache.flink.streaming.api.operators.StreamSink.processElement(StreamSink.java:39)
>         at
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:391)
>         at
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:376)
>         at
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:366)
>         at
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:349)
>         at
> org.apache.flink.streaming.api.operators.TimestampedCollector.collect(TimestampedCollector.java:51)
>         at flink_ignite_sink$Splitter.flatMap(flink_ignite_sink.java:189)
>         at flink_ignite_sink$Splitter.flatMap(flink_ignite_sink.java:1)
>         at
> org.apache.flink.streaming.api.operators.StreamFlatMap.processElement(StreamFlatMap.java:48)
>         at
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:391)
>         at
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:376)
>         at
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:366)
>         at
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:349)
>         at
> org.apache.flink.streaming.api.operators.StreamSource$NonTimestampContext.collect(StreamSource.java:161)
>         at
> org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher.emitRecord(AbstractFetcher.java:225)
>         at
> org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher.run(Kafka09Fetcher.java:253)
>         at java.lang.Thread.run(Thread.java:745)
> 02/23/2017 10:08:28     Job execution switched to status FAILED.
> [10:08:29] Ignite node stopped OK [uptime=00:00:01:343]
> 
> ------------------------------------------------------------
>  The program finished with the following exception:
> 
> java.lang.NullPointerException
>         at
> org.apache.flink.client.CliFrontend.executeProgram(CliFrontend.java:784)
>         at org.apache.flink.client.CliFrontend.run(CliFrontend.java:253)
>         at
> org.apache.flink.client.CliFrontend.parseParameters(CliFrontend.java:1005)
>         at org.apache.flink.client.CliFrontend.main(CliFrontend.java:1048)

It looks like you don't have all required Ignite libraries on the Flink
cluster. Can this be the case?

-Val



--
View this message in context: http://apache-ignite-users.70518.x6.nabble.com/java-lang-NoClassDefFoundError-Could-not-initialize-class-org-apache-ignite-sink-flink-IgniteSink-Sir-tp10703p10842.html
Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: java.lang.NoClassDefFoundError: Could not initialize class org.apache.ignite.sink.flink.IgniteSink$SinkContext$Holder

Posted by dkarachentsev <dk...@gridgain.com>.
Hi,

I tried your sample and it works fine to me. In case of initialization
error, exception would be thrown on IgniteSink constructor invocation step,
but it looks like Holder was successfully intialized, but failed later.
Could you please attach logs for provided example?

-Dmitry.



--
View this message in context: http://apache-ignite-users.70518.x6.nabble.com/java-lang-NoClassDefFoundError-Could-not-initialize-class-org-apache-ignite-sink-flink-IgniteSink-Sir-tp10703p10807.html
Sent from the Apache Ignite Users mailing list archive at Nabble.com.

Re: java.lang.NoClassDefFoundError: Could not initialize class org.apache.ignite.sink.flink.IgniteSink$SinkContext$Holder

Posted by dkarachentsev <dk...@gridgain.com>.
Is it possible to provide reproducible example?

-Dmitry.



--
View this message in context: http://apache-ignite-users.70518.x6.nabble.com/java-lang-NoClassDefFoundError-Could-not-initialize-class-org-apache-ignite-sink-flink-IgniteSink-Sir-tp10703p10750.html
Sent from the Apache Ignite Users mailing list archive at Nabble.com.