You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@drill.apache.org by "Abhishek Girish (JIRA)" <ji...@apache.org> on 2018/05/14 23:48:00 UTC

[jira] [Created] (DRILL-6416) Unit test TestTpchDistributedConcurrent.testConcurrentQueries fails with AssertionError

Abhishek Girish created DRILL-6416:
--------------------------------------

             Summary: Unit test TestTpchDistributedConcurrent.testConcurrentQueries fails with AssertionError
                 Key: DRILL-6416
                 URL: https://issues.apache.org/jira/browse/DRILL-6416
             Project: Apache Drill
          Issue Type: Bug
          Components: Tools, Build &amp; Test
            Reporter: Abhishek Girish


{code}
Running org.apache.drill.TestTpchDistributedConcurrent#testConcurrentQueries
16:38:21.784 [2505e212-b165-7812-5c91-0a407a213964:frag:3:1] ERROR o.a.d.e.w.fragment.FragmentExecutor - SYSTEM ERROR: AssertionError

Fragment 3:1

[Error Id: 436120b6-5255-437e-af53-313e1c3207e0 on drillu1.qa.lab:31064]
org.apache.drill.common.exceptions.UserException: SYSTEM ERROR: AssertionError

Fragment 3:1

[Error Id: 436120b6-5255-437e-af53-313e1c3207e0 on drillu1.qa.lab:31064]
	at org.apache.drill.common.exceptions.UserException$Builder.build(UserException.java:633) ~[drill-common-1.14.0-SNAPSHOT.jar:1.14.0-SNAPSHOT]
	at org.apache.drill.exec.work.fragment.FragmentExecutor.sendFinalState(FragmentExecutor.java:359) [classes/:na]
	at org.apache.drill.exec.work.fragment.FragmentExecutor.cleanup(FragmentExecutor.java:214) [classes/:na]
	at org.apache.drill.exec.work.fragment.FragmentExecutor.run(FragmentExecutor.java:325) [classes/:na]
	at org.apache.drill.common.SelfCleaningRunnable.run(SelfCleaningRunnable.java:38) [drill-common-1.14.0-SNAPSHOT.jar:1.14.0-SNAPSHOT]
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149) [na:1.8.0_161]
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624) [na:1.8.0_161]
	at java.lang.Thread.run(Thread.java:748) [na:1.8.0_161]
Caused by: java.lang.RuntimeException: java.lang.AssertionError
	at org.apache.drill.common.DeferredException.addThrowable(DeferredException.java:101) ~[drill-common-1.14.0-SNAPSHOT.jar:1.14.0-SNAPSHOT]
	at org.apache.drill.exec.work.fragment.FragmentExecutor.fail(FragmentExecutor.java:471) [classes/:na]
	at org.apache.drill.exec.work.fragment.FragmentExecutor.run(FragmentExecutor.java:313) [classes/:na]
	... 4 common frames omitted
Caused by: java.lang.AssertionError: null
	at org.apache.drill.exec.compile.sig.MappingSet.enterConstant(MappingSet.java:85) ~[classes/:na]
	at org.apache.drill.exec.expr.EvaluationVisitor$ConstantFilter.visitBooleanConstant(EvaluationVisitor.java:1376) ~[classes/:na]
	at org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitBooleanConstant(EvaluationVisitor.java:1043) ~[classes/:na]
	at org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitBooleanConstant(EvaluationVisitor.java:843) ~[classes/:na]
	at org.apache.drill.common.expression.ValueExpressions$BooleanExpression.accept(ValueExpressions.java:186) ~[drill-logical-1.14.0-SNAPSHOT.jar:1.14.0-SNAPSHOT]
	at org.apache.drill.exec.expr.EvaluationVisitor$EvalVisitor.visitReturnValueExpression(EvaluationVisitor.java:579) ~[classes/:na]
	at org.apache.drill.exec.expr.EvaluationVisitor$EvalVisitor.visitUnknown(EvaluationVisitor.java:342) ~[classes/:na]
	at org.apache.drill.exec.expr.EvaluationVisitor$ConstantFilter.visitUnknown(EvaluationVisitor.java:1399) ~[classes/:na]
	at org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitUnknown(EvaluationVisitor.java:1084) ~[classes/:na]
	at org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitUnknown(EvaluationVisitor.java:843) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.filter.ReturnValueExpression.accept(ReturnValueExpression.java:56) ~[classes/:na]
	at org.apache.drill.exec.expr.EvaluationVisitor.addExpr(EvaluationVisitor.java:100) ~[classes/:na]
	at org.apache.drill.exec.expr.ClassGenerator.addExpr(ClassGenerator.java:334) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch.setupWorker(NestedLoopJoinBatch.java:266) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch.buildSchema(NestedLoopJoinBatch.java:384) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:144) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next(IteratorValidatorBatchIterator.java:229) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:118) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:108) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractUnaryRecordBatch.innerNext(AbstractUnaryRecordBatch.java:63) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:164) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next(IteratorValidatorBatchIterator.java:229) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:118) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:108) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractUnaryRecordBatch.innerNext(AbstractUnaryRecordBatch.java:63) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:164) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next(IteratorValidatorBatchIterator.java:229) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:118) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:108) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractUnaryRecordBatch.innerNext(AbstractUnaryRecordBatch.java:63) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.project.ProjectRecordBatch.innerNext(ProjectRecordBatch.java:137) ~[classes/:na]
	at org.apache.drill.exec.record.AbstractRecordBatch.next(AbstractRecordBatch.java:164) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next(IteratorValidatorBatchIterator.java:229) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.BaseRootExec.next(BaseRootExec.java:105) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec.innerNext(PartitionSenderRootExec.java:152) ~[classes/:na]
	at org.apache.drill.exec.physical.impl.BaseRootExec.next(BaseRootExec.java:95) ~[classes/:na]
	at org.apache.drill.exec.work.fragment.FragmentExecutor$1.run(FragmentExecutor.java:292) ~[classes/:na]
	at org.apache.drill.exec.work.fragment.FragmentExecutor$1.run(FragmentExecutor.java:279) ~[classes/:na]
	at java.security.AccessController.doPrivileged(Native Method) ~[na:1.8.0_161]
	at javax.security.auth.Subject.doAs(Subject.java:422) ~[na:1.8.0_161]
	at org.apache.hadoop.security.UserGroupInformation.doAs(UserGroupInformation.java:1657) ~[hadoop-common-2.7.1.jar:na]
	at org.apache.drill.exec.work.fragment.FragmentExecutor.run(FragmentExecutor.java:279) [classes/:na]
	... 4 common frames omitted
submissionFailed for -- tpch11 using 1395599672 as a seed to the RNG
select
  ps.ps_partkey,
  sum(ps.ps_supplycost * ps.ps_availqty) as `value`
from
  cp.`tpch/partsupp.parquet` ps,
  cp.`tpch/supplier.parquet` s,
  cp.`tpch/nation.parquet` n
where
  ps.ps_suppkey = s.s_suppkey
  and s.s_nationkey = n.n_nationkey
  and n.n_name = 'JAPAN'
group by
  ps.ps_partkey having
    sum(ps.ps_supplycost * ps.ps_availqty) > (
      select
        sum(ps.ps_supplycost * ps.ps_availqty) * 0.0001000000
      from
        cp.`tpch/partsupp.parquet` ps,
        cp.`tpch/supplier.parquet` s,
        cp.`tpch/nation.parquet` n
      where
        ps.ps_suppkey = s.s_suppkey
        and s.s_nationkey = n.n_nationkey
        and n.n_name = 'JAPAN'
    )
order by
  `value` desc 
with org.apache.drill.common.exceptions.UserRemoteException: SYSTEM ERROR: AssertionError

Fragment 3:1

[Error Id: 436120b6-5255-437e-af53-313e1c3207e0 on drillu1.qa.lab:31064]

  (java.lang.RuntimeException) java.lang.AssertionError
    org.apache.drill.common.DeferredException.addThrowable():101
    org.apache.drill.exec.work.fragment.FragmentExecutor.fail():471
    org.apache.drill.exec.work.fragment.FragmentExecutor.run():313
    org.apache.drill.common.SelfCleaningRunnable.run():38
    java.util.concurrent.ThreadPoolExecutor.runWorker():1149
    java.util.concurrent.ThreadPoolExecutor$Worker.run():624
    java.lang.Thread.run():748
  Caused By (java.lang.AssertionError) null
    org.apache.drill.exec.compile.sig.MappingSet.enterConstant():85
    org.apache.drill.exec.expr.EvaluationVisitor$ConstantFilter.visitBooleanConstant():1376
    org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitBooleanConstant():1043
    org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitBooleanConstant():843
    org.apache.drill.common.expression.ValueExpressions$BooleanExpression.accept():186
    org.apache.drill.exec.expr.EvaluationVisitor$EvalVisitor.visitReturnValueExpression():579
    org.apache.drill.exec.expr.EvaluationVisitor$EvalVisitor.visitUnknown():342
    org.apache.drill.exec.expr.EvaluationVisitor$ConstantFilter.visitUnknown():1399
    org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitUnknown():1084
    org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitUnknown():843
    org.apache.drill.exec.physical.impl.filter.ReturnValueExpression.accept():56
    org.apache.drill.exec.expr.EvaluationVisitor.addExpr():100
    org.apache.drill.exec.expr.ClassGenerator.addExpr():334
    org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch.setupWorker():266
    org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch.buildSchema():384
    org.apache.drill.exec.record.AbstractRecordBatch.next():144
    org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next():229
    org.apache.drill.exec.record.AbstractRecordBatch.next():118
    org.apache.drill.exec.record.AbstractRecordBatch.next():108
    org.apache.drill.exec.record.AbstractUnaryRecordBatch.innerNext():63
    org.apache.drill.exec.record.AbstractRecordBatch.next():164
    org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next():229
    org.apache.drill.exec.record.AbstractRecordBatch.next():118
    org.apache.drill.exec.record.AbstractRecordBatch.next():108
    org.apache.drill.exec.record.AbstractUnaryRecordBatch.innerNext():63
    org.apache.drill.exec.record.AbstractRecordBatch.next():164
    org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next():229
    org.apache.drill.exec.record.AbstractRecordBatch.next():118
    org.apache.drill.exec.record.AbstractRecordBatch.next():108
    org.apache.drill.exec.record.AbstractUnaryRecordBatch.innerNext():63
    org.apache.drill.exec.physical.impl.project.ProjectRecordBatch.innerNext():137
    org.apache.drill.exec.record.AbstractRecordBatch.next():164
    org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next():229
    org.apache.drill.exec.physical.impl.BaseRootExec.next():105
    org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec.innerNext():152
    org.apache.drill.exec.physical.impl.BaseRootExec.next():95
    org.apache.drill.exec.work.fragment.FragmentExecutor$1.run():292
    org.apache.drill.exec.work.fragment.FragmentExecutor$1.run():279
    java.security.AccessController.doPrivileged():-2
    javax.security.auth.Subject.doAs():422
    org.apache.hadoop.security.UserGroupInformation.doAs():1657
    org.apache.drill.exec.work.fragment.FragmentExecutor.run():279
    org.apache.drill.common.SelfCleaningRunnable.run():38
    java.util.concurrent.ThreadPoolExecutor.runWorker():1149
    java.util.concurrent.ThreadPoolExecutor$Worker.run():624
    java.lang.Thread.run():748

-- tpch11 using 1395599672 as a seed to the RNG
select
  ps.ps_partkey,
  sum(ps.ps_supplycost * ps.ps_availqty) as `value`
from
  cp.`tpch/partsupp.parquet` ps,
  cp.`tpch/supplier.parquet` s,
  cp.`tpch/nation.parquet` n
where
  ps.ps_suppkey = s.s_suppkey
  and s.s_nationkey = n.n_nationkey
  and n.n_name = 'JAPAN'
group by
  ps.ps_partkey having
    sum(ps.ps_supplycost * ps.ps_availqty) > (
      select
        sum(ps.ps_supplycost * ps.ps_availqty) * 0.0001000000
      from
        cp.`tpch/partsupp.parquet` ps,
        cp.`tpch/supplier.parquet` s,
        cp.`tpch/nation.parquet` n
      where
        ps.ps_suppkey = s.s_suppkey
        and s.s_nationkey = n.n_nationkey
        and n.n_name = 'JAPAN'
    )
order by
  `value` desc  failed with org.apache.drill.common.exceptions.UserRemoteException: SYSTEM ERROR: AssertionError

Fragment 3:1

[Error Id: 436120b6-5255-437e-af53-313e1c3207e0 on drillu1.qa.lab:31064]

  (java.lang.RuntimeException) java.lang.AssertionError
    org.apache.drill.common.DeferredException.addThrowable():101
    org.apache.drill.exec.work.fragment.FragmentExecutor.fail():471
    org.apache.drill.exec.work.fragment.FragmentExecutor.run():313
    org.apache.drill.common.SelfCleaningRunnable.run():38
    java.util.concurrent.ThreadPoolExecutor.runWorker():1149
    java.util.concurrent.ThreadPoolExecutor$Worker.run():624
    java.lang.Thread.run():748
  Caused By (java.lang.AssertionError) null
    org.apache.drill.exec.compile.sig.MappingSet.enterConstant():85
    org.apache.drill.exec.expr.EvaluationVisitor$ConstantFilter.visitBooleanConstant():1376
    org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitBooleanConstant():1043
    org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitBooleanConstant():843
    org.apache.drill.common.expression.ValueExpressions$BooleanExpression.accept():186
    org.apache.drill.exec.expr.EvaluationVisitor$EvalVisitor.visitReturnValueExpression():579
    org.apache.drill.exec.expr.EvaluationVisitor$EvalVisitor.visitUnknown():342
    org.apache.drill.exec.expr.EvaluationVisitor$ConstantFilter.visitUnknown():1399
    org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitUnknown():1084
    org.apache.drill.exec.expr.EvaluationVisitor$CSEFilter.visitUnknown():843
    org.apache.drill.exec.physical.impl.filter.ReturnValueExpression.accept():56
    org.apache.drill.exec.expr.EvaluationVisitor.addExpr():100
    org.apache.drill.exec.expr.ClassGenerator.addExpr():334
    org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch.setupWorker():266
    org.apache.drill.exec.physical.impl.join.NestedLoopJoinBatch.buildSchema():384
    org.apache.drill.exec.record.AbstractRecordBatch.next():144
    org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next():229
    org.apache.drill.exec.record.AbstractRecordBatch.next():118
    org.apache.drill.exec.record.AbstractRecordBatch.next():108
    org.apache.drill.exec.record.AbstractUnaryRecordBatch.innerNext():63
    org.apache.drill.exec.record.AbstractRecordBatch.next():164
    org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next():229
    org.apache.drill.exec.record.AbstractRecordBatch.next():118
    org.apache.drill.exec.record.AbstractRecordBatch.next():108
    org.apache.drill.exec.record.AbstractUnaryRecordBatch.innerNext():63
    org.apache.drill.exec.record.AbstractRecordBatch.next():164
    org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next():229
    org.apache.drill.exec.record.AbstractRecordBatch.next():118
    org.apache.drill.exec.record.AbstractRecordBatch.next():108
    org.apache.drill.exec.record.AbstractUnaryRecordBatch.innerNext():63
    org.apache.drill.exec.physical.impl.project.ProjectRecordBatch.innerNext():137
    org.apache.drill.exec.record.AbstractRecordBatch.next():164
    org.apache.drill.exec.physical.impl.validate.IteratorValidatorBatchIterator.next():229
    org.apache.drill.exec.physical.impl.BaseRootExec.next():105
    org.apache.drill.exec.physical.impl.partitionsender.PartitionSenderRootExec.innerNext():152
    org.apache.drill.exec.physical.impl.BaseRootExec.next():95
    org.apache.drill.exec.work.fragment.FragmentExecutor$1.run():292
    org.apache.drill.exec.work.fragment.FragmentExecutor$1.run():279
    java.security.AccessController.doPrivileged():-2
    javax.security.auth.Subject.doAs():422
    org.apache.hadoop.security.UserGroupInformation.doAs():1657
    org.apache.drill.exec.work.fragment.FragmentExecutor.run():279
    org.apache.drill.common.SelfCleaningRunnable.run():38
    java.util.concurrent.ThreadPoolExecutor.runWorker():1149
    java.util.concurrent.ThreadPoolExecutor$Worker.run():624
    java.lang.Thread.run():748

