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/08/11 18:20:38 UTC

Build failed in Jenkins: beam_PreCommit_Java_Cron #214

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

Changes:

[relax] Row comparison should be faster when both are POJOs.

------------------------------------------
[...truncated 15.25 MB...]
              LogicalProject(num=[$2], starttime=[$1])
                LogicalAggregate(group=[{0, 1}], num=[COUNT()])
                  LogicalProject(auction=[$0], $f1=[HOP($3, 5000, 10000)])
                    BeamIOSourceRel(table=[[beam, Bid]])

    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: BEAMPlan>
    BeamCalcRel(expr#0..4=[{inputs}], proj#0..1=[{exprs}])
      BeamJoinRel(condition=[AND(=($2, $4), >=($1, $3))], joinType=[inner])
        BeamCalcRel(expr#0..2=[{inputs}], auction=[$t0], num=[$t2], starttime=[$t1])
          BeamAggregationRel(group=[{0, 1}], num=[COUNT()])
            BeamCalcRel(expr#0..4=[{inputs}], expr#5=[5000], expr#6=[10000], expr#7=[HOP($t3, $t5, $t6)], auction=[$t0], $f1=[$t7])
              BeamIOSourceRel(table=[[beam, Bid]])
        BeamCalcRel(expr#0..1=[{inputs}], maxnum=[$t1], starttime=[$t0])
          BeamAggregationRel(group=[{1}], maxnum=[MAX($0)])
            BeamCalcRel(expr#0..2=[{inputs}], num=[$t2], starttime=[$t1])
              BeamAggregationRel(group=[{0, 1}], num=[COUNT()])
                BeamCalcRel(expr#0..4=[{inputs}], expr#5=[5000], expr#6=[10000], expr#7=[HOP($t3, $t5, $t6)], auction=[$t0], $f1=[$t7])
                  BeamIOSourceRel(table=[[beam, Bid]])


org.apache.beam.sdk.nexmark.queries.sql.SqlQuery3Test > testJoinsPeopleWithAuctions STANDARD_ERROR
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQL:
    SELECT `P`.`name`, `P`.`city`, `P`.`state`, `A`.`id`
    FROM `beam`.`Auction` AS `A`
    INNER JOIN `beam`.`Person` AS `P` ON `A`.`seller` = `P`.`id`
    WHERE `A`.`category` = 10 AND (`P`.`state` = 'OR' OR `P`.`state` = 'ID' OR `P`.`state` = 'CA')
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQLPlan>
    LogicalProject(name=[$11], city=[$14], state=[$15], id=[$0])
      LogicalFilter(condition=[AND(=($8, 10), OR(=($15, 'OR'), =($15, 'ID'), =($15, 'CA')))])
        LogicalJoin(condition=[=($7, $10)], joinType=[inner])
          BeamIOSourceRel(table=[[beam, Auction]])
          BeamIOSourceRel(table=[[beam, Person]])

    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: BEAMPlan>
    BeamCalcRel(expr#0..17=[{inputs}], name=[$t11], city=[$t14], state=[$t15], id=[$t0])
      BeamJoinRel(condition=[=($7, $10)], joinType=[inner])
        BeamCalcRel(expr#0..9=[{inputs}], expr#10=[10], expr#11=[=($t8, $t10)], proj#0..9=[{exprs}], $condition=[$t11])
          BeamIOSourceRel(table=[[beam, Auction]])
        BeamCalcRel(expr#0..7=[{inputs}], expr#8=['OR'], expr#9=[=($t5, $t8)], expr#10=['ID'], expr#11=[=($t5, $t10)], expr#12=['CA'], expr#13=[=($t5, $t12)], expr#14=[OR($t9, $t11, $t13)], proj#0..7=[{exprs}], $condition=[$t14])
          BeamIOSourceRel(table=[[beam, Person]])


org.apache.beam.sdk.nexmark.queries.sql.SqlQuery7Test > testBids STANDARD_ERROR
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQL:
    SELECT `B`.`auction`, `B`.`price`, `B`.`bidder`, `B`.`dateTime`, `B`.`extra`
    FROM (SELECT `B`.`auction`, `B`.`price`, `B`.`bidder`, `B`.`dateTime`, `B`.`extra`, TUMBLE_START(`B`.`dateTime`, INTERVAL '10' SECOND) AS `starttime`
    FROM `beam`.`Bid` AS `B`
    GROUP BY `B`.`auction`, `B`.`price`, `B`.`bidder`, `B`.`dateTime`, `B`.`extra`, TUMBLE(`B`.`dateTime`, INTERVAL '10' SECOND)) AS `B`
    INNER JOIN (SELECT MAX(`B1`.`price`) AS `maxprice`, TUMBLE_START(`B1`.`dateTime`, INTERVAL '10' SECOND) AS `starttime`
    FROM `beam`.`Bid` AS `B1`
    GROUP BY TUMBLE(`B1`.`dateTime`, INTERVAL '10' SECOND)) AS `B1` ON `B`.`starttime` = `B1`.`starttime` AND `B`.`price` = `B1`.`maxprice`
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQLPlan>
    LogicalProject(auction=[$0], price=[$1], bidder=[$2], dateTime=[$3], extra=[$4])
      LogicalJoin(condition=[AND(=($5, $7), =($1, $6))], joinType=[inner])
        LogicalProject(auction=[$0], price=[$1], bidder=[$2], dateTime=[$3], extra=[$4], starttime=[$5])
          LogicalAggregate(group=[{0, 1, 2, 3, 4, 5}])
            LogicalProject(auction=[$0], price=[$2], bidder=[$1], dateTime=[$3], extra=[$4], $f5=[TUMBLE($3, 10000)])
              BeamIOSourceRel(table=[[beam, Bid]])
        LogicalProject(maxprice=[$1], starttime=[$0])
          LogicalAggregate(group=[{0}], maxprice=[MAX($1)])
            LogicalProject($f0=[TUMBLE($3, 10000)], price=[$2])
              BeamIOSourceRel(table=[[beam, Bid]])

    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: BEAMPlan>
    BeamCalcRel(expr#0..7=[{inputs}], proj#0..4=[{exprs}])
      BeamJoinRel(condition=[AND(=($5, $7), =($1, $6))], joinType=[inner])
        BeamCalcRel(expr#0..5=[{inputs}], proj#0..5=[{exprs}])
          BeamAggregationRel(group=[{0, 1, 2, 3, 4, 5}])
            BeamCalcRel(expr#0..4=[{inputs}], expr#5=[10000], expr#6=[TUMBLE($t3, $t5)], auction=[$t0], price=[$t2], bidder=[$t1], dateTime=[$t3], extra=[$t4], $f5=[$t6])
              BeamIOSourceRel(table=[[beam, Bid]])
        BeamCalcRel(expr#0..1=[{inputs}], maxprice=[$t1], starttime=[$t0])
          BeamAggregationRel(group=[{0}], maxprice=[MAX($1)])
            BeamCalcRel(expr#0..4=[{inputs}], expr#5=[10000], expr#6=[TUMBLE($t3, $t5)], $f0=[$t6], price=[$t2])
              BeamIOSourceRel(table=[[beam, Bid]])


org.apache.beam.sdk.nexmark.queries.sql.SqlQuery2Test > testSkipsEverySecondElement STANDARD_ERROR
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQL:
    SELECT `PCOLLECTION`.`auction`, `PCOLLECTION`.`price`
    FROM `beam`.`PCOLLECTION` AS `PCOLLECTION`
    WHERE MOD(`PCOLLECTION`.`auction`, 2) = 0
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQLPlan>
    LogicalProject(auction=[$0], price=[$2])
      LogicalFilter(condition=[=(MOD($0, 2), 0)])
        BeamIOSourceRel(table=[[beam, PCOLLECTION]])

    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: BEAMPlan>
    BeamCalcRel(expr#0..4=[{inputs}], expr#5=[2], expr#6=[MOD($t0, $t5)], expr#7=[0], expr#8=[=($t6, $t7)], auction=[$t0], price=[$t2], $condition=[$t8])
      BeamIOSourceRel(table=[[beam, PCOLLECTION]])


org.apache.beam.sdk.nexmark.queries.sql.SqlQuery2Test > testSkipsEveryThirdElement STANDARD_ERROR
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQL:
    SELECT `PCOLLECTION`.`auction`, `PCOLLECTION`.`price`
    FROM `beam`.`PCOLLECTION` AS `PCOLLECTION`
    WHERE MOD(`PCOLLECTION`.`auction`, 3) = 0
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQLPlan>
    LogicalProject(auction=[$0], price=[$2])
      LogicalFilter(condition=[=(MOD($0, 3), 0)])
        BeamIOSourceRel(table=[[beam, PCOLLECTION]])

    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: BEAMPlan>
    BeamCalcRel(expr#0..4=[{inputs}], expr#5=[3], expr#6=[MOD($t0, $t5)], expr#7=[0], expr#8=[=($t6, $t7)], auction=[$t0], price=[$t2], $condition=[$t8])
      BeamIOSourceRel(table=[[beam, PCOLLECTION]])


org.apache.beam.sdk.nexmark.queries.sql.SqlQuery1Test > testConvertsPriceToEur STANDARD_ERROR
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQL:
    SELECT `PCOLLECTION`.`auction`, `PCOLLECTION`.`bidder`, `DolToEur`(`PCOLLECTION`.`price`) AS `price`, `PCOLLECTION`.`dateTime`, `PCOLLECTION`.`extra`
    FROM `beam`.`PCOLLECTION` AS `PCOLLECTION`
    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQLPlan>
    LogicalProject(auction=[$0], bidder=[$1], price=[DolToEur($2)], dateTime=[$3], extra=[$4])
      BeamIOSourceRel(table=[[beam, PCOLLECTION]])

    Aug 11, 2018 6:20:32 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: BEAMPlan>
    BeamCalcRel(expr#0..4=[{inputs}], expr#5=[DolToEur($t2)], proj#0..1=[{exprs}], price=[$t5], dateTime=[$t3], extra=[$t4])
      BeamIOSourceRel(table=[[beam, PCOLLECTION]])


Gradle Test Executor 123 finished executing tests.

> Task :beam-sdks-java-nexmark:test
Finished generating test XML results (0.001 secs) into: <https://builds.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/nexmark/build/test-results/test>
Generating HTML test report...
Finished generating test html results (0.006 secs) into: <https://builds.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/nexmark/build/reports/tests/test>
Packing task ':beam-sdks-java-nexmark:test'
:beam-sdks-java-nexmark:test (Thread[Daemon worker,5,main]) completed. Took 8 mins 13.333 secs.
:beam-sdks-java-nexmark:shadowJar (Thread[Daemon worker,5,main]) started.

> Task :beam-sdks-java-nexmark:shadowJar
Build cache key for task ':beam-sdks-java-nexmark:shadowJar' is df7eb5fc4d27e855bc65b21c2602d7dd
Caching disabled for task ':beam-sdks-java-nexmark:shadowJar': Caching has not been enabled for the task
Task ':beam-sdks-java-nexmark:shadowJar' is not up-to-date because:
  No history is available.
*******************
GRADLE SHADOW STATS

Total Jars: 2 (includes project)
Total Time: 2.256s [2256ms]
Average Time/Jar: 1.128s [1128.0ms]
*******************
:beam-sdks-java-nexmark:shadowJar (Thread[Daemon worker,5,main]) completed. Took 2.726 secs.
:beam-sdks-java-nexmark:validateShadedJarDoesntLeakNonOrgApacheBeamClasses (Thread[Daemon worker,5,main]) started.

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

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

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

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

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

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

> Task :beam-sdks-java-io-kafka:buildDependents
Caching disabled for task ':beam-sdks-java-io-kafka:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-io-kafka:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-io-kafka:buildDependents (Thread[Task worker for ':' Thread 10,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-extensions-protobuf:extractIncludeTestProto'.
> Could not expand ZIP '<https://builds.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/build/libs/beam-sdks-java-core-2.7.0-SNAPSHOT-tests.jar'.>

* 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-examples-java:compileTestJava'.
> 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.
==============================================================================

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':beam-runners-flink_2.11:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PreCommit_Java_Cron/ws/src/runners/flink/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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 20m 5s
731 actionable tasks: 727 executed, 4 from cache

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

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

Jenkins build is back to normal : beam_PreCommit_Java_Cron #216

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


Build failed in Jenkins: beam_PreCommit_Java_Cron #215

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

------------------------------------------
[...truncated 18.01 MB...]
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:03.470Z: Autoscaling is enabled for job 2018-08-11_17_19_03-4520757645536680603. The number of workers will be between 1 and 1000.
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:03.508Z: Autoscaling was automatically enabled for job 2018-08-11_17_19_03-4520757645536680603.
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:06.565Z: Checking required Cloud APIs are enabled.
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:07.096Z: Checking permissions granted to controller Service Account.
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:10.902Z: Worker configuration: n1-standard-1 in us-central1-b.
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:11.341Z: Expanding CoGroupByKey operations into optimizable parts.
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:11.577Z: Expanding GroupByKey operations into optimizable parts.
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:11.624Z: Lifting ValueCombiningMappingFns into MergeBucketsMappingFns
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:11.934Z: Fusing adjacent ParDo, Read, Write, and Flatten operations
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:11.978Z: Unzipping flatten s13 for input s12.org.apache.beam.sdk.values.PCollection.<init>:384#639855871860d444
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.024Z: Fusing unzipped copy of WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map, through flatten WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/Flatten.PCollections, into producer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/DropShardNum
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.071Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/GroupByWindow
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.120Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/Window.Into()/Window.Assign into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Pair with random key
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.168Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.206Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.250Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/Window.Into()/Window.Assign
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.295Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Drop key/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/ExpandIterable
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.346Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Gather bundles into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Drop key/Values/Map
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.392Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Pair with random key into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Gather bundles
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.438Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.476Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.526Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Reify
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.574Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Read
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.616Z: Unzipping flatten s13-u58 for input s14.org.apache.beam.sdk.values.PCollection.<init>:384#43d0369d0f0559b7-c56
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.665Z: Fusing unzipped copy of WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign, through flatten s13-u58, into producer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.706Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Pair with random key into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.753Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.800Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.838Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.886Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/Window.Into()/Window.Assign into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Pair with random key
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.933Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:12.983Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/Window.Into()/Window.Assign
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.031Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.082Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.130Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.166Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.201Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey+WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Partial into WordCount.CountWords/Count.PerElement/Init/Map
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.256Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.295Z: Fusing consumer Window.Into()/Window.Assign into ParDo(AddTimestamp)
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.342Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Read
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.381Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Reify into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey+WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Partial
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.427Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.475Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.513Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Write into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Reify
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.552Z: Fusing consumer MapElements/Map into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.598Z: Fusing consumer ParDo(AddTimestamp) into TextIO.Read/Read
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.637Z: Fusing consumer WordCount.CountWords/ParDo(ExtractWords) into Window.Into()/Window.Assign
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.670Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/DropShardNum into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.707Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles into MapElements/Map
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.753Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Read
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.798Z: Fusing consumer WordCount.CountWords/Count.PerElement/Init/Map into WordCount.CountWords/ParDo(ExtractWords)
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:13.844Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:14.292Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Create
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:14.326Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Create
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:14.364Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:14.393Z: Starting 1 workers in us-central1-b...
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:14.393Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:14.427Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Create
    Aug 12, 2018 12:19:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:14.696Z: Executing operation TextIO.Read/Read+ParDo(AddTimestamp)+Window.Into()/Window.Assign+WordCount.CountWords/ParDo(ExtractWords)+WordCount.CountWords/Count.PerElement/Init/Map+WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey+WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Partial+WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Reify+WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Write
    Aug 12, 2018 12:19:26 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:26.015Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    Aug 12, 2018 12:19:36 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:36.498Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    Aug 12, 2018 12:19:36 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:36.541Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 12, 2018 12:19:55 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:53.015Z: Workers have started successfully.
    Aug 12, 2018 12:19:55 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:19:53.064Z: Workers have started successfully.
    Aug 12, 2018 12:20:14 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:12.735Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Close
    Aug 12, 2018 12:20:14 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:12.832Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Read+WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues+WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract+MapElements/Map+WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Reify+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Write+WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify+WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Write
    Aug 12, 2018 12:20:24 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:23.881Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Close
    Aug 12, 2018 12:20:24 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:23.975Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Read+WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow+WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten+WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/DropShardNum+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Reify+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Write
    Aug 12, 2018 12:20:24 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:24.374Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Close
    Aug 12, 2018 12:20:24 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:24.460Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Read+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/GroupByWindow+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/ExpandIterable+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Drop key/Values/Map+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Gather bundles+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Pair with random key+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/Window.Into()/Window.Assign+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write
    Aug 12, 2018 12:20:31 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:28.655Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 12, 2018 12:20:31 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:28.751Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable+WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map+WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize+WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Pair with random key+WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/Window.Into()/Window.Assign+WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify+WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write
    Aug 12, 2018 12:20:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:37.036Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 12, 2018 12:20:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:37.131Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read+WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow+WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable+WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Values/Values/Map
    Aug 12, 2018 12:20:40 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:39.580Z: Cleaning up.
    Aug 12, 2018 12:20:40 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:20:39.693Z: Stopping worker pool...
    Aug 12, 2018 12:22:04 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:22:02.872Z: Autoscaling: Resized worker pool from 1 to 0.
    Aug 12, 2018 12:22:04 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-12T00:22:02.911Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 12, 2018 12:22:12 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-11_17_19_03-4520757645536680603 finished with status DONE.
    Aug 12, 2018 12:22:12 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-08-11_17_19_03-4520757645536680603. Found 0 success, 0 failures out of 0 expected assertions.
    Aug 12, 2018 12:22:14 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-11_17_19_03-4520757645536680603 finished with status DONE.

Gradle Test Executor 96 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java-examples:preCommit
Finished generating test XML results (0.005 secs) into: <https://builds.apache.org/job/beam_PreCommit_Java_Cron/ws/src/runners/google-cloud-dataflow-java/examples/build/test-results/preCommit>
Generating HTML test report...
Finished generating test html results (0.006 secs) into: <https://builds.apache.org/job/beam_PreCommit_Java_Cron/ws/src/runners/google-cloud-dataflow-java/examples/build/reports/tests/preCommit>
Packing task ':beam-runners-google-cloud-dataflow-java-examples:preCommit'
:beam-runners-google-cloud-dataflow-java-examples:preCommit (Thread[Task worker for ':' Thread 11,5,main]) completed. Took 13 mins 58.232 secs.
:beam-examples-java:preCommit (Thread[Task worker for ':' Thread 11,5,main]) started.
:beam-runners-google-cloud-dataflow-java-examples:test (Thread[Daemon worker,5,main]) started.

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

> Task :beam-runners-google-cloud-dataflow-java-examples:test NO-SOURCE
Skipping task ':beam-runners-google-cloud-dataflow-java-examples:test' as it has no source files and no previous output files.
:beam-runners-google-cloud-dataflow-java-examples:test (Thread[Daemon worker,5,main]) completed. Took 0.003 secs.
:beam-runners-google-cloud-dataflow-java-examples:check (Thread[Daemon worker,5,main]) started.

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

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

> Task :beam-runners-google-cloud-dataflow-java-examples:buildDependents
Caching disabled for task ':beam-runners-google-cloud-dataflow-java-examples:buildDependents': Caching has not been enabled for the task
Task ':beam-runners-google-cloud-dataflow-java-examples:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-runners-google-cloud-dataflow-java-examples:buildDependents (Thread[Daemon worker,5,main]) completed. Took 0.001 secs.
:beam-examples-java:buildDependents (Thread[Daemon worker,5,main]) started.
:beam-runners-google-cloud-dataflow-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[Daemon worker,5,main]) completed. Took 0.0 secs.

> Task :beam-runners-google-cloud-dataflow-java:buildDependents
Caching disabled for task ':beam-runners-google-cloud-dataflow-java:buildDependents': Caching has not been enabled for the task
Task ':beam-runners-google-cloud-dataflow-java:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-runners-google-cloud-dataflow-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.001 secs.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 9,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 9,5,main]) completed. Took 0.001 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-sdks-java-io-elasticsearch-tests-2:compileTestJava'.
> 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.

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 21m 51s
745 actionable tasks: 740 executed, 5 from cache

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

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