Uploaded image for project: 'Atlas'
  1. Atlas
  2. ATLAS-1066

Falcon fails to post entity to Atlas due to kafka exception.

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Blocker
    • Resolution: Fixed
    • 0.7-incubating
    • None
    • None
    • Atlas , Falcon

    Description

      Set all configurations required for Falcon Atlas hook and created a Falcon cluster . The cluster is successfully submitted in Falcon . The following exception is thrown :

      2016-07-29 05:29:39,447 DEBUG - [Atlas Logger 0:] ~ <== AtlasPluginClassLoader.loadClass(org.apache.kafka.common.config.ConfigException): class org.apache.kafka.common.config.ConfigException (AtlasPluginClassLoader:142)
      2016-07-29 05:29:39,449 INFO - [Atlas Logger 0:] ~ Atlas hook failed (FalconHook:133)
      java.lang.ExceptionInInitializerError
      at org.apache.kafka.clients.producer.KafkaProducer.<init>(KafkaProducer.java:188)
      at org.apache.atlas.kafka.KafkaNotification.createProducer(KafkaNotification.java:312)
      at org.apache.atlas.kafka.KafkaNotification.sendInternal(KafkaNotification.java:220)
      at org.apache.atlas.notification.AbstractNotification.send(AbstractNotification.java:84)
      at org.apache.atlas.hook.AtlasHook.notifyEntitiesInternal(AtlasHook.java:126)
      at org.apache.atlas.hook.AtlasHook.notifyEntities(AtlasHook.java:111)
      at org.apache.atlas.hook.AtlasHook.notifyEntities(AtlasHook.java:157)
      at org.apache.atlas.falcon.hook.FalconHook.fireAndForget(FalconHook.java:161)
      at org.apache.atlas.falcon.hook.FalconHook.access$200(FalconHook.java:48)
      at org.apache.atlas.falcon.hook.FalconHook$2.run(FalconHook.java:131)
      at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:471)
      at java.util.concurrent.FutureTask.run(FutureTask.java:262)
      at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
      at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
      at java.lang.Thread.run(Thread.java:745)
      Caused by: org.apache.kafka.common.config.ConfigException: Invalid value org.apache.kafka.clients.producer.internals.DefaultPartitioner for configuration partitioner.class: Class org.apache.kafka.clients.producer.internals.DefaultPartitioner could not be found.
      at org.apache.kafka.common.config.ConfigDef.parseType(ConfigDef.java:672)
      at org.apache.kafka.common.config.ConfigDef.define(ConfigDef.java:110)
      at org.apache.kafka.common.config.ConfigDef.define(ConfigDef.java:132)
      at org.apache.kafka.common.config.ConfigDef.define(ConfigDef.java:171)
      at org.apache.kafka.common.config.ConfigDef.define(ConfigDef.java:333)
      at org.apache.kafka.common.config.ConfigDef.define(ConfigDef.java:346)
      at org.apache.kafka.clients.producer.ProducerConfig.<clinit>(ProducerConfig.java:220)
      ... 15 more

      and no messages are logged in atlas_hook_failed_messages.log

      Attachments

        1. ATLAS-1066.patch
          4 kB
          Madhan Neethiraj

        Activity

          People

            madhan Madhan Neethiraj
            sharmadhas Sharmadha S
            Votes:
            0 Vote for this issue
            Watchers:
            3 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: