You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2018/05/02 12:52:23 UTC

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #255

See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/255/display/redirect>

------------------------------------------
[...truncated 18.74 MB...]
    May 02, 2018 12:48:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:48:43.550Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 02, 2018 12:48:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:48:43.564Z: Starting 1 workers in us-central1-f...
    May 02, 2018 12:48:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:48:43.589Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 02, 2018 12:48:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:48:43.614Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 02, 2018 12:48:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:48:43.828Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 02, 2018 12:48:52 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:48:50.502Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 02, 2018 12:49:01 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:00.888Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 02, 2018 12:49:01 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:00.916Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 02, 2018 12:49:12 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:11.653Z: Autoscaling: Resized worker pool from 1 to 0.
    May 02, 2018 12:49:12 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:11.688Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 02, 2018 12:49:12 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:11.730Z: Worker pool stopped.
    May 02, 2018 12:49:19 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_05_46_15-953651023179745815 finished with status DONE.
    May 02, 2018 12:49:19 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_05_46_15-953651023179745815. Found 0 success, 0 failures out of 0 expected assertions.
    May 02, 2018 12:49:20 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 12:49:21 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 12:49:21 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 12:49:21 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 12:49:21 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

Gradle Test Executor 129 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testQuery FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testRead FAILED
    java.lang.NoClassDefFoundError: Could not initialize class com.google.cloud.spanner.SpannerImpl
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testReadAllRecordsInDb FAILED
    java.lang.NoClassDefFoundError: Could not initialize class com.google.cloud.spanner.SpannerImpl
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

org.apache.beam.sdk.io.gcp.datastore.V1ReadIT > testE2EV1ReadWithGQLQueryWithNoLimit STANDARD_ERROR
    May 02, 2018 12:49:25 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:24.192Z: Workers have started successfully.
    May 02, 2018 12:49:51 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:49.990Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 02, 2018 12:49:51 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:50.058Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 02, 2018 12:49:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:59.531Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 02, 2018 12:49:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:49:59.604Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 02, 2018 12:50:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:09.228Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 02, 2018 12:50:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:09.371Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 02, 2018 12:50:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:12.422Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 02, 2018 12:50:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:12.488Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 02, 2018 12:50:17 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:16.373Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 02, 2018 12:50:17 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:16.450Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 02, 2018 12:50:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:19.072Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 02, 2018 12:50:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:19.138Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 02, 2018 12:50:25 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:24.385Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 02, 2018 12:50:25 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:24.540Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 02, 2018 12:50:30 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:28.433Z: Cleaning up.
    May 02, 2018 12:50:30 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:50:28.579Z: Stopping worker pool...
    May 02, 2018 12:52:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:52:03.454Z: Autoscaling: Resized worker pool from 1 to 0.
    May 02, 2018 12:52:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T12:52:03.489Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 02, 2018 12:52:11 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_05_48_34-3588696115665391884 finished with status DONE.
    May 02, 2018 12:52:11 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_05_48_34-3588696115665391884. Found 1 success, 0 failures out of 1 expected assertions.
    May 02, 2018 12:52:12 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 12:52:12 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 12:52:13 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 12:52:13 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 12:52:13 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 02, 2018 12:52:13 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 02, 2018 12:52:13 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525074215000000
    May 02, 2018 12:52:14 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 02, 2018 12:52:14 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 02, 2018 12:52:14 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 02, 2018 12:52:14 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525074215000000
    May 02, 2018 12:52:15 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 02, 2018 12:52:15 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 14 mins 9.008 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 51m 53s
545 actionable tasks: 538 executed, 7 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Jenkins build is back to normal : beam_PostCommit_Java_GradleBuild #297

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/297/display/redirect>


Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #296

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/296/display/redirect>

------------------------------------------
[...truncated 18.97 MB...]
org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testFormatCounts STANDARD_ERROR
    May 07, 2018 12:33:09 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testExtractTornadoes STANDARD_ERROR
    May 07, 2018 12:33:09 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testNoTornadoes STANDARD_ERROR
    May 07, 2018 12:33:09 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.TriggerExampleTest > testExtractTotalFlow STANDARD_ERROR
    May 07, 2018 12:33:10 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 07, 2018 12:33:10 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 07, 2018 12:33:10 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 07, 2018 12:33:10 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 07, 2018 12:33:10 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 07, 2018 12:33:10 AM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit1766499359518851366/junit6389855897787085000.tmp matched 1 files with total size 54
    May 07, 2018 12:33:10 AM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit1766499359518851366/junit6389855897787085000.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 07, 2018 12:33:11 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 07, 2018 12:33:12 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo8273237631849283250.sh 
    May 07, 2018 12:33:12 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 07, 2018 12:33:12 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo8273237631849283250.sh to /tmp/test-Echoo3471210574540208309/test-Echo8273237631849283250.sh 
    May 07, 2018 12:33:12 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain7679353204955719786.sh 
    May 07, 2018 12:33:12 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 07, 2018 12:33:12 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain7679353204955719786.sh to /tmp/test-Echoo3471210574540208309/test-EchoAgain7679353204955719786.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 07, 2018 12:33:13 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923
    May 07, 2018 12:33:13 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.0 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 8.358 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':',5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':',5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':',5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':',5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':',5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':',5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 32m 47s
540 actionable tasks: 534 executed, 6 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #295

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/295/display/redirect>

------------------------------------------
[...truncated 18.38 MB...]
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testNoTornadoes STANDARD_ERROR
    May 06, 2018 6:33:32 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.TriggerExampleTest > testExtractTotalFlow STANDARD_ERROR
    May 06, 2018 6:33:33 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 06, 2018 6:33:33 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 06, 2018 6:33:33 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 06, 2018 6:33:33 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 06, 2018 6:33:33 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 06, 2018 6:33:33 PM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit7843385656570018485/junit8599143347634402894.tmp matched 1 files with total size 54
    May 06, 2018 6:33:33 PM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit7843385656570018485/junit8599143347634402894.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 06, 2018 6:33:34 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 06, 2018 6:33:35 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo7114023152707691723.sh 
    May 06, 2018 6:33:35 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 06, 2018 6:33:35 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo7114023152707691723.sh to /tmp/test-Echoo7530646802061782726/test-Echo7114023152707691723.sh 
    May 06, 2018 6:33:35 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain6217613794362464168.sh 
    May 06, 2018 6:33:35 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 06, 2018 6:33:35 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain6217613794362464168.sh to /tmp/test-Echoo7530646802061782726/test-EchoAgain6217613794362464168.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 6:33:36 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 06, 2018 6:33:36 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.0 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 8.621 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 32m 50s
540 actionable tasks: 533 executed, 7 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #294

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/294/display/redirect>

------------------------------------------
[...truncated 18.84 MB...]
org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testExtractTornadoes STANDARD_ERROR
    May 06, 2018 12:33:34 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testNoTornadoes STANDARD_ERROR
    May 06, 2018 12:33:34 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.TriggerExampleTest > testExtractTotalFlow STANDARD_ERROR
    May 06, 2018 12:33:36 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 06, 2018 12:33:36 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 06, 2018 12:33:36 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 06, 2018 12:33:36 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 06, 2018 12:33:36 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 06, 2018 12:33:36 PM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit1705413456884114845/junit5548465682445742346.tmp matched 1 files with total size 54
    May 06, 2018 12:33:36 PM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit1705413456884114845/junit5548465682445742346.tmp into bundles of size 3 took 0 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 06, 2018 12:33:36 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 06, 2018 12:33:38 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo5473439286030000226.sh 
    May 06, 2018 12:33:38 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 06, 2018 12:33:38 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo5473439286030000226.sh to /tmp/test-Echoo7892755413274477696/test-Echo5473439286030000226.sh 
    May 06, 2018 12:33:38 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain5255694668313080540.sh 
    May 06, 2018 12:33:38 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 06, 2018 12:33:38 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain5255694668313080540.sh to /tmp/test-Echoo7892755413274477696/test-EchoAgain5255694668313080540.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 12:33:39 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923
    May 06, 2018 12:33:39 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.002 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 8.898 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 6,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 6,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 32m 55s
540 actionable tasks: 535 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #293

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/293/display/redirect>

------------------------------------------
[...truncated 17.99 MB...]
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testFormatCounts STANDARD_ERROR
    May 06, 2018 6:33:01 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testExtractTornadoes STANDARD_ERROR
    May 06, 2018 6:33:01 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testNoTornadoes STANDARD_ERROR
    May 06, 2018 6:33:01 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.TriggerExampleTest > testExtractTotalFlow STANDARD_ERROR
    May 06, 2018 6:33:02 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 06, 2018 6:33:02 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 06, 2018 6:33:02 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 06, 2018 6:33:02 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 06, 2018 6:33:02 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 06, 2018 6:33:03 AM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit3657823996277541430/junit1233509403882139879.tmp matched 1 files with total size 54
    May 06, 2018 6:33:03 AM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit3657823996277541430/junit1233509403882139879.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 06, 2018 6:33:03 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 06, 2018 6:33:04 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo1569773094531655138.sh 
    May 06, 2018 6:33:04 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 06, 2018 6:33:04 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo1569773094531655138.sh to /tmp/test-Echoo1378257994041161419/test-Echo1569773094531655138.sh 
    May 06, 2018 6:33:04 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain7767438180295279093.sh 
    May 06, 2018 6:33:04 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 06, 2018 6:33:04 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain7767438180295279093.sh to /tmp/test-Echoo1378257994041161419/test-EchoAgain7767438180295279093.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 6:33:05 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 06, 2018 6:33:05 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 9.022 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 2,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 2,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 14,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 14,5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 32m 42s
540 actionable tasks: 534 executed, 6 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #292

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/292/display/redirect>

------------------------------------------
[...truncated 18.87 MB...]

org.apache.beam.examples.cookbook.TriggerExampleTest > testExtractTotalFlow STANDARD_ERROR
    May 06, 2018 12:33:56 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 06, 2018 12:33:56 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 06, 2018 12:33:56 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 06, 2018 12:33:56 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 06, 2018 12:33:56 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 06, 2018 12:33:56 AM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit6160957066959702773/junit4156955436725362484.tmp matched 1 files with total size 54
    May 06, 2018 12:33:56 AM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit6160957066959702773/junit4156955436725362484.tmp into bundles of size 3 took 0 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 06, 2018 12:33:56 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 06, 2018 12:33:57 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo9130355803824105867.sh 
    May 06, 2018 12:33:57 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 06, 2018 12:33:57 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo9130355803824105867.sh to /tmp/test-Echoo3273898319509316124/test-Echo9130355803824105867.sh 
    May 06, 2018 12:33:58 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain5401286991670379662.sh 
    May 06, 2018 12:33:58 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 06, 2018 12:33:58 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain5401286991670379662.sh to /tmp/test-Echoo3273898319509316124/test-EchoAgain5401286991670379662.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 12:33:59 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 06, 2018 12:33:59 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.0 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 8.933 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Daemon worker,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':',5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Daemon worker,5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':',5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-sdks-java-io-elasticsearch-tests-2:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/sdks/java/io/elasticsearch-tests/elasticsearch-tests-2/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 33m 42s
536 actionable tasks: 530 executed, 6 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #291

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/291/display/redirect>

------------------------------------------
[...truncated 18.25 MB...]
org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testNoTornadoes STANDARD_ERROR
    May 05, 2018 6:35:07 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.TriggerExampleTest > testExtractTotalFlow STANDARD_ERROR
    May 05, 2018 6:35:08 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 05, 2018 6:35:08 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 05, 2018 6:35:08 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 05, 2018 6:35:08 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 05, 2018 6:35:09 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 05, 2018 6:35:09 PM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit2236721908122655730/junit3955765829866012923.tmp matched 1 files with total size 54
    May 05, 2018 6:35:09 PM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit2236721908122655730/junit3955765829866012923.tmp into bundles of size 3 took 0 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 05, 2018 6:35:09 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 05, 2018 6:35:10 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo957433477712094745.sh 
    May 05, 2018 6:35:10 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 6:35:10 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo957433477712094745.sh to /tmp/test-Echoo3774141614327690151/test-Echo957433477712094745.sh 
    May 05, 2018 6:35:10 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain6780857062467032407.sh 
    May 05, 2018 6:35:10 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 6:35:10 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain6780857062467032407.sh to /tmp/test-Echoo3774141614327690151/test-EchoAgain6780857062467032407.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 6:35:11 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 05, 2018 6:35:11 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 05, 2018 6:35:11 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 05, 2018 6:35:11 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 05, 2018 6:35:11 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 6:35:12 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 05, 2018 6:35:12 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 6:35:12 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 6:35:12 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 6:35:12 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 05, 2018 6:35:12 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 05, 2018 6:35:12 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 9.094 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 10,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':',5,main]) started.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':',5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 2 failures.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 32m 46s
536 actionable tasks: 531 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #290

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/290/display/redirect>

------------------------------------------
[...truncated 18.04 MB...]
org.apache.beam.examples.cookbook.TriggerExampleTest > testExtractTotalFlow STANDARD_ERROR
    May 05, 2018 12:37:31 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 05, 2018 12:37:31 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 05, 2018 12:37:31 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 05, 2018 12:37:31 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 05, 2018 12:37:32 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 05, 2018 12:37:32 PM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit9212687438338622563/junit4516320187321236959.tmp matched 1 files with total size 54
    May 05, 2018 12:37:32 PM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit9212687438338622563/junit4516320187321236959.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 05, 2018 12:37:32 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 05, 2018 12:37:33 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo7231559481992979427.sh 
    May 05, 2018 12:37:33 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 12:37:33 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo7231559481992979427.sh to /tmp/test-Echoo7452383251467591879/test-Echo7231559481992979427.sh 
    May 05, 2018 12:37:33 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain7774125472496200769.sh 
    May 05, 2018 12:37:33 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 12:37:33 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain7774125472496200769.sh to /tmp/test-Echoo7452383251467591879/test-EchoAgain7774125472496200769.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 12:37:34 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 12:37:34 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 05, 2018 12:37:34 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 05, 2018 12:37:34 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 05, 2018 12:37:34 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 12:37:35 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 12:37:35 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 12:37:35 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 12:37:35 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 12:37:35 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 05, 2018 12:37:35 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 05, 2018 12:37:35 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.0 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 9.625 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 5,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 5,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 9,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 9,5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 35m 3s
540 actionable tasks: 535 executed, 5 from cache

Publishing build scan...
https://gradle.com/s/6egpmjweh3jro

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #289

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

Changes:

[apilloud] Revert "Merge pull request #5220: [BEAM-3983][SQL] Add BigQuery table

[apilloud] Revert "Merge pull request #4947: [BEAM-3983] Add utils for converting

------------------------------------------
[...truncated 19.09 MB...]
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.BigQueryTornadoesTest > testNoTornadoes STANDARD_ERROR
    May 05, 2018 7:50:07 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.TriggerExampleTest > testExtractTotalFlow STANDARD_ERROR
    May 05, 2018 7:50:08 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 05, 2018 7:50:08 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 05, 2018 7:50:08 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 05, 2018 7:50:08 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 05, 2018 7:50:08 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 05, 2018 7:50:08 AM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit2056391471861517291/junit7023225010637686005.tmp matched 1 files with total size 54
    May 05, 2018 7:50:08 AM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit2056391471861517291/junit7023225010637686005.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 05, 2018 7:50:09 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 05, 2018 7:50:10 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo7597536597198416588.sh 
    May 05, 2018 7:50:10 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 7:50:10 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo7597536597198416588.sh to /tmp/test-Echoo2484975182107076364/test-Echo7597536597198416588.sh 
    May 05, 2018 7:50:10 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain4709717495282757485.sh 
    May 05, 2018 7:50:10 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 7:50:10 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain4709717495282757485.sh to /tmp/test-Echoo2484975182107076364/test-EchoAgain4709717495282757485.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 7:50:11 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923
    May 05, 2018 7:50:11 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923

Gradle Test Executor 132 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.0 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 9.157 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 6,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 6,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 6,5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 32m 50s
540 actionable tasks: 537 executed, 3 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #288

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/288/display/redirect>

------------------------------------------
[...truncated 18.27 MB...]
    INFO: Initialized Semaphore for binary test-Echo4716231698709444465.sh 
    May 05, 2018 6:36:06 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 6:36:06 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo4716231698709444465.sh to /tmp/test-Echoo3361727771100599603/test-Echo4716231698709444465.sh 
    May 05, 2018 6:36:06 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain1331619613091568164.sh 
    May 05, 2018 6:36:06 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 6:36:06 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain1331619613091568164.sh to /tmp/test-Echoo3361727771100599603/test-EchoAgain1331619613091568164.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 6:36:07 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 05, 2018 6:36:07 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.003 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 9.171 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 11,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 11,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 11,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) started.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 5 failures.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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-sdks-java-io-elasticsearch-tests-2:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/sdks/java/io/elasticsearch-tests/elasticsearch-tests-2/build/reports/tests/test/index.html>

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

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-sdks-java-io-mqtt:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/sdks/java/io/mqtt/build/reports/tests/test/index.html>

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

4: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-runners-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

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

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 34m 5s
531 actionable tasks: 525 executed, 6 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #287

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

Changes:

[coheigea] Combine nested if statements

------------------------------------------
[...truncated 17.52 MB...]

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 05, 2018 1:47:08 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 05, 2018 1:47:08 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 05, 2018 1:47:08 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 05, 2018 1:47:08 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 05, 2018 1:47:08 AM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit3243753430639982705/junit6211700945323527644.tmp matched 1 files with total size 54
    May 05, 2018 1:47:08 AM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit3243753430639982705/junit6211700945323527644.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 05, 2018 1:47:09 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 05, 2018 1:47:10 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo212469953255409668.sh 
    May 05, 2018 1:47:10 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 1:47:10 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo212469953255409668.sh to /tmp/test-Echoo4307315468754083756/test-Echo212469953255409668.sh 
    May 05, 2018 1:47:10 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain3827621326807243257.sh 
    May 05, 2018 1:47:10 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 1:47:10 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain3827621326807243257.sh to /tmp/test-Echoo4307315468754083756/test-EchoAgain3827621326807243257.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 1:47:11 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 05, 2018 1:47:11 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 132 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.0 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 9.124 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Daemon worker,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Daemon worker,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 2,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 2,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 14,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 14,5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 2 failures.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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:googleCloudPlatformIntegrationTest'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 34m 14s
540 actionable tasks: 536 executed, 4 from cache

Publishing build scan...
https://gradle.com/s/5mxrifmpxuaaq

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #286

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/286/display/redirect>

------------------------------------------
[...truncated 18.57 MB...]

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 05, 2018 12:42:53 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 05, 2018 12:42:53 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 05, 2018 12:42:53 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 05, 2018 12:42:53 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 05, 2018 12:42:53 AM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit4312902488500766368/junit4794618120979304089.tmp matched 1 files with total size 54
    May 05, 2018 12:42:53 AM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit4312902488500766368/junit4794618120979304089.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 05, 2018 12:42:54 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 05, 2018 12:42:55 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo3242799358012366267.sh 
    May 05, 2018 12:42:55 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 12:42:55 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo3242799358012366267.sh to /tmp/test-Echoo7188643077925115423/test-Echo3242799358012366267.sh 
    May 05, 2018 12:42:55 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain4896300994998989362.sh 
    May 05, 2018 12:42:55 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 12:42:55 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain4896300994998989362.sh to /tmp/test-Echoo7188643077925115423/test-EchoAgain4896300994998989362.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 12:42:56 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 05, 2018 12:42:56 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 8.858 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 11,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 11,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 11,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 12,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 12,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 15,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 15,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 2 failures.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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:googleCloudPlatformIntegrationTest'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 36m 50s
540 actionable tasks: 535 executed, 5 from cache

Publishing build scan...
https://gradle.com/s/3jloqzamrmbow

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #285

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

Changes:

[mariagh] Update CoGroupByKey docstring

[sidhom] Use wildcard generics rather than Object in portable translator

[sidhom] [BEAM-4231] Runner utility for coder instantiation

------------------------------------------
[...truncated 18.53 MB...]
    May 05, 2018 12:01:21 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 05, 2018 12:01:22 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 05, 2018 12:01:22 AM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit8797751594478385634/junit6026963945541098197.tmp matched 1 files with total size 54
    May 05, 2018 12:01:22 AM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit8797751594478385634/junit6026963945541098197.tmp into bundles of size 3 took 0 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 05, 2018 12:01:22 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 05, 2018 12:01:23 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo9164136610461446023.sh 
    May 05, 2018 12:01:23 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 12:01:23 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo9164136610461446023.sh to /tmp/test-Echoo2594341069216960708/test-Echo9164136610461446023.sh 
    May 05, 2018 12:01:23 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain5018589803343715213.sh 
    May 05, 2018 12:01:23 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 05, 2018 12:01:23 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain5018589803343715213.sh to /tmp/test-Echoo2594341069216960708/test-EchoAgain5018589803343715213.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 05, 2018 12:01:24 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 05, 2018 12:01:24 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 05, 2018 12:01:25 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 05, 2018 12:01:25 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 05, 2018 12:01:25 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 12:01:25 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 05, 2018 12:01:25 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 12:01:25 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 12:01:25 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 05, 2018 12:01:25 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 05, 2018 12:01:25 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923
    May 05, 2018 12:01:25 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.002 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 9.701 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 13,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 13,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Daemon worker,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Daemon worker,5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-sdks-java-io-jms:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/sdks/java/io/jms/build/reports/tests/test/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

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

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 37m 2s
539 actionable tasks: 534 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user mariagh@mariagh.svl.corp.google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #284

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/284/display/redirect>

------------------------------------------
[...truncated 19.43 MB...]
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:24.774Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:24.806Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:24.847Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:24.892Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:24.929Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:24.979Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.017Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.067Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.114Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.161Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.200Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.242Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.278Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.322Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.363Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.411Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.459Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.502Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.548Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.597Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.638Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.693Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.736Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.786Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.822Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.864Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.914Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:25.963Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.015Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.056Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.104Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.150Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.199Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.240Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.280Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.323Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.824Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.872Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.913Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.931Z: Starting 1 workers in us-central1-c...
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:26.961Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 04, 2018 7:00:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:27.002Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 04, 2018 7:00:28 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:27.303Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 04, 2018 7:00:38 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:37.262Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 04, 2018 7:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:58.464Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 04, 2018 7:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:00:58.505Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 7:01:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:01:23.982Z: Workers have started successfully.
    May 04, 2018 7:01:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:01:52.743Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 04, 2018 7:01:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:01:52.849Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 04, 2018 7:02:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:03.175Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 04, 2018 7:02:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:03.270Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 04, 2018 7:02:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:14.206Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 04, 2018 7:02:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:14.409Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 04, 2018 7:02:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:16.376Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 04, 2018 7:02:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:16.471Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 04, 2018 7:02:22 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:21.896Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 04, 2018 7:02:22 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:21.983Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 04, 2018 7:02:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:24.582Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 04, 2018 7:02:26 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:24.664Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 04, 2018 7:02:34 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:32.191Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 04, 2018 7:02:34 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:32.388Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 04, 2018 7:02:34 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:34.318Z: Cleaning up.
    May 04, 2018 7:02:34 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:02:34.489Z: Stopping worker pool...
    May 04, 2018 7:04:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:04:16.531Z: Autoscaling: Resized worker pool from 1 to 0.
    May 04, 2018 7:04:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T19:04:16.589Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 7:04:25 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-04_12_00_17-12454349994399589657 finished with status DONE.
    May 04, 2018 7:04:25 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-04_12_00_17-12454349994399589657. Found 1 success, 0 failures out of 1 expected assertions.
    May 04, 2018 7:04:25 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 7:04:25 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 7:04:26 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 7:04:26 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 7:04:26 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 04, 2018 7:04:26 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 7:04:26 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 04, 2018 7:04:27 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 04, 2018 7:04:27 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 04, 2018 7:04:27 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 7:04:27 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 04, 2018 7:04:27 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 04, 2018 7:04:27 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 130 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.013 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 16 mins 8.066 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 1m 13s
545 actionable tasks: 541 executed, 4 from cache

Publishing build scan...
https://gradle.com/s/36wppy3mv6ndc

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #283

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

Changes:

[swegner] Remove Gradle worker cap.

[swegner] Re-enable additional Jenkins worker parallelism for Dataflow

[swegner] Adjust Jenkins Gradle memory usage based on max-workers

[swegner] Hard-code jenkins machines total memory until we find a working API

------------------------------------------
[...truncated 18.75 MB...]
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.092Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.143Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.188Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.228Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.266Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.310Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.357Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.408Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.452Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.504Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.547Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.586Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.633Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.665Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.708Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.752Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.799Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.841Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.890Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.940Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:57.990Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.027Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.073Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.113Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.152Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.190Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.238Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.287Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.322Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.363Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.410Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.456Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.501Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.544Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:58.596Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:59.108Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:59.146Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:59.178Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:59.213Z: Starting 1 workers in us-central1-b...
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:59.213Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:59.241Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 04, 2018 6:42:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:42:59.529Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 04, 2018 6:43:08 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:43:08.391Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 04, 2018 6:43:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:43:18.834Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 04, 2018 6:43:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:43:18.868Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 6:43:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:43:42.894Z: Workers have started successfully.
    May 04, 2018 6:44:08 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:08.777Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 04, 2018 6:44:08 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:08.856Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 04, 2018 6:44:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:18.914Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 04, 2018 6:44:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:19.079Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 04, 2018 6:44:28 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:27.464Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 04, 2018 6:44:28 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:27.670Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 04, 2018 6:44:31 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:31.238Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 04, 2018 6:44:31 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:31.318Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 04, 2018 6:44:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:35.365Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 04, 2018 6:44:37 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:35.467Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 04, 2018 6:44:37 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:37.991Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 04, 2018 6:44:37 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:38.087Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 04, 2018 6:44:45 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:44.152Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 04, 2018 6:44:45 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:44.379Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 04, 2018 6:44:48 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:47.538Z: Cleaning up.
    May 04, 2018 6:44:48 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:44:47.700Z: Stopping worker pool...
    May 04, 2018 6:46:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:46:32.163Z: Autoscaling: Resized worker pool from 1 to 0.
    May 04, 2018 6:46:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:46:32.209Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 6:46:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T18:46:32.268Z: Worker pool stopped.
    May 04, 2018 6:46:42 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-04_11_42_48-13575952852661823762 finished with status DONE.
    May 04, 2018 6:46:42 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-04_11_42_48-13575952852661823762. Found 1 success, 0 failures out of 1 expected assertions.
    May 04, 2018 6:46:43 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 6:46:43 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 6:46:43 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 6:46:44 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 6:46:44 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 04, 2018 6:46:44 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 6:46:44 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 04, 2018 6:46:44 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 04, 2018 6:46:44 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 04, 2018 6:46:45 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 6:46:45 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 04, 2018 6:46:45 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 04, 2018 6:46:45 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 129 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.011 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 16 mins 37.611 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 1m 9s
545 actionable tasks: 540 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #282

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/282/display/redirect>

------------------------------------------
[...truncated 18.43 MB...]
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.257Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.299Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.343Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.387Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.429Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.468Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.513Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.557Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.599Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.643Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.682Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.728Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.773Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.812Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.851Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.896Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.943Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:31.987Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.032Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.078Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.113Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.149Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.194Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.235Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.270Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.315Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.355Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.391Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.431Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.474Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.520Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.565Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.603Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.648Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 04, 2018 12:51:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:32.685Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 04, 2018 12:51:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:33.212Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 04, 2018 12:51:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:33.252Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 04, 2018 12:51:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:33.294Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 04, 2018 12:51:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:33.321Z: Starting 1 workers in us-central1-b...
    May 04, 2018 12:51:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:33.333Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 04, 2018 12:51:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:33.373Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 04, 2018 12:51:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:33.688Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 04, 2018 12:51:43 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:41.317Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 04, 2018 12:51:52 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:51.772Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 04, 2018 12:51:52 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:51:51.808Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 12:52:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:52:18.904Z: Workers have started successfully.
    May 04, 2018 12:52:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:52:35.617Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 04, 2018 12:52:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:52:35.687Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 04, 2018 12:52:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:52:44.304Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 04, 2018 12:52:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:52:44.395Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 04, 2018 12:52:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:52:52.678Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 04, 2018 12:52:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:52:52.859Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 04, 2018 12:52:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:52:55.411Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 04, 2018 12:52:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:52:55.478Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 04, 2018 12:53:00 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:53:00.104Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 04, 2018 12:53:00 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:53:00.183Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 04, 2018 12:53:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:53:04.582Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 04, 2018 12:53:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:53:04.669Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 04, 2018 12:53:12 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:53:10.613Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 04, 2018 12:53:12 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:53:10.811Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 04, 2018 12:53:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:53:13.564Z: Cleaning up.
    May 04, 2018 12:53:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:53:13.912Z: Stopping worker pool...
    May 04, 2018 12:54:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:54:30.055Z: Autoscaling: Resized worker pool from 1 to 0.
    May 04, 2018 12:54:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:54:30.100Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 12:54:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T12:54:30.156Z: Worker pool stopped.
    May 04, 2018 12:54:40 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-04_05_51_21-16515225986866055704 finished with status DONE.
    May 04, 2018 12:54:40 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-04_05_51_21-16515225986866055704. Found 1 success, 0 failures out of 1 expected assertions.
    May 04, 2018 12:54:41 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 12:54:41 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 12:54:42 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 12:54:43 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 12:54:43 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 04, 2018 12:54:43 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 12:54:43 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 04, 2018 12:54:43 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 04, 2018 12:54:43 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 04, 2018 12:54:44 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 12:54:44 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 04, 2018 12:54:44 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 04, 2018 12:54:44 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.008 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.009 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 15 mins 14.852 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 53m 32s
545 actionable tasks: 538 executed, 7 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #281

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

Changes:

[iemejia] Make MetricsHttpSinkTest more concise and fix typo

------------------------------------------
[...truncated 18.87 MB...]
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.487Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.531Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.575Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.619Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.661Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.704Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.749Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.794Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.831Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.876Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.914Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.956Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:17.988Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.024Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.067Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.102Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.145Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.181Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.225Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.259Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.304Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.348Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.389Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.435Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.471Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.512Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.549Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.594Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.630Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.665Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.710Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.754Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.790Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.830Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.872Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:18.906Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:19.350Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:19.393Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:19.430Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:19.445Z: Starting 1 workers in us-central1-f...
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:19.470Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:19.512Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 04, 2018 8:55:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:19.787Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 04, 2018 8:55:26 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:26.629Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 04, 2018 8:55:37 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:36.967Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 04, 2018 8:55:37 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:36.982Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 8:55:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:55:56.733Z: Workers have started successfully.
    May 04, 2018 8:56:27 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:27.119Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 04, 2018 8:56:27 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:27.188Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 04, 2018 8:56:40 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:38.141Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 04, 2018 8:56:40 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:38.212Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 04, 2018 8:56:50 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:49.496Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 04, 2018 8:56:50 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:49.659Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 04, 2018 8:56:54 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:52.899Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 04, 2018 8:56:54 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:52.972Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 04, 2018 8:56:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:56.925Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 04, 2018 8:56:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:56:56.993Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 04, 2018 8:57:02 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:57:01.613Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 04, 2018 8:57:02 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:57:01.688Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 04, 2018 8:57:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:57:07.024Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 04, 2018 8:57:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:57:07.277Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 04, 2018 8:57:11 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:57:10.100Z: Cleaning up.
    May 04, 2018 8:57:11 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:57:10.350Z: Stopping worker pool...
    May 04, 2018 8:58:15 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:58:15.153Z: Autoscaling: Resized worker pool from 1 to 0.
    May 04, 2018 8:58:15 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T08:58:15.179Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 8:58:23 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-04_01_55_09-8319928845033114102 finished with status DONE.
    May 04, 2018 8:58:23 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-04_01_55_09-8319928845033114102. Found 1 success, 0 failures out of 1 expected assertions.
    May 04, 2018 8:58:23 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 8:58:24 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 8:58:24 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 8:58:24 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 8:58:24 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 04, 2018 8:58:24 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 8:58:25 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 04, 2018 8:58:25 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 04, 2018 8:58:25 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 04, 2018 8:58:25 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 8:58:25 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 04, 2018 8:58:25 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 04, 2018 8:58:25 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.006 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 14 mins 25.734 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 49m 17s
545 actionable tasks: 540 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #280

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/280/display/redirect>

------------------------------------------
[...truncated 18.74 MB...]
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.051Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.095Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.166Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.208Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.247Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.277Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.312Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.347Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.381Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.412Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.443Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.469Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.503Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.529Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.563Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.598Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.630Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.657Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.684Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.717Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.755Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.791Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.827Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.848Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.883Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.919Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.949Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:12.979Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.007Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.039Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.074Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.109Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.134Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.169Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.206Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.240Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.598Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.635Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.658Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.672Z: Starting 1 workers in us-central1-f...
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.692Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.720Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 04, 2018 6:49:17 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:13.959Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 04, 2018 6:49:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:20.461Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 04, 2018 6:49:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:30.812Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 04, 2018 6:49:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:30.843Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 6:49:58 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:49:57.266Z: Workers have started successfully.
    May 04, 2018 6:50:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:20.102Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 04, 2018 6:50:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:20.206Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 04, 2018 6:50:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:29.277Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 04, 2018 6:50:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:29.352Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 04, 2018 6:50:42 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:40.674Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 04, 2018 6:50:42 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:41.110Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 04, 2018 6:50:44 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:43.952Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 04, 2018 6:50:44 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:44.042Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 04, 2018 6:50:49 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:46.899Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 04, 2018 6:50:49 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:46.998Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 04, 2018 6:50:52 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:49.645Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 04, 2018 6:50:52 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:49.734Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 04, 2018 6:50:55 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:54.402Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 04, 2018 6:50:55 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:54.652Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 04, 2018 6:50:56 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:56.839Z: Cleaning up.
    May 04, 2018 6:50:59 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:50:57.300Z: Stopping worker pool...
    May 04, 2018 6:52:14 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:52:14.145Z: Autoscaling: Resized worker pool from 1 to 0.
    May 04, 2018 6:52:14 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T06:52:14.190Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 6:52:24 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_23_49_04-1989778772426273042 finished with status DONE.
    May 04, 2018 6:52:24 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_23_49_04-1989778772426273042. Found 1 success, 0 failures out of 1 expected assertions.
    May 04, 2018 6:52:24 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 6:52:24 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 6:52:25 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 6:52:25 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 6:52:25 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 04, 2018 6:52:25 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 6:52:25 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 04, 2018 6:52:25 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 04, 2018 6:52:25 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 04, 2018 6:52:26 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 6:52:26 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 04, 2018 6:52:26 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 04, 2018 6:52:26 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.008 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.013 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 14 mins 34.3 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 51m 32s
545 actionable tasks: 538 executed, 7 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #279

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

Changes:

[apilloud] [SQL] Use the same javacc and fmpp as calcite

[apilloud] [SQL] BeamQueryPlanner uses BeamSqlParserImpl

------------------------------------------
[...truncated 19.63 MB...]
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.400Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.437Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.474Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.509Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.550Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.595Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.630Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.664Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.709Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.748Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.780Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.827Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.870Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.910Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.950Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:19.985Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.030Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.073Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.109Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.155Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.195Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.245Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.285Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.328Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.373Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.414Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.459Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.507Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.548Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.585Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.630Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.669Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.708Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.746Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.793Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:20.841Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:21.286Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:21.332Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:21.369Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:21.386Z: Starting 1 workers in us-central1-f...
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:21.412Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:21.447Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 04, 2018 5:26:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:21.753Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 04, 2018 5:26:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:26:29.266Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 04, 2018 5:27:27 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:27:25.888Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 04, 2018 5:27:27 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:27:25.933Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 5:27:45 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:27:45.454Z: Workers have started successfully.
    May 04, 2018 5:28:12 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:09.826Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 04, 2018 5:28:12 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:09.927Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 04, 2018 5:28:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:18.944Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 04, 2018 5:28:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:19.037Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 04, 2018 5:28:34 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:31.814Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 04, 2018 5:28:34 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:32.052Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 04, 2018 5:28:36 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:36.379Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 04, 2018 5:28:36 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:36.474Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 04, 2018 5:28:42 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:40.557Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 04, 2018 5:28:42 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:40.650Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 04, 2018 5:28:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:45.277Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 04, 2018 5:28:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:45.366Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 04, 2018 5:28:55 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:55.048Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 04, 2018 5:28:55 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:55.223Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 04, 2018 5:28:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:57.552Z: Cleaning up.
    May 04, 2018 5:29:00 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:28:58.149Z: Stopping worker pool...
    May 04, 2018 5:30:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:30:22.291Z: Autoscaling: Resized worker pool from 1 to 0.
    May 04, 2018 5:30:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T05:30:22.338Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 5:30:30 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_22_26_09-7009724741483317196 finished with status DONE.
    May 04, 2018 5:30:30 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_22_26_09-7009724741483317196. Found 1 success, 0 failures out of 1 expected assertions.
    May 04, 2018 5:30:30 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 5:30:31 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 5:30:31 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 5:30:31 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 5:30:31 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 04, 2018 5:30:31 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 5:30:32 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 04, 2018 5:30:32 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 04, 2018 5:30:32 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 04, 2018 5:30:32 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 5:30:32 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 04, 2018 5:30:33 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 04, 2018 5:30:33 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.006 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.008 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 17 mins 7.06 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 54m 25s
545 actionable tasks: 540 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #278

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

Changes:

[tgroh] Add an Unsupported StateRequestHandler

------------------------------------------
[...truncated 18.87 MB...]
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.022Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.049Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.077Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.107Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.144Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.199Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.240Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.279Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.315Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.355Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.392Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.431Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.457Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.496Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.536Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.568Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.606Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.641Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.682Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.727Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.770Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.800Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.838Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.873Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.913Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.948Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:00.985Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.018Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.048Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.085Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.122Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.164Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.201Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.227Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.258Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.288Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.682Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.706Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.730Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.753Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.770Z: Starting 1 workers in us-central1-f...
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:01.779Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 04, 2018 2:43:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:02.062Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 04, 2018 2:43:11 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:11.191Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 04, 2018 2:43:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:21.554Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 04, 2018 2:43:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:21.598Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 2:43:51 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:43:48.903Z: Workers have started successfully.
    May 04, 2018 2:44:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:20.116Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 04, 2018 2:44:20 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:20.188Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 04, 2018 2:44:31 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:29.203Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 04, 2018 2:44:31 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:29.262Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 04, 2018 2:44:39 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:39.035Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 04, 2018 2:44:39 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:39.172Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 04, 2018 2:44:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:43.058Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 04, 2018 2:44:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:43.138Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 04, 2018 2:44:48 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:48.253Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 04, 2018 2:44:48 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:48.322Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 04, 2018 2:44:53 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:53.057Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 04, 2018 2:44:53 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:53.162Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 04, 2018 2:45:01 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:59.275Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 04, 2018 2:45:01 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:44:59.467Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 04, 2018 2:45:02 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:45:01.463Z: Cleaning up.
    May 04, 2018 2:45:02 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:45:01.853Z: Stopping worker pool...
    May 04, 2018 2:46:03 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:46:02.926Z: Autoscaling: Resized worker pool from 1 to 0.
    May 04, 2018 2:46:03 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-04T02:46:02.952Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 04, 2018 2:46:14 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_19_42_49-5295481362565482554 finished with status DONE.
    May 04, 2018 2:46:14 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_19_42_49-5295481362565482554. Found 1 success, 0 failures out of 1 expected assertions.
    May 04, 2018 2:46:15 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 2:46:15 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 2:46:16 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 04, 2018 2:46:16 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 04, 2018 2:46:16 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 04, 2018 2:46:16 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 2:46:17 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 04, 2018 2:46:17 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 04, 2018 2:46:17 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 04, 2018 2:46:17 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 04, 2018 2:46:17 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 04, 2018 2:46:18 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 04, 2018 2:46:18 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 129 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.006 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 14 mins 53.963 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 52m 25s
545 actionable tasks: 538 executed, 7 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #277

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/277/display/redirect>

------------------------------------------
[...truncated 18.85 MB...]

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 04, 2018 12:39:13 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 04, 2018 12:39:13 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 04, 2018 12:39:14 AM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit2802740750844789913/junit7670987741804310477.tmp matched 1 files with total size 54
    May 04, 2018 12:39:14 AM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit2802740750844789913/junit7670987741804310477.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 04, 2018 12:39:14 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 04, 2018 12:39:15 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo4661759351989372341.sh 
    May 04, 2018 12:39:15 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 04, 2018 12:39:15 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo4661759351989372341.sh to /tmp/test-Echoo1560119465224277674/test-Echo4661759351989372341.sh 
    May 04, 2018 12:39:16 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain6246923428479559223.sh 
    May 04, 2018 12:39:16 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 04, 2018 12:39:16 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain6246923428479559223.sh to /tmp/test-Echoo1560119465224277674/test-EchoAgain6246923428479559223.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 04, 2018 12:39:17 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923
    May 04, 2018 12:39:17 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.002 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 10.716 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 10,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 10,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 3 failures.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

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

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 38m 20s
536 actionable tasks: 530 executed, 6 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #276

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

Changes:

[apilloud] [SQL] Add BeamEnumerableConverter

------------------------------------------
[...truncated 18.46 MB...]
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:40.812Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:40.847Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:40.878Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:40.907Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:40.938Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:40.978Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.010Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.045Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.074Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.108Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.137Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.172Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.203Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.237Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.275Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.314Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.335Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.366Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.401Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.439Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.476Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.512Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.542Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.566Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.594Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.613Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.655Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.691Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.723Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.762Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.800Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.838Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.880Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.916Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:41.949Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:42.326Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:42.357Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:42.391Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:42.404Z: Starting 1 workers in us-central1-b...
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:42.422Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:42.456Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 11:36:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:42.677Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 11:36:50 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:36:49.604Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 11:37:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:37:15.720Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 11:37:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:37:15.748Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 11:37:46 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:37:45.282Z: Workers have started successfully.
    May 03, 2018 11:38:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:04.935Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 11:38:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:05.000Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 11:38:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:14.071Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 11:38:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:14.120Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 11:38:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:23.469Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 11:38:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:23.641Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 11:38:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:25.769Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 11:38:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:25.834Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 11:38:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:29.930Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 11:38:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:29.992Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 11:38:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:34.606Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 11:38:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:34.672Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 11:38:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:42.601Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 11:38:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:42.736Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 11:38:46 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:45.654Z: Cleaning up.
    May 03, 2018 11:38:46 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:38:45.906Z: Stopping worker pool...
    May 03, 2018 11:40:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:40:11.854Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 11:40:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:40:11.878Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 11:40:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:40:11.917Z: Worker pool stopped.
    May 03, 2018 11:40:23 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_16_36_30-2773143734847853713 finished with status DONE.
    May 03, 2018 11:40:23 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_16_36_30-2773143734847853713. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 11:40:23 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 11:40:24 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 11:40:24 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 11:40:25 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 11:40:25 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 11:40:25 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 11:40:25 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 03, 2018 11:40:25 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 11:40:25 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 11:40:25 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 11:40:25 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 03, 2018 11:40:26 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 11:40:26 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.011 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 16 mins 0.329 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 55m 16s
545 actionable tasks: 540 executed, 5 from cache

Publishing build scan...
https://gradle.com/s/5q3j2qikslgqy

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #275

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

Changes:

[tgroh] Add additional methods to QueryablePipeline

[tgroh] Expand the ExecutableGraph interface

------------------------------------------
[...truncated 19.11 MB...]
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:48.737Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:48.791Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:48.840Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:48.886Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:48.928Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:48.966Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.008Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.059Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.110Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.148Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.194Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.243Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.297Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.340Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.395Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.423Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.467Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.513Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.557Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.610Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.661Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.710Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.757Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.802Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.845Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.892Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.936Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:49.987Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.039Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.088Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.138Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.177Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.221Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.269Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.319Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.357Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.899Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.929Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:50.964Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:51.005Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:51.005Z: Starting 1 workers in us-central1-f...
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:51.060Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:51.367Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 11:09:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:09:58.136Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 11:10:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:10:08.493Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 11:10:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:10:08.533Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 11:10:39 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:10:38.321Z: Workers have started successfully.
    May 03, 2018 11:11:02 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:01.534Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 11:11:02 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:01.632Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 11:11:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:09.663Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 11:11:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:09.778Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 11:11:28 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:28.428Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 11:11:28 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:28.669Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 11:11:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:30.737Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 11:11:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:30.865Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 11:11:38 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:36.806Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 11:11:38 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:36.899Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 11:11:40 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:40.694Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 11:11:43 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:40.837Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 11:11:49 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:48.224Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 11:11:49 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:48.463Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 11:11:55 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:53.590Z: Cleaning up.
    May 03, 2018 11:11:55 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:11:53.752Z: Stopping worker pool...
    May 03, 2018 11:13:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:13:18.734Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 11:13:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T23:13:18.783Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 11:13:27 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_16_09_38-13312937649770522894 finished with status DONE.
    May 03, 2018 11:13:27 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_16_09_38-13312937649770522894. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 11:13:27 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 11:13:28 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 11:13:28 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 11:13:29 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 130 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.009 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 14 mins 49.673 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 52m 55s
545 actionable tasks: 541 executed, 4 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #274

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

Changes:

[tgroh] Add ProtoOverrides

------------------------------------------
[...truncated 19.44 MB...]
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.368Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.414Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.460Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.497Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.546Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.600Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.643Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.712Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.749Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.792Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.829Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.871Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.894Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.933Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:04.977Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.010Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.048Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.096Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.139Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.173Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.214Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.253Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.290Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.328Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.370Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.408Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.453Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.500Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.548Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.574Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.613Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.652Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.696Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.740Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:05.780Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:06.277Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:06.317Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:06.358Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:06.371Z: Starting 1 workers in us-central1-f...
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:06.391Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:06.438Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:06.780Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 10:49:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:13.261Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 10:49:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:23.688Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 10:49:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:23.719Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 10:49:55 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:49:54.889Z: Workers have started successfully.
    May 03, 2018 10:50:22 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:50:21.679Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 10:50:22 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:50:21.810Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 10:50:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:50:31.138Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 10:50:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:50:31.283Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 10:50:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:50:54.278Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 10:50:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:50:54.503Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 10:50:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:50:57.807Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 10:50:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:50:57.930Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 10:51:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:51:02.972Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 10:51:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:51:03.090Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 10:51:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:51:08.606Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 10:51:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:51:08.713Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 10:51:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:51:14.558Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 10:51:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:51:14.798Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 10:51:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:51:18.373Z: Cleaning up.
    May 03, 2018 10:51:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:51:18.644Z: Stopping worker pool...
    May 03, 2018 10:52:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:52:34.981Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 10:52:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:52:35.033Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 10:52:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:52:35.094Z: Worker pool stopped.
    May 03, 2018 10:52:45 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_15_48_40-13398087055690859696 finished with status DONE.
    May 03, 2018 10:52:45 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_15_48_40-13398087055690859696. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 10:52:45 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 10:52:45 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 10:52:46 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 10:52:46 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 10:52:46 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 10:52:46 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 10:52:46 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 03, 2018 10:52:46 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 10:52:46 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 10:52:47 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 10:52:47 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 03, 2018 10:52:47 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 10:52:47 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 15 mins 45.839 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 53m 16s
545 actionable tasks: 540 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #273

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

Changes:

[jasonkuster] Add labels to Go SDK Dataflow Runner.

[jasonkuster] Add verbose error message if unmarshaling fails for label flag.

------------------------------------------
[...truncated 19.10 MB...]
    INFO: 2018-05-03T22:46:14.188Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 03, 2018 10:46:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:46:18.884Z: Cleaning up.
    May 03, 2018 10:46:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:46:19.001Z: Stopping worker pool...

org.apache.beam.sdk.io.gcp.datastore.V1ReadIT > testE2EV1ReadWithGQLQueryWithNoLimit STANDARD_ERROR
    May 03, 2018 10:46:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:46:21.626Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 10:46:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:46:21.802Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 10:46:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:46:23.766Z: Cleaning up.
    May 03, 2018 10:46:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:46:24.025Z: Stopping worker pool...
    May 03, 2018 10:47:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:47:32.105Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 10:47:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:47:32.140Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 10:47:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:47:32.180Z: Worker pool stopped.

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 03, 2018 10:47:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:47:34.030Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 10:47:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:47:34.056Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 10:47:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T22:47:34.094Z: Worker pool stopped.

org.apache.beam.sdk.io.gcp.datastore.V1ReadIT > testE2EV1ReadWithGQLQueryWithNoLimit STANDARD_ERROR
    May 03, 2018 10:47:41 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_15_44_29-5645445011856715246 finished with status DONE.
    May 03, 2018 10:47:41 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_15_44_29-5645445011856715246. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 10:47:41 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 10:47:41 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 10:47:42 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 10:47:42 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 10:47:42 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 10:47:42 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 03, 2018 10:47:42 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_15_44_43-4440649276218068697 finished with status DONE.
    May 03, 2018 10:47:42 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_15_44_43-4440649276218068697. Found 0 success, 0 failures out of 0 expected assertions.

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 10:47:42 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 03, 2018 10:47:43 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 10:47:43 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 10:47:43 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 10:47:43 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 03, 2018 10:47:43 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 10:47:43 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 03, 2018 10:47:43 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities

Gradle Test Executor 122 finished executing tests.
Gradle Test Executor 130 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 03, 2018 10:47:43 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 10:47:44 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 10:47:44 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 10:47:44 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testQuery FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testRead FAILED
    java.lang.NoClassDefFoundError: Could not initialize class com.google.cloud.spanner.SpannerImpl
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testReadAllRecordsInDb FAILED
    java.lang.NoClassDefFoundError: Could not initialize class com.google.cloud.spanner.SpannerImpl
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.011 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 15 mins 16.228 secs.

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-sdks-java-maven-archetypes-examples:generateAndBuildArchetypeTest'.
> Process 'command '/home/jenkins/tools/maven/apache-maven-3.5.2/bin/mvn'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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-sdks-java-maven-archetypes-starter:generateAndBuildArchetypeTest'.
> Process 'command '/home/jenkins/tools/maven/apache-maven-3.5.2/bin/mvn'' finished with non-zero exit value 1

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

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 50m 14s
545 actionable tasks: 542 executed, 3 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #272

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

Changes:

[sidhom] Move SyntheticNodes to top-level construction package and rename

[sidhom] Pull Flink execution environment utilities into static methods

[sidhom] Refactor Runner/SDK wire coder creation into a shared utility

[sidhom] [BEAM-3972] Translate portable batch pipelines by proto

[sidhom] FIXUP: Use ModelCoders to create proto coders and use WireCoders to

[sidhom] FIXUP: Use RunnerApi in WireCoders to prepare for coder instantiation

------------------------------------------
[...truncated 19.00 MB...]
    INFO: 2018-05-03T21:53:58.855Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:58.894Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:58.937Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:58.969Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.011Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.051Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.086Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.126Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.169Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.206Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.239Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.291Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.325Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.348Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.393Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.438Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.482Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.529Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.582Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.622Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.671Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.718Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.755Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.797Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.850Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.897Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.937Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:53:59.966Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.015Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.072Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.124Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.164Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.203Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.254Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.299Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.349Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.812Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.851Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.890Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.920Z: Starting 1 workers in us-central1-f...
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.920Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:00.962Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 9:54:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:01.253Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 9:54:11 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:09.886Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 9:54:22 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:20.235Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 9:54:22 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:20.268Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 9:54:46 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:54:45.971Z: Workers have started successfully.
    May 03, 2018 9:55:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:19.058Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 9:55:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:19.146Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 9:55:29 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:26.106Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 9:55:29 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:26.206Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 9:55:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:36.060Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 9:55:38 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:36.246Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 9:55:38 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:38.226Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 9:55:38 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:38.318Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 9:55:45 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:44.322Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 9:55:45 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:44.424Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 9:55:48 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:47.255Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 9:55:48 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:47.335Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 9:55:55 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:53.634Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 9:55:55 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:53.848Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 9:55:55 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:55.804Z: Cleaning up.
    May 03, 2018 9:55:58 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:55:56.291Z: Stopping worker pool...
    May 03, 2018 9:57:16 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:57:16.297Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 9:57:16 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:57:16.342Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 9:57:16 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T21:57:16.413Z: Worker pool stopped.
    May 03, 2018 9:57:24 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_14_53_48-12800418559103507864 finished with status DONE.
    May 03, 2018 9:57:24 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_14_53_48-12800418559103507864. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 9:57:24 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 9:57:25 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 9:57:25 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 9:57:25 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 9:57:25 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 9:57:25 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 9:57:26 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 03, 2018 9:57:26 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 9:57:26 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 9:57:26 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 9:57:26 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 03, 2018 9:57:26 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 9:57:26 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 15 mins 27.856 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 55m 55s
545 actionable tasks: 539 executed, 6 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #271

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

Changes:

[coheigea] A few small fixes to catch a few regressions - put String literals

------------------------------------------
[...truncated 19.59 MB...]
    INFO: 2018-05-03T20:56:33.045Z: Unzipping flatten s18-u63 for input s19.output-c61
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.071Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.102Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.138Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.175Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.209Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.239Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.278Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.307Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.348Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.374Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.410Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.440Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.468Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.507Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.542Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.576Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.607Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.642Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.681Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.707Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.746Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.779Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.810Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.845Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.865Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.894Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.921Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.952Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:33.986Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.022Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.056Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.091Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.132Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.168Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.212Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.238Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.577Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.607Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.649Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.657Z: Starting 1 workers in us-central1-f...
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.701Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:34.741Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 8:56:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:35.002Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 8:56:43 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:41.302Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 8:56:57 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:56.858Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 8:56:57 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:56:56.887Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 8:57:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:57:21.242Z: Workers have started successfully.
    May 03, 2018 8:57:40 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:57:40.302Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 8:57:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:57:40.377Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 8:57:50 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:57:49.889Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 8:57:50 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:57:49.947Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 8:57:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:57:58.037Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 8:57:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:57:58.181Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 8:58:00 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:00.101Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 8:58:00 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:00.164Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 8:58:06 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:05.067Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 8:58:06 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:05.121Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 8:58:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:09.855Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 8:58:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:09.958Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 8:58:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:17.980Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 8:58:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:18.128Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 8:58:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:18.987Z: Cleaning up.
    May 03, 2018 8:58:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:58:19.425Z: Stopping worker pool...
    May 03, 2018 8:59:51 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:59:49.719Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 8:59:51 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T20:59:49.752Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 8:59:58 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_13_56_24-11412966935738282797 finished with status DONE.
    May 03, 2018 8:59:58 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_13_56_24-11412966935738282797. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 8:59:58 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 8:59:58 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 8:59:59 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 8:59:59 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 8:59:59 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 8:59:59 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 8:59:59 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 03, 2018 9:00:00 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 9:00:00 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 9:00:00 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 9:00:00 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 03, 2018 9:00:00 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 9:00:00 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 129 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.008 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.014 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 18 mins 13.515 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 57m 15s
545 actionable tasks: 542 executed, 3 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #270

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

Changes:

[mairbek] Templatize host name in SpannerIO

------------------------------------------
[...truncated 18.41 MB...]
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.400Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.428Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.466Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.510Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.556Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.602Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.649Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.695Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.740Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.788Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.835Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.867Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.912Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:34.960Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.004Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.041Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.079Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.125Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.162Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.205Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.256Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.301Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.345Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.385Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.431Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.905Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:35.951Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:36.000Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:36.000Z: Starting 1 workers in us-central1-c...
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:36.043Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:36.089Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 7:35:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:36.392Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 7:35:46 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:45.692Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 7:35:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:56.310Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 7:35:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:35:56.354Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 7:36:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:36:20.076Z: Workers have started successfully.
    May 03, 2018 7:36:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:36:52.531Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 7:36:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:36:52.605Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 7:37:08 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:05.615Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 7:37:08 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:05.782Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 7:37:17 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:15.594Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 7:37:17 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:15.779Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 7:37:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:18.723Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 7:37:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:18.829Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 7:37:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:21.978Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 7:37:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:22.084Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 7:37:26 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:24.868Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 7:37:26 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:24.960Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 7:37:34 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:33.575Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 7:37:34 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:33.766Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 7:37:34 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:34.741Z: Cleaning up.
    May 03, 2018 7:37:37 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:37:35.068Z: Stopping worker pool...
    May 03, 2018 7:39:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:39:13.178Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 7:39:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T19:39:13.223Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 7:39:21 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_12_35_24-6433896427272042969 finished with status DONE.
    May 03, 2018 7:39:21 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_12_35_24-6433896427272042969. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 7:39:22 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 7:39:22 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 7:39:23 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 7:39:23 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 7:39:23 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 7:39:23 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 7:39:24 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525247019000000
    May 03, 2018 7:39:24 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 7:39:24 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 7:39:24 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 7:39:25 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525247019000000
    May 03, 2018 7:39:25 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 7:39:25 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 130 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 16 mins 23.832 secs.

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-sdks-java-maven-archetypes-examples:generateAndBuildArchetypeTest'.
> Process 'command '/home/jenkins/tools/maven/apache-maven-3.5.2/bin/mvn'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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-sdks-java-maven-archetypes-starter:generateAndBuildArchetypeTest'.
> Process 'command '/home/jenkins/tools/maven/apache-maven-3.5.2/bin/mvn'' finished with non-zero exit value 1

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

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 54m 30s
545 actionable tasks: 541 executed, 4 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #269

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/269/display/redirect>

------------------------------------------
[...truncated 18.02 MB...]
    May 03, 2018 6:35:33 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 03, 2018 6:35:33 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 03, 2018 6:35:33 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 03, 2018 6:35:33 PM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit6409348636958124581/junit2342581293048061808.tmp matched 1 files with total size 54
    May 03, 2018 6:35:33 PM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit6409348636958124581/junit2342581293048061808.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 03, 2018 6:35:34 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 03, 2018 6:35:35 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo4341223240733571356.sh 
    May 03, 2018 6:35:35 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 03, 2018 6:35:35 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo4341223240733571356.sh to /tmp/test-Echoo5831730217039580461/test-Echo4341223240733571356.sh 
    May 03, 2018 6:35:35 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain2220651213357172878.sh 
    May 03, 2018 6:35:35 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 03, 2018 6:35:35 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain2220651213357172878.sh to /tmp/test-Echoo5831730217039580461/test-EchoAgain2220651213357172878.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 03, 2018 6:35:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 03, 2018 6:35:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 03, 2018 6:35:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 03, 2018 6:35:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 03, 2018 6:35:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 03, 2018 6:35:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 03, 2018 6:35:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 03, 2018 6:35:36 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 03, 2018 6:35:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 03, 2018 6:35:36 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 03, 2018 6:35:37 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 03, 2018 6:35:37 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 131 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.002 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 9,5,main]) completed. Took 10.641 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 9,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 9,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 9,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 9,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 15,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 15,5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 2 failures.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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:googleCloudPlatformIntegrationTest'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 34m 53s
540 actionable tasks: 535 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #268

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/268/display/redirect>

------------------------------------------
[...truncated 18.45 MB...]
    INFO: 2018-05-03T12:50:02.334Z: Unzipping flatten s18-u63 for input s19.output-c61
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.369Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.403Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.442Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.476Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.507Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.545Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.580Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.616Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.640Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.675Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.705Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.740Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.775Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.804Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.839Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.875Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.903Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.926Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.958Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:02.988Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.018Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.053Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.088Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.123Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.159Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.183Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.215Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.244Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.273Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.300Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.330Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.370Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.401Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.433Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.467Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.497Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.887Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.924Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.958Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.968Z: Starting 1 workers in us-central1-f...
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:03.995Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:04.025Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 12:50:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:04.263Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 12:50:11 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:10.762Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 12:50:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:21.133Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 12:50:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:21.163Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 12:50:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:50:39.242Z: Workers have started successfully.
    May 03, 2018 12:51:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:09.395Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 12:51:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:09.474Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 12:51:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:19.118Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 12:51:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:19.198Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 12:51:29 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:27.678Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 12:51:29 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:27.860Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 12:51:31 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:29.680Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 12:51:31 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:29.752Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 12:51:34 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:33.480Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 12:51:34 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:33.545Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 12:51:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:35.191Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 12:51:35 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:35.272Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 12:51:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:42.239Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 12:51:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:42.420Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 12:51:46 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:45.254Z: Cleaning up.
    May 03, 2018 12:51:46 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:51:45.650Z: Stopping worker pool...
    May 03, 2018 12:53:00 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:52:58.509Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 12:53:00 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T12:52:58.533Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 12:53:08 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_05_49_54-17882948021705097795 finished with status DONE.
    May 03, 2018 12:53:09 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_05_49_54-17882948021705097795. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 12:53:09 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 12:53:09 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 12:53:10 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 12:53:10 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 12:53:10 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 12:53:10 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 12:53:11 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525074215000000
    May 03, 2018 12:53:11 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 12:53:11 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 12:53:11 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 12:53:12 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525074215000000
    May 03, 2018 12:53:12 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 12:53:12 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.006 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 14 mins 49.186 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 52m 24s
545 actionable tasks: 537 executed, 8 from cache

Publishing build scan...
https://gradle.com/s/66r4y7dkegzxc

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #267

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

Changes:

[echauchot] [BEAM-4138] Support runners that do not support committed metrics in

------------------------------------------
[...truncated 18.11 MB...]
    INFO: 2018-05-03T08:35:44.235Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.249Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.281Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.310Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.337Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.371Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.404Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.429Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.455Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.486Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.512Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.543Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.570Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.601Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.614Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.638Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.663Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.698Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.722Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.751Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.784Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.834Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.858Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.885Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.917Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.945Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:44.980Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.011Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.040Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.066Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.092Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.116Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.149Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.175Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.497Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.528Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.557Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.568Z: Starting 1 workers in us-central1-f...
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.589Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 8:35:46 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:45.614Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 8:35:53 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:53.172Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 8:35:53 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:53.416Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 8:36:00 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:35:58.656Z: Autoscaling: Resizing worker pool from 1 to 5.
    May 03, 2018 8:36:06 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:36:04.670Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 8:36:06 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:36:04.705Z: Resized worker pool to 1, though goal was 5.  This could be a quota issue.
    May 03, 2018 8:36:15 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:36:15.009Z: Autoscaling: Raised the number of workers to 5 based on the rate of progress in the currently running step(s).
    May 03, 2018 8:36:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:36:30.243Z: Workers have started successfully.
    May 03, 2018 8:37:03 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:01.154Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 8:37:03 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:01.224Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 8:37:10 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:10.708Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 8:37:12 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:10.761Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 8:37:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:21.556Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 8:37:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:21.688Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 8:37:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:24.445Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 8:37:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:24.503Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 8:37:27 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:26.408Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 8:37:27 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:26.463Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 8:37:28 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:28.099Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 8:37:28 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:28.169Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 8:37:33 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:32.381Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 8:37:33 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:32.540Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 8:37:36 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:33.715Z: Cleaning up.
    May 03, 2018 8:37:36 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:37:34.043Z: Stopping worker pool...
    May 03, 2018 8:39:24 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:39:23.140Z: Autoscaling: Resized worker pool from 5 to 0.
    May 03, 2018 8:39:24 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:39:23.172Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 8:39:24 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T08:39:23.205Z: Worker pool stopped.
    May 03, 2018 8:39:33 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-03_01_35_35-12778377950292178163 finished with status DONE.
    May 03, 2018 8:39:33 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-03_01_35_35-12778377950292178163. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 8:39:33 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 8:39:34 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 8:39:34 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 8:39:35 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 8:39:35 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 8:39:35 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 8:39:35 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525074215000000
    May 03, 2018 8:39:35 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 8:39:35 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 8:39:36 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 8:39:36 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525074215000000
    May 03, 2018 8:39:36 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 8:39:36 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 130 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.006 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.008 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 15 mins 42.878 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 53m 16s
545 actionable tasks: 540 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #266

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/266/display/redirect>

------------------------------------------
[...truncated 18.72 MB...]

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 03, 2018 6:47:02 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:00.248Z: Cleaning up.
    May 03, 2018 6:47:02 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:00.358Z: Stopping worker pool...

org.apache.beam.sdk.io.gcp.datastore.V1ReadIT > testE2EV1ReadWithGQLQueryWithNoLimit STANDARD_ERROR
    May 03, 2018 6:47:05 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:05.290Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 6:47:06 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:05.311Z: Resized worker pool to 1, though goal was 5.  This could be a quota issue.
    May 03, 2018 6:47:16 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:15.599Z: Autoscaling: Raised the number of workers to 5 based on the rate of progress in the currently running step(s).
    May 03, 2018 6:47:30 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:30.239Z: Workers have started successfully.
    May 03, 2018 6:47:50 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:49.656Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 6:47:50 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:49.718Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 6:47:59 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:58.636Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 6:47:59 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:47:58.708Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 6:48:06 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:05.728Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 6:48:06 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:05.851Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 6:48:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:08.279Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 6:48:08 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:08.345Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 6:48:11 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:09.943Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 6:48:11 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:09.994Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 6:48:11 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:11.475Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 6:48:14 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:11.539Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 6:48:18 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:15.952Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 6:48:18 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:16.122Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 6:48:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:18.103Z: Cleaning up.
    May 03, 2018 6:48:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:18.313Z: Stopping worker pool...

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 03, 2018 6:48:47 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:46.874Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 6:48:47 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:48:46.913Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 6:48:56 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_23_45_55-9386743335383481535 finished with status DONE.
    May 03, 2018 6:48:56 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_23_45_55-9386743335383481535. Found 0 success, 0 failures out of 0 expected assertions.
    May 03, 2018 6:48:57 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 6:48:57 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 6:48:58 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 6:48:58 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 6:48:58 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

Gradle Test Executor 129 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testQuery FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testRead FAILED
    java.lang.NoClassDefFoundError: Could not initialize class com.google.cloud.spanner.SpannerImpl
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testReadAllRecordsInDb FAILED
    java.lang.NoClassDefFoundError: Could not initialize class com.google.cloud.spanner.SpannerImpl
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

org.apache.beam.sdk.io.gcp.datastore.V1ReadIT > testE2EV1ReadWithGQLQueryWithNoLimit STANDARD_ERROR
    May 03, 2018 6:49:50 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:49:49.094Z: Autoscaling: Resized worker pool from 5 to 0.
    May 03, 2018 6:49:50 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:49:49.120Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 6:49:50 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T06:49:49.156Z: Worker pool stopped.
    May 03, 2018 6:49:57 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_23_46_36-4093343978809629662 finished with status DONE.
    May 03, 2018 6:49:57 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_23_46_36-4093343978809629662. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 6:49:58 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 6:49:58 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 6:49:59 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 6:49:59 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 6:49:59 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 6:49:59 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 6:49:59 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525074215000000
    May 03, 2018 6:49:59 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 6:49:59 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 6:50:00 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 6:50:00 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525074215000000
    May 03, 2018 6:50:00 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 6:50:00 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 121 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 16 mins 8.751 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 48m 47s
545 actionable tasks: 537 executed, 8 from cache

Publishing build scan...
https://gradle.com/s/5b3xv5o6blssi

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user mairbek@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #265

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

Changes:

[tgroh] Add KV and Window Coder Utilities to ModelCoders

[tgroh] Use ModelCoders in ProcessBundleDescriptors

------------------------------------------
[...truncated 18.84 MB...]
    INFO: 2018-05-03T02:50:14.344Z: Unzipping flatten s18-u63 for input s19.output-c61
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.375Z: Fusing unzipped copy of PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous), through flatten s18-u63, into producer PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.413Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.444Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.482Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.521Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.550Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.587Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.624Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.651Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.684Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.712Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.763Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.805Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.838Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.875Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.910Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.950Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:14.987Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.032Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.068Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.101Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.133Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.177Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.211Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.252Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.288Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.329Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.369Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.413Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.447Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.492Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.532Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.573Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.616Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.654Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:15.687Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:16.102Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:16.142Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:16.185Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:16.193Z: Starting 1 workers in us-central1-f...
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:16.221Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:16.271Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 2:50:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:16.586Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 2:50:27 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:24.955Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 2:50:36 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:35.333Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 2:50:36 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:35.362Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 2:50:52 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:50:51.910Z: Workers have started successfully.
    May 03, 2018 2:51:28 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:28.445Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 2:51:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:28.527Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 2:51:39 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:38.696Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 2:51:39 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:38.784Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 2:51:49 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:48.730Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 2:51:49 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:48.927Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 2:51:53 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:51.740Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 2:51:53 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:51.852Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 2:51:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:57.820Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 2:52:00 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:51:57.913Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 2:52:03 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:52:01.617Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 2:52:03 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:52:01.696Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 2:52:07 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:52:06.859Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 2:52:07 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:52:07.030Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 2:52:11 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:52:09.917Z: Cleaning up.
    May 03, 2018 2:52:11 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:52:10.027Z: Stopping worker pool...
    May 03, 2018 2:53:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:53:30.917Z: Autoscaling: Resized worker pool from 1 to 0.
    May 03, 2018 2:53:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:53:30.971Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 2:53:39 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_19_50_03-2861017550352735069 finished with status DONE.
    May 03, 2018 2:53:39 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_19_50_03-2861017550352735069. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 2:53:40 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 2:53:41 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 2:53:41 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 2:53:42 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 2:53:42 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 2:53:42 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 2:53:42 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525074215000000
    May 03, 2018 2:53:42 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 2:53:42 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 2:53:43 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 2:53:43 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525074215000000
    May 03, 2018 2:53:43 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 2:53:43 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.009 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 14 mins 45.866 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 55m 58s
545 actionable tasks: 543 executed, 2 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user mairbek@google.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #264

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

Changes:

[sidhom] Remove StateRequestHandler from JobBundleFactory

------------------------------------------
[...truncated 19.17 MB...]
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.634Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.663Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.696Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.728Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.765Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.797Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.829Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.855Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.876Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.911Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.945Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:55.982Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.017Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.051Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.085Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.115Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.150Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.184Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.216Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.253Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.286Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.314Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.353Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.381Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.419Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.452Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.835Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.870Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.903Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.913Z: Starting 1 workers in us-central1-b...
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.931Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 03, 2018 2:38:57 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:38:56.971Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 03, 2018 2:39:05 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:39:04.810Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 03, 2018 2:39:05 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:39:05.178Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 03, 2018 2:39:13 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:39:10.497Z: Autoscaling: Resizing worker pool from 1 to 5.
    May 03, 2018 2:39:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:39:16.752Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 03, 2018 2:39:19 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:39:16.780Z: Resized worker pool to 1, though goal was 5.  This could be a quota issue.
    May 03, 2018 2:39:28 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:39:27.222Z: Autoscaling: Raised the number of workers to 4 based on the rate of progress in the currently running step(s).
    May 03, 2018 2:39:28 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:39:27.255Z: Resized worker pool to 4, though goal was 5.  This could be a quota issue.
    May 03, 2018 2:39:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:39:32.508Z: Autoscaling: Raised the number of workers to 5 based on the rate of progress in the currently running step(s).
    May 03, 2018 2:39:45 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:39:45.208Z: Workers have started successfully.
    May 03, 2018 2:40:14 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:13.494Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 03, 2018 2:40:14 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:13.552Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 03, 2018 2:40:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:22.256Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 03, 2018 2:40:23 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:22.306Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 03, 2018 2:40:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:33.516Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 03, 2018 2:40:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:33.670Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 03, 2018 2:40:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:35.117Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 03, 2018 2:40:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:35.179Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 03, 2018 2:40:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:37.365Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 03, 2018 2:40:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:37.427Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 03, 2018 2:40:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:38.032Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 03, 2018 2:40:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:38.114Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 03, 2018 2:40:42 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:41.783Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 03, 2018 2:40:42 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:41.940Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 03, 2018 2:40:44 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:44.188Z: Cleaning up.
    May 03, 2018 2:40:44 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:40:44.577Z: Stopping worker pool...
    May 03, 2018 2:42:33 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:42:31.886Z: Autoscaling: Resized worker pool from 5 to 0.
    May 03, 2018 2:42:33 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-03T02:42:31.917Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 03, 2018 2:42:42 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_19_38_47-2280171109099942268 finished with status DONE.
    May 03, 2018 2:42:42 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_19_38_47-2280171109099942268. Found 1 success, 0 failures out of 1 expected assertions.
    May 03, 2018 2:42:42 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 2:42:43 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 2:42:43 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 03, 2018 2:42:44 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 03, 2018 2:42:44 AM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 03, 2018 2:42:44 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 2:42:44 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525074215000000
    May 03, 2018 2:42:44 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 03, 2018 2:42:44 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 03, 2018 2:42:45 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 03, 2018 2:42:45 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525074215000000
    May 03, 2018 2:42:45 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 03, 2018 2:42:45 AM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 124 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 15 mins 15.558 secs.

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-sdks-java-extensions-sql:compileJava'.
> Compilation failed with exit code 1; see the compiler error output for details.

* Try:
Run with --stacktrace option to get the stack trace. Run with --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:googleCloudPlatformIntegrationTest'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 49m 56s
517 actionable tasks: 509 executed, 8 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user mairbek@google.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #263

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/263/display/redirect>

------------------------------------------
[...truncated 18.83 MB...]
    May 03, 2018 12:52:16 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 03, 2018 12:52:16 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 03, 2018 12:52:16 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 03, 2018 12:52:17 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 03, 2018 12:52:17 AM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit8703048259214916703/junit6687294031692171187.tmp matched 1 files with total size 54
    May 03, 2018 12:52:17 AM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit8703048259214916703/junit6687294031692171187.tmp into bundles of size 3 took 1 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 03, 2018 12:52:17 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 03, 2018 12:52:19 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo1409110507523819686.sh 
    May 03, 2018 12:52:19 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 03, 2018 12:52:19 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo1409110507523819686.sh to /tmp/test-Echoo4606077102089523250/test-Echo1409110507523819686.sh 
    May 03, 2018 12:52:19 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain2873987014956674910.sh 
    May 03, 2018 12:52:19 AM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 03, 2018 12:52:19 AM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain2873987014956674910.sh to /tmp/test-Echoo4606077102089523250/test-EchoAgain2873987014956674910.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 03, 2018 12:52:20 AM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 03, 2018 12:52:20 AM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 132 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.002 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Daemon worker,5,main]) completed. Took 11.036 secs.
:beam-examples-java:check (Thread[Daemon worker,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Daemon worker,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Daemon worker,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Daemon worker,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 2 failures.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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:googleCloudPlatformIntegrationTest'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 40m 5s
540 actionable tasks: 535 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user mairbek@google.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #262

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

Changes:

[mairbek] Wait for input collection

[mairbek] Expose DatabaseAdminClient

[mairbek] Consistently use lower case table name and column names

[mairbek] Addressed comments

------------------------------------------
[...truncated 18.92 MB...]
    INFO: 2018-05-02T21:57:38.514Z: Fusing consumer PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous) into PAssert$3/CreateActual/FilterActuals/Window.Assign
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.535Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.550Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.563Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.580Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.593Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.616Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.630Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.651Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.667Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.689Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.713Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.743Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.796Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.818Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.842Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.866Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.890Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.913Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.937Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.959Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:38.984Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.002Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.025Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.047Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.071Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.093Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.107Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.131Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.148Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.165Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.181Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.198Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.217Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.231Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.504Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.527Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.551Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.559Z: Starting 1 workers in us-central1-f...
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.574Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 02, 2018 9:57:42 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:39.598Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 02, 2018 9:57:48 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:46.712Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 02, 2018 9:57:48 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:47.057Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 02, 2018 9:57:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:52.380Z: Autoscaling: Resizing worker pool from 1 to 5.
    May 02, 2018 9:57:58 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:58.413Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 02, 2018 9:57:58 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:57:58.438Z: Resized worker pool to 1, though goal was 5.  This could be a quota issue.
    May 02, 2018 9:58:09 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:58:08.778Z: Autoscaling: Raised the number of workers to 5 based on the rate of progress in the currently running step(s).
    May 02, 2018 9:58:26 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:58:24.860Z: Workers have started successfully.
    May 02, 2018 9:58:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:58:53.019Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 02, 2018 9:58:54 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:58:53.078Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 02, 2018 9:59:03 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:02.077Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 02, 2018 9:59:03 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:02.128Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 02, 2018 9:59:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:08.476Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 02, 2018 9:59:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:08.589Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 02, 2018 9:59:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:11.816Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 02, 2018 9:59:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:11.860Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 02, 2018 9:59:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:13.722Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 02, 2018 9:59:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:13.771Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 02, 2018 9:59:17 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:15.311Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 02, 2018 9:59:17 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:15.361Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 02, 2018 9:59:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:19.565Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 02, 2018 9:59:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:19.730Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 02, 2018 9:59:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:21.928Z: Cleaning up.
    May 02, 2018 9:59:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T21:59:22.477Z: Stopping worker pool...
    May 02, 2018 10:01:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T22:01:19.472Z: Autoscaling: Resized worker pool from 5 to 0.
    May 02, 2018 10:01:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T22:01:19.492Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 02, 2018 10:01:29 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_14_57_31-12777708045916078769 finished with status DONE.
    May 02, 2018 10:01:29 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_14_57_31-12777708045916078769. Found 1 success, 0 failures out of 1 expected assertions.
    May 02, 2018 10:01:35 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 10:01:35 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 10:01:36 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 10:01:36 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 10:01:36 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 02, 2018 10:01:36 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 02, 2018 10:01:37 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525074215000000
    May 02, 2018 10:01:37 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 02, 2018 10:01:37 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 02, 2018 10:01:37 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 02, 2018 10:01:38 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525074215000000
    May 02, 2018 10:01:38 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 02, 2018 10:01:38 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 16 mins 34.806 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 53m 48s
545 actionable tasks: 540 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com
Not sending mail to unregistered user mairbek@google.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #261

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

Changes:

[axelmagn] Create ArtifactSource Interface

[axelmagn] Create RemoteBundle interface

[axelmagn] Create JobInfo for job declaration by operators.

[axelmagn] Create BundleFactory chain.

------------------------------------------
[...truncated 18.87 MB...]
    INFO: Uploading /home/jenkins/.m2/repository/org/json/json/20160810/json-20160810.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/json-20160810-L3-Jnwdm5lAXdEpMT8FNRg.jar
    May 02, 2018 8:10:02 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/commons-logging/commons-logging/1.2/commons-logging-1.2.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/commons-logging-1.2-BAtLTY6siG9rSio70vMbAA.jar
    May 02, 2018 8:10:02 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/io/netty/netty-codec-http/4.1.8.Final/netty-codec-http-4.1.8.Final.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/netty-codec-http-4.1.8.Final-uBsfxiZeL3IeVQNS0QTHUw.jar
    May 02, 2018 8:10:02 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/org/threeten/threetenbp/1.3.3/threetenbp-1.3.3.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/threetenbp-1.3.3-bEXFSgaAYiXSdUtR-98IjQ.jar
    May 02, 2018 8:10:02 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/org/mockito/mockito-core/1.9.5/mockito-core-1.9.5.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/mockito-core-1.9.5-b3PPBKVutgqqmWUG58EPxw.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/org/objenesis/objenesis/2.6/objenesis-2.6.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/objenesis-2.6-X_rD9RQFypspFZcKIks-jw.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/commons-codec/commons-codec/1.3/commons-codec-1.3.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/commons-codec-1.3-jhScEFN0HANzalLfg5dNzA.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/io/netty/netty-buffer/4.1.8.Final/netty-buffer-4.1.8.Final.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/netty-buffer-4.1.8.Final-iwny8IFMu0G1ln10Yx5VrA.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/io/netty/netty-transport/4.1.8.Final/netty-transport-4.1.8.Final.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/netty-transport-4.1.8.Final-PXWj5ZmqlznhCnqhkcOwDA.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/io/netty/netty-codec/4.1.8.Final/netty-codec-4.1.8.Final.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/netty-codec-4.1.8.Final-Og5DJ4MB-fn1oSzjKqVU_w.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.gradle/caches/modules-2/files-2.1/com.esotericsoftware.kryo/kryo/2.21/9a4e69cff8d225729656f7e97e40893b23bffef/kryo-2.21.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/kryo-2.21-olkSUBNMYGe-WXkdlwcytQ.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/org/xerial/snappy/snappy-java/1.1.4/snappy-java-1.1.4.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/snappy-java-1.1.4-SFNwbMuGq13aaoKVzeS1Tw.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/io/netty/netty-resolver/4.1.8.Final/netty-resolver-4.1.8.Final.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/netty-resolver-4.1.8.Final-ZBELwscrxRZgRR5DKH9siA.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/org/apache/httpcomponents/httpcore/4.0.1/httpcore-4.0.1.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/httpcore-4.0.1-bBlj_YrAxAwATJ6JLg13Aw.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/com/squareup/okio/okio/1.6.0/okio-1.6.0.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/okio-1.6.0-Fk0cKMMjz24qkX1gN0xXGA.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/com/google/protobuf/nano/protobuf-javanano/3.0.0-alpha-5/protobuf-javanano-3.0.0-alpha-5.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/protobuf-javanano-3.0.0-alpha-5-SsS7fZe7brffHbAGUgRrnw.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/com/google/code/gson/gson/2.7/gson-2.7.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/gson-2.7-UTSiNQ9YiQ_7nbC0AEcZXQ.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/com/squareup/okhttp/okhttp/2.5.0/okhttp-2.5.0.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/okhttp-2.5.0-64v0X4G_nxfR_PsuymOqpg.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.gradle/caches/modules-2/files-2.1/com.esotericsoftware.reflectasm/reflectasm/1.07/76f11c94a53ee975a0d9154b325c408b210155bd/reflectasm-1.07-shaded.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/reflectasm-1.07-shaded-IELCIoQPsh49E873w5ZYMQ.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.gradle/caches/modules-2/files-2.1/com.esotericsoftware.minlog/minlog/1.2/59bfcd171d82f9981a5e242b9e840191f650e209/minlog-1.2.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/minlog-1.2-98-99jtn3wu_pMfLJgiFvA.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/com/google/guava/guava/20.0/guava-20.0.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/guava-20.0-8yqKJSRiDb7Mn2v2ogwpPw.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.gradle/caches/modules-2/files-2.1/org.ow2.asm/asm/4.0/659add6efc75a4715d738e73f07505246edf4d66/asm-4.0.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/asm-4.0-Mi2PiMURGvYS34OMAZHNfg.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/io/netty/netty-common/4.1.8.Final/netty-common-4.1.8.Final.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/netty-common-4.1.8.Final-lafOW8vGsI6SRwZSmXNClg.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.gradle/caches/modules-2/files-2.1/org.yaml/snakeyaml/1.17/7a27ea250c5130b2922b86dea63cbb1cc10a660c/snakeyaml-1.17.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/snakeyaml-1.17-q2IcPO4xYjatBKbw_k3RfA.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.gradle/caches/modules-2/files-2.1/com.fasterxml.jackson.dataformat/jackson-dataformat-yaml/2.8.9/607f3253c20267e385c85f60c859760a73a29e37/jackson-dataformat-yaml-2.8.9.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/jackson-dataformat-yaml-2.8.9-Ihvaydyl6xlTJI7nXOBqRQ.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/com/google/auto/value/auto-value/1.4/auto-value-1.4.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/auto-value-1.4-_7tYdqNvCowycFIDpBenFw.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/sdks/java/io/google-cloud-platform/build/libs/beam-sdks-java-io-google-cloud-platform-2.5.0-SNAPSHOT-shaded-tests.jar> to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/beam-sdks-java-io-google-cloud-platform-2.5.0-SNAPSHOT-shaded-tests-sGYfTa2W8FyXkefCFJeBKQ.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading /home/jenkins/.m2/repository/io/netty/netty-tcnative-boringssl-static/1.1.33.Fork26/netty-tcnative-boringssl-static-1.1.33.Fork26.jar to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/netty-tcnative-boringssl-static-1.1.33.Fork26-29XB0C44MyezMyoCB5cCbw.jar
    May 02, 2018 8:10:03 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/sdks/java/io/google-cloud-platform/build/libs/beam-sdks-java-io-google-cloud-platform-2.5.0-SNAPSHOT-shaded.jar> to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/beam-sdks-java-io-google-cloud-platform-2.5.0-SNAPSHOT-shaded-DPm7N_WS0oFwy3XpxfCywQ.jar
    May 02, 2018 8:10:08 PM org.apache.beam.runners.dataflow.util.PackageUtil stageClasspathElements
    INFO: Staging files complete: 0 files cached, 128 files newly uploaded
    May 02, 2018 8:10:08 PM org.apache.beam.runners.dataflow.DataflowPipelineTranslator$Translator addStep
    INFO: Adding GenerateSequence/Read(BoundedCountingSource) as step s1
    May 02, 2018 8:10:08 PM org.apache.beam.runners.dataflow.DataflowPipelineTranslator$Translator addStep
    INFO: Adding ParDo(CreateEntity) as step s2
    May 02, 2018 8:10:08 PM org.apache.beam.runners.dataflow.DataflowPipelineTranslator$Translator addStep
    INFO: Adding DatastoreV1.Write/Convert to Mutation/Map as step s3
    May 02, 2018 8:10:08 PM org.apache.beam.runners.dataflow.DataflowPipelineTranslator$Translator addStep
    INFO: Adding DatastoreV1.Write/Write Mutation to Datastore as step s4
    May 02, 2018 8:10:08 PM org.apache.beam.runners.dataflow.DataflowRunner run
    INFO: Staging pipeline description to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/
    May 02, 2018 8:10:08 PM org.apache.beam.runners.dataflow.util.PackageUtil tryStagePackage
    INFO: Uploading <8774 bytes, hash mXdshZPrDXIlzrVHHUNk4g> to gs://temp-storage-for-end-to-end-tests/testpipeline-jenkins-0502201001-230dbe61/output/results/staging/pipeline-mXdshZPrDXIlzrVHHUNk4g.pb

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_OUT
    Dataflow SDK version: 2.5.0-SNAPSHOT

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 02, 2018 8:10:10 PM org.apache.beam.runners.dataflow.DataflowRunner run
    INFO: To access the Dataflow monitoring console, please navigate to https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2018-05-02_13_10_09-2125814904411264031?project=apache-beam-testing

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_OUT
    Submitted job: 2018-05-02_13_10_09-2125814904411264031

org.apache.beam.sdk.io.gcp.datastore.V1WriteIT > testE2EV1Write STANDARD_ERROR
    May 02, 2018 8:10:10 PM org.apache.beam.runners.dataflow.DataflowRunner run
    INFO: To cancel the job using the 'gcloud' tool, run:
    > gcloud dataflow jobs --project=apache-beam-testing cancel --region=us-central1 2018-05-02_13_10_09-2125814904411264031
    May 02, 2018 8:10:10 PM org.apache.beam.runners.dataflow.TestDataflowRunner run
    INFO: Running Dataflow job 2018-05-02_13_10_09-2125814904411264031 with 0 expected assertions.
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:09.112Z: Autoscaling is enabled for job 2018-05-02_13_10_09-2125814904411264031. The number of workers will be between 1 and 1000.
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:09.132Z: Autoscaling was automatically enabled for job 2018-05-02_13_10_09-2125814904411264031.
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:11.773Z: Checking required Cloud APIs are enabled.
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:11.954Z: Checking permissions granted to controller Service Account.
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:16.524Z: Worker configuration: n1-standard-1 in us-central1-c.
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:16.910Z: Expanding CoGroupByKey operations into optimizable parts.
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:16.944Z: Expanding GroupByKey operations into optimizable parts.
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:16.973Z: Lifting ValueCombiningMappingFns into MergeBucketsMappingFns
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:17.046Z: Fusing adjacent ParDo, Read, Write, and Flatten operations
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:17.063Z: Fusing consumer ParDo(CreateEntity) into GenerateSequence/Read(BoundedCountingSource)
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:17.090Z: Fusing consumer DatastoreV1.Write/Write Mutation to Datastore into DatastoreV1.Write/Convert to Mutation/Map
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:17.122Z: Fusing consumer DatastoreV1.Write/Convert to Mutation/Map into ParDo(CreateEntity)
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:17.431Z: Executing operation GenerateSequence/Read(BoundedCountingSource)+ParDo(CreateEntity)+DatastoreV1.Write/Convert to Mutation/Map+DatastoreV1.Write/Write Mutation to Datastore
    May 02, 2018 8:10:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:17.503Z: Starting 1 workers in us-central1-c...
    May 02, 2018 8:10:27 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:26.941Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 02, 2018 8:10:38 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:10:37.511Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 02, 2018 8:11:04 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:11:04.361Z: Workers have started successfully.
    May 02, 2018 8:11:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:11:35.728Z: Cleaning up.
    May 02, 2018 8:11:36 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:11:35.847Z: Stopping worker pool...
    May 02, 2018 8:13:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:13:15.195Z: Autoscaling: Resized worker pool from 1 to 0.
    May 02, 2018 8:13:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:13:15.222Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 02, 2018 8:13:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T20:13:15.267Z: Worker pool stopped.
    May 02, 2018 8:13:25 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_13_10_09-2125814904411264031 finished with status DONE.
    May 02, 2018 8:13:25 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_13_10_09-2125814904411264031. Found 0 success, 0 failures out of 0 expected assertions.
    May 02, 2018 8:13:26 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 8:13:27 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 8:13:28 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 8:13:28 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 8:13:28 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testQuery FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testRead FAILED
    java.lang.NoClassDefFoundError: Could not initialize class com.google.cloud.spanner.SpannerImpl
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

Gradle Test Executor 122 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT > testReadAllRecordsInDb FAILED
    java.lang.NoClassDefFoundError: Could not initialize class com.google.cloud.spanner.SpannerImpl
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.setUp(SpannerReadIT.java:93)

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerReadIT.tearDown(SpannerReadIT.java:217)

13 tests completed, 4 failed
Finished generating test XML results (0.006 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.008 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 27 mins 56.96 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 0m 42s
545 actionable tasks: 540 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user axelmagn@gmail.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #260

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

Changes:

[tgroh] Remove unused Test Utilities, Test

------------------------------------------
[...truncated 18.83 MB...]
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:52.781Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:52.812Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:52.847Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:52.880Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:52.914Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:52.949Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:52.971Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:52.991Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.008Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.035Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.059Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.084Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.116Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.149Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.180Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.209Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.234Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.267Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.289Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.314Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.344Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.366Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.391Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.406Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.774Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.803Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.819Z: Starting 1 workers in us-central1-c...
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.819Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.856Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 02, 2018 7:05:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:05:53.891Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 02, 2018 7:06:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:06:03.416Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 02, 2018 7:06:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:06:03.802Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 02, 2018 7:06:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:06:09.305Z: Autoscaling: Resizing worker pool from 1 to 5.
    May 02, 2018 7:06:39 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:06:37.448Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 02, 2018 7:06:39 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:06:37.478Z: Resized worker pool to 1, though goal was 5.  This could be a quota issue.
    May 02, 2018 7:07:09 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:07:09.089Z: Autoscaling: Raised the number of workers to 5 based on the rate of progress in the currently running step(s).
    May 02, 2018 7:07:13 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:07:12.590Z: Workers have started successfully.
    May 02, 2018 7:07:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:07:30.689Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 02, 2018 7:07:32 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:07:30.737Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 02, 2018 7:07:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:07:40.164Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 02, 2018 7:07:41 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:07:40.220Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 02, 2018 7:07:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:07:55.133Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 02, 2018 7:07:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:07:55.268Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 02, 2018 7:08:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:03.524Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 02, 2018 7:08:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:03.580Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 02, 2018 7:08:11 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:11.212Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 02, 2018 7:08:11 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:11.269Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 02, 2018 7:08:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:13.129Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 02, 2018 7:08:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:13.190Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 02, 2018 7:08:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:17.367Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 02, 2018 7:08:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:17.462Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 02, 2018 7:08:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:18.269Z: Cleaning up.
    May 02, 2018 7:08:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:08:18.799Z: Stopping worker pool...
    May 02, 2018 7:09:57 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:09:56.102Z: Autoscaling: Resized worker pool from 5 to 0.
    May 02, 2018 7:09:57 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T19:09:56.117Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 02, 2018 7:10:06 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_12_05_44-14871495689365246619 finished with status DONE.
    May 02, 2018 7:10:06 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_12_05_44-14871495689365246619. Found 1 success, 0 failures out of 1 expected assertions.
    May 02, 2018 7:10:07 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 7:10:07 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 7:10:08 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 7:10:08 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 7:10:08 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 02, 2018 7:10:08 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 02, 2018 7:10:09 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525074215000000
    May 02, 2018 7:10:09 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 02, 2018 7:10:09 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 02, 2018 7:10:09 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 02, 2018 7:10:09 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525074215000000
    May 02, 2018 7:10:09 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 02, 2018 7:10:09 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 129 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.007 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[main,5,main]) completed. Took 17 mins 56.871 secs.

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-sdks-java-maven-archetypes-examples:generateAndBuildArchetypeTest'.
> Process 'command '/home/jenkins/tools/maven/apache-maven-3.5.2/bin/mvn'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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-sdks-java-maven-archetypes-starter:generateAndBuildArchetypeTest'.
> Process 'command '/home/jenkins/tools/maven/apache-maven-3.5.2/bin/mvn'' finished with non-zero exit value 1

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

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 55m 49s
545 actionable tasks: 540 executed, 5 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #259

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/259/display/redirect>

------------------------------------------
[...truncated 19.59 MB...]
    May 02, 2018 6:43:55 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.TriggerExampleTest > testExtractTotalFlow STANDARD_ERROR
    May 02, 2018 6:43:57 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testFilterSingleMonthDataFn STANDARD_ERROR
    May 02, 2018 6:43:57 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.FilterExamplesTest > testProjectionFn STANDARD_ERROR
    May 02, 2018 6:43:57 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractCountryInfoFn STANDARD_ERROR
    May 02, 2018 6:43:57 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.cookbook.JoinExamplesTest > testExtractEventDataFn STANDARD_ERROR
    May 02, 2018 6:43:57 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.DebuggingWordCountTest > testDebuggingWordCount STANDARD_ERROR
    May 02, 2018 6:43:57 PM org.apache.beam.sdk.io.FileBasedSource getEstimatedSizeBytes
    INFO: Filepattern /tmp/junit7688379987344560127/junit4509727555484717318.tmp matched 1 files with total size 54
    May 02, 2018 6:43:57 PM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit7688379987344560127/junit4509727555484717318.tmp into bundles of size 3 took 0 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 02, 2018 6:43:58 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 02, 2018 6:43:59 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo218432434358590604.sh 
    May 02, 2018 6:43:59 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 02, 2018 6:43:59 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo218432434358590604.sh to /tmp/test-Echoo6570224116478865471/test-Echo218432434358590604.sh 
    May 02, 2018 6:43:59 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain3779072099562518527.sh 
    May 02, 2018 6:43:59 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 02, 2018 6:43:59 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain3779072099562518527.sh to /tmp/test-Echoo6570224116478865471/test-EchoAgain3779072099562518527.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 02, 2018 6:44:00 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 02, 2018 6:44:00 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 02, 2018 6:44:01 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 02, 2018 6:44:01 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 02, 2018 6:44:01 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 02, 2018 6:44:01 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 02, 2018 6:44:01 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 02, 2018 6:44:01 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 02, 2018 6:44:01 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 02, 2018 6:44:01 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 02, 2018 6:44:01 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923
    May 02, 2018 6:44:01 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923

Gradle Test Executor 132 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.004 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 10.873 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 13,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 13,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 15,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 15,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 2 failures.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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:googleCloudPlatformIntegrationTest'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 43m 19s
540 actionable tasks: 539 executed, 1 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #258

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

Changes:

[github] Fix DynamicDestinations documentation

------------------------------------------
[...truncated 17.90 MB...]
    May 02, 2018 6:02:24 PM org.apache.beam.sdk.io.FileBasedSource split
    INFO: Splitting filepattern /tmp/junit1475608711116988403/junit9128274499579332023.tmp into bundles of size 3 took 0 ms and produced 1 files and 18 bundles

org.apache.beam.examples.WordCountTest > testExtractWordsFn STANDARD_ERROR
    May 02, 2018 6:02:24 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 02, 2018 6:02:25 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo2923726372027294620.sh 
    May 02, 2018 6:02:25 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 02, 2018 6:02:26 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo2923726372027294620.sh to /tmp/test-Echoo5745353248225255550/test-Echo2923726372027294620.sh 
    May 02, 2018 6:02:26 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain9207570007618915658.sh 
    May 02, 2018 6:02:26 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 02, 2018 6:02:26 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain9207570007618915658.sh to /tmp/test-Echoo5745353248225255550/test-EchoAgain9207570007618915658.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 02, 2018 6:02:27 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923
    May 02, 2018 6:02:27 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923

Gradle Test Executor 132 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.004 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 12,5,main]) completed. Took 11.116 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 12,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 12,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 12,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 12,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 12,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 12,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 12,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 12,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':',5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 12,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':',5,main]) completed. Took 0.0 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 12,5,main]) completed. Took 0.0 secs.

FAILURE: Build completed with 4 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-sdks-java-maven-archetypes-starter:generateAndBuildArchetypeTest'.
> Process 'command '/home/jenkins/tools/maven/apache-maven-3.5.2/bin/mvn'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --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-sdks-java-maven-archetypes-examples:generateAndBuildArchetypeTest'.
> Process 'command '/home/jenkins/tools/maven/apache-maven-3.5.2/bin/mvn'' finished with non-zero exit value 1

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

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-runners-direct-java:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/direct-java/build/reports/tests/test/index.html>

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

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 42m 40s
540 actionable tasks: 537 executed, 3 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #257

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

Changes:

[github] Count compressed records with a long to avoid overflow

------------------------------------------
[...truncated 18.00 MB...]
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.subprocess.ExampleEchoPipelineTest > testExampleEchoPipeline STANDARD_ERROR
    May 02, 2018 5:30:55 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-Echo2336041064492455357.sh 
    May 02, 2018 5:30:55 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 02, 2018 5:30:55 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-Echo2336041064492455357.sh to /tmp/test-Echoo9205932006238815312/test-Echo2336041064492455357.sh 
    May 02, 2018 5:30:55 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils initSemaphore
    INFO: Initialized Semaphore for binary test-EchoAgain5511295495971032017.sh 
    May 02, 2018 5:30:55 PM org.apache.beam.examples.subprocess.utils.CallingSubProcessUtils setUp
    INFO: Calling filesetup to move Executables to worker.
    May 02, 2018 5:30:55 PM org.apache.beam.examples.subprocess.utils.FileUtils copyFileFromGCSToWorker
    INFO: Moving File /tmp/test-EchoAgain5511295495971032017.sh to /tmp/test-Echoo9205932006238815312/test-EchoAgain5511295495971032017.sh 

org.apache.beam.examples.complete.game.HourlyTeamScoreTest > testUserScoresFilter STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user18_ApricotCaneToad,ApricotCaneToad,14,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,7,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,4,1447965690000,2015-11-19 12:41:31.053
    GOT user18_BananaEmu,BananaEmu,1,1447965690000,2015-11-19 12:41:31.053
    GOT user2_AmberCockatoo,AmberCockatoo,13,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user3_BananaEmu,BananaEmu,17,1447965690000,2015-11-19 12:41:31.053
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user0_AndroidGreenEchidna,AndroidGreenEchidna,0,1447965690000,2015-11-19 12:41:31.053
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testTeamScoreSums STANDARD_ERROR
    May 02, 2018 5:30:56 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 02, 2018 5:30:56 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_OUT
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoresBadInput STANDARD_ERROR
    May 02, 2018 5:30:57 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2
    May 02, 2018 5:30:57 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"
    May 02, 2018 5:30:57 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user13_BisqueBilby,BisqueBilby,xxx,1447955630000,2015-11-19 09:53:53.444, For input string: "xxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 02, 2018 5:30:57 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_ERROR
    May 02, 2018 5:30:57 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testUserScoreSums STANDARD_OUT
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 02, 2018 5:30:57 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user0_MagentaKangaroo,MagentaKangaroo,3,1447955630000,2015-11-19 09:53:53.444
    GOT user13_ApricotQuokka,ApricotQuokka,15,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AmberNumbat,AmberNumbat,11,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AlmondWallaby,AlmondWallaby,15,1447955630000,2015-11-19 09:53:53.444
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,12,1447955630000,2015-11-19 09:53:53.444
    GOT user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 02, 2018 5:30:57 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on user6_AliceBlueDingo,AliceBlueDingo,4,xxxxxxx,2015-11-19 09:53:53.444, For input string: "xxxxxxx"

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user7_AndroidGreenKookaburra,AndroidGreenKookaburra,11,1447955630000,2015-11-19 09:53:53.444
    GOT THIS IS A PARSE ERROR,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_ERROR
    May 02, 2018 5:30:57 PM org.apache.beam.examples.complete.game.UserScore$ParseEventFn processElement
    INFO: Parse error on THIS IS A PARSE ERROR,2015-11-19 09:53:53.444, 2

org.apache.beam.examples.complete.game.UserScoreTest > testParseEventFn STANDARD_OUT
    GOT user19_BisqueBilby,BisqueBilby,6,1447955630000,2015-11-19 09:53:53.444
    GOT user19_BisqueBilby,BisqueBilby,8,1447955630000,2015-11-19 09:53:53.444

org.apache.beam.examples.complete.game.GameStatsTest > testCalculateSpammyUsers STANDARD_ERROR
    May 02, 2018 5:30:57 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-2 spammer score 66 with mean 24.923076923076923
    May 02, 2018 5:30:57 PM org.apache.beam.examples.complete.game.GameStats$CalculateSpammyUsers$1 processElement
    INFO: user Robot-1 spammer score 116 with mean 24.923076923076923

Gradle Test Executor 132 finished executing tests.

> Task :beam-examples-java:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.002 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/examples/java/build/reports/tests/test>
Packing task ':beam-examples-java:test'
:beam-examples-java:test (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 9.747 secs.
:beam-examples-java:check (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-examples-java:check
Skipping task ':beam-examples-java:check' as it has no actions.
:beam-examples-java:check (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:beam-examples-java:build (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-examples-java:build
Skipping task ':beam-examples-java:build' as it has no actions.
:beam-examples-java:build (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-examples-java:buildDependents
Caching disabled for task ':beam-examples-java:buildDependents': Caching has not been enabled for the task
Task ':beam-examples-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-sdks-java-io-google-cloud-platform:buildDependents
Caching disabled for task ':beam-sdks-java-io-google-cloud-platform:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-google-cloud-platform:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:beam-runners-direct-java:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) started.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) started.

> Task :beam-runners-direct-java:buildDependents
Caching disabled for task ':beam-runners-direct-java:buildDependents': Caching has not been enabled for the task
Task ':beam-runners-direct-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-runners-direct-java:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.001 secs.
:beam-runners-core-java:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) started.
:beam-runners-local-java-core:buildDependents (Thread[Task worker for ':' Thread 11,5,main]) started.

> Task :beam-sdks-java-extensions-google-cloud-platform-core:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-google-cloud-platform-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-google-cloud-platform-core:buildDependents (Thread[Task worker for ':' Thread 8,5,main]) completed. Took 0.001 secs.

> Task :beam-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-extensions-protobuf:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 13,5,main]) completed. Took 0.001 secs.

> Task :beam-runners-core-java:buildDependents
Caching disabled for task ':beam-runners-core-java:buildDependents': Caching has not been enabled for the task
Task ':beam-runners-core-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-runners-core-java:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.

> Task :beam-runners-local-java-core:buildDependents
Caching disabled for task ':beam-runners-local-java-core:buildDependents': Caching has not been enabled for the task
Task ':beam-runners-local-java-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-runners-local-java-core:buildDependents (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 0.0 secs.
:beam-runners-core-construction-java:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-runners-core-construction-java:buildDependents
Caching disabled for task ':beam-runners-core-construction-java:buildDependents': Caching has not been enabled for the task
Task ':beam-runners-core-construction-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-runners-core-construction-java:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-core:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :beam-sdks-java-core:buildDependents
Caching disabled for task ':beam-sdks-java-core:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-core:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-core:buildDependents (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.
:javaPreCommit (Thread[Task worker for ':' Thread 4,5,main]) started.

> Task :javaPreCommit
Skipping task ':javaPreCommit' as it has no actions.
:javaPreCommit (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 0.0 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 38m 16s
545 actionable tasks: 542 executed, 3 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com

Build failed in Jenkins: beam_PostCommit_Java_GradleBuild #256

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

Changes:

[alan] [BEAM-4218] Fix failing javadoc build

------------------------------------------
[...truncated 19.03 MB...]
    INFO: 2018-05-02T17:00:57.532Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.554Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.578Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.597Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey) into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.618Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.643Z: Fusing consumer PAssert$3/CreateActual/RewindowActuals/Window.Assign into PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.664Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.677Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.701Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.723Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial into PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.745Z: Fusing consumer PAssert$3/CreateActual/ParDo(Anonymous) into PAssert$3/CreateActual/RewindowActuals/Window.Assign
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.768Z: Fusing consumer PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map into PAssert$3/CreateActual/ParDo(Anonymous)
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.795Z: Fusing consumer Combine.globally(Count)/ProduceDefault into Combine.globally(Count)/CreateVoid/Read(CreateSource)
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.819Z: Fusing consumer Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow) into Combine.globally(Count)/Values/Values/Map
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.840Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.862Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial into Combine.globally(Count)/WithKeys/AddKeys/Map
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.885Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.905Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.933Z: Fusing consumer Combine.globally(Count)/WithKeys/AddKeys/Map into DatastoreV1.Read/Read
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.954Z: Fusing consumer DatastoreV1.Read/Reshuffle/Pair with random key into DatastoreV1.Read/Split
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:57.978Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.001Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify into DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.018Z: Fusing consumer Combine.globally(Count)/Values/Values/Map into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.038Z: Fusing consumer DatastoreV1.Read/Split into DatastoreV1.Read/ParDo(GqlQueryTranslate)
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.060Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign into DatastoreV1.Read/Reshuffle/Pair with random key
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.086Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write into Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.111Z: Fusing consumer DatastoreV1.Read/ParDo(GqlQueryTranslate) into DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.148Z: Fusing consumer DatastoreV1.Read/Read into DatastoreV1.Read/Reshuffle/Values/Values/Map
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.175Z: Fusing consumer DatastoreV1.Read/Reshuffle/Values/Values/Map into DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.197Z: Fusing consumer DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable into DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.217Z: Fusing consumer Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract into Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.241Z: Fusing consumer PAssert$3/RunChecks into PAssert$3/WindowToken/Window.Assign
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.265Z: Fusing consumer PAssert$3/WindowToken/Window.Assign into PAssert$3/Create.Values/Read(CreateSource)
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.279Z: Fusing consumer PAssert$3/VerifyAssertions/ParDo(DefaultConclude) into PAssert$3/RunChecks
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.559Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Create
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.577Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Create
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.601Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Create
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.611Z: Starting 1 workers in us-central1-f...
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.625Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Create
    May 02, 2018 5:00:59 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:00:58.648Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Create
    May 02, 2018 5:01:07 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:01:06.448Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    May 02, 2018 5:01:07 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:01:06.700Z: Executing operation DatastoreV1.Read/Create.OfValueProvider/Create.Values/Read(CreateSource)+DatastoreV1.Read/ParDo(GqlQueryTranslate)+DatastoreV1.Read/Split+DatastoreV1.Read/Reshuffle/Pair with random key+DatastoreV1.Read/Reshuffle/Reshuffle/Window.Into()/Window.Assign+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Reify+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Write
    May 02, 2018 5:01:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:01:11.933Z: Autoscaling: Resizing worker pool from 1 to 5.
    May 02, 2018 5:01:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:01:17.956Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    May 02, 2018 5:01:18 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:01:17.979Z: Resized worker pool to 1, though goal was 5.  This could be a quota issue.
    May 02, 2018 5:01:29 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:01:28.373Z: Autoscaling: Raised the number of workers to 4 based on the rate of progress in the currently running step(s).
    May 02, 2018 5:01:29 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:01:28.409Z: Resized worker pool to 4, though goal was 5.  This could be a quota issue.
    May 02, 2018 5:01:45 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:01:43.045Z: Workers have started successfully.
    May 02, 2018 5:02:06 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:04.535Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Close
    May 02, 2018 5:02:06 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:04.612Z: Executing operation DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/Read+DatastoreV1.Read/Reshuffle/Reshuffle/GroupByKey/GroupByWindow+DatastoreV1.Read/Reshuffle/Reshuffle/ExpandIterable+DatastoreV1.Read/Reshuffle/Values/Values/Map+DatastoreV1.Read/Read+Combine.globally(Count)/WithKeys/AddKeys/Map+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Partial+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Reify+Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Write
    May 02, 2018 5:02:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:10.603Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Close
    May 02, 2018 5:02:10 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:10.658Z: Executing operation Combine.globally(Count)/Combine.perKey(Count)/GroupByKey/Read+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues+Combine.globally(Count)/Combine.perKey(Count)/Combine.GroupedValues/Extract+Combine.globally(Count)/Values/Values/Map+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write+Combine.globally(Count)/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    May 02, 2018 5:02:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:14.824Z: Executing operation Combine.globally(Count)/View.AsIterable/CreateDataflowView
    May 02, 2018 5:02:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:14.829Z: Autoscaling: Raised the number of workers to 5 based on the rate of progress in the currently running step(s).
    May 02, 2018 5:02:15 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:14.983Z: Executing operation Combine.globally(Count)/CreateVoid/Read(CreateSource)+Combine.globally(Count)/ProduceDefault+PAssert$3/CreateActual/FilterActuals/Window.Assign+PAssert$3/CreateActual/GatherPanes/Reify.Window/ParDo(Anonymous)+PAssert$3/CreateActual/GatherPanes/WithKeys/AddKeys/Map+PAssert$3/CreateActual/GatherPanes/Window.Into()/Window.Assign+PAssert$3/CreateActual/GatherPanes/GroupByKey/Reify+PAssert$3/CreateActual/GatherPanes/GroupByKey/Write
    May 02, 2018 5:02:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:17.651Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Close
    May 02, 2018 5:02:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:17.748Z: Executing operation PAssert$3/CreateActual/GatherPanes/GroupByKey/Read+PAssert$3/CreateActual/GatherPanes/GroupByKey/GroupByWindow+PAssert$3/CreateActual/GatherPanes/Values/Values/Map+PAssert$3/CreateActual/ExtractPane/Map+PAssert$3/CreateActual/Flatten.Iterables/FlattenIterables/FlatMap+PAssert$3/CreateActual/RewindowActuals/Window.Assign+PAssert$3/CreateActual/ParDo(Anonymous)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/WithKeys/AddKeys/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Partial+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Reify+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Write
    May 02, 2018 5:02:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:19.259Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Close
    May 02, 2018 5:02:19 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:19.338Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/GroupByKey/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Combine.perKey(Singleton)/Combine.GroupedValues/Extract+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/Combine.globally(Singleton)/Values/Values/Map+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/ParDo(UseWindowHashAsKeyAndWindowAsSortKey)+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Write
    May 02, 2018 5:02:22 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:19.766Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Close
    May 02, 2018 5:02:22 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:19.836Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/BatchViewOverrides.GroupByWindowHashAsKeyAndWindowAsSortKey/BatchViewOverrides.GroupByKeyAndSortValuesOnly/Read+PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/ParDo(IsmRecordForSingularValuePerWindow)
    May 02, 2018 5:02:24 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:23.924Z: Executing operation PAssert$3/CreateActual/View.AsSingleton/Combine.GloballyAsSingletonView/CreateDataflowView
    May 02, 2018 5:02:26 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:24.094Z: Executing operation PAssert$3/Create.Values/Read(CreateSource)+PAssert$3/WindowToken/Window.Assign+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    May 02, 2018 5:02:29 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:27.345Z: Cleaning up.
    May 02, 2018 5:02:29 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:02:27.713Z: Stopping worker pool...
    May 02, 2018 5:04:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:04:18.721Z: Autoscaling: Resized worker pool from 5 to 0.
    May 02, 2018 5:04:20 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-05-02T17:04:18.762Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    May 02, 2018 5:04:28 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-05-02_10_00_49-5073698852881494751 finished with status DONE.
    May 02, 2018 5:04:28 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-05-02_10_00_49-5073698852881494751. Found 1 success, 0 failures out of 1 expected assertions.
    May 02, 2018 5:04:29 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 5:04:29 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 5:04:30 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Writing batch of 500 entities
    May 02, 2018 5:04:30 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil$V1TestWriter flushBatch
    INFO: Successfully wrote 500 entities
    May 02, 2018 5:04:30 PM org.apache.beam.sdk.io.gcp.datastore.V1TestUtil deleteAllEntities
    INFO: Successfully deleted 1000 entities

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithLargeDataset STANDARD_ERROR
    May 02, 2018 5:04:30 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 02, 2018 5:04:30 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind sort_1G is 1525074215000000
    May 02, 2018 5:04:31 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 2130000000
    May 02, 2018 5:04:31 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 32 splits

org.apache.beam.sdk.io.gcp.datastore.SplitQueryFnIT > testSplitQueryFnWithSmallDataset STANDARD_ERROR
    May 02, 2018 5:04:31 PM org.apache.beam.sdk.transforms.DoFnTester of
    WARNING: Your tests use DoFnTester, which may not exercise DoFns correctly. Please use TestPipeline instead.
    May 02, 2018 5:04:31 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedSizeBytes
    INFO: Latest stats timestamp for kind shakespeare is 1525074215000000
    May 02, 2018 5:04:31 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read getEstimatedNumSplits
    INFO: Estimated size bytes for the query is: 26383451
    May 02, 2018 5:04:31 PM org.apache.beam.sdk.io.gcp.datastore.DatastoreV1$Read$SplitQueryFn processElement
    INFO: Splitting the query into 12 splits

Gradle Test Executor 128 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest FAILED

org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT > testWrite FAILED
    java.lang.NoClassDefFoundError: com/google/api/gax/retrying/ExceptionRetryAlgorithm
        at java.lang.ClassLoader.defineClass1(Native Method)
        at java.lang.ClassLoader.defineClass(ClassLoader.java:763)
        at java.security.SecureClassLoader.defineClass(SecureClassLoader.java:142)
        at java.net.URLClassLoader.defineClass(URLClassLoader.java:467)
        at java.net.URLClassLoader.access$100(URLClassLoader.java:73)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:368)
        at java.net.URLClassLoader$1.run(URLClassLoader.java:362)
        at java.security.AccessController.doPrivileged(Native Method)
        at java.net.URLClassLoader.findClass(URLClassLoader.java:361)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
        at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
        at com.google.cloud.BaseService.<clinit>(BaseService.java:48)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:60)
        at com.google.cloud.spanner.SpannerOptions$DefaultSpannerFactory.create(SpannerOptions.java:55)
        at com.google.cloud.ServiceOptions.getService(ServiceOptions.java:426)
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.setUp(SpannerWriteIT.java:91)

        Caused by:
        java.lang.ClassNotFoundException: com.google.api.gax.retrying.ExceptionRetryAlgorithm
            at java.net.URLClassLoader.findClass(URLClassLoader.java:381)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:424)
            at sun.misc.Launcher$AppClassLoader.loadClass(Launcher.java:338)
            at java.lang.ClassLoader.loadClass(ClassLoader.java:357)
            ... 17 more

    java.lang.NullPointerException
        at org.apache.beam.sdk.io.gcp.spanner.SpannerWriteIT.tearDown(SpannerWriteIT.java:148)

13 tests completed, 4 failed
Finished generating test XML results (0.008 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/test-results/googleCloudPlatformIntegrationTest>
Generating HTML test report...
Finished generating test html results (0.01 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_GradleBuild/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/googleCloudPlatformIntegrationTest>
:beam-runners-google-cloud-dataflow-java:googleCloudPlatformIntegrationTest (Thread[Task worker for ':',5,main]) completed. Took 16 mins 27.016 secs.

FAILURE: Build failed with an exception.

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

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
See https://docs.gradle.org/4.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 54m 36s
545 actionable tasks: 537 executed, 8 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
Recording test results
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user apilloud@google.com
Not sending mail to unregistered user pgerver@us.ibm.com
Not sending mail to unregistered user szewinho@gmail.com
Not sending mail to unregistered user katarzyna.kucharczyk@polidea.com
Not sending mail to unregistered user ekirpichov@gmail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user swegner@google.com
Not sending mail to unregistered user herohde@google.com
Not sending mail to unregistered user kedin@google.com
Not sending mail to unregistered user relax@relax-macbookpro2.roam.corp.google.com
Not sending mail to unregistered user sidhom@google.com
Not sending mail to unregistered user wcn@google.com
Not sending mail to unregistered user aaltay@gmail.com
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user rober@frantil.com
Not sending mail to unregistered user ankurgoenka@gmail.com