See 
<https://ci-beam.apache.org/job/beam_SQLBigQueryIO_Batch_Performance_Test_Java/1365/display/redirect?page=changes>

Changes:

[dpcollins] [BEAM-10114] Convert PubsubLiteIO read to use SplittableDoFn.

[dpcollins] Fix test.

[dpcollins] fix: Testing issues

[dpcollins] [BEAM-10114] Convert PubsubLiteIO to use an SDF for reads.

[dpcollins] [BEAM-10114] Add byte and time limiting

[dpcollins] [BEAM-10114] Add byte and time limiting

[dpcollins] [BEAM-10114] Add byte and time limiting

[dpcollins] [BEAM-10114] Add byte and time limiting

[dpcollins] [BEAM-10114] Add byte and time limiting

[dpcollins] [BEAM-10114] Add byte and time limiting

[dpcollins] fix: Linter issues

[dpcollins] fix: linters

[dpcollins] fix: linters

[Pablo Estrada] Adding limitations of SchemaUpdateOptions to BQIO javadoc.

[Robert Bradshaw] [BEAM-11472] Support SDF on non-splitting runners such as 
legacy

[dpcollins] fix: Remove unnecessary shuffle.

[dpcollins] fix: Address comments


------------------------------------------
[...truncated 375.03 KB...]
    SLF4J: Found binding in 
[jar:file:/home/jenkins/.gradle/caches/modules-2/files-2.1/org.slf4j/slf4j-jdk14/1.7.30/d35953dd2fe54ebe39fdf18cfd82fe6eb35b25ed/slf4j-jdk14-1.7.30.jar!/org/slf4j/impl/StaticLoggerBinder.class]
    SLF4J: See http://www.slf4j.org/codes.html#multiple_bindings for an 
explanation.
    SLF4J: Actual binding is of type [org.slf4j.impl.JDK14LoggerFactory]

org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryIOPushDownIT 
> readUsingDirectReadMethod STANDARD_ERROR
    Dec 16, 2020 6:47:18 AM 
org.apache.beam.runners.dataflow.options.DataflowPipelineOptions$StagingLocationFactory
 create
    INFO: No stagingLocation provided, falling back to gcpTempLocation
    Dec 16, 2020 6:47:18 AM org.apache.beam.runners.dataflow.DataflowRunner 
fromOptions
    INFO: PipelineOptions.filesToStage was not specified. Defaulting to files 
from the classpath: will stage 227 files. Enable logging at DEBUG level to see 
which files will be staged.
    Dec 16, 2020 6:47:20 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery method is set to: DIRECT_READ
    Dec 16, 2020 6:47:20 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery writeDisposition is set to: WRITE_EMPTY
    Dec 16, 2020 6:47:21 AM 
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner convertToBeamRel
    INFO: SQL:
    SELECT `HACKER_NEWS`.`by` AS `author`, `HACKER_NEWS`.`type`, 
`HACKER_NEWS`.`title`, `HACKER_NEWS`.`score`
    FROM `beam`.`HACKER_NEWS` AS `HACKER_NEWS`
    WHERE (`HACKER_NEWS`.`type` = 'story' OR `HACKER_NEWS`.`type` = 'job') AND 
`HACKER_NEWS`.`score` > 2
    Dec 16, 2020 6:47:21 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery method is set to: DIRECT_READ
    Dec 16, 2020 6:47:21 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery writeDisposition is set to: WRITE_EMPTY
    Dec 16, 2020 6:47:21 AM 
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner convertToBeamRel
    INFO: SQLPlan>
    LogicalProject(author=[$4], type=[$8], title=[$0], score=[$5])
      LogicalFilter(condition=[AND(OR(=($8, 'story'), =($8, 'job')), >($5, 2))])
        BeamIOSourceRel(table=[[beam, HACKER_NEWS]])

    Dec 16, 2020 6:47:21 AM 
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner convertToBeamRel
    INFO: BEAMPlan>
    BeamCalcRel(expr#0..13=[{inputs}], expr#14=['story':VARCHAR], 
expr#15=[=($t8, $t14)], expr#16=['job':VARCHAR], expr#17=[=($t8, $t16)], 
expr#18=[OR($t15, $t17)], expr#19=[2], expr#20=[>($t5, $t19)], 
expr#21=[AND($t18, $t20)], author=[$t4], type=[$t8], title=[$t0], score=[$t5], 
$condition=[$t21])
      BeamIOSourceRel(table=[[beam, HACKER_NEWS]])


org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryIOPushDownIT 
> readUsingDirectReadMethod FAILED
    java.lang.IllegalStateException: Unable to return a default Coder for 
BeamIOSourceRel_3/ParDo(RowMonitor)/ParMultiDo(RowMonitor).output 
[PCollection@1300973767]. Correct one of the following root causes:
      No Coder has been manually specified;  you may do so using .setCoder().
      Inferring a Coder from the CoderRegistry failed: Cannot provide a coder 
for a Beam Row. Please provide a schema instead using PCollection.setRowSchema.
      Using the default output Coder from the producing PTransform failed: 
PTransform.getOutputCoder called.
        at 
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkState(Preconditions.java:507)
        at org.apache.beam.sdk.values.PCollection.getCoder(PCollection.java:280)
        at 
org.apache.beam.sdk.values.PCollection.finishSpecifying(PCollection.java:117)
        at 
org.apache.beam.sdk.runners.TransformHierarchy.finishSpecifyingInput(TransformHierarchy.java:153)
        at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:546)
        at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:498)
        at 
org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils.toPCollection(BeamSqlRelUtils.java:72)
        at 
org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils.toPCollection(BeamSqlRelUtils.java:42)
        at 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryIOPushDownIT.readUsingDirectReadMethod(BigQueryIOPushDownIT.java:162)

org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryIOPushDownIT 
> readUsingDefaultMethod STANDARD_ERROR
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery method is set to: DEFAULT
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery writeDisposition is set to: WRITE_EMPTY
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner convertToBeamRel
    INFO: SQL:
    SELECT `HACKER_NEWS`.`by` AS `author`, `HACKER_NEWS`.`type`, 
`HACKER_NEWS`.`title`, `HACKER_NEWS`.`score`
    FROM `beam`.`HACKER_NEWS` AS `HACKER_NEWS`
    WHERE (`HACKER_NEWS`.`type` = 'story' OR `HACKER_NEWS`.`type` = 'job') AND 
`HACKER_NEWS`.`score` > 2
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery method is set to: DEFAULT
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery writeDisposition is set to: WRITE_EMPTY
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner convertToBeamRel
    INFO: SQLPlan>
    LogicalProject(author=[$4], type=[$8], title=[$0], score=[$5])
      LogicalFilter(condition=[AND(OR(=($8, 'story'), =($8, 'job')), >($5, 2))])
        BeamIOSourceRel(table=[[beam, HACKER_NEWS]])

    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner convertToBeamRel
    INFO: BEAMPlan>
    BeamCalcRel(expr#0..13=[{inputs}], expr#14=['story':VARCHAR], 
expr#15=[=($t8, $t14)], expr#16=['job':VARCHAR], expr#17=[=($t8, $t16)], 
expr#18=[OR($t15, $t17)], expr#19=[2], expr#20=[>($t5, $t19)], 
expr#21=[AND($t18, $t20)], author=[$t4], type=[$t8], title=[$t0], score=[$t5], 
$condition=[$t21])
      BeamIOSourceRel(table=[[beam, HACKER_NEWS]])


org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryIOPushDownIT 
> readUsingDefaultMethod FAILED
    java.lang.IllegalStateException: Unable to return a default Coder for 
BeamIOSourceRel_95/ParDo(RowMonitor)/ParMultiDo(RowMonitor).output 
[PCollection@1936127891]. Correct one of the following root causes:
      No Coder has been manually specified;  you may do so using .setCoder().
      Inferring a Coder from the CoderRegistry failed: Cannot provide a coder 
for a Beam Row. Please provide a schema instead using PCollection.setRowSchema.
      Using the default output Coder from the producing PTransform failed: 
PTransform.getOutputCoder called.
        at 
org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkState(Preconditions.java:507)
        at org.apache.beam.sdk.values.PCollection.getCoder(PCollection.java:280)
        at 
org.apache.beam.sdk.values.PCollection.finishSpecifying(PCollection.java:117)
        at 
org.apache.beam.sdk.runners.TransformHierarchy.finishSpecifyingInput(TransformHierarchy.java:153)
        at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:546)
        at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:498)
        at 
org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils.toPCollection(BeamSqlRelUtils.java:72)
        at 
org.apache.beam.sdk.extensions.sql.impl.rel.BeamSqlRelUtils.toPCollection(BeamSqlRelUtils.java:42)
        at 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryIOPushDownIT.readUsingDefaultMethod(BigQueryIOPushDownIT.java:176)

org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryIOPushDownIT 
> readUsingDirectReadMethodPushDown STANDARD_ERROR
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery method is set to: DIRECT_READ
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery writeDisposition is set to: WRITE_EMPTY
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner convertToBeamRel
    INFO: SQL:
    SELECT `HACKER_NEWS`.`by` AS `author`, `HACKER_NEWS`.`type`, 
`HACKER_NEWS`.`title`, `HACKER_NEWS`.`score`
    FROM `beam`.`HACKER_NEWS` AS `HACKER_NEWS`
    WHERE (`HACKER_NEWS`.`type` = 'story' OR `HACKER_NEWS`.`type` = 'job') AND 
`HACKER_NEWS`.`score` > 2
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery method is set to: DIRECT_READ
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable <init>
    INFO: BigQuery writeDisposition is set to: WRITE_EMPTY
    Dec 16, 2020 6:47:22 AM 
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner convertToBeamRel
    INFO: SQLPlan>
    LogicalProject(author=[$4], type=[$8], title=[$0], score=[$5])
      LogicalFilter(condition=[AND(OR(=($8, 'story'), =($8, 'job')), >($5, 2))])
        BeamIOSourceRel(table=[[beam, HACKER_NEWS]])

    Dec 16, 2020 6:47:23 AM 
org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner convertToBeamRel
    INFO: BEAMPlan>
    BeamCalcRel(expr#0..3=[{inputs}], proj#0..3=[{exprs}])
      BeamPushDownIOSourceRel(table=[[beam, HACKER_NEWS]], usedFields=[[by, 
type, title, score]], BigQueryFilter=[[supported{OR(=($8, 'story'), =($8, 
'job'))>($5, 2)}, unsupported{}]])

    Dec 16, 2020 6:47:23 AM 
org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryTable 
buildIOReader
    INFO: Pushing down the following filter: (`type` = 'story' OR `type` = 
'job') AND `score` > 2
    Dec 16, 2020 6:47:24 AM org.apache.beam.runners.dataflow.DataflowRunner run
    INFO: Executing pipeline on the Dataflow Service, which will have billing 
implications related to Google Compute Engine usage and other Google Cloud 
Services.
    Dec 16, 2020 6:47:26 AM org.apache.beam.runners.dataflow.util.PackageUtil 
stageClasspathElements
    INFO: Uploading 228 files from PipelineOptions.filesToStage to staging 
location to prepare for execution.
    Dec 16, 2020 6:47:26 AM 
org.apache.beam.runners.dataflow.util.PackageUtil$PackageAttributes 
forFileToStage
    INFO: Staging custom dataflow-worker.jar as 
beam-runners-google-cloud-dataflow-java-legacy-worker-2.27.0-SNAPSHOT-SY51_ntnFm08YbRxJRsH0MUwRdL3yw8xnIg9nfCgmLo.jar
    Dec 16, 2020 6:47:26 AM org.apache.beam.runners.dataflow.util.PackageUtil 
tryStagePackage
    INFO: Uploading /tmp/test3994974508035849026.zip to 
gs://temp-storage-for-perf-tests/loadtests/staging/test-eur-Vbxqx2nKtnyMznevlvkWE8ZyO04I2rKFvTiUuFw.jar
    Dec 16, 2020 6:47:26 AM org.apache.beam.runners.dataflow.util.PackageUtil 
tryStagePackage
    INFO: Uploading 
<https://ci-beam.apache.org/job/beam_SQLBigQueryIO_Batch_Performance_Test_Java/ws/src/sdks/java/core/build/libs/beam-sdks-java-core-2.27.0-SNAPSHOT-unshaded.jar>
 to 
gs://temp-storage-for-perf-tests/loadtests/staging/beam-sdks-java-core-2.27.0-SNAPSHOT-unshaded-OW-DxFLOoYKWln4uUcpaFWFs-k2oVHeTrNj3yo3L4n4.jar
    Dec 16, 2020 6:47:26 AM org.apache.beam.runners.dataflow.util.PackageUtil 
tryStagePackage
    INFO: Uploading 
<https://ci-beam.apache.org/job/beam_SQLBigQueryIO_Batch_Performance_Test_Java/ws/src/sdks/java/core/build/libs/beam-sdks-java-core-2.27.0-SNAPSHOT.jar>
 to 
gs://temp-storage-for-perf-tests/loadtests/staging/beam-sdks-java-core-2.27.0-SNAPSHOT-IPL1w6RaPK9UFFa2pRDNG5khIiPIej85lVYZ6mPIPt8.jar
    Dec 16, 2020 6:47:27 AM org.apache.beam.runners.dataflow.util.PackageUtil 
tryStagePackage
    INFO: Uploading 
/home/jenkins/.gradle/caches/modules-2/files-2.1/org.conscrypt/conscrypt-openjdk-uber/2.5.1/3658b276ab54bd600f754b3c8cf4b7cd77fc61e6/conscrypt-openjdk-uber-2.5.1.jar
 to 
gs://temp-storage-for-perf-tests/loadtests/staging/conscrypt-openjdk-uber-2.5.1-AfnHQstZKhUeLmK9U5eomAYoqWcAH82s1KpHRGeGhfM.jar
    Dec 16, 2020 6:47:27 AM org.apache.beam.runners.dataflow.util.PackageUtil 
stageClasspathElements
    INFO: Staging files complete: 224 files cached, 4 files newly uploaded in 1 
seconds
    Dec 16, 2020 6:47:27 AM 
org.apache.beam.runners.dataflow.DataflowPipelineTranslator$Translator addStep
    INFO: Adding BeamPushDownIOSourceRel_229/Read Input BQ Rows with 
push-down/Read(BigQueryStorageTableSource) as step s1
    Dec 16, 2020 6:47:27 AM 
org.apache.beam.runners.dataflow.DataflowPipelineTranslator$Translator addStep
    INFO: Adding BeamPushDownIOSourceRel_229/ParDo(RowMonitor) as step s2
    Dec 16, 2020 6:47:28 AM 
org.apache.beam.runners.dataflow.DataflowPipelineTranslator$Translator addStep
    INFO: Adding BeamCalcRel_285/ParDo(Calc) as step s3
    Dec 16, 2020 6:47:28 AM 
org.apache.beam.runners.dataflow.DataflowPipelineTranslator$Translator addStep
    INFO: Adding ParDo(TimeMonitor) as step s4
    Dec 16, 2020 6:47:28 AM org.apache.beam.runners.dataflow.DataflowRunner run
    INFO: Staging pipeline description to 
gs://temp-storage-for-perf-tests/loadtests/staging/
    Dec 16, 2020 6:47:28 AM org.apache.beam.runners.dataflow.util.PackageUtil 
tryStagePackage
    INFO: Uploading <99757 bytes, hash 
8c714193c83f27c2a2199fe1ec95366b5d33fcb7680725f1af771cb7b8cffa78> to 
gs://temp-storage-for-perf-tests/loadtests/staging/pipeline-jHFBk8g_J8KiGZ_h7JU2a10z_LdoByXxr3cct7jP-ng.pb
    Dec 16, 2020 6:47:28 AM org.apache.beam.runners.dataflow.DataflowRunner run
    INFO: Dataflow SDK version: 2.27.0-SNAPSHOT
    Dec 16, 2020 6:47:30 AM org.apache.beam.runners.dataflow.DataflowRunner run
    INFO: To access the Dataflow monitoring console, please navigate to 
https://console.cloud.google.com/dataflow/jobs/us-central1/2020-12-15_22_47_28-14521982427422251357?project=apache-beam-testing
    Dec 16, 2020 6:47:30 AM org.apache.beam.runners.dataflow.DataflowRunner run
    INFO: Submitted job: 2020-12-15_22_47_28-14521982427422251357
    Dec 16, 2020 6:47:30 AM org.apache.beam.runners.dataflow.DataflowRunner run
    INFO: To cancel the job using the 'gcloud' tool, run:
    > gcloud dataflow jobs --project=apache-beam-testing cancel 
--region=us-central1 2020-12-15_22_47_28-14521982427422251357
    Dec 16, 2020 6:47:30 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    WARNING: 2020-12-16T06:47:28.421Z: The requested max number of workers (5) 
is ignored as autoscaling is explicitly disabled (autoscalingAlgorithm=NONE).
    Dec 16, 2020 6:47:42 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:41.242Z: Worker configuration: n1-standard-1 in 
us-central1-f.
    Dec 16, 2020 6:47:42 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:41.724Z: Expanding CoGroupByKey operations into 
optimizable parts.
    Dec 16, 2020 6:47:42 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:41.957Z: Expanding GroupByKey operations into 
optimizable parts.
    Dec 16, 2020 6:47:42 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:41.996Z: Lifting ValueCombiningMappingFns into 
MergeBucketsMappingFns
    Dec 16, 2020 6:47:42 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:42.088Z: Fusing adjacent ParDo, Read, Write, and 
Flatten operations
    Dec 16, 2020 6:47:42 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:42.126Z: Fusing consumer 
BeamPushDownIOSourceRel_229/ParDo(RowMonitor) into 
BeamPushDownIOSourceRel_229/Read Input BQ Rows with 
push-down/Read(BigQueryStorageTableSource)
    Dec 16, 2020 6:47:42 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:42.162Z: Fusing consumer BeamCalcRel_285/ParDo(Calc) 
into BeamPushDownIOSourceRel_229/ParDo(RowMonitor)
    Dec 16, 2020 6:47:42 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:42.197Z: Fusing consumer ParDo(TimeMonitor) into 
BeamCalcRel_285/ParDo(Calc)
    Dec 16, 2020 6:47:44 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:42.797Z: Executing operation 
BeamPushDownIOSourceRel_229/Read Input BQ Rows with 
push-down/Read(BigQueryStorageTableSource)+BeamPushDownIOSourceRel_229/ParDo(RowMonitor)+BeamCalcRel_285/ParDo(Calc)+ParDo(TimeMonitor)
    Dec 16, 2020 6:47:44 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:47:42.897Z: Starting 5 workers in us-central1-f...
    Dec 16, 2020 6:48:09 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:48:09.268Z: Autoscaling: Raised the number of workers 
to 4 based on the rate of progress in the currently running stage(s).
    Dec 16, 2020 6:48:09 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:48:09.299Z: Resized worker pool to 4, though goal was 
5.  This could be a quota issue.
    Dec 16, 2020 6:48:17 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:48:16.022Z: Your project already contains 100 
Dataflow-created metric descriptors, so new user metrics of the form 
custom.googleapis.com/* will not be created. However, all user metrics are also 
available in the metric dataflow.googleapis.com/job/user_counter. If you rely 
on the custom metrics, you can delete old / unused metric descriptors. See 
https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.list
 and 
https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.delete
    Dec 16, 2020 6:48:21 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:48:19.627Z: Autoscaling: Raised the number of workers 
to 5 based on the rate of progress in the currently running stage(s).
    Dec 16, 2020 6:48:36 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:48:36.401Z: Workers have started successfully.
    Dec 16, 2020 6:48:36 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:48:36.430Z: Workers have started successfully.
    Dec 16, 2020 6:49:10 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:49:09.329Z: Finished operation 
BeamPushDownIOSourceRel_229/Read Input BQ Rows with 
push-down/Read(BigQueryStorageTableSource)+BeamPushDownIOSourceRel_229/ParDo(RowMonitor)+BeamCalcRel_285/ParDo(Calc)+ParDo(TimeMonitor)
    Dec 16, 2020 6:49:10 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:49:09.519Z: Cleaning up.
    Dec 16, 2020 6:49:10 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:49:09.627Z: Stopping worker pool...
    Dec 16, 2020 6:50:02 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:50:01.980Z: Autoscaling: Resized worker pool from 5 to 
0.
    Dec 16, 2020 6:50:02 AM 
org.apache.beam.runners.dataflow.util.MonitoringUtil$LoggingHandler process
    INFO: 2020-12-16T06:50:02.033Z: Worker pool stopped.
    Dec 16, 2020 6:50:09 AM 
org.apache.beam.runners.dataflow.DataflowPipelineJob logTerminalState
    INFO: Job 2020-12-15_22_47_28-14521982427422251357 finished with status 
DONE.

org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryIOPushDownIT 
> readUsingDirectReadMethodPushDown STANDARD_OUT
    Load test results for test (ID): b79ebf8a-6e19-43f5-a74c-e9cfe4d2a855 and 
timestamp: 2020-12-16T06:50:09.272000000Z:
                     Metric:                    Value:
                 fields_read                 4375276.0
                   read_time                    11.933

org.apache.beam.sdk.extensions.sql.meta.provider.bigquery.BigQueryIOPushDownIT 
> readUsingDirectReadMethodPushDown STANDARD_ERROR
    Dec 16, 2020 6:50:09 AM 
org.apache.beam.sdk.testutils.publishing.InfluxDBPublisher publishWithCheck
    WARNING: Missing property -- measurement/database. Metrics won't be 
published.

Gradle Test Executor 2 finished executing tests.

> Task :sdks:java:extensions:sql:perf-tests:integrationTest FAILED

3 tests completed, 2 failed
Finished generating test XML results (0.024 secs) into: 
<https://ci-beam.apache.org/job/beam_SQLBigQueryIO_Batch_Performance_Test_Java/ws/src/sdks/java/extensions/sql/perf-tests/build/test-results/integrationTest>
Generating HTML test report...
Finished generating test html results (0.033 secs) into: 
<https://ci-beam.apache.org/job/beam_SQLBigQueryIO_Batch_Performance_Test_Java/ws/src/sdks/java/extensions/sql/perf-tests/build/reports/tests/integrationTest>
Watching 2165 directories to track changes
Watching 2171 directories to track changes
Watching 2172 directories to track changes
:sdks:java:extensions:sql:perf-tests:integrationTest (Thread[Execution worker 
for ':' Thread 3,5,main]) completed. Took 2 mins 56.634 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task 
':sdks:java:extensions:sql:perf-tests:integrationTest'.
> There were failing tests. See the report at: 
> file://<https://ci-beam.apache.org/job/beam_SQLBigQueryIO_Batch_Performance_Test_Java/ws/src/sdks/java/extensions/sql/perf-tests/build/reports/tests/integrationTest/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 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See 
https://docs.gradle.org/6.7/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5m 52s
139 actionable tasks: 91 executed, 48 from cache
Watching 2172 directories to track changes

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

Stopped 1 worker daemon(s).
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: [email protected]
For additional commands, e-mail: [email protected]

Reply via email to