DevOps | Cloud | Analytics | Open Source | Programming





How To Fix - Spark Error "SparkContext. java.lang.nullpointerexception" ?



In this post , we will see How To Fix - Spark Error "SparkContext. java.lang.nullpointerexception". There might be multiple reasons rendering this issue to occur.

On screen\terminal, you see something similar as below -


ERROR SparkContext: Error initializing SparkContext.
java.lang.NullPointerException

  The best thing to do when such issues occur is to scan through all the relevant logs produced by the application. Let's check what all we could Try out to fix this issue - (P..S. - Additionally check our other post which might also help  - How To Fix – “SparkContext: Error initializing SparkContext” in Spark ?)  

  • Check all the process(s) are running as expected by running the below command. The services to be checked are - ResourceManager, RunJar, SecondaryNameNode, DataNode, NodeManager, NameNode

$ jps

 

  • Get some more detailed logs if you are not already. In your Spark "conf" directory , use the "log4j.properties" file and set it to below value for more details -

log4j.rootCategory=DEBUG, console

If  you want to log to a file , create a Sparkdriver_log4j.properties file in any dir within the node\machine where Spark jobs will be submitted . Contents of the Sparkdriver_log4j.properties (This scenario is for Client Mode)


log4j.rootCategory=INFO,FILE
log4j.appender.FILE.File=/tmp/SparkDriver.log


Add below to the spark-submit command so that log4j properties are used to log the driver loggins to a file.


\--driver-java-options "-Dlog4j.configuration=file:/tmp/Sparkdriver\_log4j.properties"


spark-submit --driver-java-options "-Dlog4j.configuration=file:/tmp/Sparkdriver\_log4j.properties"
--class org.apache.spark.examples.SparkApp --master yarn-client --num-executors 3
--driver-memory 512m --executor-memory 512m --executor-cores 1 spark-code-app\*.jar 10

   

  • Switch on the Spark History-server - it entails all the past events when a SparkContext gets terminated or fails. To use this feature, whenever you use the Spark-Submit command , use the additions as highlighted below -

\# Create the Dir for the Logs to store

hdfs dfs -mkdir /histEventLogs

Add the below in the Spark-Submit command or Spark-shell command to use the History server facility.


\--conf spark.eventLog.enabled=true 
--conf spark.eventLog.dir=hdfs://<hdfsNameNodeAddress>:8020/histEventLogs


$ spark-shell --conf spark.eventLog.enabled=true --conf spark.eventLog.dir=hdfs://<hdfsNameNodeAddress>:8020/histEventLogs

  Try out these steps along with the other details from this post - How To Fix – “SparkContext: Error initializing SparkContext” in Spark ?) Hope this will help you to solve the error.  

Additional Read -

 


Spark Error Initializing SparkContext ,spark-shell error initializing sparkcontext ,error spark.sparkcontext error initializing sparkcontext. java.lang.nullpointerexception ,error spark.sparkcontext error initializing sparkcontext cloudera ,org.apache.spark.sparkcontext - error initializing sparkcontext talend ,error initializing sparkcontext invalid spark url ,spark error spark.sparkcontext error initializing sparkcontext ,org.apache.spark.sparkcontext - error initializing sparkcontext ,org.apache.spark.sparkcontext - error initializing sparkcontext. java.lang.nullpointerexception ,error sparkcontext error initializing sparkcontext. org.apache.spark.sparkexception ,error initializing sparkcontext ,sparkcontext error initializing sparkcontext ,spark error sparkcontext error initializing sparkcontext ,spark-shell error sparkcontext error initializing sparkcontext ,error org.apache.spark.sparkcontext - error initializing sparkcontext. talend ,error spark.sparkcontext error initializing sparkcontext. java.io.filenotfoundexception ,error spark.sparkcontext error initializing sparkcontext yarn application has already ended ,error initializing sparkcontext. org.apache.spark.sparkexception unable to load yarn support ,error spark.sparkcontext error initializing sparkcontext ,spark.sparkcontext error initializing sparkcontext ,


apache spark error ,apache spark error handling ,apache spark errors ,import org.apache.spark error ,org.apache.spark.sparkexception error communicating with mapoutputtracker ,org.apache.spark.sparkcontext - error initializing sparkcontext ,org.apache.spark.sparkcontext - error initializing sparkcontext talend ,org.apache.spark.sparkcontext - error initializing sparkcontext. java.lang.nullpointerexception ,org.apache.spark.sparkexception error sending message ,error package org.apache.spark.api.java does not exist ,org.apache.spark.sparkexception error from python worker ,org.apache.spark.sparkcontext - error initializing sparkcontext. java.lang.nullpointerexception ,org.apache.spark.sparkexception error sending message ,error apache.spark.executor.coarsegrainedexecutorbackend - received signal term ,error org.apache.spark.scheduler.asynceventqueue ,error package org.apache.spark.broadcast is not a value ,error org.apache.spark.contextcleaner - error cleaning broadcast ,error org.apache.spark.executor.coarsegrainedexecutorbackend received signal term ,error org.apache.spark.sql.catalyst.errors.package$treenodeexception execute tree ,error org.apache.spark.sql.catalyst.parser.parseexception ,error org.apache.spark.scheduler.cluster.yarnscheduler lost executor ,error org.apache.spark.network.client.transportclient - failed to send rpc ,error org.apache.spark.executor.coarsegrainedexecutorbackend ,error org.apache.spark.deploy.yarn.applicationmaster - received signal term ,error org.apache.spark.deploy.yarn.applicationmaster ,error org.apache.spark.deploy.yarn.applicationmaster - received signal 15 sigterm ,error org.apache.spark.deploy.history.historyserver received signal term ,error org.apache.spark.deploy.yarn.applicationmaster - uncaught exception ,error org.apache.spark.deploy.history.historyserver failed to bind historyserver ,error org.apache.spark.sql.dataframereader does not take parameters ,error package org.apache.spark does not exist ,org.apache.spark.sparkdriverexecutionexception execution error ,error org.apache.spark.executor.coarsegrainedexecutorbackend - received signal 15 sigterm ,error org.apache.spark.executor.executor - managed memory leak detected ,error org.apache.spark.executor.executor ,error org.apache.spark.sparkexception exception thrown in awaitresult ,error org.apache.spark.sql.execution.datasources.fileformatwriter - aborting job null ,org.apache.spark.shuffle.fetchfailedexception error in opening filesegmentmanagedbuffer ,import org.apache.spark.sql.functions.\_ error ,org.apache.spark.sparkexception error getting partition metadata for ,org.apache.spark.sql.hive.hivesessionstatebuilder error ,org.apache.spark.sql.hive.hive external catalog error ,main error org.apache.spark.sparkcontext - error initializing sparkcontext ,error org.apache.spark.sparkexception job aborted ,error org.apache.spark.sparkexception job aborted. (state= code=0) ,error org.apache.spark.scheduler.livelistenerbus - sparklistenerbus has already stopped ,error org.apache.spark.scheduler.livelistenerbus ,import org.apache.spark.ml error ,error org.apache.spark.network.server.transportrequesthandler ,error org.apache.spark.network.shuffle.retryingblockfetcher ,error org.apache.spark.network.client.transportresponsehandler ,error org.apache.spark.rdd.rdd string does not take parameters ,org.apache.spark.sql.sources.datasourceregister error reading configuration file ,error org.apache.spark.sql.runtimeconfig does not take parameters ,org.apache.spark.sparkexception error asking standalone scheduler to shut down executors ,import org.apache.spark.sparkcontext error ,org.apache.spark.memory.sparkoutofmemoryerror error while calling spill() ,error org.apache.spark.scheduler.tasksetmanager ,org.apache.spark.network.server.transportrequesthandler error sending result chunkfetchsuccess ,error org.apache.spark.sparkexception task not serializable ,import org.apache.spark.sql.types.\_ error ,org.apache.spark.network.server.transportrequesthandler - error while invoking rpchandler#receive() ,error org.apache.spark.ui.sparkui - failed to bind sparkui ,error org.apache.spark.util.utils - aborting task ,error org.apache.spark.util.utils - uncaught exception in thread pool-1-thread-1 ,apache kafka error ,apache kafka error handling ,apache kafka error codes ,apache kafka errors ,apache kafka error tolerance ,apache.kafka.common.errors.timeoutexception ,apache kafka consumer error handling ,apache kafka producer error handling ,apache.kafka.common.errors.recordtoolargeexception ,org.apache.kafka.common.utils.appinfoparser - error registering appinfo mbean ,apache.kafka.common.errors.serializationexception error registering avro schema ,apache.kafka.common.errors.timeoutexception failed to update metadata after ,apache.kafka.common.errors.notleaderforpartitionexception ,apache.kafka.common.errors.groupauthorizationexception not authorized to access group ,apache.kafka.common.errors ,apache kafka error while fetching metadata with correlation id ,org.apache.kafka.clients.fetchsessionhandler error sending fetch request ,apache.kafka.clients.networkclient - error while fetching metadata with correlation id ,org.apache.storm.kafka.failedfetchexception error fetching data from ,org.apache.kafka.common.kafkaexception unexpected error fetching metadata for topic ,org.apache.kafka.common.kafkaexception unexpected error from syncgroup ,org.apache.kafka.common.errors.invalidrequestexception error getting request for apikey ,error org.apache.kafka.common.errors.invalidreplicationfactorexception ,error org.apache.kafka.common.errors.invalidreplicationfactorexception replication factor 1


org.apache.kafka.common.kafkaexception error unregistering mbean ,org.apache.kafka.common.kafkaexception error creating mbean attribute for metricname ,org.apache.kafka.common.errors.kafkastorageexception error while deleting segments for ,org.apache.kafka.common.errors.kafkastorageexception error while renaming dir for ,org.apache.kafka.common.errors.kafkastorageexception error while creating log for ,org.apache.kafka.common.errors.kafkastorageexception error while flushing log for ,org.apache.kafka.common.errors.clustered authorizationexception error listing groups ,org.apache.kafka.clients.networkclient error connecting to node ,org.apache.kafka.clients.networkclient error ,org.apache.kafka.clients.networkclient error while fetching metadata with correlation ,org.apache.kafka.clients.networkclient error while fetching metadata ,error org.apache.kafka.clients.networkclient failed authentication due to ssl handshake failed ,apache.kafka.common.network.selector error in i/o with ,error org.apache.kafka.clients.consumer.internals.consumercoordinator ,error (org.apache.kafka.clients.producer.internals.errorloggingcallback) ,error org.apache.kafka.common.utils.kafkathread ,error org.apache.kafka.common.utils.kafkathread - uncaught exception in thread ,error org.apache.kafka.clients.networkclient ,error org.apache.kafka.clients.producer.internals.sender ,error o.apache.kafka.clients.networkclient ,org.apache.kafka.streams.errors.processorstateexception error while executing flush from store ,org.apache.kafka.streams.errors.processorstateexception error while creating the state manager ,org.apache.kafka.common.errors.serializationexception error retrieving avro schema ,org.apache.kafka.common.errors.serializationexception error retrieving avro schema string ,org.apache.kafka.common.errors.serializationexception error registering json schema ,org.apache.kafka.common.errors.serializationexception error registering protobuf schema ,org.apache.kafka.common.errors.serializationexception error retrieving json schema ,org.apache.kafka.streams.errors.invalidstatestoreexception ,org.apache.kafka.streams.errors.lockexception failed to lock the global state directory ,org.apache.kafka.streams.errors.topologyexception invalid topology ,org.apache.kafka.streams.errors.processorstateexception ,org.apache.kafka.streams.errors.logandcontinueexceptionhandler ,org.apache.kafka.common.kafkaexception unexpected error in addoffsetstot response ,error handling in apache kafka ,org.apache.kafka.common.errors.authorizationexception ,org.apache.kafka.common.errors.apiexception ,org.apache.kafka.common.errors.cluster authorizationexception cluster authorization failed ,org.apache.kafka.common.errors.topicauthorizationexception authorization failed ,org.apache.kafka.common.errors.timeoutexception aborted due to timeout ,org.apache.kafka.common.errors.sasl authenticationexception authentication failed ,org.apache.kafka.common.errors.cluster authorizationexception ,org.apache.kafka.common.errors.brokernotavailableexception ,org.apache.kafka.common.errors.timeoutexception batch expired ,org.apache.kafka.connect.errors.connectexception bulk request failed ,org.apache.kafka.common.errors.timeoutexception batch creation plus linger time ,org.apache.kafka.connect.runtime.rest.errors.badrequestexception ,org.apache.kafka.streams.errors.processorstateexception base state directory ,org.apache.kafka.common.errors.recordtoolargeexception buffer.memory ,org.apache.kafka.common.errors.timeoutexception batch containing ,org.apache.kafka.common.errors.disconnectexception ,org.apache.kafka.common.errors.disconnectexception null ,org.apache.kafka.connect.errors.dataexception ,org.apache.kafka.connect.errors.dataexception cannot infer mapping without schema ,org.apache.kafka.connect.errors.dataexception failed to serialize avro data from topic ,org.apache.kafka.connect.errors.dataexception failed to deserialize data for topic to avro ,org.apache.kafka.connect.errors.dataexception is not a valid field name ,org.apache.kafka.connect.errors.dataexception unknown schema type null ,org.apache.kafka.common.errors.timeoutexception expiring 1 record(s) ,org.apache.kafka.common.errors.timeoutexception expiring 4 records) ,rg.apache.kafka.common.errors.timeoutexception expiring 1 record(s) for ,org.apache.kafka.common.errors.timeoutexception expiring 10 record(s) for ,org.apache.kafka.common.errors.timeoutexception expiring 6 record(s) ,org.apache.kafka.common.errors.timeoutexception expiring 11 records) ,org.apache.kafka.common.errors.timeoutexception expiring 18 records) ,org.apache.kafka.common.errors.timeoutexception expiring 3 record ,org.apache.kafka.common.errors.fencedinstanceidexception ,org.apache.kafka.common.errors.timeoutexception failed to get offsets by times in 30000ms ,org.apache.kafka.connect.errors.connectexception flush timeout expired with unflushed records ,org.apache.kafka.common.errors.interruptexception flush interrupted ,org.apache.kafka.common.errors.groupauthorizationexception ,org.apache.kafka.common.errors.groupnotemptyexception the group is not empty ,org.apache.kafka.common.errors.groupnotempty exception ,org.apache.kafka.common.errors.groupcoordinatornotavailableexception ,org.apache.kafka.common.errors.groupid notfoundexception the group id does not exist ,java org.apache.kafka.common.errors.groupauthorizationexception not authorized to access group ,org.apache.kafka.common.errors.timeoutexception has passed since last append ,org.apache.kafka.common.errors.timeoutexception has passed since batch creation ,org.apache.kafka.common.errors.interruptexception java.lang.interruptedexception ,org.apache.kafka.common.errors.invalidgroupidexception the configured groupid is invalid ,org.apache.kafka.common.errors.invalidtopicexception invalid topics ,org.apache.kafka.common.errors.invalidtopicexception ,org.apache.kafka.common.errors.invalidreplicationfactorexception ,org.apache.kafka.common.errors.inconsistentgroupprotocolexception ,org.apache.kafka.common.errors.invalidpidmappingexception ,org.apache.kafka.common.errors jar ,org.apache.kafka.connect.errors.dataexception java.nio.channels.closedchannelexception ,org.apache.kafka.connect.errors.connectexception java.lang.reflect.invocationtargetexception ,org.apache.kafka.connect.errors.dataexception jsonconverter with schemas.enable requires ,org.apache.kafka.connect.errors.dataexception java.sql.sqlexception numeric overflow ,org.apache.kafka.connect.errors.connectexception java.nio.channels.closedchannelexception ,org.apache.kafka.common.errors.serializationexception jar ,org.apache.kafka.common.errors.kafkastorageexception ,org.apache.kafka.common.errors.kafkastorageexception no log directories available ,org.apache.kafka.common.errors.unknownserverexception keepererrorcode = session expired for ,org.apache.kafka.streams.errors.logandfailexceptionhandler ,org.apache.kafka.common.errors.leadernotavailable exception ,org.apache.kafka.common.errors.timeoutexception license topic could not be created ,org.apache.kafka.common.errors.memberidrequiredexception ,org.apache.kafka.connect.errors.dataexception multipart upload failed to complete ,org.apache.kafka.common.errors.recordtoolargeexception max.request.size ,org.apache.kafka.connect.errors.dataexception map is not supported as the document id ,org.apache.kafka.connect.errors.connectexception maven ,org.apache.kafka.common.errors.networkexception ,org.apache.kafka.common.errors.notleaderforpartitionexception this server is not the leader ,org.apache.kafka.common.errors.not coordinator exception this is not the correct coordinator ,org.apache.kafka.common.errors.notcontrollerexception ,org.apache.kafka.common.errors.notcoordinatorexception ,org.apache.kafka.common.errors.notenoughreplicasafterappendexception ,org.apache.kafka.common.errors.timeoutexception ,org.apache.kafka.common.errors.timeoutexception timed out waiting for a node assignment ,org.apache.kafka.common.errors.topicauthorizationexception not authorized to access topics ,org.apache.kafka.common.errors.sslauthenticationexception ssl handshake failed ,org.apache.kafka.common.errors.serializationexception unknown magic byte ,org.apache.kafka.common.errors.groupauthorizationexception not authorized to access group ,org.apache.kafka.common.errors.recordtoolargeexception ,org.apache.kafka.common.errors.producerfencedexception ,org.apache.kafka.common.errors.policy violation exception topic replication factor must be 3 ,org.apache.kafka.common.errors.policy violation exception ,org.apache.kafka.streams.errors.production exceptionhandler ,org.apache.kafka.common.protocol.errors ,org.apache.kafka.common.errors.recordtoolargeexception there are some messages at partition=offset ,org.apache.kafka.common.errors.recordtoolargeexception consumer ,org.apache.kafka.common.errors.recordbatchtoolargeexception ,org.apache.kafka.connect.errors.retriableexception ,org.apache.kafka.common.errors.retriableexception ,org.apache.kafka.common.errors.recordtoolargeexception there are some messages at ,org.apache.kafka.streams.errors.invalidstatestoreexception the state store ,org.apache.kafka.streams.errors ,org.apache.kafka.common.errors.timeoutexception timeout of 60000ms ,org.apache.kafka.common.errors.timeoutexception topic not present in metadata ,org.apache.kafka.common.errors.unknowntopicorpartitionexception ,org.apache.kafka.common.errors.unknownserverexception ,org.apache.kafka.common.errors.unknownproduceridexception ,org.apache.kafka.common.errors.unsupportedversionexception ,org.apache.kafka.common.errors.unknownmemberid exception the coordinator is not aware of this member ,org.apache.kafka.common.errors.unknownmemberidexception ,org.apache.kafka.common.errors.unsupportedformessageformatexception ,org.apache.kafka.connect.errors.connectexception value schema must be of type struct ,org.apache.kafka.common.errors.wakeupexception ,exception org.apache.kafka.common.errors.wakeupexception ,kafka connect org.apache.kafka.common.errors.wakeupexception ,org.apache.kafka.connect.errors.connectexception worker is shutting down ,org.apache.kafka.common.errors.timeoutexception expiring ,org.apache.kafka.common.errors.timeoutexception topic ,org.apache.kafka.common.errors.timeoutexception consumer ,kafka shaded.org.apache.kafka.common.errors.timeoutexception ,catch org.apache.kafka.common.errors.timeoutexception ,pega org.apache.kafka.common.errors.timeoutexception ,spring org.apache.kafka.common.errors.timeoutexception ,org.apache.kafka.common.errors.timeoutexception timeout of ,org.apache.kafka.common.errors.timeoutexception the request timed out ,org.apache.kafka.common.errors.timeoutexception failed to allocate memory ,org.apache.kafka.common.errors.timeoutexception failed to send request after ,org.apache.kafka.common.errors.timeoutexception failed to update metadata after ms ,rg.apache.kafka.common.errors.timeoutexception failed to update metadata after ,org.apache.kafka.common.errors.timeoutexception not present in metadata after ,caused by org.apache.kafka.common.errors.timeoutexception ,caused by org.apache.kafka.common.errors.timeoutexception expiring 1 record(s) ,


caused by org.apache.kafka.common.errors.timeoutexception aborted due to timeout ,caused by org.apache.kafka.common.errors.timeoutexception topic ,caused by org.apache.kafka.common.errors.timeoutexception failed to update metadata ,caused by org.apache.kafka.common.errors.timeoutexception call(call name=findcoordinator ,org.apache.kafka.common.errors.timeoutexception call(callname=listtopics ,org.apache.kafka.common.errors.timeoutexception call ,org.apache.kafka.common.errors.timeoutexception call(call name=list nodes ,org.apache.kafka.common.errors.timeoutexception failed initializing cluster resolver ,routing to failure due to org.apache.kafka.common.errors.timeoutexception ,org.apache.kafka.common.errors.timeoutexception failed to get offsets by times in 60000ms ,org.apache.kafka.common.errors.timeoutexception failed to send request ,org.apache.kafka.common.errors.timeoutexception failed to get offsets by times in 30003ms ,caused by org.apache.kafka.common.errors.timeoutexception error listing groups on ,org.apache.kafka.common.errors.timeoutexception the adminclient thread has exited ,how to catch org.apache.kafka.common.errors.timeoutexception ,how to fix org.apache.kafka.common.errors.timeoutexception ,org.apache.kafka.common.errors.timeoutexception not present in metadata ,org.apache.kafka.common.errors.timeoutexception no record information is available ,exception is org.apache.kafka.common.errors.timeoutexception ,nested exception is org.apache.kafka.common.errors.timeoutexception ,org.apache.kafka.common.errors.timeoutexception failed to get offsets by times in ,java.lang.noclassdeffounderror org/apache/kafka/common/errors/timeoutexception ,java.util.concurrent.executionexception org.apache.kafka.common.errors.timeoutexception ,java.util.concurrent.executionexception org.apache.kafka.common.errors.timeoutexception topic ,java.util.concurrent.executionexception org.apache.kafka.common.errors.timeoutexception expiring ,java.util.concurrent.executionexception org.apache.kafka.common.errors.timeoutexception call ,kafka org.apache.kafka.common.errors.timeoutexception ,kafka org.apache.kafka.common.errors.timeoutexception expiring ,kafka streams org.apache.kafka.common.errors.timeoutexception ,logstash org.apache.kafka.common.errors.timeoutexception ,org.apache.kafka.common.errors.timeoutexception failed to update metadata after ,org.apache.kafka.common.errors.timeoutexception failed to get offsets by times ,org.apache.kafka.common.errors.timeoutexception producer ,org.apache.kafka.common.errors.timeoutexception pega ,org.apache.kafka.common.errors.timeoutexception expiring record(s) ,org.apache.kafka.common.errors.timeoutexception failed to update metadata ,org.apache.kafka.common.errors.timeoutexception expiring 1 record ,org.apache.kafka.common.errors.timeoutexception expiring 5 records) ,org.apache.kafka.common.errors.timeoutexception stackoverflow ,org.apache.kafka.common.errors.timeoutexception spark ,org.apache.kafka.common.errors.timeoutexception timeout of 60000ms expired before the position ,org.apache.kafka.common.errors.timeoutexception timeout expired ,org.apache.kafka.common.errors.timeoutexception timeout expired while fetching ,apache kafka consumer exception handling ,logstash org.apache.kafka.common.errors.recordtoolargeexception ,spark org.apache.kafka.common.errors.recordtoolargeexception ,org.apache.kafka.common.errors.recordtoolargeexception the message is ,caused by org.apache.kafka.common.errors.recordtoolargeexception ,org.apache.kafka.common.errors.recordtoolargeexception kafka connect ,java.util.concurrent.executionexception org.apache.kafka.common.errors.recordtoolargeexception ,kafkaproducer.send() failed org.apache.kafka.common.errors.recordtoolargeexception ,logstash kafkaproducer.send() failed org.apache.kafka.common.errors.recordtoolargeexception ,kafka org.apache.kafka.common.errors.recordtoolargeexception ,org.apache.kafka.common.errors.recordtoolargeexception producer ,rg.apache.kafka.common.errors.serializationexception error registering avro schema ,caused by org.apache.kafka.common.errors.serializationexception error registering avro schema ,org.apache.kafka.common.errors.serializationexception error registering avro schema ,org.apache.kafka.common.errors.serializationexception error registering avro schema string ,kafka shaded.org.apache.kafka.common.errors.timeoutexception failed to update metadata after ,caused by org.apache.kafka.common.errors.timeoutexception failed to update metadata after ,kafka org.apache.kafka.common.errors.timeoutexception failed to update metadata after ,due to org.apache.kafka.common.errors.notleaderforpartitionexception ,kafka org.apache.kafka.common.errors.notleaderforpartitionexception ,org.apache.kafka.common.errors.notleaderforpartitionexception ,org.apache.kafka.common.errors.groupauthorizationexception not authorized to access group anonymous ,caused by org.apache.kafka.common.errors.groupauthorizationexception not authorized to access group ,org.apache.kafka.common.errors.groupauthorizationexception not authorized to access group group\_id ,kafka org.apache.kafka.common.errors.groupauthorizationexception not authorized to access group ,org.apache.kafka.common.errors.serializationexception ,org.apache.kafka.common.errors.topicauthorizationexception ,caused by org.apache.kafka.common.errors.serializationexception can't deserialize data ,caused by org.apache.kafka.common.errors.sslauthenticationexception ssl handshake failed ,org.apache.kafka.common.errors.coordinator unavailableexception the coordinator is not available ,org.apache.kafka.common.errors.corruptrecordexception ,org.apache.kafka.common.errors.coordinatornotavailableexception ,org.apache.kafka.common.errors.cluster authorizationexception request request ,org.apache.kafka.common.errors.clusterauthorizationexception is not authorized ,org.apache.kafka.common.errors.controllermovedexception ,org.apache.kafka.common.errors.disconnectexception cancelled fetchmetadata request ,org.apache.kafka.common.errors.disconnectexception cancelled fetchmetadata request with correlation ,logstash org.apache.kafka.common.errors.disconnectexception ,package org.apache.kafka.common.errors does not exist ,caused by org.apache.kafka.common.errors.disconnectexception null ,org.apache.kafka.common.errors.disconnectexception error sending fetch request ,handle org.apache.kafka.common.errors.serializationexception ,logstash org.apache.kafka.common.errors.sslauthenticationexception ssl handshake failed ,org.apache.kafka.common.errors.illegalsaslstateexception ,druid org.apache.kafka.common.errors.interruptexception java.lang.interruptedexception ,streamsets org.apache.kafka.common.errors.interruptexception java.lang.interruptedexception ,java org.apache.kafka.common.errors ,org.apache.kafka.common.errors.serializationexception error deserializing json to avro of schema ,org.apache.kafka.common.errors.serializationexception com.fasterxml.jackson.core.jsonparseexception ,join group failed with org.apache.kafka.common.errors.memberidrequiredexception ,join group failed with org.apache.kafka.common.errors.member required exception ,method threw 'org.apache.kafka.common.errors.serializationexception' exception ,org.apache.kafka.common.errors.notcoordinatorforgroup exception ,org.apache.kafka.common.errors.serializationexception can't deserialize data ,org.apache.kafka.common.errors.serializationexception can't convert value of class ,org.apache.kafka.common.errors.sslauthenticationexception ,org.apache.kafka.common.errors.serializationexception could not find class ,org.apache.kafka.common.errors.unsupportedsaslmechanismexception ,org.apache.kafka.common.errors.serializationexception error deserializing key/value for partition ,java.lang.noclassdeffounderror org/apache/kafka/common/errors/wakeupexception ,java.lang.classnotfoundexception org.apache.kafka.common.errors.wakeupexception ,org.apache.kafka.clients.networkclient error while fetching metadata with correlation id ,caused by org.apache.kafka.common.kafkaexception unexpected error fetching metadata for topic ,error org.apache.kafka.common.errors.invalidreplicationfactorexception replication factor