You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by GitBox <gi...@apache.org> on 2019/03/08 00:53:41 UTC

[GitHub] [pulsar] rdhabalia opened a new pull request #3786: [pulsar-function] fix deadlock in pulsar-source

rdhabalia opened a new pull request #3786: [pulsar-function] fix deadlock in pulsar-source
URL: https://github.com/apache/pulsar/pull/3786
 
 
   ### Motivation
   
   addresses : #3749
   
   ```
   "external-repl-prop/assignment-test/assign-restart3-0" #572 prio=5 os_prio=0 tid=0x00007f59acd3b800 nid=0x6027 waiting on condition [0x00007f5928fd3000]
      java.lang.Thread.State: WAITING (parking)
           at sun.misc.Unsafe.park(Native Method)
           - parking to wait for  <0x00000000ded111a0> (a java.util.concurrent.CompletableFuture$Signaller)
           at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
           at java.util.concurrent.CompletableFuture$Signaller.block(CompletableFuture.java:1693)
           at java.util.concurrent.ForkJoinPool.managedBlock(ForkJoinPool.java:3323)
           at java.util.concurrent.CompletableFuture.waitingGet(CompletableFuture.java:1729)
           at java.util.concurrent.CompletableFuture.join(CompletableFuture.java:1934)
           at org.apache.pulsar.functions.source.PulsarSource$$Lambda$694/350554052.apply(Unknown Source)
           at java.util.stream.ReferencePipeline$3$1.accept(ReferencePipeline.java:193)
           at java.util.ArrayList$ArrayListSpliterator.forEachRemaining(ArrayList.java:1374)
           at java.util.stream.AbstractPipeline.copyInto(AbstractPipeline.java:481)
           at java.util.stream.AbstractPipeline.wrapAndCopyInto(AbstractPipeline.java:471)
           at java.util.stream.ReduceOps$ReduceOp.evaluateSequential(ReduceOps.java:708)
           at java.util.stream.AbstractPipeline.evaluate(AbstractPipeline.java:234)
           at java.util.stream.ReferencePipeline.collect(ReferencePipeline.java:499)
           at org.apache.pulsar.functions.source.PulsarSource.open(PulsarSource.java:103)
           at org.apache.pulsar.functions.instance.JavaInstanceRunnable.setupInput(JavaInstanceRunnable.java:681)
           at org.apache.pulsar.functions.instance.JavaInstanceRunnable.setupJavaInstance(JavaInstanceRunnable.java:203)
           at org.apache.pulsar.functions.instance.JavaInstanceRunnable.run(JavaInstanceRunnable.java:237)
           at java.lang.Thread.run(Thread.java:748)
   :
   : 
   "pulsar-external-listener-173-1" #554 prio=5 os_prio=0 tid=0x00007f59d8049000 nid=0x6014 in Object.wait() [0x00007f592d7f7000]
      java.lang.Thread.State: WAITING (on object monitor)
           at java.lang.Object.wait(Native Method)
           at java.lang.Thread.join(Thread.java:1252)
           - locked <0x00000000deb85640> (a java.lang.Thread)
           at java.lang.Thread.join(Thread.java:1326)
           at org.apache.pulsar.functions.runtime.ThreadRuntime.stop(ThreadRuntime.java:123)
           at org.apache.pulsar.functions.runtime.RuntimeSpawner.close(RuntimeSpawner.java:151)
           at org.apache.pulsar.functions.worker.FunctionActioner.stopFunction(FunctionActioner.java:243)
           at org.apache.pulsar.functions.worker.FunctionRuntimeManager.conditionallyStopFunction(FunctionRuntimeManager.java:853)
           at org.apache.pulsar.functions.worker.FunctionRuntimeManager.updateAssignment(FunctionRuntimeManager.java:657)
           at org.apache.pulsar.functions.worker.FunctionRuntimeManager.processAssignment(FunctionRuntimeManager.java:599)
           - locked <0x00000000dc9b5e50> (a org.apache.pulsar.functions.worker.FunctionRuntimeManager)
           at org.apache.pulsar.functions.worker.FunctionAssignmentTailer.processAssignment(FunctionAssignmentTailer.java:82)
           at org.apache.pulsar.functions.worker.FunctionAssignmentTailer.accept(FunctionAssignmentTailer.java:88)
           at org.apache.pulsar.functions.worker.FunctionAssignmentTailer.accept(FunctionAssignmentTailer.java:32)
           at java.util.concurrent.CompletableFuture.uniAccept(CompletableFuture.java:656)
           at java.util.concurrent.CompletableFuture$UniAccept.tryFire(CompletableFuture.java:632)
           at java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:474)
           at java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1962)
           at org.apache.pulsar.client.impl.ConsumerImpl.lambda$interceptAndComplete$9(ConsumerImpl.java:883)
           at org.apache.pulsar.client.impl.ConsumerImpl$$Lambda$644/1307772323.run(Unknown Source)
           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 io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
           at java.lang.Thread.run(Thread.java:748)
   
   ```

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services