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/19 12:14:30 UTC

Build failed in Jenkins: beam_PreCommit_Java_Cron #245

See <https://builds.apache.org/job/beam_PreCommit_Java_Cron/245/display/redirect>

------------------------------------------
[...truncated 14.35 MB...]
    GROUP BY `B1`.`auction`, HOP(`B1`.`dateTime`, INTERVAL '5' SECOND, INTERVAL '10' SECOND)) AS `AuctionBids`
    INNER JOIN (SELECT MAX(`CountBids`.`num`) AS `maxnum`, `CountBids`.`starttime`
    FROM (SELECT COUNT(*) AS `num`, HOP_START(`B2`.`dateTime`, INTERVAL '5' SECOND, INTERVAL '10' SECOND) AS `starttime`
    FROM `beam`.`Bid` AS `B2`
    GROUP BY `B2`.`auction`, HOP(`B2`.`dateTime`, INTERVAL '5' SECOND, INTERVAL '10' SECOND)) AS `CountBids`
    GROUP BY `CountBids`.`starttime`) AS `MaxBids` ON `AuctionBids`.`starttime` = `MaxBids`.`starttime` AND `AuctionBids`.`num` >= `MaxBids`.`maxnum`
    Aug 19, 2018 12:14:24 PM org.apache.beam.sdk.extensions.sql.impl.BeamQueryPlanner convertToBeamRel
    INFO: SQLPlan>
    LogicalProject(auction=[$0], num=[$1])
      LogicalJoin(condition=[AND(=($2, $4), >=($1, $3))], joinType=[inner])
        LogicalProject(auction=[$0], num=[$2], starttime=[$1])
          LogicalAggregate(group=[{0, 1}], num=[COUNT()])
            LogicalProject(auction=[$0], $f1=[HOP($3, 5000, 10000)])
              BeamIOSourceRel(table=[[beam, Bid]])
        LogicalProject(maxnum=[$1], starttime=[$0])
          LogicalAggregate(group=[{0}], maxnum=[MAX($1)])
            LogicalProject(starttime=[$1], num=[$0])
              LogicalProject(num=[$2], starttime=[$1])
                LogicalAggregate(group=[{0, 1}], num=[COUNT()])
                  LogicalProject(auction=[$0], $f1=[HOP($3, 5000, 10000)])
                    BeamIOSourceRel(table=[[beam, Bid]])

    Aug 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 19, 2018 12:14:24 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 107 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.003 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[Task worker for ':' Thread 7,5,main]) completed. Took 3 mins 32.313 secs.
:beam-sdks-java-nexmark:shadowJar (Thread[Task worker for ':' Thread 7,5,main]) started.

