You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2020/03/06 06:40:24 UTC

Build failed in Jenkins: beam_PerformanceTests_JDBC #3245

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

Changes:

[chuck.yang] Use Avro format for file loads to BigQuery

[github] Revert "[BEAM-6374] Emit PCollection metrics from GoSDK (#10942)"

[github] Merge pull request #11032 from [BEAM-8335] Display rather than logging


------------------------------------------
[...truncated 382.57 KB...]
    Caused by: org.apache.beam.sdk.util.UserCodeException: org.postgresql.util.PSQLException: The connection attempt failed.
    	at org.apache.beam.sdk.util.UserCodeException.wrap(UserCodeException.java:36)
    	at org.apache.beam.sdk.io.jdbc.JdbcIO$ReadFn$DoFnInvoker.invokeSetup(Unknown Source)
    	at org.apache.beam.runners.dataflow.worker.DoFnInstanceManagers$ConcurrentQueueInstanceManager.deserializeCopy(DoFnInstanceManagers.java:80)
    	at org.apache.beam.runners.dataflow.worker.DoFnInstanceManagers$ConcurrentQueueInstanceManager.peek(DoFnInstanceManagers.java:62)
    	at org.apache.beam.runners.dataflow.worker.UserParDoFnFactory.create(UserParDoFnFactory.java:95)
    	at org.apache.beam.runners.dataflow.worker.DefaultParDoFnFactory.create(DefaultParDoFnFactory.java:75)
    	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory.createParDoOperation(IntrinsicMapTaskExecutorFactory.java:264)
    	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory.access$000(IntrinsicMapTaskExecutorFactory.java:86)
    	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory$1.typedApply(IntrinsicMapTaskExecutorFactory.java:183)
    	... 14 more
    Caused by: org.postgresql.util.PSQLException: The connection attempt failed.
    	at org.postgresql.core.v3.ConnectionFactoryImpl.openConnectionImpl(ConnectionFactoryImpl.java:257)
    	at org.postgresql.core.ConnectionFactory.openConnection(ConnectionFactory.java:49)
    	at org.postgresql.jdbc.PgConnection.<init>(PgConnection.java:195)
    	at org.postgresql.Driver.makeConnection(Driver.java:452)
    	at org.postgresql.Driver.connect(Driver.java:254)
    	at java.sql.DriverManager.getConnection(DriverManager.java:664)
    	at java.sql.DriverManager.getConnection(DriverManager.java:247)
    	at org.postgresql.ds.common.BaseDataSource.getConnection(BaseDataSource.java:94)
    	at org.postgresql.ds.common.BaseDataSource.getConnection(BaseDataSource.java:79)
    	at org.apache.beam.sdk.io.jdbc.JdbcIO$ReadFn.setup(JdbcIO.java:882)
    Caused by: java.net.SocketTimeoutException: connect timed out
    	at java.net.PlainSocketImpl.socketConnect(Native Method)
    	at java.net.AbstractPlainSocketImpl.doConnect(AbstractPlainSocketImpl.java:350)
    	at java.net.AbstractPlainSocketImpl.connectToAddress(AbstractPlainSocketImpl.java:206)
    	at java.net.AbstractPlainSocketImpl.connect(AbstractPlainSocketImpl.java:188)
    	at java.net.SocksSocketImpl.connect(SocksSocketImpl.java:392)
    	at java.net.Socket.connect(Socket.java:589)
    	at org.postgresql.core.PGStream.<init>(PGStream.java:69)
    	at org.postgresql.core.v3.ConnectionFactoryImpl.openConnectionImpl(ConnectionFactoryImpl.java:156)
    	at org.postgresql.core.ConnectionFactory.openConnection(ConnectionFactory.java:49)
    	at org.postgresql.jdbc.PgConnection.<init>(PgConnection.java:195)
    	at org.postgresql.Driver.makeConnection(Driver.java:452)
    	at org.postgresql.Driver.connect(Driver.java:254)
    	at java.sql.DriverManager.getConnection(DriverManager.java:664)
    	at java.sql.DriverManager.getConnection(DriverManager.java:247)
    	at org.postgresql.ds.common.BaseDataSource.getConnection(BaseDataSource.java:94)
    	at org.postgresql.ds.common.BaseDataSource.getConnection(BaseDataSource.java:79)
    	at org.apache.beam.sdk.io.jdbc.JdbcIO$ReadFn.setup(JdbcIO.java:882)
    	at org.apache.beam.sdk.io.jdbc.JdbcIO$ReadFn$DoFnInvoker.invokeSetup(Unknown Source)
    	at org.apache.beam.runners.dataflow.worker.DoFnInstanceManagers$ConcurrentQueueInstanceManager.deserializeCopy(DoFnInstanceManagers.java:80)
    	at org.apache.beam.runners.dataflow.worker.DoFnInstanceManagers$ConcurrentQueueInstanceManager.peek(DoFnInstanceManagers.java:62)
    	at org.apache.beam.runners.dataflow.worker.UserParDoFnFactory.create(UserParDoFnFactory.java:95)
    	at org.apache.beam.runners.dataflow.worker.DefaultParDoFnFactory.create(DefaultParDoFnFactory.java:75)
    	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory.createParDoOperation(IntrinsicMapTaskExecutorFactory.java:264)
    	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory.access$000(IntrinsicMapTaskExecutorFactory.java:86)
    	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory$1.typedApply(IntrinsicMapTaskExecutorFactory.java:183)
    	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory$1.typedApply(IntrinsicMapTaskExecutorFactory.java:165)
    	at org.apache.beam.runners.dataflow.worker.graph.Networks$TypeSafeNodeFunction.apply(Networks.java:63)
    	at org.apache.beam.runners.dataflow.worker.graph.Networks$TypeSafeNodeFunction.apply(Networks.java:50)
    	at org.apache.beam.runners.dataflow.worker.graph.Networks.replaceDirectedNetworkNodes(Networks.java:87)
    	at org.apache.beam.runners.dataflow.worker.IntrinsicMapTaskExecutorFactory.create(IntrinsicMapTaskExecutorFactory.java:125)
    	at org.apache.beam.runners.dataflow.worker.BatchDataflowWorker.doWork(BatchDataflowWorker.java:353)
    	at org.apache.beam.runners.dataflow.worker.BatchDataflowWorker.getAndPerformWork(BatchDataflowWorker.java:306)
    	at org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarness$WorkerThread.doWork(DataflowBatchWorkerHarness.java:140)
    	at org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarness$WorkerThread.call(DataflowBatchWorkerHarness.java:120)
    	at org.apache.beam.runners.dataflow.worker.DataflowBatchWorkerHarness$WorkerThread.call(DataflowBatchWorkerHarness.java:107)
    	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
    	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
    	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
    	at java.lang.Thread.run(Thread.java:748)

    Mar 06, 2020 6:37:09 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:37:09.553Z: Finished operation JdbcIO.Read/Create.Values/Read(CreateSource)+JdbcIO.Read/JdbcIO.ReadAll/ParDo(Read)+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Consume/ParDo(Anonymous)+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    Mar 06, 2020 6:37:09 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:37:09.716Z: Executing operation JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/View.AsIterable/CreateDataflowView
    Mar 06, 2020 6:37:12 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:37:09.816Z: Finished operation JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/View.AsIterable/CreateDataflowView
    Mar 06, 2020 6:37:12 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:37:09.951Z: Executing operation JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Identity+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Pair with random key+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/Window.Into()/Window.Assign+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write
    Mar 06, 2020 6:37:52 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:37:50.827Z: Finished operation JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Identity+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Pair with random key+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/Window.Into()/Window.Assign+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Reify+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Write
    Mar 06, 2020 6:37:52 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:37:50.920Z: Executing operation JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Mar 06, 2020 6:37:52 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:37:51.000Z: Finished operation JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Close
    Mar 06, 2020 6:37:52 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:37:51.076Z: Executing operation JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Values/Values/Map+ParDo(TimeMonitor)+Count All/WithKeys/AddKeys/Map+ParDo(SelectName)+Combine.globally(Top(Reversed))/WithKeys/AddKeys/Map+Combine.globally(Top(Natural))/WithKeys/AddKeys/Map+Count All/Combine.perKey(Count)/GroupByKey+Count All/Combine.perKey(Count)/Combine.GroupedValues/Partial+Count All/Combine.perKey(Count)/GroupByKey/Reify+Hash row contents/WithKeys/AddKeys/Map+Hash row contents/Combine.perKey(Hashing)/GroupByKey+Hash row contents/Combine.perKey(Hashing)/Combine.GroupedValues/Partial+Hash row contents/Combine.perKey(Hashing)/GroupByKey/Reify+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/Combine.GroupedValues/Partial+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey/Reify+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/Combine.GroupedValues/Partial+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey/Reify+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey/Write+Count All/Combine.perKey(Count)/GroupByKey/Write+Hash row contents/Combine.perKey(Hashing)/GroupByKey/Write+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey/Write
    Mar 06, 2020 6:38:28 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.031Z: Finished operation JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/Read+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/GroupByKey/GroupByWindow+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Reshuffle/ExpandIterable+JdbcIO.Read/JdbcIO.ReadAll/JdbcIO.Reparallelize/Reshuffle.ViaRandomKey/Values/Values/Map+ParDo(TimeMonitor)+Count All/WithKeys/AddKeys/Map+ParDo(SelectName)+Combine.globally(Top(Reversed))/WithKeys/AddKeys/Map+Combine.globally(Top(Natural))/WithKeys/AddKeys/Map+Count All/Combine.perKey(Count)/GroupByKey+Count All/Combine.perKey(Count)/Combine.GroupedValues/Partial+Count All/Combine.perKey(Count)/GroupByKey/Reify+Hash row contents/WithKeys/AddKeys/Map+Hash row contents/Combine.perKey(Hashing)/GroupByKey+Hash row contents/Combine.perKey(Hashing)/Combine.GroupedValues/Partial+Hash row contents/Combine.perKey(Hashing)/GroupByKey/Reify+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/Combine.GroupedValues/Partial+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey/Reify+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/Combine.GroupedValues/Partial+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey/Reify+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey/Write+Count All/Combine.perKey(Count)/GroupByKey/Write+Hash row contents/Combine.perKey(Hashing)/GroupByKey/Write+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey/Write
    Mar 06, 2020 6:38:28 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.127Z: Executing operation Count All/Combine.perKey(Count)/GroupByKey/Close
    Mar 06, 2020 6:38:28 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.172Z: Executing operation Hash row contents/Combine.perKey(Hashing)/GroupByKey/Close
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.211Z: Executing operation Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey/Close
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.213Z: Finished operation Count All/Combine.perKey(Count)/GroupByKey/Close
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.248Z: Executing operation Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey/Close
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.367Z: Finished operation Hash row contents/Combine.perKey(Hashing)/GroupByKey/Close
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.394Z: Finished operation Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey/Close
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.412Z: Executing operation Count All/Combine.perKey(Count)/GroupByKey/Read+Count All/Combine.perKey(Count)/Combine.GroupedValues+Count All/Combine.perKey(Count)/Combine.GroupedValues/Extract+Count All/Values/Values/Map+PAssert$0/GroupGlobally/Window.Into()/Window.Assign+PAssert$0/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$0/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$0/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Write+Count All/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.435Z: Finished operation Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey/Close
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.457Z: Executing operation Hash row contents/Combine.perKey(Hashing)/GroupByKey/Read+Hash row contents/Combine.perKey(Hashing)/Combine.GroupedValues+Hash row contents/Combine.perKey(Hashing)/Combine.GroupedValues/Extract+Hash row contents/Values/Values/Map+PAssert$1/GroupGlobally/Window.Into()/Window.Assign+PAssert$1/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$1/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$1/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.506Z: Executing operation Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey/Read+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/Combine.GroupedValues+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/Combine.GroupedValues/Extract+Combine.globally(Top(Reversed))/Values/Values/Map+PAssert$2/GroupGlobally/Window.Into()/Window.Assign+PAssert$2/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$2/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$2/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Write+Combine.globally(Top(Reversed))/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    Mar 06, 2020 6:38:29 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:28.545Z: Executing operation Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey/Read+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/Combine.GroupedValues+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/Combine.GroupedValues/Extract+Combine.globally(Top(Natural))/Values/Values/Map+Combine.globally(Top(Natural))/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)+PAssert$3/GroupGlobally/Window.Into()/Window.Assign+PAssert$3/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$3/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$3/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:32.439Z: Finished operation Hash row contents/Combine.perKey(Hashing)/GroupByKey/Read+Hash row contents/Combine.perKey(Hashing)/Combine.GroupedValues+Hash row contents/Combine.perKey(Hashing)/Combine.GroupedValues/Extract+Hash row contents/Values/Values/Map+PAssert$1/GroupGlobally/Window.Into()/Window.Assign+PAssert$1/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$1/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$1/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:32.501Z: Executing operation PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/Close
    Mar 06, 2020 6:38:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:32.556Z: Finished operation PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/Close
    Mar 06, 2020 6:38:32 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:32.626Z: Executing operation PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/Read+PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/GroupByWindow+PAssert$1/GroupGlobally/GatherAllOutputs/Values/Values/Map+PAssert$1/GroupGlobally/RewindowActuals/Window.Assign+PAssert$1/GroupGlobally/KeyForDummy/AddKeys/Map+PAssert$1/GroupGlobally/GroupDummyAndContents/Reify+PAssert$1/GroupGlobally/GroupDummyAndContents/Write
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:33.414Z: Finished operation PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/Read+PAssert$1/GroupGlobally/GatherAllOutputs/GroupByKey/GroupByWindow+PAssert$1/GroupGlobally/GatherAllOutputs/Values/Values/Map+PAssert$1/GroupGlobally/RewindowActuals/Window.Assign+PAssert$1/GroupGlobally/KeyForDummy/AddKeys/Map+PAssert$1/GroupGlobally/GroupDummyAndContents/Reify+PAssert$1/GroupGlobally/GroupDummyAndContents/Write
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:33.503Z: Executing operation PAssert$1/GroupGlobally/GroupDummyAndContents/Close
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:33.620Z: Finished operation PAssert$1/GroupGlobally/GroupDummyAndContents/Close
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:33.902Z: Executing operation PAssert$1/GroupGlobally/GroupDummyAndContents/Read+PAssert$1/GroupGlobally/GroupDummyAndContents/GroupByWindow+PAssert$1/GroupGlobally/Values/Values/Map+PAssert$1/GroupGlobally/ParDo(Concat)+PAssert$1/GetPane/Map+PAssert$1/RunChecks+PAssert$1/VerifyAssertions/ParDo(DefaultConclude)
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:34.382Z: Finished operation Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/GroupByKey/Read+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/Combine.GroupedValues+Combine.globally(Top(Natural))/Combine.perKey(Top(Natural))/Combine.GroupedValues/Extract+Combine.globally(Top(Natural))/Values/Values/Map+Combine.globally(Top(Natural))/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)+PAssert$3/GroupGlobally/Window.Into()/Window.Assign+PAssert$3/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$3/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$3/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:34.542Z: Finished operation Count All/Combine.perKey(Count)/GroupByKey/Read+Count All/Combine.perKey(Count)/Combine.GroupedValues+Count All/Combine.perKey(Count)/Combine.GroupedValues/Extract+Count All/Values/Values/Map+PAssert$0/GroupGlobally/Window.Into()/Window.Assign+PAssert$0/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$0/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$0/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Write+Count All/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:34.558Z: Executing operation Combine.globally(Top(Natural))/View.AsIterable/CreateDataflowView
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:34.613Z: Finished operation Combine.globally(Top(Natural))/View.AsIterable/CreateDataflowView
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:34.724Z: Executing operation Count All/View.AsIterable/CreateDataflowView
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:34.770Z: Executing operation Combine.globally(Top(Natural))/CreateVoid/Read(CreateSource)+Combine.globally(Top(Natural))/ProduceDefault+PAssert$3/GroupGlobally/Window.Into()/Window.Assign+PAssert$3/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$3/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$3/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:34.840Z: Finished operation Count All/View.AsIterable/CreateDataflowView
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:34.886Z: Finished operation Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/GroupByKey/Read+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/Combine.GroupedValues+Combine.globally(Top(Reversed))/Combine.perKey(Top(Reversed))/Combine.GroupedValues/Extract+Combine.globally(Top(Reversed))/Values/Values/Map+PAssert$2/GroupGlobally/Window.Into()/Window.Assign+PAssert$2/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$2/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$2/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Write+Combine.globally(Top(Reversed))/View.AsIterable/ParDo(ToIsmRecordForGlobalWindow)
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.016Z: Executing operation Count All/CreateVoid/Read(CreateSource)+Count All/ProduceDefault+PAssert$0/GroupGlobally/Window.Into()/Window.Assign+PAssert$0/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$0/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$0/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.052Z: Executing operation Combine.globally(Top(Reversed))/View.AsIterable/CreateDataflowView
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.115Z: Finished operation Combine.globally(Top(Reversed))/View.AsIterable/CreateDataflowView
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.280Z: Executing operation Combine.globally(Top(Reversed))/CreateVoid/Read(CreateSource)+Combine.globally(Top(Reversed))/ProduceDefault+PAssert$2/GroupGlobally/Window.Into()/Window.Assign+PAssert$2/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$2/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$2/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.284Z: Finished operation Combine.globally(Top(Natural))/CreateVoid/Read(CreateSource)+Combine.globally(Top(Natural))/ProduceDefault+PAssert$3/GroupGlobally/Window.Into()/Window.Assign+PAssert$3/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$3/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$3/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:35 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.376Z: Executing operation PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Close
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.404Z: Finished operation PAssert$1/GroupGlobally/GroupDummyAndContents/Read+PAssert$1/GroupGlobally/GroupDummyAndContents/GroupByWindow+PAssert$1/GroupGlobally/Values/Values/Map+PAssert$1/GroupGlobally/ParDo(Concat)+PAssert$1/GetPane/Map+PAssert$1/RunChecks+PAssert$1/VerifyAssertions/ParDo(DefaultConclude)
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.443Z: Finished operation PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Close
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.526Z: Executing operation PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Read+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/GroupByWindow+PAssert$3/GroupGlobally/GatherAllOutputs/Values/Values/Map+PAssert$3/GroupGlobally/RewindowActuals/Window.Assign+PAssert$3/GroupGlobally/KeyForDummy/AddKeys/Map+PAssert$3/GroupGlobally/GroupDummyAndContents/Reify+PAssert$3/GroupGlobally/GroupDummyAndContents/Write
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.637Z: Finished operation Count All/CreateVoid/Read(CreateSource)+Count All/ProduceDefault+PAssert$0/GroupGlobally/Window.Into()/Window.Assign+PAssert$0/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$0/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$0/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.773Z: Executing operation PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Close
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.804Z: Finished operation Combine.globally(Top(Reversed))/CreateVoid/Read(CreateSource)+Combine.globally(Top(Reversed))/ProduceDefault+PAssert$2/GroupGlobally/Window.Into()/Window.Assign+PAssert$2/GroupGlobally/GatherAllOutputs/Reify.Window/ParDo(Anonymous)+PAssert$2/GroupGlobally/GatherAllOutputs/WithKeys/AddKeys/Map+PAssert$2/GroupGlobally/GatherAllOutputs/Window.Into()/Window.Assign+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Reify+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Write
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:35.848Z: Finished operation PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/Read+PAssert$3/GroupGlobally/GatherAllOutputs/GroupByKey/GroupByWindow+PAssert$3/GroupGlobally/GatherAllOutputs/Values/Values/Map+PAssert$3/GroupGlobally/RewindowActuals/Window.Assign+PAssert$3/GroupGlobally/KeyForDummy/AddKeys/Map+PAssert$3/GroupGlobally/GroupDummyAndContents/Reify+PAssert$3/GroupGlobally/GroupDummyAndContents/Write
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:36.029Z: Executing operation PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Close
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:36.064Z: Finished operation PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Close
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:36.388Z: Executing operation PAssert$3/GroupGlobally/GroupDummyAndContents/Close
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:36.398Z: Finished operation PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Close
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:36.487Z: Executing operation PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Read+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/GroupByWindow+PAssert$0/GroupGlobally/GatherAllOutputs/Values/Values/Map+PAssert$0/GroupGlobally/RewindowActuals/Window.Assign+PAssert$0/GroupGlobally/KeyForDummy/AddKeys/Map+PAssert$0/GroupGlobally/GroupDummyAndContents/Reify+PAssert$0/GroupGlobally/GroupDummyAndContents/Write
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:36.704Z: Finished operation PAssert$3/GroupGlobally/GroupDummyAndContents/Close
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:36.758Z: Executing operation PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Read+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/GroupByWindow+PAssert$2/GroupGlobally/GatherAllOutputs/Values/Values/Map+PAssert$2/GroupGlobally/RewindowActuals/Window.Assign+PAssert$2/GroupGlobally/KeyForDummy/AddKeys/Map+PAssert$2/GroupGlobally/GroupDummyAndContents/Reify+PAssert$2/GroupGlobally/GroupDummyAndContents/Write
    Mar 06, 2020 6:38:38 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:37.651Z: Executing operation PAssert$3/GroupGlobally/GroupDummyAndContents/Read+PAssert$3/GroupGlobally/GroupDummyAndContents/GroupByWindow+PAssert$3/GroupGlobally/Values/Values/Map+PAssert$3/GroupGlobally/ParDo(Concat)+PAssert$3/GetPane/Map+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:39.003Z: Finished operation PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/Read+PAssert$2/GroupGlobally/GatherAllOutputs/GroupByKey/GroupByWindow+PAssert$2/GroupGlobally/GatherAllOutputs/Values/Values/Map+PAssert$2/GroupGlobally/RewindowActuals/Window.Assign+PAssert$2/GroupGlobally/KeyForDummy/AddKeys/Map+PAssert$2/GroupGlobally/GroupDummyAndContents/Reify+PAssert$2/GroupGlobally/GroupDummyAndContents/Write
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:39.034Z: Finished operation PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/Read+PAssert$0/GroupGlobally/GatherAllOutputs/GroupByKey/GroupByWindow+PAssert$0/GroupGlobally/GatherAllOutputs/Values/Values/Map+PAssert$0/GroupGlobally/RewindowActuals/Window.Assign+PAssert$0/GroupGlobally/KeyForDummy/AddKeys/Map+PAssert$0/GroupGlobally/GroupDummyAndContents/Reify+PAssert$0/GroupGlobally/GroupDummyAndContents/Write
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:39.074Z: Executing operation PAssert$2/GroupGlobally/GroupDummyAndContents/Close
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:39.097Z: Executing operation PAssert$0/GroupGlobally/GroupDummyAndContents/Close
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:39.130Z: Finished operation PAssert$2/GroupGlobally/GroupDummyAndContents/Close
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:39.157Z: Finished operation PAssert$0/GroupGlobally/GroupDummyAndContents/Close
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:39.206Z: Executing operation PAssert$2/GroupGlobally/GroupDummyAndContents/Read+PAssert$2/GroupGlobally/GroupDummyAndContents/GroupByWindow+PAssert$2/GroupGlobally/Values/Values/Map+PAssert$2/GroupGlobally/ParDo(Concat)+PAssert$2/GetPane/Map+PAssert$2/RunChecks+PAssert$2/VerifyAssertions/ParDo(DefaultConclude)
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:39.256Z: Executing operation PAssert$0/GroupGlobally/GroupDummyAndContents/Read+PAssert$0/GroupGlobally/GroupDummyAndContents/GroupByWindow+PAssert$0/GroupGlobally/Values/Values/Map+PAssert$0/GroupGlobally/ParDo(Concat)+PAssert$0/GetPane/Map+PAssert$0/RunChecks+PAssert$0/VerifyAssertions/ParDo(DefaultConclude)
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:40.079Z: Finished operation PAssert$3/GroupGlobally/GroupDummyAndContents/Read+PAssert$3/GroupGlobally/GroupDummyAndContents/GroupByWindow+PAssert$3/GroupGlobally/Values/Values/Map+PAssert$3/GroupGlobally/ParDo(Concat)+PAssert$3/GetPane/Map+PAssert$3/RunChecks+PAssert$3/VerifyAssertions/ParDo(DefaultConclude)
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:40.162Z: Finished operation PAssert$2/GroupGlobally/GroupDummyAndContents/Read+PAssert$2/GroupGlobally/GroupDummyAndContents/GroupByWindow+PAssert$2/GroupGlobally/Values/Values/Map+PAssert$2/GroupGlobally/ParDo(Concat)+PAssert$2/GetPane/Map+PAssert$2/RunChecks+PAssert$2/VerifyAssertions/ParDo(DefaultConclude)
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:41.177Z: Finished operation PAssert$0/GroupGlobally/GroupDummyAndContents/Read+PAssert$0/GroupGlobally/GroupDummyAndContents/GroupByWindow+PAssert$0/GroupGlobally/Values/Values/Map+PAssert$0/GroupGlobally/ParDo(Concat)+PAssert$0/GetPane/Map+PAssert$0/RunChecks+PAssert$0/VerifyAssertions/ParDo(DefaultConclude)
    Mar 06, 2020 6:38:41 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:41.391Z: Cleaning up.
    Mar 06, 2020 6:38:43 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:38:41.496Z: Stopping worker pool...
    Mar 06, 2020 6:40:01 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:40:01.457Z: Autoscaling: Resized worker pool from 5 to 0.
    Mar 06, 2020 6:40:01 AM org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-03-06T06:40:01.507Z: Worker pool stopped.
    Mar 06, 2020 6:40:12 AM org.apache.beam.runners.dataflow.DataflowPipelineJob logTerminalState
    INFO: Job 2020-03-05_22_34_19-2895804211012471805 finished with status DONE.

org.apache.beam.sdk.io.jdbc.JdbcIOIT > testWriteThenRead STANDARD_OUT
    Load test results for test (ID): 3d03ab04-3d3c-40a3-af1f-f966e8a89e64 and timestamp: 2020-03-06T06:40:12.246000000Z:
                     Metric:                    Value:
                  write_time                    131.34
                  total_size              2.60841472E8
    Load test results for test (ID): 3d03ab04-3d3c-40a3-af1f-f966e8a89e64 and timestamp: 2020-03-06T06:40:12.246000000Z:
                     Metric:                    Value:
                   read_time                    35.193

Gradle Test Executor 1 finished executing tests.

> Task :sdks:java:io:jdbc:integrationTest FAILED
:sdks:java:io:jdbc:integrationTest (Thread[Execution worker for ':' Thread 4,5,main]) completed. Took 11 mins 26.763 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:io:jdbc:integrationTest'.
> java.io.IOException: No space left on device

* 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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 12m 19s
81 actionable tasks: 53 executed, 28 from cache

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

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

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


Jenkins build is back to normal : beam_PerformanceTests_JDBC #3246

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


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