You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2019/04/04 18:55:49 UTC

Build failed in Jenkins: beam_PreCommit_JavaPortabilityApi_Cron #610

See <https://builds.apache.org/job/beam_PreCommit_JavaPortabilityApi_Cron/610/display/redirect?page=changes>

Changes:

[valentyn] Remove restrictions for Python 3.7 in Dataflow runner.

[robert] [BEAM-3545] Support Metrics in Go SDK CombineFns

[github] [BEAM-2220, BEAM-6519] Clean-up package namespace underneath

[pabloem] Fixing BQFL test for windows.

------------------------------------------
[...truncated 58.89 KB...]
e38df31d449c: Waiting
fbb641a8b943: Preparing
12cb127eee44: Waiting
fbb641a8b943: Waiting
604829a174eb: Waiting
f7d12d471667: Layer already exists
f350d0146bb3: Layer already exists
e38df31d449c: Layer already exists
af5ae4841776: Layer already exists
b17cc31e431b: Layer already exists
12cb127eee44: Layer already exists
604829a174eb: Layer already exists
fbb641a8b943: Layer already exists
992161255ec1: Pushed
fd9621efd004: Pushed
86ec5bb409b7: Pushed
12c3e72366b5: Pushed
20190404185024: digest: sha256:0f2f58ed2d67e3c9eb8305fd5fb4a56bef5c4301c109d5c667485ae7d6d3786f size: 2841

> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:compileTestJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
Note: Some input files use unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:testClasses
> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:packageTests
> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:assemble
> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:analyzeTestClassesDependencies SKIPPED
> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:analyzeDependencies SKIPPED
> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:checkstyleTest SKIPPED
> Task :beam-runners-google-cloud-dataflow-java-examples:preCommitFnApiWorker
> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:test

org.apache.beam.runners.dataflow.worker.WorkerCustomSourcesTest > testOversplittingDesiredBundleSizeScaledFirst FAILED
    java.lang.OutOfMemoryError at WorkerCustomSourcesTest.java:426

org.apache.beam.runners.dataflow.worker.WorkerCustomSourcesTest > testLargeNumberOfSplitsReturnsSplittableOnlyBoundedSources FAILED
    java.lang.OutOfMemoryError at WorkerCustomSourcesTest.java:426

> Task :beam-runners-google-cloud-dataflow-java-examples:preCommitFnApiWorker

org.apache.beam.examples.WindowedWordCountIT > testWindowedWordCountInBatchStaticSharding FAILED
    java.lang.OutOfMemoryError at WindowedWordCountIT.java:188

org.apache.beam.examples.WindowedWordCountIT > testWindowedWordCountInBatchDynamicSharding FAILED
    java.lang.OutOfMemoryError at WindowedWordCountIT.java:170

org.apache.beam.examples.WordCountIT > testE2EWordCount FAILED
    java.lang.OutOfMemoryError at WordCountIT.java:69

3 tests completed, 3 failed

> Task :beam-runners-google-cloud-dataflow-java-examples:preCommitFnApiWorker FAILED

> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:test

org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarnessTest > testThatWeRetryIfTaskExecutionFailAgainAndAgainByUnknownException FAILED
    java.lang.OutOfMemoryError at DataflowBatchWorkerHarnessTest.java:117

org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarnessTest > testNumberOfWorkerHarnessThreadsIsHonored FAILED
    java.lang.OutOfMemoryError at DataflowBatchWorkerHarnessTest.java:126

org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarnessTest > testThatWeRetryIfTaskExecutionFailAgainAndAgainByIOException FAILED
    java.lang.OutOfMemoryError at DataflowBatchWorkerHarnessTest.java:111

> Task :beam-runners-google-cloud-dataflow-java:cleanUpDockerImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20190404185024
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0f2f58ed2d67e3c9eb8305fd5fb4a56bef5c4301c109d5c667485ae7d6d3786f
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0f2f58ed2d67e3c9eb8305fd5fb4a56bef5c4301c109d5c667485ae7d6d3786f
  Associated tags:
 - 20190404185024
Tags:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java:20190404185024
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20190404185024].
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0f2f58ed2d67e3c9eb8305fd5fb4a56bef5c4301c109d5c667485ae7d6d3786f].

> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:test

org.apache.beam.runners.dataflow.worker.WorkerCustomSourcesSplitOnlySourceTest > testAllSplitsAreReturned[4] FAILED
    java.lang.OutOfMemoryError at WorkerCustomSourcesSplitOnlySourceTest.java:69

org.apache.beam.runners.dataflow.worker.WorkerCustomSourcesSplitOnlySourceTest > testAllSplitsAreReturned[5] FAILED
    java.lang.OutOfMemoryError at WorkerCustomSourcesSplitOnlySourceTest.java:69

org.apache.beam.runners.dataflow.worker.WorkerCustomSourcesSplitOnlySourceTest > testAllSplitsAreReturned[6] FAILED
    java.lang.OutOfMemoryError at WorkerCustomSourcesSplitOnlySourceTest.java:69

org.apache.beam.runners.dataflow.worker.WorkerCustomSourcesSplitOnlySourceTest > testAllSplitsAreReturned[7] FAILED
    java.lang.OutOfMemoryError at WorkerCustomSourcesSplitOnlySourceTest.java:69

org.apache.beam.runners.dataflow.worker.BatchModeExecutionContextTest > stateSamplingInBatch FAILED
    java.lang.OutOfMemoryError

org.apache.beam.runners.dataflow.worker.DeltaCounterCellTest > testAtomicSumAndReset FAILED
    java.lang.OutOfMemoryError

org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorTest > testPerElementProcessingTimeCounters FAILED
    java.lang.OutOfMemoryError at IntrinsicMapTaskExecutorTest.java:263

org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactoryTest > testExecutionContextPlumbing FAILED
    java.lang.OutOfMemoryError at IntrinsicMapTaskExecutorFactoryTest.java:281

org.apache.beam.runners.dataflow.worker.status.WorkerStatusPagesTest > testThreadz FAILED
    java.lang.IllegalStateException at WorkerStatusPagesTest.java:82

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testExceptionInvalidatesCache[0: [streamingEngine=false]] FAILED
    java.lang.AssertionError at StreamingDataflowWorkerTest.java:2294

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testBasic[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testKeyTokenInvalidException[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testBasicHarness[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testKeyCommitTooLargeException[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testUnboundedSourcesDrain[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testIgnoreRetriedKeys[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testNumberOfWorkerHarnessThreadsIsHonored[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testActiveWorkRefresh[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testHugeCommits[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testUnboundedSources[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testMergeSessionWindows[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testAssignWindows[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testMergeWindows[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testKeyCommitTooLargeException_StreamingEngine[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:982

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testLimitOnOutputBundleSizeWithMultipleSinks[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testLimitOnOutputBundleSize[0: [streamingEngine=false]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:636

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testExceptions[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testKeyChange[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:1044

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testExceptionInvalidatesCache[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:2241

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testBasic[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:690

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testBasicHarness[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:653

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testKeyCommitTooLargeException[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:927

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testUnboundedSourcesDrain[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:1976

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testIgnoreRetriedKeys[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:747

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testNumberOfWorkerHarnessThreadsIsHonored[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testHugeCommits[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:2394

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testUnboundedSources[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:1815

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testMergeSessionWindows[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:1655

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testAssignWindows[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:1226

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testMergeWindows[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:1348

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testKeyCommitTooLargeException_StreamingEngine[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:982

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testLimitOnOutputBundleSizeWithMultipleSinks[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:2551

org.apache.beam.runners.dataflow.worker.StreamingDataflowWorkerTest > testLimitOnOutputBundleSize[1: [streamingEngine=true]] FAILED
    java.lang.OutOfMemoryError at StreamingDataflowWorkerTest.java:2472

885 tests completed, 48 failed

> Task :beam-runners-google-cloud-dataflow-java-fn-api-worker:test FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-runners-google-cloud-dataflow-java-examples:preCommitFnApiWorker'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PreCommit_JavaPortabilityApi_Cron/ws/src/runners/google-cloud-dataflow-java/examples/build/reports/tests/preCommitFnApiWorker/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-runners-google-cloud-dataflow-java-fn-api-worker:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PreCommit_JavaPortabilityApi_Cron/ws/src/runners/google-cloud-dataflow-java/worker/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.
==============================================================================

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 28s
96 actionable tasks: 76 executed, 19 from cache, 1 up-to-date

Publishing build scan...
https://gradle.com/s/srriamaqe4f4k

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Jenkins build is back to normal : beam_PreCommit_JavaPortabilityApi_Cron #611

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PreCommit_JavaPortabilityApi_Cron/611/display/redirect?page=changes>


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org