> Task :beam-sdks-java-nexmark:shadowJar
Build cache key for task ':beam-sdks-java-nexmark:shadowJar' is cf7ce4bfd81fc288d5e9d9604662e175
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.127s [2127ms]
Average Time/Jar: 1.0635s [1063.5ms]
*******************
:beam-sdks-java-nexmark:shadowJar (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 2.4 secs.
:beam-sdks-java-nexmark:validateShadedJarDoesntLeakNonOrgApacheBeamClasses (Thread[Task worker for ':' Thread 7,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[Task worker for ':' Thread 7,5,main]) completed. Took 0.042 secs.
:beam-sdks-java-nexmark:check (Thread[Task worker for ':' Thread 7,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[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-nexmark:build (Thread[Task worker for ':' Thread 7,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[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-nexmark:buildDependents (Thread[Task worker for ':' Thread 7,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 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-sql:buildDependents (Thread[Task worker for ':' Thread 7,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 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-join-library:buildDependents (Thread[Task worker for ':' Thread 7,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 7,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-spark: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.
==============================================================================

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.
==============================================================================

* 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 14m 5s
781 actionable tasks: 776 executed, 5 from cache

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

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 #251

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


Build failed in Jenkins: beam_PreCommit_Java_Cron #250

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

Changes:

[jbonofre] [BEAM-5150] Disable MqttIO ReadTest for now, investigating the cause

------------------------------------------
[...truncated 17.61 MB...]
    INFO: 2018-08-20T18:16:19.241Z: Fusing adjacent ParDo, Read, Write, and Flatten operations
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.278Z: Unzipping flatten s13 for input s12.org.apache.beam.sdk.values.PCollection.<init>:384#639855871860d444
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.321Z: 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 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.365Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.403Z: 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 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.451Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.499Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.544Z: 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 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.583Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Drop key/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/ExpandIterable
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.627Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Gather bundles into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Drop key/Values/Map
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.665Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Pair with random key into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Gather bundles
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.710Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.755Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.800Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Reify
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.846Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Read
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.884Z: Unzipping flatten s13-u58 for input s14.org.apache.beam.sdk.values.PCollection.<init>:384#43d0369d0f0559b7-c56
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.913Z: 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 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:19.958Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Pair with random key into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.002Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.042Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.091Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.140Z: 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 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.184Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.231Z: 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 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.268Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.313Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.360Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.406Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.450Z: 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 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.496Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.529Z: Fusing consumer Window.Into()/Window.Assign into ParDo(AddTimestamp)
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.565Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Read
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.602Z: 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 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.647Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.689Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.728Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Write into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Reify
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.773Z: Fusing consumer MapElements/Map into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.818Z: Fusing consumer ParDo(AddTimestamp) into TextIO.Read/Read
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.863Z: Fusing consumer WordCount.CountWords/ParDo(ExtractWords) into Window.Into()/Window.Assign
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.900Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/DropShardNum into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.945Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles into MapElements/Map
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:20.982Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Read
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:21.027Z: Fusing consumer WordCount.CountWords/Count.PerElement/Init/Map into WordCount.CountWords/ParDo(ExtractWords)
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:21.053Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:21.501Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Create
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:21.547Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Create
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:21.590Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:21.602Z: Starting 1 workers in us-central1-b...
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:21.627Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:21.661Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Create
    Aug 20, 2018 6:16:23 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:21.976Z: 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 20, 2018 6:16:31 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:30.675Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    Aug 20, 2018 6:16:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:42.083Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    Aug 20, 2018 6:16:44 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:16:42.122Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 20, 2018 6:17:11 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:17:09.827Z: Workers have started successfully.
    Aug 20, 2018 6:17:11 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:17:09.869Z: Workers have started successfully.
    Aug 20, 2018 6:17:48 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:17:46.357Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Close
    Aug 20, 2018 6:17:48 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:17:46.451Z: 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 20, 2018 6:17:58 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:17:58.092Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Close
    Aug 20, 2018 6:17:58 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:17:58.177Z: 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 20, 2018 6:18:00 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:17:59.367Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Close
    Aug 20, 2018 6:18:00 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:17:59.456Z: 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 20, 2018 6:18:07 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:18:05.231Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 20, 2018 6:18:07 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:18:05.313Z: 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 20, 2018 6:18:11 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:18:11.137Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 20, 2018 6:18:11 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:18:11.241Z: 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 20, 2018 6:18:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:18:14.697Z: Cleaning up.
    Aug 20, 2018 6:18:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:18:14.789Z: Stopping worker pool...
    Aug 20, 2018 6:19:47 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:19:46.588Z: Autoscaling: Resized worker pool from 1 to 0.
    Aug 20, 2018 6:19:47 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T18:19:46.632Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 20, 2018 6:19:55 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-20_11_16_12-6811629777588081507 finished with status DONE.
    Aug 20, 2018 6:19:55 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-08-20_11_16_12-6811629777588081507. Found 0 success, 0 failures out of 0 expected assertions.
    Aug 20, 2018 6:19:57 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-20_11_16_12-6811629777588081507 finished with status DONE.

Gradle Test Executor 95 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java-examples:preCommit
Finished generating test XML results (0.004 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.004 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 ':',5,main]) completed. Took 11 mins 54.222 secs.
:beam-examples-java:preCommit (Thread[Task worker for ':',5,main]) started.
:beam-runners-google-cloud-dataflow-java-examples:test (Thread[Task worker for ':' Thread 3,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 ':',5,main]) completed. Took 0.001 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[Task worker for ':' Thread 3,5,main]) completed. Took 0.003 secs.
:beam-runners-google-cloud-dataflow-java-examples:check (Thread[Task worker for ':' Thread 3,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[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-runners-google-cloud-dataflow-java-examples:build (Thread[Task worker for ':' Thread 3,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[Task worker for ':' Thread 3,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.0 secs.
:beam-examples-java:buildDependents (Thread[Daemon worker,5,main]) started.
:beam-runners-google-cloud-dataflow-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[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 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.001 secs.
:beam-runners-direct-java:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Daemon worker,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 10,5,main]) completed. Took 0.0 secs.
:beam-runners-local-java-core:buildDependents (Thread[Task worker for ':' Thread 10,5,main]) started.

> 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 10,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.001 secs.

FAILURE: Build 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_PreCommit_Java_Cron/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.

* 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 19m 40s
803 actionable tasks: 798 executed, 5 from cache

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

Build cache (/home/jenkins/.gradle/caches/build-cache-1) remove files older than Mon Aug 13 18:00:25 UTC 2018.
Build cache (/home/jenkins/.gradle/caches/build-cache-1) removing 1012 cache entries (63 MB reclaimed).
Build cache (/home/jenkins/.gradle/caches/build-cache-1) cleaned up in 0.154 secs.
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

Build failed in Jenkins: beam_PreCommit_Java_Cron #249

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

Changes:

[ryan.blake.williams] clean up artifacts per-job in portable VR tests

[mxm] Correct field visibility in SingletonKeyedWorkitem

[mxm] Remove FlinkRunner dependency of FlinkPipelineTranslator

[mxm] Rename BatchFlinkExecutableStageContext FlinkBatchExecutableStageContext

------------------------------------------
[...truncated 17.40 MB...]
    INFO: 2018-08-20T12:17:50.023Z: 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 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.053Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Pair with random key into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.076Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.122Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.171Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.216Z: 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 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.259Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.302Z: 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 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.353Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.521Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.585Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.656Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.718Z: 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 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.752Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.817Z: Fusing consumer Window.Into()/Window.Assign into ParDo(AddTimestamp)
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.868Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Read
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.913Z: 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 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.960Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:50.995Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.041Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Write into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Reify
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.089Z: Fusing consumer MapElements/Map into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.134Z: Fusing consumer ParDo(AddTimestamp) into TextIO.Read/Read
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.180Z: Fusing consumer WordCount.CountWords/ParDo(ExtractWords) into Window.Into()/Window.Assign
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.230Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/DropShardNum into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.275Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles into MapElements/Map
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.316Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Read
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.363Z: Fusing consumer WordCount.CountWords/Count.PerElement/Init/Map into WordCount.CountWords/ParDo(ExtractWords)
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.411Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.900Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Create
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.944Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Create
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:51.989Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:52.000Z: Starting 1 workers in us-central1-c...
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:52.039Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:52.087Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Create
    Aug 20, 2018 12:17:56 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:17:52.389Z: 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 20, 2018 12:18:03 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:18:02.033Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    Aug 20, 2018 12:18:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:18:13.337Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    Aug 20, 2018 12:18:14 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:18:13.379Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 20, 2018 12:18:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:18:32.134Z: Workers have started successfully.
    Aug 20, 2018 12:18:33 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:18:32.181Z: Workers have started successfully.
    Aug 20, 2018 12:18:51 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:18:49.782Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Close
    Aug 20, 2018 12:18:51 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:18:49.894Z: 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 20, 2018 12:19:02 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:01.807Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Close
    Aug 20, 2018 12:19:02 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:02.072Z: 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 20, 2018 12:19:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:04.011Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Close
    Aug 20, 2018 12:19:05 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:04.114Z: 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 20, 2018 12:19:07 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:07.004Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 20, 2018 12:19:07 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:07.120Z: 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 20, 2018 12:19:17 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:16.776Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 20, 2018 12:19:17 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:16.882Z: 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 20, 2018 12:19:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:20.468Z: Cleaning up.
    Aug 20, 2018 12:19:21 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:19:20.629Z: Stopping worker pool...
    Aug 20, 2018 12:20:47 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:20:45.749Z: Autoscaling: Resized worker pool from 1 to 0.
    Aug 20, 2018 12:20:47 PM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T12:20:45.792Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 20, 2018 12:20:54 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-20_05_17_41-5977545321086927189 finished with status DONE.
    Aug 20, 2018 12:20:54 PM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-08-20_05_17_41-5977545321086927189. Found 0 success, 0 failures out of 0 expected assertions.
    Aug 20, 2018 12:20:56 PM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-20_05_17_41-5977545321086927189 finished with status DONE.

Gradle Test Executor 94 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java-examples:preCommit
Finished generating test XML results (0.006 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.009 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 12 mins 8.347 secs.
:beam-examples-java:preCommit (Thread[Task worker for ':' Thread 11,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.
:beam-runners-google-cloud-dataflow-java-examples:test (Thread[Task worker for ':' Thread 8,5,main]) started.

> 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[Task worker for ':' Thread 8,5,main]) completed. Took 0.003 secs.
:beam-runners-google-cloud-dataflow-java-examples:check (Thread[Task worker for ':' Thread 8,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[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.
:beam-runners-google-cloud-dataflow-java-examples:build (Thread[Task worker for ':' Thread 3,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[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-runners-google-cloud-dataflow-java-examples:buildDependents (Thread[Task worker for ':' Thread 3,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[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.
: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[Task worker for ':' Thread 3,5,main]) completed. Took 0.001 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.001 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-protobuf:buildDependents (Thread[Task worker for ':' Thread 3,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.0 secs.
:beam-runners-java-fn-execution:buildDependents (Thread[Task worker for ':' Thread 4,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-runners-local-java-core:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.

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

> 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 7,5,main]) completed. Took 0.001 secs.

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

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

> Task :beam-sdks-java-fn-execution:buildDependents
Caching disabled for task ':beam-sdks-java-fn-execution:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-fn-execution:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-fn-execution: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-apex: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 20m 24s
804 actionable tasks: 799 executed, 5 from cache

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

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

Build failed in Jenkins: beam_PreCommit_Java_Cron #248

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

------------------------------------------
[...truncated 18.05 MB...]
    INFO: 2018-08-20T06:17:23.687Z: 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 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:23.724Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Pair with random key into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:23.768Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:23.805Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:23.852Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:23.894Z: 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 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:23.939Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:23.986Z: 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 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.032Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.055Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.101Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.145Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.188Z: 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 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.231Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.277Z: Fusing consumer Window.Into()/Window.Assign into ParDo(AddTimestamp)
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.324Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Read
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.370Z: 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 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.415Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.451Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.496Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Write into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Reify
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.541Z: Fusing consumer MapElements/Map into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.584Z: Fusing consumer ParDo(AddTimestamp) into TextIO.Read/Read
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.629Z: Fusing consumer WordCount.CountWords/ParDo(ExtractWords) into Window.Into()/Window.Assign
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.700Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/DropShardNum into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.740Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles into MapElements/Map
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.784Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Read
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.822Z: Fusing consumer WordCount.CountWords/Count.PerElement/Init/Map into WordCount.CountWords/ParDo(ExtractWords)
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:24.869Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:25.329Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Create
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:25.366Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Create
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:25.408Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:25.418Z: Starting 1 workers in us-central1-b...
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:25.453Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 20, 2018 6:17:25 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:25.489Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Create
    Aug 20, 2018 6:17:28 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:25.780Z: 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 20, 2018 6:17:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:17:34.724Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    Aug 20, 2018 6:18:54 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:18:52.443Z: Workers have started successfully.
    Aug 20, 2018 6:18:56 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:18:54.780Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    Aug 20, 2018 6:18:56 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:18:54.806Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 20, 2018 6:19:24 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:19:23.639Z: Workers have started successfully.
    Aug 20, 2018 6:20:01 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:01.406Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Close
    Aug 20, 2018 6:20:01 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:01.502Z: 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 20, 2018 6:20:15 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:12.561Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Close
    Aug 20, 2018 6:20:15 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:12.661Z: 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 20, 2018 6:20:15 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:14.759Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Close
    Aug 20, 2018 6:20:15 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:14.876Z: 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 20, 2018 6:20:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:20.194Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 20, 2018 6:20:21 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:20.295Z: 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 20, 2018 6:20:30 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:28.753Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 20, 2018 6:20:30 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:28.834Z: 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 20, 2018 6:20:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:31.485Z: Cleaning up.
    Aug 20, 2018 6:20:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:20:31.584Z: Stopping worker pool...
    Aug 20, 2018 6:22:00 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:21:59.388Z: Autoscaling: Resized worker pool from 1 to 0.
    Aug 20, 2018 6:22:00 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T06:21:59.432Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 20, 2018 6:22:07 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-19_23_17_15-427150897996958170 finished with status DONE.
    Aug 20, 2018 6:22:07 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-08-19_23_17_15-427150897996958170. Found 0 success, 0 failures out of 0 expected assertions.
    Aug 20, 2018 6:22:09 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-19_23_17_15-427150897996958170 finished with status DONE.

Gradle Test Executor 94 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java-examples:preCommit
Finished generating test XML results (0.006 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.007 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 9,5,main]) completed. Took 13 mins 51.167 secs.
:beam-examples-java:preCommit (Thread[Task worker for ':' Thread 9,5,main]) started.
:beam-runners-google-cloud-dataflow-java-examples:test (Thread[Task worker for ':' Thread 3,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 9,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[Task worker for ':' Thread 3,5,main]) completed. Took 0.003 secs.
:beam-runners-google-cloud-dataflow-java-examples:check (Thread[Task worker for ':' Thread 3,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[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-runners-google-cloud-dataflow-java-examples:build (Thread[Task worker for ':' Thread 3,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[Task worker for ':' Thread 3,5,main]) completed. Took 0.0 secs.
:beam-runners-google-cloud-dataflow-java-examples:buildDependents (Thread[Task worker for ':' Thread 3,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[Task worker for ':' Thread 3,5,main]) completed. Took 0.001 secs.
:beam-examples-java:buildDependents (Thread[Task worker for ':' Thread 3,5,main]) started.
:beam-runners-google-cloud-dataflow-java:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) started.

> 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 5,5,main]) completed. Took 0.0 secs.

> 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.001 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 9,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 9,5,main]) completed. Took 0.002 secs.
:beam-runners-direct-java:buildDependents (Thread[Task worker for ':' Thread 9,5,main]) started.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 5,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.

> 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-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 5,5,main]) completed. Took 0.0 secs.
:beam-runners-direct-java:buildDependents (Thread[Task worker for ':' Thread 9,5,main]) completed. Took 0.0 secs.
:beam-runners-java-fn-execution:buildDependents (Thread[Task worker for ':' Thread 9,5,main]) started.

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

> Task :beam-sdks-java-harness:buildDependents
Caching disabled for task ':beam-sdks-java-harness:buildDependents': Caching has not been enabled for the task
Task ':beam-sdks-java-harness:buildDependents' is not up-to-date because:
  Task has not declared any outputs despite executing actions.
:beam-sdks-java-harness:buildDependents (Thread[Task worker for ':' Thread 9,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.

> Task :beam-vendor-sdks-java-extensions-protobuf:buildDependents
Caching disabled for task ':beam-vendor-sdks-java-extensions-protobuf:buildDependents': Caching has not been enabled for the task
Task ':beam-vendor-sdks-java-extensions-protobuf: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 4,5,main]) completed. Took 0.0 secs.
:beam-vendor-sdks-java-extensions-protobuf: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 10,5,main]) started.
:beam-sdks-java-fn-execution:buildDependents (Thread[Task worker for ':' Thread 5,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 10,5,main]) completed. Took 0.0 secs.

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

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-apex: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 22m 0s
804 actionable tasks: 799 executed, 5 from cache

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

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

Build failed in Jenkins: beam_PreCommit_Java_Cron #247

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

------------------------------------------
[...truncated 17.35 MB...]
    INFO: 2018-08-20T00:16:33.366Z: Expanding GroupByKey operations into optimizable parts.
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:33.402Z: Lifting ValueCombiningMappingFns into MergeBucketsMappingFns
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:33.716Z: Fusing adjacent ParDo, Read, Write, and Flatten operations
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:33.763Z: Unzipping flatten s13 for input s12.org.apache.beam.sdk.values.PCollection.<init>:384#639855871860d444
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:33.806Z: 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 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:33.846Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:33.890Z: 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 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:33.934Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:33.979Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.023Z: 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 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.061Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Drop key/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/ExpandIterable
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.105Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Gather bundles into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Drop key/Values/Map
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.141Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Pair with random key into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Gather bundles
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.185Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.230Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.270Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Reify
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.315Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Read
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.361Z: Unzipping flatten s13-u58 for input s14.org.apache.beam.sdk.values.PCollection.<init>:384#43d0369d0f0559b7-c56
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.404Z: 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 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.443Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Pair with random key into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.488Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.532Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.560Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.599Z: 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 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.634Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.670Z: 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 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.714Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.750Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Finalize into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Values/Values/Map
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.784Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.829Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/Window.Into()/Window.Assign into WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Add void key/AddKeys/Map
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.873Z: 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 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.917Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.951Z: Fusing consumer Window.Into()/Window.Assign into ParDo(AddTimestamp)
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:34.995Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Read
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.040Z: 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 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.075Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.119Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Write into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Reify
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.163Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Write into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Reify
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.208Z: Fusing consumer MapElements/Map into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.253Z: Fusing consumer ParDo(AddTimestamp) into TextIO.Read/Read
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.294Z: Fusing consumer WordCount.CountWords/ParDo(ExtractWords) into Window.Into()/Window.Assign
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.339Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/DropShardNum into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnwritten
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.379Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/WriteUnshardedBundles into MapElements/Map
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.427Z: Fusing consumer WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/GroupByWindow into WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Read
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.465Z: Fusing consumer WordCount.CountWords/Count.PerElement/Init/Map into WordCount.CountWords/ParDo(ExtractWords)
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.543Z: Fusing consumer WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues/Extract into WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/Combine.GroupedValues
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.968Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Create
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:35.993Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Create
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:36.025Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:36.060Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Create
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:36.072Z: Starting 1 workers in us-central1-b...
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:36.094Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Create
    Aug 20, 2018 12:16:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:36.442Z: 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 20, 2018 12:16:44 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:16:44.571Z: Autoscaling: Raised the number of workers to 0 based on the rate of progress in the currently running step(s).
    Aug 20, 2018 12:17:01 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:00.946Z: Autoscaling: Raised the number of workers to 1 based on the rate of progress in the currently running step(s).
    Aug 20, 2018 12:17:01 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:00.984Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 20, 2018 12:17:18 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:18.243Z: Workers have started successfully.
    Aug 20, 2018 12:17:18 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:18.288Z: Workers have started successfully.
    Aug 20, 2018 12:17:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:34.322Z: Executing operation WordCount.CountWords/Count.PerElement/Combine.perKey(Count)/GroupByKey/Close
    Aug 20, 2018 12:17:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:34.417Z: 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 20, 2018 12:17:47 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:45.617Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/WriteUnshardedBundlesToTempFiles/GroupUnwritten/Close
    Aug 20, 2018 12:17:47 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:45.706Z: 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 20, 2018 12:17:49 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:47.818Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle/GroupByKey/Close
    Aug 20, 2018 12:17:49 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:47.908Z: 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 20, 2018 12:17:54 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:54.280Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/GatherTempFileResults/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 20, 2018 12:17:54 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:54.369Z: 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 20, 2018 12:18:02 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:59.507Z: Executing operation WriteOneFilePerWindow/TextIO.Write/WriteFiles/FinalizeTempFileBundles/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Aug 20, 2018 12:18:02 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:17:59.590Z: 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 20, 2018 12:18:04 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:18:03.850Z: Cleaning up.
    Aug 20, 2018 12:18:04 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:18:03.947Z: Stopping worker pool...
    Aug 20, 2018 12:20:07 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:20:05.583Z: Autoscaling: Resized worker pool from 1 to 0.
    Aug 20, 2018 12:20:07 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2018-08-20T00:20:05.617Z: Autoscaling: Would further reduce the number of workers but reached the minimum number allowed for the job.
    Aug 20, 2018 12:20:13 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-19_17_16_26-3881464120808931553 finished with status DONE.
    Aug 20, 2018 12:20:13 AM org.apache.beam.runners.dataflow.TestDataflowRunner checkForPAssertSuccess
    INFO: Success result for Dataflow job 2018-08-19_17_16_26-3881464120808931553. Found 0 success, 0 failures out of 0 expected assertions.
    Aug 20, 2018 12:20:15 AM org.apache.beam.runners.dataflow.DataflowPipelineJob waitUntilFinish
    INFO: Job 2018-08-19_17_16_26-3881464120808931553 finished with status DONE.

Gradle Test Executor 94 finished executing tests.

> Task :beam-runners-google-cloud-dataflow-java-examples:preCommit
Finished generating test XML results (0.004 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.004 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 2,5,main]) completed. Took 11 mins 38.708 secs.
:beam-examples-java:preCommit (Thread[Task worker for ':' Thread 2,5,main]) started.
:beam-runners-google-cloud-dataflow-java-examples:test (Thread[Task worker for ':' Thread 8,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 2,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[Task worker for ':' Thread 8,5,main]) completed. Took 0.002 secs.
:beam-runners-google-cloud-dataflow-java-examples:check (Thread[Task worker for ':' Thread 8,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[Task worker for ':' Thread 8,5,main]) completed. Took 0.0 secs.
:beam-runners-google-cloud-dataflow-java-examples:build (Thread[Task worker for ':' Thread 4,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[Task worker for ':' Thread 4,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.0 secs.
:beam-examples-java:buildDependents (Thread[Daemon worker,5,main]) started.
:beam-runners-google-cloud-dataflow-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[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 8,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-io-google-cloud-platform:buildDependents (Thread[Task worker for ':' Thread 8,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 8,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-protobuf:buildDependents (Thread[Task worker for ':' Thread 4,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 4,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-apex: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.
==============================================================================

2: 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_PreCommit_Java_Cron/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.
==============================================================================

* 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 19m 52s
796 actionable tasks: 791 executed, 5 from cache

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

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

Build failed in Jenkins: beam_PreCommit_Java_Cron #246

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

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

    Aug 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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 19, 2018 6:13:49 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.005 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[Task worker for ':' Thread 7,5,main]) completed. Took 3 mins 13.441 secs.
:beam-sdks-java-nexmark:shadowJar (Thread[Task worker for ':' Thread 7,5,main]) started.

> Task :beam-sdks-java-nexmark:shadowJar
Build cache key for task ':beam-sdks-java-nexmark:shadowJar' is cce84a005eb96aedb16988002206284d
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.016s [2016ms]
Average Time/Jar: 1.008s [1008.0ms]
*******************
:beam-sdks-java-nexmark:shadowJar (Thread[Task worker for ':' Thread 7,5,main]) completed. Took 2.279 secs.
:beam-sdks-java-nexmark:validateShadedJarDoesntLeakNonOrgApacheBeamClasses (Thread[Task worker for ':' Thread 7,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[Task worker for ':' Thread 7,5,main]) completed. Took 0.034 secs.
:beam-sdks-java-nexmark:check (Thread[Task worker for ':' Thread 7,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[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-nexmark:build (Thread[Task worker for ':' Thread 7,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[Task worker for ':' Thread 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-nexmark:buildDependents (Thread[Task worker for ':' Thread 7,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 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-sql:buildDependents (Thread[Task worker for ':' Thread 7,5,main]) started.
:beam-sdks-java-io-kafka:buildDependents (Thread[Task worker for ':' Thread 4,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 7,5,main]) completed. Took 0.0 secs.
:beam-sdks-java-extensions-join-library:buildDependents (Thread[Task worker for ':' Thread 7,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 7,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 4,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-apex: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.
==============================================================================

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.
==============================================================================

* 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 13m 40s
782 actionable tasks: 777 executed, 5 from cache

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

Build cache (/home/jenkins/.gradle/caches/build-cache-1) remove files older than Sun Aug 12 18:00:19 UTC 2018.
Build cache (/home/jenkins/.gradle/caches/build-cache-1) removing 1297 cache entries (72 MB reclaimed).
Build cache (/home/jenkins/.gradle/caches/build-cache-1) cleaned up in 0.195 secs.
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure