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

Fail to get code completion in IPython interpreter

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Open
    • Major
    • Resolution: Unresolved
    • 0.10.0
    • None
    • python
    • None

    Description

      It looks like it only happens in jupyter-client=7

      
      ERROR [2021-09-21 19:53:12,756] ({pool-2-thread-1} ProcessFunction.java[process]:47) - Internal error processing completion
      io.grpc.StatusRuntimeException: UNKNOWN: Exception calling application: There is no current event loop in thread 'ThreadPoolExecutor-0_1'.
              at io.grpc.stub.ClientCalls.toStatusRuntimeException(ClientCalls.java:233)
              at io.grpc.stub.ClientCalls.getUnchecked(ClientCalls.java:214)
              at io.grpc.stub.ClientCalls.blockingUnaryCall(ClientCalls.java:139)
              at org.apache.zeppelin.interpreter.jupyter.proto.JupyterKernelGrpc$JupyterKernelBlockingStub.complete(JupyterKernelGrpc.java:330)
              at org.apache.zeppelin.jupyter.JupyterKernelClient.complete(JupyterKernelClient.java:296)
              at org.apache.zeppelin.jupyter.JupyterKernelInterpreter.completion(JupyterKernelInterpreter.java:347)
              at org.apache.zeppelin.interpreter.LazyOpenInterpreter.completion(LazyOpenInterpreter.java:145)
              at org.apache.zeppelin.interpreter.remote.RemoteInterpreterServer.completion(RemoteInterpreterServer.java:974)
              at org.apache.zeppelin.interpreter.thrift.RemoteInterpreterService$Processor$completion.getResult(RemoteInterpreterService.java:1932)
              at org.apache.zeppelin.interpreter.thrift.RemoteInterpreterService$Processor$completion.getResult(RemoteInterpreterService.java:1911)
              at org.apache.zeppelin.shaded.org.apache.thrift.ProcessFunction.process(ProcessFunction.java:38)
              at org.apache.zeppelin.shaded.org.apache.thrift.TBaseProcessor.process(TBaseProcessor.java:38)
              at org.apache.zeppelin.shaded.org.apache.thrift.server.TThreadPoolServer$WorkerProcess.run(TThreadPoolServer.java:313)
              at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
              at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
              at java.lang.Thread.run(Thread.java:748) 

      Attachments

        Issue Links

          Activity

            People

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

              Dates

                Created:
                Updated: