Uploaded image for project: 'Zeppelin'
  1. Zeppelin
  2. ZEPPELIN-1270

Remove getting SQLContext from SparkSession.wrapped()

    XMLWordPrintableJSON

Details

    • Improvement
    • Status: Resolved
    • Minor
    • Resolution: Fixed
    • None
    • 0.6.1, 0.7.0
    • None
    • None

    Description

      SparkSession.wrapped is only for spark 2.0 preview, it is not supported in spark 2.0 release. So I think we can remove that piece of code. Otherwise we will get the following error in log which might be a little confusing.

      08:05:44,946 - Thread(pool-2-thread-3) - (Utils.java:40) - org.apache.spark.sql.SparkSession.wrapped()
      java.lang.NoSuchMethodException: org.apache.spark.sql.SparkSession.wrapped()
          at java.lang.Class.getMethod(Class.java:1786)
          at org.apache.zeppelin.spark.Utils.invokeMethod(Utils.java:38)
          at org.apache.zeppelin.spark.Utils.invokeMethod(Utils.java:33)
          at org.apache.zeppelin.spark.SparkInterpreter.getSQLContext_2(SparkInterpreter.java:241)
          at org.apache.zeppelin.spark.SparkInterpreter.getSQLContext(SparkInterpreter.java:229)
          at org.apache.zeppelin.spark.SparkInterpreter.open(SparkInterpreter.java:744)
          at org.apache.zeppelin.interpreter.LazyOpenInterpreter.open(LazyOpenInterpreter.java:69)
          at org.apache.zeppelin.spark.SparkRInterpreter.getSparkInterpreter(SparkRInterpreter.java:188)
          at org.apache.zeppelin.spark.SparkRInterpreter.open(SparkRInterpreter.java:72)
          at org.apache.zeppelin.interpreter.LazyOpenInterpreter.open(LazyOpenInterpreter.java:69)
          at org.apache.zeppelin.interpreter.LazyOpenInterpreter.interpret(LazyOpenInterpreter.java:93)
          at org.apache.zeppelin.interpreter.remote.RemoteInterpreterServer$InterpretJob.jobRun(RemoteInterpreterServer.java:383)
          at org.apache.zeppelin.scheduler.Job.run(Job.java:176)
          at org.apache.zeppelin.scheduler.FIFOScheduler$1.run(FIFOScheduler.java:139)
          at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
          at java.util.concurrent.FutureTask.run(FutureTask.java:266)
          at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$201(ScheduledThreadPoolExecutor.java:180)
          at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:293)
          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)
      

      Attachments

        Issue Links

          Activity

            People

              zjffdu Jeff Zhang
              zjffdu Jeff Zhang
              Votes:
              0 Vote for this issue
              Watchers:
              4 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: