You are viewing a plain text version of this content. The canonical link for it is here.
Posted to users@zeppelin.apache.org by Vikram Ramakrishnan <wh...@gmail.com> on 2015/09/09 20:41:51 UTC

object serializer is not a member of package org.apache.spark.streaming.kafka

am trying to get streaming data from kafka into spark for visualizing in
zeppelin.
getting the following error. what am i doing wrong

<console>:29: error: object serializer is not a member of package
org.apache.spark.streaming.kafka import kafka.serializer.DefaultDecoder

Here's a snippet of the code i'm trying to run from zeppeline (not pasting
the entire code for brevity sakes)...


-------

import org.apache.spark.streaming._
import org.apache.spark.SparkContext
import org.apache.spark.streaming.kafka.KafkaUtils

import kafka.serializer.DefaultDecoder

val kafkaConf = Map(
      "metadata.broker.list" -> "xxxx",
      "zookeeper.connect" -> "yyyy:2181",
      "group.id" -> "fpti-example-zeppelin",
      "auto.offset.reset" -> "smallest",
      "zookeeper.connection.timeout.ms" -> "1000")

val ssc = new StreamingContext(sc, Seconds(2))

 //Create stream from kafka
    val lines = KafkaUtils.createDirectStream[Array[Byte], Array[Byte],
DefaultDecoder, DefaultDecoder](ssc, kafkaConf, Set("fpti.platform.enrch"))
​​

-- 
-Vikram.