interruptedException: null from 
java.util.concurrent.locks.AbstractQueuedSynchronizer.doAcquireSharedInterruptibly(AbstractQueuedSynchronizer.java:998)
java.util.concurrent.locks.AbstractQueuedSynchronizer.acquireSharedInterruptibly(AbstractQueuedSynchronizer.java:1304)
java.util.concurrent.Semaphore.acquire(Semaphore.java:467)
org.apache.drill.TestTpchDistributedConcurrent.testConcurrentQueries(TestTpchDistributedConcurrent.java:194)
sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
java.lang.reflect.Method.invoke(Method.java:498)
org.junit.runners.model.FrameworkMethod$1.runReflectiveCall(FrameworkMethod.java:50)
org.junit.internal.runners.model.ReflectiveCallable.run(ReflectiveCallable.java:12)
org.junit.runners.model.FrameworkMethod.invokeExplosively(FrameworkMethod.java:47)
mockit.integration.junit4.internal.JUnit4TestRunnerDecorator.executeTestMethod(JUnit4TestRunnerDecorator.java:154)
mockit.integration.junit4.internal.JUnit4TestRunnerDecorator.invokeExplosively(JUnit4TestRunnerDecorator.java:70)
mockit.integration.junit4.internal.FakeFrameworkMethod.invokeExplosively(FakeFrameworkMethod.java:34)
org.junit.runners.model.FrameworkMethod.invokeExplosively(FrameworkMethod.java)
org.junit.internal.runners.statements.InvokeMethod.evaluate(InvokeMethod.java:17)
org.junit.internal.runners.statements.RunBefores.evaluate(RunBefores.java:26)
org.junit.internal.runners.statements.RunAfters.evaluate(RunAfters.java:27)
org.junit.internal.runners.statements.FailOnTimeout$CallableStatement.call(FailOnTimeout.java:298)
org.junit.internal.runners.statements.FailOnTimeout$CallableStatement.call(FailOnTimeout.java:292)
java.util.concurrent.FutureTask.run(FutureTask.java:266)
java.lang.Thread.run(Thread.java:748)

QuerySubmitter quitting.
16:38:21.851 [main] ERROR org.apache.drill.TestReporter - Test Failed (d: 0 B(1 B), h: 788.2 MiB(2.0 GiB), nh: 7.7 MiB(339.7 MiB)): testConcurrentQueries(org.apache.drill.TestTpchDistributedConcurrent)
java.lang.AssertionError: Query error caused interruption expected null, but was:<java.lang.InterruptedException>
	at org.apache.drill.TestTpchDistributedConcurrent.testConcurrentQueries(TestTpchDistributedConcurrent.java:218) ~[test-classes/:na]
	at java.lang.Thread.run(Thread.java:748) ~[na:1.8.0_161]
{code}



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)